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/01/08 15:31:16 UTC

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

Repository: hbase-site
Updated Branches:
  refs/heads/asf-site a4ad3e636 -> 123d826c8


http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html
index 6d723a9..f4327b3 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html
@@ -32,39 +32,39 @@
 <span class="sourceLineNo">024</span>import java.util.HashSet;<a name="line.24"></a>
 <span class="sourceLineNo">025</span>import java.util.Map;<a name="line.25"></a>
 <span class="sourceLineNo">026</span>import java.util.concurrent.atomic.AtomicLong;<a name="line.26"></a>
-<span class="sourceLineNo">027</span>import java.util.concurrent.atomic.AtomicReference;<a name="line.27"></a>
-<span class="sourceLineNo">028</span><a name="line.28"></a>
-<span class="sourceLineNo">029</span>import org.apache.hadoop.conf.Configuration;<a name="line.29"></a>
-<span class="sourceLineNo">030</span>import org.apache.hadoop.hbase.Cell;<a name="line.30"></a>
-<span class="sourceLineNo">031</span>import org.apache.hadoop.hbase.CellScanner;<a name="line.31"></a>
-<span class="sourceLineNo">032</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.32"></a>
-<span class="sourceLineNo">033</span>import org.apache.hadoop.hbase.HColumnDescriptor;<a name="line.33"></a>
-<span class="sourceLineNo">034</span>import org.apache.hadoop.hbase.HTableDescriptor;<a name="line.34"></a>
-<span class="sourceLineNo">035</span>import org.apache.hadoop.hbase.NamespaceDescriptor;<a name="line.35"></a>
-<span class="sourceLineNo">036</span>import org.apache.hadoop.hbase.TableName;<a name="line.36"></a>
-<span class="sourceLineNo">037</span>import org.apache.hadoop.hbase.client.Admin;<a name="line.37"></a>
-<span class="sourceLineNo">038</span>import org.apache.hadoop.hbase.client.Connection;<a name="line.38"></a>
-<span class="sourceLineNo">039</span>import org.apache.hadoop.hbase.client.Get;<a name="line.39"></a>
-<span class="sourceLineNo">040</span>import org.apache.hadoop.hbase.client.Result;<a name="line.40"></a>
-<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.client.ResultScanner;<a name="line.41"></a>
-<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.client.Scan;<a name="line.42"></a>
-<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.client.SnapshotDescription;<a name="line.43"></a>
-<span class="sourceLineNo">044</span>import org.apache.hadoop.hbase.client.SnapshotType;<a name="line.44"></a>
-<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.client.Table;<a name="line.45"></a>
-<span class="sourceLineNo">046</span>import org.apache.hadoop.hbase.master.HMaster;<a name="line.46"></a>
-<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore.SnapshotWithSize;<a name="line.47"></a>
-<span class="sourceLineNo">048</span>import org.apache.hadoop.hbase.quotas.SpaceQuotaHelperForTests.NoFilesToDischarge;<a name="line.48"></a>
-<span class="sourceLineNo">049</span>import org.apache.hadoop.hbase.quotas.SpaceQuotaHelperForTests.SpaceQuotaSnapshotPredicate;<a name="line.49"></a>
-<span class="sourceLineNo">050</span>import org.apache.hadoop.hbase.testclassification.MediumTests;<a name="line.50"></a>
-<span class="sourceLineNo">051</span>import org.junit.AfterClass;<a name="line.51"></a>
-<span class="sourceLineNo">052</span>import org.junit.Before;<a name="line.52"></a>
-<span class="sourceLineNo">053</span>import org.junit.BeforeClass;<a name="line.53"></a>
-<span class="sourceLineNo">054</span>import org.junit.Rule;<a name="line.54"></a>
-<span class="sourceLineNo">055</span>import org.junit.Test;<a name="line.55"></a>
-<span class="sourceLineNo">056</span>import org.junit.experimental.categories.Category;<a name="line.56"></a>
-<span class="sourceLineNo">057</span>import org.junit.rules.TestName;<a name="line.57"></a>
-<span class="sourceLineNo">058</span>import org.slf4j.Logger;<a name="line.58"></a>
-<span class="sourceLineNo">059</span>import org.slf4j.LoggerFactory;<a name="line.59"></a>
+<span class="sourceLineNo">027</span>import org.apache.hadoop.conf.Configuration;<a name="line.27"></a>
+<span class="sourceLineNo">028</span>import org.apache.hadoop.hbase.Cell;<a name="line.28"></a>
+<span class="sourceLineNo">029</span>import org.apache.hadoop.hbase.CellScanner;<a name="line.29"></a>
+<span class="sourceLineNo">030</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.30"></a>
+<span class="sourceLineNo">031</span>import org.apache.hadoop.hbase.HColumnDescriptor;<a name="line.31"></a>
+<span class="sourceLineNo">032</span>import org.apache.hadoop.hbase.HTableDescriptor;<a name="line.32"></a>
+<span class="sourceLineNo">033</span>import org.apache.hadoop.hbase.NamespaceDescriptor;<a name="line.33"></a>
+<span class="sourceLineNo">034</span>import org.apache.hadoop.hbase.TableName;<a name="line.34"></a>
+<span class="sourceLineNo">035</span>import org.apache.hadoop.hbase.client.Admin;<a name="line.35"></a>
+<span class="sourceLineNo">036</span>import org.apache.hadoop.hbase.client.Connection;<a name="line.36"></a>
+<span class="sourceLineNo">037</span>import org.apache.hadoop.hbase.client.Get;<a name="line.37"></a>
+<span class="sourceLineNo">038</span>import org.apache.hadoop.hbase.client.Result;<a name="line.38"></a>
+<span class="sourceLineNo">039</span>import org.apache.hadoop.hbase.client.ResultScanner;<a name="line.39"></a>
+<span class="sourceLineNo">040</span>import org.apache.hadoop.hbase.client.Scan;<a name="line.40"></a>
+<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.client.SnapshotDescription;<a name="line.41"></a>
+<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.client.SnapshotType;<a name="line.42"></a>
+<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.client.Table;<a name="line.43"></a>
+<span class="sourceLineNo">044</span>import org.apache.hadoop.hbase.master.HMaster;<a name="line.44"></a>
+<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore.SnapshotWithSize;<a name="line.45"></a>
+<span class="sourceLineNo">046</span>import org.apache.hadoop.hbase.quotas.SpaceQuotaHelperForTests.NoFilesToDischarge;<a name="line.46"></a>
+<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.quotas.SpaceQuotaHelperForTests.SpaceQuotaSnapshotPredicate;<a name="line.47"></a>
+<span class="sourceLineNo">048</span>import org.apache.hadoop.hbase.regionserver.HStore;<a name="line.48"></a>
+<span class="sourceLineNo">049</span>import org.apache.hadoop.hbase.testclassification.MediumTests;<a name="line.49"></a>
+<span class="sourceLineNo">050</span>import org.junit.AfterClass;<a name="line.50"></a>
+<span class="sourceLineNo">051</span>import org.junit.Before;<a name="line.51"></a>
+<span class="sourceLineNo">052</span>import org.junit.BeforeClass;<a name="line.52"></a>
+<span class="sourceLineNo">053</span>import org.junit.Rule;<a name="line.53"></a>
+<span class="sourceLineNo">054</span>import org.junit.Test;<a name="line.54"></a>
+<span class="sourceLineNo">055</span>import org.junit.experimental.categories.Category;<a name="line.55"></a>
+<span class="sourceLineNo">056</span>import org.junit.rules.TestName;<a name="line.56"></a>
+<span class="sourceLineNo">057</span>import org.slf4j.Logger;<a name="line.57"></a>
+<span class="sourceLineNo">058</span>import org.slf4j.LoggerFactory;<a name="line.58"></a>
+<span class="sourceLineNo">059</span><a name="line.59"></a>
 <span class="sourceLineNo">060</span>import org.apache.hbase.thirdparty.com.google.common.collect.HashMultimap;<a name="line.60"></a>
 <span class="sourceLineNo">061</span>import org.apache.hbase.thirdparty.com.google.common.collect.Iterables;<a name="line.61"></a>
 <span class="sourceLineNo">062</span>import org.apache.hbase.thirdparty.com.google.common.collect.Multimap;<a name="line.62"></a>
@@ -247,132 +247,137 @@
 <span class="sourceLineNo">239</span>    helper.writeData(tn1, 256L * SpaceQuotaHelperForTests.ONE_KILOBYTE);<a name="line.239"></a>
 <span class="sourceLineNo">240</span>    admin.flush(tn1);<a name="line.240"></a>
 <span class="sourceLineNo">241</span><a name="line.241"></a>
-<span class="sourceLineNo">242</span>    final AtomicReference&lt;Long&gt; lastSeenSize = new AtomicReference&lt;&gt;();<a name="line.242"></a>
-<span class="sourceLineNo">243</span>    // Wait for the Master chore to run to see the usage (with a fudge factor)<a name="line.243"></a>
-<span class="sourceLineNo">244</span>    TEST_UTIL.waitFor(30_000, new SpaceQuotaSnapshotPredicate(conn, tn1) {<a name="line.244"></a>
-<span class="sourceLineNo">245</span>      @Override<a name="line.245"></a>
-<span class="sourceLineNo">246</span>      boolean evaluate(SpaceQuotaSnapshot snapshot) throws Exception {<a name="line.246"></a>
-<span class="sourceLineNo">247</span>        lastSeenSize.set(snapshot.getUsage());<a name="line.247"></a>
-<span class="sourceLineNo">248</span>        return snapshot.getUsage() &gt; 230L * SpaceQuotaHelperForTests.ONE_KILOBYTE;<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>    // Create a snapshot on the table<a name="line.252"></a>
-<span class="sourceLineNo">253</span>    final String snapshotName = tn1 + "snapshot";<a name="line.253"></a>
-<span class="sourceLineNo">254</span>    admin.snapshot(new SnapshotDescription(snapshotName, tn1, SnapshotType.SKIPFLUSH));<a name="line.254"></a>
-<span class="sourceLineNo">255</span><a name="line.255"></a>
-<span class="sourceLineNo">256</span>    // Get the snapshots<a name="line.256"></a>
-<span class="sourceLineNo">257</span>    Multimap&lt;TableName,String&gt; snapshotsToCompute = testChore.getSnapshotsToComputeSize();<a name="line.257"></a>
-<span class="sourceLineNo">258</span>    assertEquals(<a name="line.258"></a>
-<span class="sourceLineNo">259</span>        "Expected to see the single snapshot: " + snapshotsToCompute, 1, snapshotsToCompute.size());<a name="line.259"></a>
-<span class="sourceLineNo">260</span><a name="line.260"></a>
-<span class="sourceLineNo">261</span>    // Get the size of our snapshot<a name="line.261"></a>
-<span class="sourceLineNo">262</span>    Multimap&lt;TableName,SnapshotWithSize&gt; snapshotsWithSize = testChore.computeSnapshotSizes(<a name="line.262"></a>
-<span class="sourceLineNo">263</span>        snapshotsToCompute);<a name="line.263"></a>
-<span class="sourceLineNo">264</span>    assertEquals(1, snapshotsWithSize.size());<a name="line.264"></a>
-<span class="sourceLineNo">265</span>    SnapshotWithSize sws = Iterables.getOnlyElement(snapshotsWithSize.get(tn1));<a name="line.265"></a>
-<span class="sourceLineNo">266</span>    assertEquals(snapshotName, sws.getName());<a name="line.266"></a>
-<span class="sourceLineNo">267</span>    // The snapshot should take up no space since the table refers to it completely<a name="line.267"></a>
-<span class="sourceLineNo">268</span>    assertEquals(0, sws.getSize());<a name="line.268"></a>
-<span class="sourceLineNo">269</span><a name="line.269"></a>
-<span class="sourceLineNo">270</span>    // Write some more data, flush it, and then major_compact the table<a name="line.270"></a>
-<span class="sourceLineNo">271</span>    helper.writeData(tn1, 256L * SpaceQuotaHelperForTests.ONE_KILOBYTE);<a name="line.271"></a>
-<span class="sourceLineNo">272</span>    admin.flush(tn1);<a name="line.272"></a>
-<span class="sourceLineNo">273</span>    TEST_UTIL.compact(tn1, true);<a name="line.273"></a>
-<span class="sourceLineNo">274</span><a name="line.274"></a>
-<span class="sourceLineNo">275</span>    // Test table should reflect it's original size since ingest was deterministic<a name="line.275"></a>
-<span class="sourceLineNo">276</span>    TEST_UTIL.waitFor(30_000, new SpaceQuotaSnapshotPredicate(conn, tn1) {<a name="line.276"></a>
-<span class="sourceLineNo">277</span>      @Override<a name="line.277"></a>
-<span class="sourceLineNo">278</span>      boolean evaluate(SpaceQuotaSnapshot snapshot) throws Exception {<a name="line.278"></a>
-<span class="sourceLineNo">279</span>        LOG.debug("Current usage=" + snapshot.getUsage() + " lastSeenSize=" + lastSeenSize.get());<a name="line.279"></a>
-<span class="sourceLineNo">280</span>        return closeInSize(<a name="line.280"></a>
-<span class="sourceLineNo">281</span>            snapshot.getUsage(), lastSeenSize.get(), SpaceQuotaHelperForTests.ONE_KILOBYTE);<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>    // Wait for no compacted files on the regions of our table<a name="line.285"></a>
-<span class="sourceLineNo">286</span>    TEST_UTIL.waitFor(30_000, new NoFilesToDischarge(TEST_UTIL.getMiniHBaseCluster(), tn1));<a name="line.286"></a>
-<span class="sourceLineNo">287</span><a name="line.287"></a>
-<span class="sourceLineNo">288</span>    // Still should see only one snapshot<a name="line.288"></a>
-<span class="sourceLineNo">289</span>    snapshotsToCompute = testChore.getSnapshotsToComputeSize();<a name="line.289"></a>
-<span class="sourceLineNo">290</span>    assertEquals(<a name="line.290"></a>
-<span class="sourceLineNo">291</span>        "Expected to see the single snapshot: " + snapshotsToCompute, 1, snapshotsToCompute.size());<a name="line.291"></a>
-<span class="sourceLineNo">292</span>    snapshotsWithSize = testChore.computeSnapshotSizes(<a name="line.292"></a>
-<span class="sourceLineNo">293</span>            snapshotsToCompute);<a name="line.293"></a>
-<span class="sourceLineNo">294</span>    assertEquals(1, snapshotsWithSize.size());<a name="line.294"></a>
-<span class="sourceLineNo">295</span>    sws = Iterables.getOnlyElement(snapshotsWithSize.get(tn1));<a name="line.295"></a>
-<span class="sourceLineNo">296</span>    assertEquals(snapshotName, sws.getName());<a name="line.296"></a>
-<span class="sourceLineNo">297</span>    // The snapshot should take up the size the table originally took up<a name="line.297"></a>
-<span class="sourceLineNo">298</span>    assertEquals(lastSeenSize.get().longValue(), sws.getSize());<a name="line.298"></a>
-<span class="sourceLineNo">299</span>  }<a name="line.299"></a>
-<span class="sourceLineNo">300</span><a name="line.300"></a>
-<span class="sourceLineNo">301</span>  @Test<a name="line.301"></a>
-<span class="sourceLineNo">302</span>  public void testPersistingSnapshotsForNamespaces() throws Exception {<a name="line.302"></a>
-<span class="sourceLineNo">303</span>    Multimap&lt;TableName,SnapshotWithSize&gt; snapshotsWithSizes = HashMultimap.create();<a name="line.303"></a>
-<span class="sourceLineNo">304</span>    TableName tn1 = TableName.valueOf("ns1:tn1");<a name="line.304"></a>
-<span class="sourceLineNo">305</span>    TableName tn2 = TableName.valueOf("ns1:tn2");<a name="line.305"></a>
-<span class="sourceLineNo">306</span>    TableName tn3 = TableName.valueOf("ns2:tn1");<a name="line.306"></a>
-<span class="sourceLineNo">307</span>    TableName tn4 = TableName.valueOf("ns2:tn2");<a name="line.307"></a>
-<span class="sourceLineNo">308</span>    TableName tn5 = TableName.valueOf("tn1");<a name="line.308"></a>
-<span class="sourceLineNo">309</span><a name="line.309"></a>
-<span class="sourceLineNo">310</span>    snapshotsWithSizes.put(tn1, new SnapshotWithSize("", 1024L));<a name="line.310"></a>
-<span class="sourceLineNo">311</span>    snapshotsWithSizes.put(tn2, new SnapshotWithSize("", 1024L));<a name="line.311"></a>
-<span class="sourceLineNo">312</span>    snapshotsWithSizes.put(tn3, new SnapshotWithSize("", 512L));<a name="line.312"></a>
-<span class="sourceLineNo">313</span>    snapshotsWithSizes.put(tn4, new SnapshotWithSize("", 1024L));<a name="line.313"></a>
-<span class="sourceLineNo">314</span>    snapshotsWithSizes.put(tn5, new SnapshotWithSize("", 3072L));<a name="line.314"></a>
-<span class="sourceLineNo">315</span><a name="line.315"></a>
-<span class="sourceLineNo">316</span>    Map&lt;String,Long&gt; nsSizes = testChore.groupSnapshotSizesByNamespace(snapshotsWithSizes);<a name="line.316"></a>
-<span class="sourceLineNo">317</span>    assertEquals(3, nsSizes.size());<a name="line.317"></a>
-<span class="sourceLineNo">318</span>    assertEquals(2048L, (long) nsSizes.get("ns1"));<a name="line.318"></a>
-<span class="sourceLineNo">319</span>    assertEquals(1536L, (long) nsSizes.get("ns2"));<a name="line.319"></a>
-<span class="sourceLineNo">320</span>    assertEquals(3072L, (long) nsSizes.get(NamespaceDescriptor.DEFAULT_NAMESPACE_NAME_STR));<a name="line.320"></a>
-<span class="sourceLineNo">321</span>  }<a name="line.321"></a>
-<span class="sourceLineNo">322</span><a name="line.322"></a>
-<span class="sourceLineNo">323</span>  private long count(Table t) throws IOException {<a name="line.323"></a>
-<span class="sourceLineNo">324</span>    try (ResultScanner rs = t.getScanner(new Scan())) {<a name="line.324"></a>
-<span class="sourceLineNo">325</span>      long sum = 0;<a name="line.325"></a>
-<span class="sourceLineNo">326</span>      for (Result r : rs) {<a name="line.326"></a>
-<span class="sourceLineNo">327</span>        while (r.advance()) {<a name="line.327"></a>
-<span class="sourceLineNo">328</span>          sum++;<a name="line.328"></a>
-<span class="sourceLineNo">329</span>        }<a name="line.329"></a>
-<span class="sourceLineNo">330</span>      }<a name="line.330"></a>
-<span class="sourceLineNo">331</span>      return sum;<a name="line.331"></a>
-<span class="sourceLineNo">332</span>    }<a name="line.332"></a>
-<span class="sourceLineNo">333</span>  }<a name="line.333"></a>
-<span class="sourceLineNo">334</span><a name="line.334"></a>
-<span class="sourceLineNo">335</span>  private long extractSnapshotSize(<a name="line.335"></a>
-<span class="sourceLineNo">336</span>      Table quotaTable, TableName tn, String snapshot) throws IOException {<a name="line.336"></a>
-<span class="sourceLineNo">337</span>    Get g = QuotaTableUtil.makeGetForSnapshotSize(tn, snapshot);<a name="line.337"></a>
-<span class="sourceLineNo">338</span>    Result r = quotaTable.get(g);<a name="line.338"></a>
-<span class="sourceLineNo">339</span>    assertNotNull(r);<a name="line.339"></a>
-<span class="sourceLineNo">340</span>    CellScanner cs = r.cellScanner();<a name="line.340"></a>
-<span class="sourceLineNo">341</span>    cs.advance();<a name="line.341"></a>
-<span class="sourceLineNo">342</span>    Cell c = cs.current();<a name="line.342"></a>
-<span class="sourceLineNo">343</span>    assertNotNull(c);<a name="line.343"></a>
-<span class="sourceLineNo">344</span>    return QuotaTableUtil.extractSnapshotSize(<a name="line.344"></a>
-<span class="sourceLineNo">345</span>        c.getValueArray(), c.getValueOffset(), c.getValueLength());<a name="line.345"></a>
-<span class="sourceLineNo">346</span>  }<a name="line.346"></a>
-<span class="sourceLineNo">347</span><a name="line.347"></a>
-<span class="sourceLineNo">348</span>  private void verify(Table t, IOThrowingRunnable test) throws IOException {<a name="line.348"></a>
-<span class="sourceLineNo">349</span>    admin.disableTable(t.getName());<a name="line.349"></a>
-<span class="sourceLineNo">350</span>    admin.truncateTable(t.getName(), false);<a name="line.350"></a>
-<span class="sourceLineNo">351</span>    test.run();<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>  @FunctionalInterface<a name="line.354"></a>
-<span class="sourceLineNo">355</span>  private interface IOThrowingRunnable {<a name="line.355"></a>
-<span class="sourceLineNo">356</span>    void run() throws IOException;<a name="line.356"></a>
+<span class="sourceLineNo">242</span>    final long snapshotSize = TEST_UTIL.getMiniHBaseCluster().getRegions(tn1).stream()<a name="line.242"></a>
+<span class="sourceLineNo">243</span>        .flatMap(r -&gt; r.getStores().stream()).mapToLong(HStore::getHFilesSize).sum();<a name="line.243"></a>
+<span class="sourceLineNo">244</span><a name="line.244"></a>
+<span class="sourceLineNo">245</span>    // Wait for the Master chore to run to see the usage (with a fudge factor)<a name="line.245"></a>
+<span class="sourceLineNo">246</span>    TEST_UTIL.waitFor(30_000, new SpaceQuotaSnapshotPredicate(conn, tn1) {<a name="line.246"></a>
+<span class="sourceLineNo">247</span>      @Override<a name="line.247"></a>
+<span class="sourceLineNo">248</span>      boolean evaluate(SpaceQuotaSnapshot snapshot) throws Exception {<a name="line.248"></a>
+<span class="sourceLineNo">249</span>        return snapshot.getUsage() == snapshotSize;<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>    // Create a snapshot on the table<a name="line.253"></a>
+<span class="sourceLineNo">254</span>    final String snapshotName = tn1 + "snapshot";<a name="line.254"></a>
+<span class="sourceLineNo">255</span>    admin.snapshot(new SnapshotDescription(snapshotName, tn1, SnapshotType.SKIPFLUSH));<a name="line.255"></a>
+<span class="sourceLineNo">256</span><a name="line.256"></a>
+<span class="sourceLineNo">257</span>    // Get the snapshots<a name="line.257"></a>
+<span class="sourceLineNo">258</span>    Multimap&lt;TableName,String&gt; snapshotsToCompute = testChore.getSnapshotsToComputeSize();<a name="line.258"></a>
+<span class="sourceLineNo">259</span>    assertEquals(<a name="line.259"></a>
+<span class="sourceLineNo">260</span>        "Expected to see the single snapshot: " + snapshotsToCompute, 1, snapshotsToCompute.size());<a name="line.260"></a>
+<span class="sourceLineNo">261</span><a name="line.261"></a>
+<span class="sourceLineNo">262</span>    // Get the size of our snapshot<a name="line.262"></a>
+<span class="sourceLineNo">263</span>    Multimap&lt;TableName,SnapshotWithSize&gt; snapshotsWithSize = testChore.computeSnapshotSizes(<a name="line.263"></a>
+<span class="sourceLineNo">264</span>        snapshotsToCompute);<a name="line.264"></a>
+<span class="sourceLineNo">265</span>    assertEquals(1, snapshotsWithSize.size());<a name="line.265"></a>
+<span class="sourceLineNo">266</span>    SnapshotWithSize sws = Iterables.getOnlyElement(snapshotsWithSize.get(tn1));<a name="line.266"></a>
+<span class="sourceLineNo">267</span>    assertEquals(snapshotName, sws.getName());<a name="line.267"></a>
+<span class="sourceLineNo">268</span>    // The snapshot should take up no space since the table refers to it completely<a name="line.268"></a>
+<span class="sourceLineNo">269</span>    assertEquals(0, sws.getSize());<a name="line.269"></a>
+<span class="sourceLineNo">270</span><a name="line.270"></a>
+<span class="sourceLineNo">271</span>    // Write some more data, flush it, and then major_compact the table<a name="line.271"></a>
+<span class="sourceLineNo">272</span>    helper.writeData(tn1, 256L * SpaceQuotaHelperForTests.ONE_KILOBYTE);<a name="line.272"></a>
+<span class="sourceLineNo">273</span>    admin.flush(tn1);<a name="line.273"></a>
+<span class="sourceLineNo">274</span>    TEST_UTIL.compact(tn1, true);<a name="line.274"></a>
+<span class="sourceLineNo">275</span><a name="line.275"></a>
+<span class="sourceLineNo">276</span>    // Test table should reflect it's original size since ingest was deterministic<a name="line.276"></a>
+<span class="sourceLineNo">277</span>    TEST_UTIL.waitFor(30_000, new SpaceQuotaSnapshotPredicate(conn, tn1) {<a name="line.277"></a>
+<span class="sourceLineNo">278</span>      private final long regionSize = TEST_UTIL.getMiniHBaseCluster().getRegions(tn1).stream()<a name="line.278"></a>
+<span class="sourceLineNo">279</span>          .flatMap(r -&gt; r.getStores().stream()).mapToLong(HStore::getHFilesSize).sum();<a name="line.279"></a>
+<span class="sourceLineNo">280</span><a name="line.280"></a>
+<span class="sourceLineNo">281</span>      @Override<a name="line.281"></a>
+<span class="sourceLineNo">282</span>      boolean evaluate(SpaceQuotaSnapshot snapshot) throws Exception {<a name="line.282"></a>
+<span class="sourceLineNo">283</span>        LOG.debug("Current usage=" + snapshot.getUsage() + " snapshotSize=" + snapshotSize);<a name="line.283"></a>
+<span class="sourceLineNo">284</span>        // The usage of table space consists of region size and snapshot size<a name="line.284"></a>
+<span class="sourceLineNo">285</span>        return closeInSize(snapshot.getUsage(), snapshotSize + regionSize,<a name="line.285"></a>
+<span class="sourceLineNo">286</span>            SpaceQuotaHelperForTests.ONE_KILOBYTE);<a name="line.286"></a>
+<span class="sourceLineNo">287</span>      }<a name="line.287"></a>
+<span class="sourceLineNo">288</span>    });<a name="line.288"></a>
+<span class="sourceLineNo">289</span><a name="line.289"></a>
+<span class="sourceLineNo">290</span>    // Wait for no compacted files on the regions of our table<a name="line.290"></a>
+<span class="sourceLineNo">291</span>    TEST_UTIL.waitFor(30_000, new NoFilesToDischarge(TEST_UTIL.getMiniHBaseCluster(), tn1));<a name="line.291"></a>
+<span class="sourceLineNo">292</span><a name="line.292"></a>
+<span class="sourceLineNo">293</span>    // Still should see only one snapshot<a name="line.293"></a>
+<span class="sourceLineNo">294</span>    snapshotsToCompute = testChore.getSnapshotsToComputeSize();<a name="line.294"></a>
+<span class="sourceLineNo">295</span>    assertEquals(<a name="line.295"></a>
+<span class="sourceLineNo">296</span>        "Expected to see the single snapshot: " + snapshotsToCompute, 1, snapshotsToCompute.size());<a name="line.296"></a>
+<span class="sourceLineNo">297</span>    snapshotsWithSize = testChore.computeSnapshotSizes(<a name="line.297"></a>
+<span class="sourceLineNo">298</span>            snapshotsToCompute);<a name="line.298"></a>
+<span class="sourceLineNo">299</span>    assertEquals(1, snapshotsWithSize.size());<a name="line.299"></a>
+<span class="sourceLineNo">300</span>    sws = Iterables.getOnlyElement(snapshotsWithSize.get(tn1));<a name="line.300"></a>
+<span class="sourceLineNo">301</span>    assertEquals(snapshotName, sws.getName());<a name="line.301"></a>
+<span class="sourceLineNo">302</span>    // The snapshot should take up the size the table originally took up<a name="line.302"></a>
+<span class="sourceLineNo">303</span>    assertEquals(snapshotSize, sws.getSize());<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>  @Test<a name="line.306"></a>
+<span class="sourceLineNo">307</span>  public void testPersistingSnapshotsForNamespaces() throws Exception {<a name="line.307"></a>
+<span class="sourceLineNo">308</span>    Multimap&lt;TableName,SnapshotWithSize&gt; snapshotsWithSizes = HashMultimap.create();<a name="line.308"></a>
+<span class="sourceLineNo">309</span>    TableName tn1 = TableName.valueOf("ns1:tn1");<a name="line.309"></a>
+<span class="sourceLineNo">310</span>    TableName tn2 = TableName.valueOf("ns1:tn2");<a name="line.310"></a>
+<span class="sourceLineNo">311</span>    TableName tn3 = TableName.valueOf("ns2:tn1");<a name="line.311"></a>
+<span class="sourceLineNo">312</span>    TableName tn4 = TableName.valueOf("ns2:tn2");<a name="line.312"></a>
+<span class="sourceLineNo">313</span>    TableName tn5 = TableName.valueOf("tn1");<a name="line.313"></a>
+<span class="sourceLineNo">314</span><a name="line.314"></a>
+<span class="sourceLineNo">315</span>    snapshotsWithSizes.put(tn1, new SnapshotWithSize("", 1024L));<a name="line.315"></a>
+<span class="sourceLineNo">316</span>    snapshotsWithSizes.put(tn2, new SnapshotWithSize("", 1024L));<a name="line.316"></a>
+<span class="sourceLineNo">317</span>    snapshotsWithSizes.put(tn3, new SnapshotWithSize("", 512L));<a name="line.317"></a>
+<span class="sourceLineNo">318</span>    snapshotsWithSizes.put(tn4, new SnapshotWithSize("", 1024L));<a name="line.318"></a>
+<span class="sourceLineNo">319</span>    snapshotsWithSizes.put(tn5, new SnapshotWithSize("", 3072L));<a name="line.319"></a>
+<span class="sourceLineNo">320</span><a name="line.320"></a>
+<span class="sourceLineNo">321</span>    Map&lt;String,Long&gt; nsSizes = testChore.groupSnapshotSizesByNamespace(snapshotsWithSizes);<a name="line.321"></a>
+<span class="sourceLineNo">322</span>    assertEquals(3, nsSizes.size());<a name="line.322"></a>
+<span class="sourceLineNo">323</span>    assertEquals(2048L, (long) nsSizes.get("ns1"));<a name="line.323"></a>
+<span class="sourceLineNo">324</span>    assertEquals(1536L, (long) nsSizes.get("ns2"));<a name="line.324"></a>
+<span class="sourceLineNo">325</span>    assertEquals(3072L, (long) nsSizes.get(NamespaceDescriptor.DEFAULT_NAMESPACE_NAME_STR));<a name="line.325"></a>
+<span class="sourceLineNo">326</span>  }<a name="line.326"></a>
+<span class="sourceLineNo">327</span><a name="line.327"></a>
+<span class="sourceLineNo">328</span>  private long count(Table t) throws IOException {<a name="line.328"></a>
+<span class="sourceLineNo">329</span>    try (ResultScanner rs = t.getScanner(new Scan())) {<a name="line.329"></a>
+<span class="sourceLineNo">330</span>      long sum = 0;<a name="line.330"></a>
+<span class="sourceLineNo">331</span>      for (Result r : rs) {<a name="line.331"></a>
+<span class="sourceLineNo">332</span>        while (r.advance()) {<a name="line.332"></a>
+<span class="sourceLineNo">333</span>          sum++;<a name="line.333"></a>
+<span class="sourceLineNo">334</span>        }<a name="line.334"></a>
+<span class="sourceLineNo">335</span>      }<a name="line.335"></a>
+<span class="sourceLineNo">336</span>      return sum;<a name="line.336"></a>
+<span class="sourceLineNo">337</span>    }<a name="line.337"></a>
+<span class="sourceLineNo">338</span>  }<a name="line.338"></a>
+<span class="sourceLineNo">339</span><a name="line.339"></a>
+<span class="sourceLineNo">340</span>  private long extractSnapshotSize(<a name="line.340"></a>
+<span class="sourceLineNo">341</span>      Table quotaTable, TableName tn, String snapshot) throws IOException {<a name="line.341"></a>
+<span class="sourceLineNo">342</span>    Get g = QuotaTableUtil.makeGetForSnapshotSize(tn, snapshot);<a name="line.342"></a>
+<span class="sourceLineNo">343</span>    Result r = quotaTable.get(g);<a name="line.343"></a>
+<span class="sourceLineNo">344</span>    assertNotNull(r);<a name="line.344"></a>
+<span class="sourceLineNo">345</span>    CellScanner cs = r.cellScanner();<a name="line.345"></a>
+<span class="sourceLineNo">346</span>    cs.advance();<a name="line.346"></a>
+<span class="sourceLineNo">347</span>    Cell c = cs.current();<a name="line.347"></a>
+<span class="sourceLineNo">348</span>    assertNotNull(c);<a name="line.348"></a>
+<span class="sourceLineNo">349</span>    return QuotaTableUtil.extractSnapshotSize(<a name="line.349"></a>
+<span class="sourceLineNo">350</span>        c.getValueArray(), c.getValueOffset(), c.getValueLength());<a name="line.350"></a>
+<span class="sourceLineNo">351</span>  }<a name="line.351"></a>
+<span class="sourceLineNo">352</span><a name="line.352"></a>
+<span class="sourceLineNo">353</span>  private void verify(Table t, IOThrowingRunnable test) throws IOException {<a name="line.353"></a>
+<span class="sourceLineNo">354</span>    admin.disableTable(t.getName());<a name="line.354"></a>
+<span class="sourceLineNo">355</span>    admin.truncateTable(t.getName(), false);<a name="line.355"></a>
+<span class="sourceLineNo">356</span>    test.run();<a name="line.356"></a>
 <span class="sourceLineNo">357</span>  }<a name="line.357"></a>
 <span class="sourceLineNo">358</span><a name="line.358"></a>
-<span class="sourceLineNo">359</span>  /**<a name="line.359"></a>
-<span class="sourceLineNo">360</span>   * Computes if {@code size2} is within {@code delta} of {@code size1}, inclusive.<a name="line.360"></a>
-<span class="sourceLineNo">361</span>   */<a name="line.361"></a>
-<span class="sourceLineNo">362</span>  boolean closeInSize(long size1, long size2, long delta) {<a name="line.362"></a>
-<span class="sourceLineNo">363</span>    long lower = size1 - delta;<a name="line.363"></a>
-<span class="sourceLineNo">364</span>    long upper = size1 + delta;<a name="line.364"></a>
-<span class="sourceLineNo">365</span>    return lower &lt;= size2 &amp;&amp; size2 &lt;= upper;<a name="line.365"></a>
-<span class="sourceLineNo">366</span>  }<a name="line.366"></a>
-<span class="sourceLineNo">367</span>}<a name="line.367"></a>
+<span class="sourceLineNo">359</span>  @FunctionalInterface<a name="line.359"></a>
+<span class="sourceLineNo">360</span>  private interface IOThrowingRunnable {<a name="line.360"></a>
+<span class="sourceLineNo">361</span>    void run() throws IOException;<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>  /**<a name="line.364"></a>
+<span class="sourceLineNo">365</span>   * Computes if {@code size2} is within {@code delta} of {@code size1}, inclusive.<a name="line.365"></a>
+<span class="sourceLineNo">366</span>   */<a name="line.366"></a>
+<span class="sourceLineNo">367</span>  boolean closeInSize(long size1, long size2, long delta) {<a name="line.367"></a>
+<span class="sourceLineNo">368</span>    long lower = size1 - delta;<a name="line.368"></a>
+<span class="sourceLineNo">369</span>    long upper = size1 + delta;<a name="line.369"></a>
+<span class="sourceLineNo">370</span>    return lower &lt;= size2 &amp;&amp; size2 &lt;= upper;<a name="line.370"></a>
+<span class="sourceLineNo">371</span>  }<a name="line.371"></a>
+<span class="sourceLineNo">372</span>}<a name="line.372"></a>
 
 
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html
index 6d723a9..f4327b3 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html
@@ -32,39 +32,39 @@
 <span class="sourceLineNo">024</span>import java.util.HashSet;<a name="line.24"></a>
 <span class="sourceLineNo">025</span>import java.util.Map;<a name="line.25"></a>
 <span class="sourceLineNo">026</span>import java.util.concurrent.atomic.AtomicLong;<a name="line.26"></a>
-<span class="sourceLineNo">027</span>import java.util.concurrent.atomic.AtomicReference;<a name="line.27"></a>
-<span class="sourceLineNo">028</span><a name="line.28"></a>
-<span class="sourceLineNo">029</span>import org.apache.hadoop.conf.Configuration;<a name="line.29"></a>
-<span class="sourceLineNo">030</span>import org.apache.hadoop.hbase.Cell;<a name="line.30"></a>
-<span class="sourceLineNo">031</span>import org.apache.hadoop.hbase.CellScanner;<a name="line.31"></a>
-<span class="sourceLineNo">032</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.32"></a>
-<span class="sourceLineNo">033</span>import org.apache.hadoop.hbase.HColumnDescriptor;<a name="line.33"></a>
-<span class="sourceLineNo">034</span>import org.apache.hadoop.hbase.HTableDescriptor;<a name="line.34"></a>
-<span class="sourceLineNo">035</span>import org.apache.hadoop.hbase.NamespaceDescriptor;<a name="line.35"></a>
-<span class="sourceLineNo">036</span>import org.apache.hadoop.hbase.TableName;<a name="line.36"></a>
-<span class="sourceLineNo">037</span>import org.apache.hadoop.hbase.client.Admin;<a name="line.37"></a>
-<span class="sourceLineNo">038</span>import org.apache.hadoop.hbase.client.Connection;<a name="line.38"></a>
-<span class="sourceLineNo">039</span>import org.apache.hadoop.hbase.client.Get;<a name="line.39"></a>
-<span class="sourceLineNo">040</span>import org.apache.hadoop.hbase.client.Result;<a name="line.40"></a>
-<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.client.ResultScanner;<a name="line.41"></a>
-<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.client.Scan;<a name="line.42"></a>
-<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.client.SnapshotDescription;<a name="line.43"></a>
-<span class="sourceLineNo">044</span>import org.apache.hadoop.hbase.client.SnapshotType;<a name="line.44"></a>
-<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.client.Table;<a name="line.45"></a>
-<span class="sourceLineNo">046</span>import org.apache.hadoop.hbase.master.HMaster;<a name="line.46"></a>
-<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore.SnapshotWithSize;<a name="line.47"></a>
-<span class="sourceLineNo">048</span>import org.apache.hadoop.hbase.quotas.SpaceQuotaHelperForTests.NoFilesToDischarge;<a name="line.48"></a>
-<span class="sourceLineNo">049</span>import org.apache.hadoop.hbase.quotas.SpaceQuotaHelperForTests.SpaceQuotaSnapshotPredicate;<a name="line.49"></a>
-<span class="sourceLineNo">050</span>import org.apache.hadoop.hbase.testclassification.MediumTests;<a name="line.50"></a>
-<span class="sourceLineNo">051</span>import org.junit.AfterClass;<a name="line.51"></a>
-<span class="sourceLineNo">052</span>import org.junit.Before;<a name="line.52"></a>
-<span class="sourceLineNo">053</span>import org.junit.BeforeClass;<a name="line.53"></a>
-<span class="sourceLineNo">054</span>import org.junit.Rule;<a name="line.54"></a>
-<span class="sourceLineNo">055</span>import org.junit.Test;<a name="line.55"></a>
-<span class="sourceLineNo">056</span>import org.junit.experimental.categories.Category;<a name="line.56"></a>
-<span class="sourceLineNo">057</span>import org.junit.rules.TestName;<a name="line.57"></a>
-<span class="sourceLineNo">058</span>import org.slf4j.Logger;<a name="line.58"></a>
-<span class="sourceLineNo">059</span>import org.slf4j.LoggerFactory;<a name="line.59"></a>
+<span class="sourceLineNo">027</span>import org.apache.hadoop.conf.Configuration;<a name="line.27"></a>
+<span class="sourceLineNo">028</span>import org.apache.hadoop.hbase.Cell;<a name="line.28"></a>
+<span class="sourceLineNo">029</span>import org.apache.hadoop.hbase.CellScanner;<a name="line.29"></a>
+<span class="sourceLineNo">030</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.30"></a>
+<span class="sourceLineNo">031</span>import org.apache.hadoop.hbase.HColumnDescriptor;<a name="line.31"></a>
+<span class="sourceLineNo">032</span>import org.apache.hadoop.hbase.HTableDescriptor;<a name="line.32"></a>
+<span class="sourceLineNo">033</span>import org.apache.hadoop.hbase.NamespaceDescriptor;<a name="line.33"></a>
+<span class="sourceLineNo">034</span>import org.apache.hadoop.hbase.TableName;<a name="line.34"></a>
+<span class="sourceLineNo">035</span>import org.apache.hadoop.hbase.client.Admin;<a name="line.35"></a>
+<span class="sourceLineNo">036</span>import org.apache.hadoop.hbase.client.Connection;<a name="line.36"></a>
+<span class="sourceLineNo">037</span>import org.apache.hadoop.hbase.client.Get;<a name="line.37"></a>
+<span class="sourceLineNo">038</span>import org.apache.hadoop.hbase.client.Result;<a name="line.38"></a>
+<span class="sourceLineNo">039</span>import org.apache.hadoop.hbase.client.ResultScanner;<a name="line.39"></a>
+<span class="sourceLineNo">040</span>import org.apache.hadoop.hbase.client.Scan;<a name="line.40"></a>
+<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.client.SnapshotDescription;<a name="line.41"></a>
+<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.client.SnapshotType;<a name="line.42"></a>
+<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.client.Table;<a name="line.43"></a>
+<span class="sourceLineNo">044</span>import org.apache.hadoop.hbase.master.HMaster;<a name="line.44"></a>
+<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore.SnapshotWithSize;<a name="line.45"></a>
+<span class="sourceLineNo">046</span>import org.apache.hadoop.hbase.quotas.SpaceQuotaHelperForTests.NoFilesToDischarge;<a name="line.46"></a>
+<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.quotas.SpaceQuotaHelperForTests.SpaceQuotaSnapshotPredicate;<a name="line.47"></a>
+<span class="sourceLineNo">048</span>import org.apache.hadoop.hbase.regionserver.HStore;<a name="line.48"></a>
+<span class="sourceLineNo">049</span>import org.apache.hadoop.hbase.testclassification.MediumTests;<a name="line.49"></a>
+<span class="sourceLineNo">050</span>import org.junit.AfterClass;<a name="line.50"></a>
+<span class="sourceLineNo">051</span>import org.junit.Before;<a name="line.51"></a>
+<span class="sourceLineNo">052</span>import org.junit.BeforeClass;<a name="line.52"></a>
+<span class="sourceLineNo">053</span>import org.junit.Rule;<a name="line.53"></a>
+<span class="sourceLineNo">054</span>import org.junit.Test;<a name="line.54"></a>
+<span class="sourceLineNo">055</span>import org.junit.experimental.categories.Category;<a name="line.55"></a>
+<span class="sourceLineNo">056</span>import org.junit.rules.TestName;<a name="line.56"></a>
+<span class="sourceLineNo">057</span>import org.slf4j.Logger;<a name="line.57"></a>
+<span class="sourceLineNo">058</span>import org.slf4j.LoggerFactory;<a name="line.58"></a>
+<span class="sourceLineNo">059</span><a name="line.59"></a>
 <span class="sourceLineNo">060</span>import org.apache.hbase.thirdparty.com.google.common.collect.HashMultimap;<a name="line.60"></a>
 <span class="sourceLineNo">061</span>import org.apache.hbase.thirdparty.com.google.common.collect.Iterables;<a name="line.61"></a>
 <span class="sourceLineNo">062</span>import org.apache.hbase.thirdparty.com.google.common.collect.Multimap;<a name="line.62"></a>
@@ -247,132 +247,137 @@
 <span class="sourceLineNo">239</span>    helper.writeData(tn1, 256L * SpaceQuotaHelperForTests.ONE_KILOBYTE);<a name="line.239"></a>
 <span class="sourceLineNo">240</span>    admin.flush(tn1);<a name="line.240"></a>
 <span class="sourceLineNo">241</span><a name="line.241"></a>
-<span class="sourceLineNo">242</span>    final AtomicReference&lt;Long&gt; lastSeenSize = new AtomicReference&lt;&gt;();<a name="line.242"></a>
-<span class="sourceLineNo">243</span>    // Wait for the Master chore to run to see the usage (with a fudge factor)<a name="line.243"></a>
-<span class="sourceLineNo">244</span>    TEST_UTIL.waitFor(30_000, new SpaceQuotaSnapshotPredicate(conn, tn1) {<a name="line.244"></a>
-<span class="sourceLineNo">245</span>      @Override<a name="line.245"></a>
-<span class="sourceLineNo">246</span>      boolean evaluate(SpaceQuotaSnapshot snapshot) throws Exception {<a name="line.246"></a>
-<span class="sourceLineNo">247</span>        lastSeenSize.set(snapshot.getUsage());<a name="line.247"></a>
-<span class="sourceLineNo">248</span>        return snapshot.getUsage() &gt; 230L * SpaceQuotaHelperForTests.ONE_KILOBYTE;<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>    // Create a snapshot on the table<a name="line.252"></a>
-<span class="sourceLineNo">253</span>    final String snapshotName = tn1 + "snapshot";<a name="line.253"></a>
-<span class="sourceLineNo">254</span>    admin.snapshot(new SnapshotDescription(snapshotName, tn1, SnapshotType.SKIPFLUSH));<a name="line.254"></a>
-<span class="sourceLineNo">255</span><a name="line.255"></a>
-<span class="sourceLineNo">256</span>    // Get the snapshots<a name="line.256"></a>
-<span class="sourceLineNo">257</span>    Multimap&lt;TableName,String&gt; snapshotsToCompute = testChore.getSnapshotsToComputeSize();<a name="line.257"></a>
-<span class="sourceLineNo">258</span>    assertEquals(<a name="line.258"></a>
-<span class="sourceLineNo">259</span>        "Expected to see the single snapshot: " + snapshotsToCompute, 1, snapshotsToCompute.size());<a name="line.259"></a>
-<span class="sourceLineNo">260</span><a name="line.260"></a>
-<span class="sourceLineNo">261</span>    // Get the size of our snapshot<a name="line.261"></a>
-<span class="sourceLineNo">262</span>    Multimap&lt;TableName,SnapshotWithSize&gt; snapshotsWithSize = testChore.computeSnapshotSizes(<a name="line.262"></a>
-<span class="sourceLineNo">263</span>        snapshotsToCompute);<a name="line.263"></a>
-<span class="sourceLineNo">264</span>    assertEquals(1, snapshotsWithSize.size());<a name="line.264"></a>
-<span class="sourceLineNo">265</span>    SnapshotWithSize sws = Iterables.getOnlyElement(snapshotsWithSize.get(tn1));<a name="line.265"></a>
-<span class="sourceLineNo">266</span>    assertEquals(snapshotName, sws.getName());<a name="line.266"></a>
-<span class="sourceLineNo">267</span>    // The snapshot should take up no space since the table refers to it completely<a name="line.267"></a>
-<span class="sourceLineNo">268</span>    assertEquals(0, sws.getSize());<a name="line.268"></a>
-<span class="sourceLineNo">269</span><a name="line.269"></a>
-<span class="sourceLineNo">270</span>    // Write some more data, flush it, and then major_compact the table<a name="line.270"></a>
-<span class="sourceLineNo">271</span>    helper.writeData(tn1, 256L * SpaceQuotaHelperForTests.ONE_KILOBYTE);<a name="line.271"></a>
-<span class="sourceLineNo">272</span>    admin.flush(tn1);<a name="line.272"></a>
-<span class="sourceLineNo">273</span>    TEST_UTIL.compact(tn1, true);<a name="line.273"></a>
-<span class="sourceLineNo">274</span><a name="line.274"></a>
-<span class="sourceLineNo">275</span>    // Test table should reflect it's original size since ingest was deterministic<a name="line.275"></a>
-<span class="sourceLineNo">276</span>    TEST_UTIL.waitFor(30_000, new SpaceQuotaSnapshotPredicate(conn, tn1) {<a name="line.276"></a>
-<span class="sourceLineNo">277</span>      @Override<a name="line.277"></a>
-<span class="sourceLineNo">278</span>      boolean evaluate(SpaceQuotaSnapshot snapshot) throws Exception {<a name="line.278"></a>
-<span class="sourceLineNo">279</span>        LOG.debug("Current usage=" + snapshot.getUsage() + " lastSeenSize=" + lastSeenSize.get());<a name="line.279"></a>
-<span class="sourceLineNo">280</span>        return closeInSize(<a name="line.280"></a>
-<span class="sourceLineNo">281</span>            snapshot.getUsage(), lastSeenSize.get(), SpaceQuotaHelperForTests.ONE_KILOBYTE);<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>    // Wait for no compacted files on the regions of our table<a name="line.285"></a>
-<span class="sourceLineNo">286</span>    TEST_UTIL.waitFor(30_000, new NoFilesToDischarge(TEST_UTIL.getMiniHBaseCluster(), tn1));<a name="line.286"></a>
-<span class="sourceLineNo">287</span><a name="line.287"></a>
-<span class="sourceLineNo">288</span>    // Still should see only one snapshot<a name="line.288"></a>
-<span class="sourceLineNo">289</span>    snapshotsToCompute = testChore.getSnapshotsToComputeSize();<a name="line.289"></a>
-<span class="sourceLineNo">290</span>    assertEquals(<a name="line.290"></a>
-<span class="sourceLineNo">291</span>        "Expected to see the single snapshot: " + snapshotsToCompute, 1, snapshotsToCompute.size());<a name="line.291"></a>
-<span class="sourceLineNo">292</span>    snapshotsWithSize = testChore.computeSnapshotSizes(<a name="line.292"></a>
-<span class="sourceLineNo">293</span>            snapshotsToCompute);<a name="line.293"></a>
-<span class="sourceLineNo">294</span>    assertEquals(1, snapshotsWithSize.size());<a name="line.294"></a>
-<span class="sourceLineNo">295</span>    sws = Iterables.getOnlyElement(snapshotsWithSize.get(tn1));<a name="line.295"></a>
-<span class="sourceLineNo">296</span>    assertEquals(snapshotName, sws.getName());<a name="line.296"></a>
-<span class="sourceLineNo">297</span>    // The snapshot should take up the size the table originally took up<a name="line.297"></a>
-<span class="sourceLineNo">298</span>    assertEquals(lastSeenSize.get().longValue(), sws.getSize());<a name="line.298"></a>
-<span class="sourceLineNo">299</span>  }<a name="line.299"></a>
-<span class="sourceLineNo">300</span><a name="line.300"></a>
-<span class="sourceLineNo">301</span>  @Test<a name="line.301"></a>
-<span class="sourceLineNo">302</span>  public void testPersistingSnapshotsForNamespaces() throws Exception {<a name="line.302"></a>
-<span class="sourceLineNo">303</span>    Multimap&lt;TableName,SnapshotWithSize&gt; snapshotsWithSizes = HashMultimap.create();<a name="line.303"></a>
-<span class="sourceLineNo">304</span>    TableName tn1 = TableName.valueOf("ns1:tn1");<a name="line.304"></a>
-<span class="sourceLineNo">305</span>    TableName tn2 = TableName.valueOf("ns1:tn2");<a name="line.305"></a>
-<span class="sourceLineNo">306</span>    TableName tn3 = TableName.valueOf("ns2:tn1");<a name="line.306"></a>
-<span class="sourceLineNo">307</span>    TableName tn4 = TableName.valueOf("ns2:tn2");<a name="line.307"></a>
-<span class="sourceLineNo">308</span>    TableName tn5 = TableName.valueOf("tn1");<a name="line.308"></a>
-<span class="sourceLineNo">309</span><a name="line.309"></a>
-<span class="sourceLineNo">310</span>    snapshotsWithSizes.put(tn1, new SnapshotWithSize("", 1024L));<a name="line.310"></a>
-<span class="sourceLineNo">311</span>    snapshotsWithSizes.put(tn2, new SnapshotWithSize("", 1024L));<a name="line.311"></a>
-<span class="sourceLineNo">312</span>    snapshotsWithSizes.put(tn3, new SnapshotWithSize("", 512L));<a name="line.312"></a>
-<span class="sourceLineNo">313</span>    snapshotsWithSizes.put(tn4, new SnapshotWithSize("", 1024L));<a name="line.313"></a>
-<span class="sourceLineNo">314</span>    snapshotsWithSizes.put(tn5, new SnapshotWithSize("", 3072L));<a name="line.314"></a>
-<span class="sourceLineNo">315</span><a name="line.315"></a>
-<span class="sourceLineNo">316</span>    Map&lt;String,Long&gt; nsSizes = testChore.groupSnapshotSizesByNamespace(snapshotsWithSizes);<a name="line.316"></a>
-<span class="sourceLineNo">317</span>    assertEquals(3, nsSizes.size());<a name="line.317"></a>
-<span class="sourceLineNo">318</span>    assertEquals(2048L, (long) nsSizes.get("ns1"));<a name="line.318"></a>
-<span class="sourceLineNo">319</span>    assertEquals(1536L, (long) nsSizes.get("ns2"));<a name="line.319"></a>
-<span class="sourceLineNo">320</span>    assertEquals(3072L, (long) nsSizes.get(NamespaceDescriptor.DEFAULT_NAMESPACE_NAME_STR));<a name="line.320"></a>
-<span class="sourceLineNo">321</span>  }<a name="line.321"></a>
-<span class="sourceLineNo">322</span><a name="line.322"></a>
-<span class="sourceLineNo">323</span>  private long count(Table t) throws IOException {<a name="line.323"></a>
-<span class="sourceLineNo">324</span>    try (ResultScanner rs = t.getScanner(new Scan())) {<a name="line.324"></a>
-<span class="sourceLineNo">325</span>      long sum = 0;<a name="line.325"></a>
-<span class="sourceLineNo">326</span>      for (Result r : rs) {<a name="line.326"></a>
-<span class="sourceLineNo">327</span>        while (r.advance()) {<a name="line.327"></a>
-<span class="sourceLineNo">328</span>          sum++;<a name="line.328"></a>
-<span class="sourceLineNo">329</span>        }<a name="line.329"></a>
-<span class="sourceLineNo">330</span>      }<a name="line.330"></a>
-<span class="sourceLineNo">331</span>      return sum;<a name="line.331"></a>
-<span class="sourceLineNo">332</span>    }<a name="line.332"></a>
-<span class="sourceLineNo">333</span>  }<a name="line.333"></a>
-<span class="sourceLineNo">334</span><a name="line.334"></a>
-<span class="sourceLineNo">335</span>  private long extractSnapshotSize(<a name="line.335"></a>
-<span class="sourceLineNo">336</span>      Table quotaTable, TableName tn, String snapshot) throws IOException {<a name="line.336"></a>
-<span class="sourceLineNo">337</span>    Get g = QuotaTableUtil.makeGetForSnapshotSize(tn, snapshot);<a name="line.337"></a>
-<span class="sourceLineNo">338</span>    Result r = quotaTable.get(g);<a name="line.338"></a>
-<span class="sourceLineNo">339</span>    assertNotNull(r);<a name="line.339"></a>
-<span class="sourceLineNo">340</span>    CellScanner cs = r.cellScanner();<a name="line.340"></a>
-<span class="sourceLineNo">341</span>    cs.advance();<a name="line.341"></a>
-<span class="sourceLineNo">342</span>    Cell c = cs.current();<a name="line.342"></a>
-<span class="sourceLineNo">343</span>    assertNotNull(c);<a name="line.343"></a>
-<span class="sourceLineNo">344</span>    return QuotaTableUtil.extractSnapshotSize(<a name="line.344"></a>
-<span class="sourceLineNo">345</span>        c.getValueArray(), c.getValueOffset(), c.getValueLength());<a name="line.345"></a>
-<span class="sourceLineNo">346</span>  }<a name="line.346"></a>
-<span class="sourceLineNo">347</span><a name="line.347"></a>
-<span class="sourceLineNo">348</span>  private void verify(Table t, IOThrowingRunnable test) throws IOException {<a name="line.348"></a>
-<span class="sourceLineNo">349</span>    admin.disableTable(t.getName());<a name="line.349"></a>
-<span class="sourceLineNo">350</span>    admin.truncateTable(t.getName(), false);<a name="line.350"></a>
-<span class="sourceLineNo">351</span>    test.run();<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>  @FunctionalInterface<a name="line.354"></a>
-<span class="sourceLineNo">355</span>  private interface IOThrowingRunnable {<a name="line.355"></a>
-<span class="sourceLineNo">356</span>    void run() throws IOException;<a name="line.356"></a>
+<span class="sourceLineNo">242</span>    final long snapshotSize = TEST_UTIL.getMiniHBaseCluster().getRegions(tn1).stream()<a name="line.242"></a>
+<span class="sourceLineNo">243</span>        .flatMap(r -&gt; r.getStores().stream()).mapToLong(HStore::getHFilesSize).sum();<a name="line.243"></a>
+<span class="sourceLineNo">244</span><a name="line.244"></a>
+<span class="sourceLineNo">245</span>    // Wait for the Master chore to run to see the usage (with a fudge factor)<a name="line.245"></a>
+<span class="sourceLineNo">246</span>    TEST_UTIL.waitFor(30_000, new SpaceQuotaSnapshotPredicate(conn, tn1) {<a name="line.246"></a>
+<span class="sourceLineNo">247</span>      @Override<a name="line.247"></a>
+<span class="sourceLineNo">248</span>      boolean evaluate(SpaceQuotaSnapshot snapshot) throws Exception {<a name="line.248"></a>
+<span class="sourceLineNo">249</span>        return snapshot.getUsage() == snapshotSize;<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>    // Create a snapshot on the table<a name="line.253"></a>
+<span class="sourceLineNo">254</span>    final String snapshotName = tn1 + "snapshot";<a name="line.254"></a>
+<span class="sourceLineNo">255</span>    admin.snapshot(new SnapshotDescription(snapshotName, tn1, SnapshotType.SKIPFLUSH));<a name="line.255"></a>
+<span class="sourceLineNo">256</span><a name="line.256"></a>
+<span class="sourceLineNo">257</span>    // Get the snapshots<a name="line.257"></a>
+<span class="sourceLineNo">258</span>    Multimap&lt;TableName,String&gt; snapshotsToCompute = testChore.getSnapshotsToComputeSize();<a name="line.258"></a>
+<span class="sourceLineNo">259</span>    assertEquals(<a name="line.259"></a>
+<span class="sourceLineNo">260</span>        "Expected to see the single snapshot: " + snapshotsToCompute, 1, snapshotsToCompute.size());<a name="line.260"></a>
+<span class="sourceLineNo">261</span><a name="line.261"></a>
+<span class="sourceLineNo">262</span>    // Get the size of our snapshot<a name="line.262"></a>
+<span class="sourceLineNo">263</span>    Multimap&lt;TableName,SnapshotWithSize&gt; snapshotsWithSize = testChore.computeSnapshotSizes(<a name="line.263"></a>
+<span class="sourceLineNo">264</span>        snapshotsToCompute);<a name="line.264"></a>
+<span class="sourceLineNo">265</span>    assertEquals(1, snapshotsWithSize.size());<a name="line.265"></a>
+<span class="sourceLineNo">266</span>    SnapshotWithSize sws = Iterables.getOnlyElement(snapshotsWithSize.get(tn1));<a name="line.266"></a>
+<span class="sourceLineNo">267</span>    assertEquals(snapshotName, sws.getName());<a name="line.267"></a>
+<span class="sourceLineNo">268</span>    // The snapshot should take up no space since the table refers to it completely<a name="line.268"></a>
+<span class="sourceLineNo">269</span>    assertEquals(0, sws.getSize());<a name="line.269"></a>
+<span class="sourceLineNo">270</span><a name="line.270"></a>
+<span class="sourceLineNo">271</span>    // Write some more data, flush it, and then major_compact the table<a name="line.271"></a>
+<span class="sourceLineNo">272</span>    helper.writeData(tn1, 256L * SpaceQuotaHelperForTests.ONE_KILOBYTE);<a name="line.272"></a>
+<span class="sourceLineNo">273</span>    admin.flush(tn1);<a name="line.273"></a>
+<span class="sourceLineNo">274</span>    TEST_UTIL.compact(tn1, true);<a name="line.274"></a>
+<span class="sourceLineNo">275</span><a name="line.275"></a>
+<span class="sourceLineNo">276</span>    // Test table should reflect it's original size since ingest was deterministic<a name="line.276"></a>
+<span class="sourceLineNo">277</span>    TEST_UTIL.waitFor(30_000, new SpaceQuotaSnapshotPredicate(conn, tn1) {<a name="line.277"></a>
+<span class="sourceLineNo">278</span>      private final long regionSize = TEST_UTIL.getMiniHBaseCluster().getRegions(tn1).stream()<a name="line.278"></a>
+<span class="sourceLineNo">279</span>          .flatMap(r -&gt; r.getStores().stream()).mapToLong(HStore::getHFilesSize).sum();<a name="line.279"></a>
+<span class="sourceLineNo">280</span><a name="line.280"></a>
+<span class="sourceLineNo">281</span>      @Override<a name="line.281"></a>
+<span class="sourceLineNo">282</span>      boolean evaluate(SpaceQuotaSnapshot snapshot) throws Exception {<a name="line.282"></a>
+<span class="sourceLineNo">283</span>        LOG.debug("Current usage=" + snapshot.getUsage() + " snapshotSize=" + snapshotSize);<a name="line.283"></a>
+<span class="sourceLineNo">284</span>        // The usage of table space consists of region size and snapshot size<a name="line.284"></a>
+<span class="sourceLineNo">285</span>        return closeInSize(snapshot.getUsage(), snapshotSize + regionSize,<a name="line.285"></a>
+<span class="sourceLineNo">286</span>            SpaceQuotaHelperForTests.ONE_KILOBYTE);<a name="line.286"></a>
+<span class="sourceLineNo">287</span>      }<a name="line.287"></a>
+<span class="sourceLineNo">288</span>    });<a name="line.288"></a>
+<span class="sourceLineNo">289</span><a name="line.289"></a>
+<span class="sourceLineNo">290</span>    // Wait for no compacted files on the regions of our table<a name="line.290"></a>
+<span class="sourceLineNo">291</span>    TEST_UTIL.waitFor(30_000, new NoFilesToDischarge(TEST_UTIL.getMiniHBaseCluster(), tn1));<a name="line.291"></a>
+<span class="sourceLineNo">292</span><a name="line.292"></a>
+<span class="sourceLineNo">293</span>    // Still should see only one snapshot<a name="line.293"></a>
+<span class="sourceLineNo">294</span>    snapshotsToCompute = testChore.getSnapshotsToComputeSize();<a name="line.294"></a>
+<span class="sourceLineNo">295</span>    assertEquals(<a name="line.295"></a>
+<span class="sourceLineNo">296</span>        "Expected to see the single snapshot: " + snapshotsToCompute, 1, snapshotsToCompute.size());<a name="line.296"></a>
+<span class="sourceLineNo">297</span>    snapshotsWithSize = testChore.computeSnapshotSizes(<a name="line.297"></a>
+<span class="sourceLineNo">298</span>            snapshotsToCompute);<a name="line.298"></a>
+<span class="sourceLineNo">299</span>    assertEquals(1, snapshotsWithSize.size());<a name="line.299"></a>
+<span class="sourceLineNo">300</span>    sws = Iterables.getOnlyElement(snapshotsWithSize.get(tn1));<a name="line.300"></a>
+<span class="sourceLineNo">301</span>    assertEquals(snapshotName, sws.getName());<a name="line.301"></a>
+<span class="sourceLineNo">302</span>    // The snapshot should take up the size the table originally took up<a name="line.302"></a>
+<span class="sourceLineNo">303</span>    assertEquals(snapshotSize, sws.getSize());<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>  @Test<a name="line.306"></a>
+<span class="sourceLineNo">307</span>  public void testPersistingSnapshotsForNamespaces() throws Exception {<a name="line.307"></a>
+<span class="sourceLineNo">308</span>    Multimap&lt;TableName,SnapshotWithSize&gt; snapshotsWithSizes = HashMultimap.create();<a name="line.308"></a>
+<span class="sourceLineNo">309</span>    TableName tn1 = TableName.valueOf("ns1:tn1");<a name="line.309"></a>
+<span class="sourceLineNo">310</span>    TableName tn2 = TableName.valueOf("ns1:tn2");<a name="line.310"></a>
+<span class="sourceLineNo">311</span>    TableName tn3 = TableName.valueOf("ns2:tn1");<a name="line.311"></a>
+<span class="sourceLineNo">312</span>    TableName tn4 = TableName.valueOf("ns2:tn2");<a name="line.312"></a>
+<span class="sourceLineNo">313</span>    TableName tn5 = TableName.valueOf("tn1");<a name="line.313"></a>
+<span class="sourceLineNo">314</span><a name="line.314"></a>
+<span class="sourceLineNo">315</span>    snapshotsWithSizes.put(tn1, new SnapshotWithSize("", 1024L));<a name="line.315"></a>
+<span class="sourceLineNo">316</span>    snapshotsWithSizes.put(tn2, new SnapshotWithSize("", 1024L));<a name="line.316"></a>
+<span class="sourceLineNo">317</span>    snapshotsWithSizes.put(tn3, new SnapshotWithSize("", 512L));<a name="line.317"></a>
+<span class="sourceLineNo">318</span>    snapshotsWithSizes.put(tn4, new SnapshotWithSize("", 1024L));<a name="line.318"></a>
+<span class="sourceLineNo">319</span>    snapshotsWithSizes.put(tn5, new SnapshotWithSize("", 3072L));<a name="line.319"></a>
+<span class="sourceLineNo">320</span><a name="line.320"></a>
+<span class="sourceLineNo">321</span>    Map&lt;String,Long&gt; nsSizes = testChore.groupSnapshotSizesByNamespace(snapshotsWithSizes);<a name="line.321"></a>
+<span class="sourceLineNo">322</span>    assertEquals(3, nsSizes.size());<a name="line.322"></a>
+<span class="sourceLineNo">323</span>    assertEquals(2048L, (long) nsSizes.get("ns1"));<a name="line.323"></a>
+<span class="sourceLineNo">324</span>    assertEquals(1536L, (long) nsSizes.get("ns2"));<a name="line.324"></a>
+<span class="sourceLineNo">325</span>    assertEquals(3072L, (long) nsSizes.get(NamespaceDescriptor.DEFAULT_NAMESPACE_NAME_STR));<a name="line.325"></a>
+<span class="sourceLineNo">326</span>  }<a name="line.326"></a>
+<span class="sourceLineNo">327</span><a name="line.327"></a>
+<span class="sourceLineNo">328</span>  private long count(Table t) throws IOException {<a name="line.328"></a>
+<span class="sourceLineNo">329</span>    try (ResultScanner rs = t.getScanner(new Scan())) {<a name="line.329"></a>
+<span class="sourceLineNo">330</span>      long sum = 0;<a name="line.330"></a>
+<span class="sourceLineNo">331</span>      for (Result r : rs) {<a name="line.331"></a>
+<span class="sourceLineNo">332</span>        while (r.advance()) {<a name="line.332"></a>
+<span class="sourceLineNo">333</span>          sum++;<a name="line.333"></a>
+<span class="sourceLineNo">334</span>        }<a name="line.334"></a>
+<span class="sourceLineNo">335</span>      }<a name="line.335"></a>
+<span class="sourceLineNo">336</span>      return sum;<a name="line.336"></a>
+<span class="sourceLineNo">337</span>    }<a name="line.337"></a>
+<span class="sourceLineNo">338</span>  }<a name="line.338"></a>
+<span class="sourceLineNo">339</span><a name="line.339"></a>
+<span class="sourceLineNo">340</span>  private long extractSnapshotSize(<a name="line.340"></a>
+<span class="sourceLineNo">341</span>      Table quotaTable, TableName tn, String snapshot) throws IOException {<a name="line.341"></a>
+<span class="sourceLineNo">342</span>    Get g = QuotaTableUtil.makeGetForSnapshotSize(tn, snapshot);<a name="line.342"></a>
+<span class="sourceLineNo">343</span>    Result r = quotaTable.get(g);<a name="line.343"></a>
+<span class="sourceLineNo">344</span>    assertNotNull(r);<a name="line.344"></a>
+<span class="sourceLineNo">345</span>    CellScanner cs = r.cellScanner();<a name="line.345"></a>
+<span class="sourceLineNo">346</span>    cs.advance();<a name="line.346"></a>
+<span class="sourceLineNo">347</span>    Cell c = cs.current();<a name="line.347"></a>
+<span class="sourceLineNo">348</span>    assertNotNull(c);<a name="line.348"></a>
+<span class="sourceLineNo">349</span>    return QuotaTableUtil.extractSnapshotSize(<a name="line.349"></a>
+<span class="sourceLineNo">350</span>        c.getValueArray(), c.getValueOffset(), c.getValueLength());<a name="line.350"></a>
+<span class="sourceLineNo">351</span>  }<a name="line.351"></a>
+<span class="sourceLineNo">352</span><a name="line.352"></a>
+<span class="sourceLineNo">353</span>  private void verify(Table t, IOThrowingRunnable test) throws IOException {<a name="line.353"></a>
+<span class="sourceLineNo">354</span>    admin.disableTable(t.getName());<a name="line.354"></a>
+<span class="sourceLineNo">355</span>    admin.truncateTable(t.getName(), false);<a name="line.355"></a>
+<span class="sourceLineNo">356</span>    test.run();<a name="line.356"></a>
 <span class="sourceLineNo">357</span>  }<a name="line.357"></a>
 <span class="sourceLineNo">358</span><a name="line.358"></a>
-<span class="sourceLineNo">359</span>  /**<a name="line.359"></a>
-<span class="sourceLineNo">360</span>   * Computes if {@code size2} is within {@code delta} of {@code size1}, inclusive.<a name="line.360"></a>
-<span class="sourceLineNo">361</span>   */<a name="line.361"></a>
-<span class="sourceLineNo">362</span>  boolean closeInSize(long size1, long size2, long delta) {<a name="line.362"></a>
-<span class="sourceLineNo">363</span>    long lower = size1 - delta;<a name="line.363"></a>
-<span class="sourceLineNo">364</span>    long upper = size1 + delta;<a name="line.364"></a>
-<span class="sourceLineNo">365</span>    return lower &lt;= size2 &amp;&amp; size2 &lt;= upper;<a name="line.365"></a>
-<span class="sourceLineNo">366</span>  }<a name="line.366"></a>
-<span class="sourceLineNo">367</span>}<a name="line.367"></a>
+<span class="sourceLineNo">359</span>  @FunctionalInterface<a name="line.359"></a>
+<span class="sourceLineNo">360</span>  private interface IOThrowingRunnable {<a name="line.360"></a>
+<span class="sourceLineNo">361</span>    void run() throws IOException;<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>  /**<a name="line.364"></a>
+<span class="sourceLineNo">365</span>   * Computes if {@code size2} is within {@code delta} of {@code size1}, inclusive.<a name="line.365"></a>
+<span class="sourceLineNo">366</span>   */<a name="line.366"></a>
+<span class="sourceLineNo">367</span>  boolean closeInSize(long size1, long size2, long delta) {<a name="line.367"></a>
+<span class="sourceLineNo">368</span>    long lower = size1 - delta;<a name="line.368"></a>
+<span class="sourceLineNo">369</span>    long upper = size1 + delta;<a name="line.369"></a>
+<span class="sourceLineNo">370</span>    return lower &lt;= size2 &amp;&amp; size2 &lt;= upper;<a name="line.370"></a>
+<span class="sourceLineNo">371</span>  }<a name="line.371"></a>
+<span class="sourceLineNo">372</span>}<a name="line.372"></a>
 
 
 


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/checkstyle-aggregate.html
----------------------------------------------------------------------
diff --git a/checkstyle-aggregate.html b/checkstyle-aggregate.html
index 316d1cd..1167d69 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -8507,7 +8507,7 @@
 <td><a href="#org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker.java">org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.java</a></td>
 <td>0</td>
 <td>0</td>
-<td>3</td></tr>
+<td>4</td></tr>
 <tr class="b">
 <td><a href="#org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher.java">org/apache/hadoop/hbase/regionserver/querymatcher/CompactionScanQueryMatcher.java</a></td>
 <td>0</td>
@@ -8527,7 +8527,7 @@
 <td><a href="#org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker.java">org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.java</a></td>
 <td>0</td>
 <td>0</td>
-<td>2</td></tr>
+<td>1</td></tr>
 <tr class="b">
 <td><a href="#org.apache.hadoop.hbase.regionserver.querymatcher.IncludeAllCompactionQueryMatcher.java">org/apache/hadoop/hbase/regionserver/querymatcher/IncludeAllCompactionQueryMatcher.java</a></td>
 <td>0</td>
@@ -48348,2089 +48348,2089 @@
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</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>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>427</td></tr>
+<td>428</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>428</td></tr>
+<td>429</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>429</td></tr>
+<td>430</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>430</td></tr>
+<td>431</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>431</td></tr>
+<td>432</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>433</td></tr>
+<td>434</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>434</td></tr>
+<td>435</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>435</td></tr>
+<td>436</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>436</td></tr>
+<td>437</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>437</td></tr>
+<td>438</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>438</td></tr>
+<td>439</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>440</td></tr>
+<td>441</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>441</td></tr>
+<td>442</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>442</td></tr>
+<td>443</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>443</td></tr>
+<td>444</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>444</td></tr>
+<td>445</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>445</td></tr>
+<td>446</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>447</td></tr>
+<td>448</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>448</td></tr>
+<td>449</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>449</td></tr>
+<td>450</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>450</td></tr>
+<td>451</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>451</td></tr>
+<td>452</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>452</td></tr>
+<td>453</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>454</td></tr>
+<td>455</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>455</td></tr>
+<td>456</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>456</td></tr>
+<td>457</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>457</td></tr>
+<td>458</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>458</td></tr>
+<td>459</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>459</td></tr>
+<td>460</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>461</td></tr>
+<td>462</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>462</td></tr>
+<td>463</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>463</td></tr>
+<td>464</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>464</td></tr>
+<td>465</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>465</td></tr>
+<td>466</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>466</td></tr>
+<td>467</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>565</td></tr>
+<td>566</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>sizes</td>
 <td>LineLength</td>
 <td>Line is longer than 100 characters (found 104).</td>
-<td>582</td></tr>
+<td>583</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>LeftCurly</td>
 <td>'{' at column 34 should have line break after.</td>
-<td>598</td></tr>
+<td>599</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>623</td></tr>
+<td>624</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>644</td></tr>
+<td>645</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>sizes</td>
 <td>LineLength</td>
 <td>Line is longer than 100 characters (found 104).</td>
-<td>658</td></tr>
+<td>659</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>672</td></tr>
+<td>673</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>sizes</td>
 <td>LineLength</td>
 <td>Line is longer than 100 characters (found 112).</td>
-<td>678</td></tr>
+<td>679</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>sizes</td>
 <td>LineLength</td>
 <td>Line is longer than 100 characters (found 102).</td>
-<td>686</td></tr>
+<td>687</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>sizes</td>
 <td>MethodLength</td>
 <td>Method length is 156 lines (max allowed is 150).</td>
-<td>765</td></tr>
+<td>766</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>840</td></tr>
+<td>841</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>841</td></tr>
+<td>842</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>842</td></tr>
+<td>843</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>843</td></tr>
+<td>844</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>845</td></tr>
+<td>846</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>846</td></tr>
+<td>847</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>847</td></tr>
+<td>848</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>848</td></tr>
+<td>849</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>850</td></tr>
+<td>851</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>851</td></tr>
+<td>852</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>852</td></tr>
+<td>853</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>853</td></tr>
+<td>854</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>855</td></tr>
+<td>856</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>856</td></tr>
+<td>857</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>857</td></tr>
+<td>858</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>858</td></tr>
+<td>859</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>859</td></tr>
+<td>860</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>860</td></tr>
+<td>861</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>862</td></tr>
+<td>863</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>863</td></tr>
+<td>864</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>864</td></tr>
+<td>865</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>865</td></tr>
+<td>866</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>866</td></tr>
+<td>867</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>867</td></tr>
+<td>868</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>869</td></tr>
+<td>870</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>870</td></tr>
+<td>871</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>871</td></tr>
+<td>872</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>872</td></tr>
+<td>873</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>873</td></tr>
+<td>874</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>874</td></tr>
+<td>875</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>889</td></tr>
+<td>890</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>890</td></tr>
+<td>891</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>891</td></tr>
+<td>892</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>892</td></tr>
+<td>893</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>894</td></tr>
+<td>895</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>895</td></tr>
+<td>896</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>896</td></tr>
+<td>897</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>897</td></tr>
+<td>898</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>899</td></tr>
+<td>900</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>900</td></tr>
+<td>901</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>901</td></tr>
+<td>902</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>902</td></tr>
+<td>903</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>904</td></tr>
+<td>905</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>905</td></tr>
+<td>906</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>906</td></tr>
+<td>907</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>907</td></tr>
+<td>908</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>909</td></tr>
+<td>910</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>910</td></tr>
+<td>911</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>911</td></tr>
+<td>912</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>912</td></tr>
+<td>913</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>914</td></tr>
+<td>915</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>915</td></tr>
+<td>916</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>916</td></tr>
+<td>917</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>917</td></tr>
+<td>918</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>927</td></tr>
+<td>928</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>928</td></tr>
+<td>929</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>929</td></tr>
+<td>930</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>931</td></tr>
+<td>932</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>932</td></tr>
+<td>933</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>933</td></tr>
+<td>934</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>936</td></tr>
+<td>937</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>937</td></tr>
+<td>938</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>938</td></tr>
+<td>939</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>940</td></tr>
+<td>941</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>941</td></tr>
+<td>942</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>942</td></tr>
+<td>943</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>945</td></tr>
+<td>946</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>946</td></tr>
+<td>947</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>947</td></tr>
+<td>948</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>949</td></tr>
+<td>950</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>950</td></tr>
+<td>951</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>951</td></tr>
+<td>952</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>955</td></tr>
+<td>956</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>956</td></tr>
+<td>957</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>957</td></tr>
+<td>958</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>959</td></tr>
+<td>960</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>960</td></tr>
+<td>961</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>961</td></tr>
+<td>962</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>965</td></tr>
+<td>966</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>966</td></tr>
+<td>967</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>967</td></tr>
+<td>968</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>969</td></tr>
+<td>970</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>970</td></tr>
+<td>971</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>971</td></tr>
+<td>972</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>975</td></tr>
+<td>976</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>976</td></tr>
+<td>977</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>977</td></tr>
+<td>978</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>979</td></tr>
+<td>980</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>980</td></tr>
+<td>981</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>981</td></tr>
+<td>982</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>985</td></tr>
+<td>986</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>987</td></tr>
+<td>988</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>988</td></tr>
+<td>989</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>990</td></tr>
+<td>991</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>992</td></tr>
+<td>993</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>993</td></tr>
+<td>994</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>994</td></tr>
+<td>995</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>996</td></tr>
+<td>997</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>997</td></tr>
+<td>998</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>998</td></tr>
+<td>999</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1000</td></tr>
+<td>1001</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1001</td></tr>
+<td>1002</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1002</td></tr>
+<td>1003</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1004</td></tr>
+<td>1005</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1005</td></tr>
+<td>1006</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1006</td></tr>
+<td>1007</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1008</td></tr>
+<td>1009</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1009</td></tr>
+<td>1010</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1010</td></tr>
+<td>1011</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1012</td></tr>
+<td>1013</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1013</td></tr>
+<td>1014</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1014</td></tr>
+<td>1015</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1016</td></tr>
+<td>1017</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1022</td></tr>
+<td>1023</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1024</td></tr>
+<td>1025</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1025</td></tr>
+<td>1026</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1027</td></tr>
+<td>1028</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1029</td></tr>
+<td>1030</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1030</td></tr>
+<td>1031</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1031</td></tr>
+<td>1032</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1033</td></tr>
+<td>1034</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1034</td></tr>
+<td>1035</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1035</td></tr>
+<td>1036</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1037</td></tr>
+<td>1038</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1038</td></tr>
+<td>1039</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1039</td></tr>
+<td>1040</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1041</td></tr>
+<td>1042</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1042</td></tr>
+<td>1043</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1043</td></tr>
+<td>1044</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1045</td></tr>
+<td>1046</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1046</td></tr>
+<td>1047</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1047</td></tr>
+<td>1048</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1049</td></tr>
+<td>1050</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1050</td></tr>
+<td>1051</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be 8.</td>
-<td>1051</td></tr>
+<td>1052</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1053</td></tr>
+<td>1054</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def rcurly' have incorrect indentation level 4, expected level should be 2.</td>
-<td>1055</td></tr>
+<td>1056</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1139</td></tr>
+<td>1140</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1140</td></tr>
+<td>1141</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1141</td></tr>
+<td>1142</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1142</td></tr>
+<td>1143</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1143</td></tr>
+<td>1144</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1144</td></tr>
+<td>1145</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1146</td></tr>
+<td>1147</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1147</td></tr>
+<td>1148</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1148</td></tr>
+<td>1149</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1149</td></tr>
+<td>1150</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1150</td></tr>
+<td>1151</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1151</td></tr>
+<td>1152</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1153</td></tr>
+<td>1154</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1154</td></tr>
+<td>1155</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1155</td></tr>
+<td>1156</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1156</td></tr>
+<td>1157</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1157</td></tr>
+<td>1158</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1158</td></tr>
+<td>1159</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1160</td></tr>
+<td>1161</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1161</td></tr>
+<td>1162</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1162</td></tr>
+<td>1163</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1163</td></tr>
+<td>1164</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1164</td></tr>
+<td>1165</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1165</td></tr>
+<td>1166</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1167</td></tr>
+<td>1168</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1168</td></tr>
+<td>1169</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1169</td></tr>
+<td>1170</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1170</td></tr>
+<td>1171</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1171</td></tr>
+<td>1172</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1172</td></tr>
+<td>1173</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1187</td></tr>
+<td>1188</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1188</td></tr>
+<td>1189</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1189</td></tr>
+<td>1190</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1190</td></tr>
+<td>1191</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1191</td></tr>
+<td>1192</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1192</td></tr>
+<td>1193</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1194</td></tr>
+<td>1195</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1195</td></tr>
+<td>1196</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1196</td></tr>
+<td>1197</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1197</td></tr>
+<td>1198</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1198</td></tr>
+<td>1199</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1199</td></tr>
+<td>1200</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1305</td></tr>
+<td>1306</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1306</td></tr>
+<td>1307</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1307</td></tr>
+<td>1308</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1308</td></tr>
+<td>1309</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1309</td></tr>
+<td>1310</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1310</td></tr>
+<td>1311</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1312</td></tr>
+<td>1313</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1313</td></tr>
+<td>1314</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1314</td></tr>
+<td>1315</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1315</td></tr>
+<td>1316</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1316</td></tr>
+<td>1317</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1317</td></tr>
+<td>1318</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1319</td></tr>
+<td>1320</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1320</td></tr>
+<td>1321</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1321</td></tr>
+<td>1322</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1322</td></tr>
+<td>1323</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1323</td></tr>
+<td>1324</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1324</td></tr>
+<td>1325</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1341</td></tr>
+<td>1342</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1342</td></tr>
+<td>1343</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1343</td></tr>
+<td>1344</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1344</td></tr>
+<td>1345</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1345</td></tr>
+<td>1346</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1346</td></tr>
+<td>1347</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1348</td></tr>
+<td>1349</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1349</td></tr>
+<td>1350</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1350</td></tr>
+<td>1351</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1351</td></tr>
+<td>1352</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1352</td></tr>
+<td>1353</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1353</td></tr>
+<td>1354</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1355</td></tr>
+<td>1356</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1356</td></tr>
+<td>1357</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1357</td></tr>
+<td>1358</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1358</td></tr>
+<td>1359</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1359</td></tr>
+<td>1360</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1360</td></tr>
+<td>1361</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1382</td></tr>
+<td>1383</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1406</td></tr>
+<td>1407</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1407</td></tr>
+<td>1408</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1408</td></tr>
+<td>1409</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1409</td></tr>
+<td>1410</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1410</td></tr>
+<td>1411</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1411</td></tr>
+<td>1412</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'CompareOperator' have incorrect indentation level 4, expected level should be 6.</td>
-<td>1422</td></tr>
+<td>1423</td></tr>
 <tr class="b">
 <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>1423</td></tr>
+<td>1424</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 preceded with whitespace.</td>
-<td>1423</td></tr>
+<td>1424</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1428</td></tr>
+<td>1429</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1429</td></tr>
+<td>1430</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1430</td></tr>
+<td>1431</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1431</td></tr>
+<td>1432</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1432</td></tr>
+<td>1433</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1433</td></tr>
+<td>1434</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1434</td></tr>
+<td>1435</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1435</td></tr>
+<td>1436</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1436</td></tr>
+<td>1437</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'CompareOperator' have incorrect indentation level 4, expected level should be 6.</td>
-<td>1443</td></tr>
+<td>1444</td></tr>
 <tr class="b">
 <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>1444</td></tr>
+<td>1445</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 preceded with whitespace.</td>
-<td>1444</td></tr>
+<td>1445</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1449</td></tr>
+<td>1450</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1450</td></tr>
+<td>1451</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1451</td></tr>
+<td>1452</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1452</td></tr>
+<td>1453</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1453</td></tr>
+<td>1454</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1454</td></tr>
+<td>1455</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1455</td></tr>
+<td>1456</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1456</td></tr>
+<td>1457</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1457</td></tr>
+<td>1458</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1470</td></tr>
+<td>1471</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1471</td></tr>
+<td>1472</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1472</td></tr>
+<td>1473</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1473</td></tr>
+<td>1474</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1474</td></tr>
+<td>1475</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1475</td></tr>
+<td>1476</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1476</td></tr>
+<td>1477</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1477</td></tr>
+<td>1478</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1478</td></tr>
+<td>1479</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1479</td></tr>
+<td>1480</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1480</td></tr>
+<td>1481</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1481</td></tr>
+<td>1482</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1482</td></tr>
+<td>1483</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1483</td></tr>
+<td>1484</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1484</td></tr>
+<td>1485</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1485</td></tr>
+<td>1486</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1486</td></tr>
+<td>1487</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1487</td></tr>
+<td>1488</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1567</td></tr>
+<td>1568</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1568</td></tr>
+<td>1569</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1569</td></tr>
+<td>1570</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1600</td></tr>
+<td>1601</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1601</td></tr>
+<td>1602</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1602</td></tr>
+<td>1603</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>1603</td></tr>
+<td>1604</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>1670</td></tr>
+<td>1671</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>1692</td></tr>
+<td>1693</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>1713</td></tr>
+<td>1714</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>1744</td></tr>
+<td>1745</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>whitespace</td>
 <td>ParenPad</td>
 <td>')' is preceded with whitespace.</td>
-<td>1763</td></tr>
+<td>1764</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1870</td></tr>
+<td>1930</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1873</td></tr>
+<td>1933</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1889</td></tr>
+<td>1949</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1905</td></tr>
+<td>1965</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1928</td></tr>
+<td>1988</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1932</td></tr>
+<td>1992</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1933</td></tr>
+<td>1993</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1934</td></tr>
+<td>1994</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 6, expected level should be 4.</td>
-<td>1938</td></tr>
+<td>1998<

<TRUNCATED>

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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html
index f9a542b..8cf9fd1 100644
--- a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html
+++ b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html
@@ -577,13 +577,14 @@ implements <a href="../../../../../../org/apache/hadoop/hbase/regionserver/query
 <ul class="blockList">
 <li class="blockList">
 <h4>doneWithColumn</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#line.216">doneWithColumn</a>(<a href="../../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</pre>
+<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#line.211">doneWithColumn</a>(<a href="../../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</pre>
+<div class="block"><span class="descfrmTypeLabel">Description copied from interface:&nbsp;<code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">ColumnTracker</a></code></span></div>
 <div class="block">This method is used to inform the column tracker that we are done with this column. We may get
  this information from external filters or timestamp range and we then need to indicate this
- information to tracker. It is required only in case of ExplicitColumnTracker.</div>
+ information to tracker. It is currently implemented for ExplicitColumnTracker.</div>
 <dl>
-<dt><span class="paramLabel">Parameters:</span></dt>
-<dd><code>cell</code> - </dd>
+<dt><span class="overrideSpecifyLabel">Specified by:</span></dt>
+<dd><code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">doneWithColumn</a></code>&nbsp;in interface&nbsp;<code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html" title="interface in org.apache.hadoop.hbase.regionserver.querymatcher">ColumnTracker</a></code></dd>
 </dl>
 </li>
 </ul>
@@ -593,7 +594,7 @@ implements <a href="../../../../../../org/apache/hadoop/hbase/regionserver/query
 <ul class="blockList">
 <li class="blockList">
 <h4>getNextRowOrNextColumn</h4>
-<pre>public&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a>&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#line.238">getNextRowOrNextColumn</a>(<a href="../../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</pre>
+<pre>public&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a>&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#line.233">getNextRowOrNextColumn</a>(<a href="../../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</pre>
 <div class="block"><span class="descfrmTypeLabel">Description copied from interface:&nbsp;<code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#getNextRowOrNextColumn-org.apache.hadoop.hbase.Cell-">ColumnTracker</a></code></span></div>
 <div class="block">Retrieve the MatchCode for the next row or column</div>
 <dl>
@@ -608,7 +609,7 @@ implements <a href="../../../../../../org/apache/hadoop/hbase/regionserver/query
 <ul class="blockList">
 <li class="blockList">
 <h4>isDone</h4>
-<pre>public&nbsp;boolean&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#line.248">isDone</a>(long&nbsp;timestamp)</pre>
+<pre>public&nbsp;boolean&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#line.243">isDone</a>(long&nbsp;timestamp)</pre>
 <div class="block"><span class="descfrmTypeLabel">Description copied from interface:&nbsp;<code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#isDone-long-">ColumnTracker</a></code></span></div>
 <div class="block">Give the tracker a chance to declare it's done based on only the timestamp
  to allow an early out.</div>
@@ -626,7 +627,7 @@ implements <a href="../../../../../../org/apache/hadoop/hbase/regionserver/query
 <ul class="blockListLast">
 <li class="blockList">
 <h4>beforeShipped</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#line.253">beforeShipped</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#line.248">beforeShipped</a>()
                    throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block"><span class="descfrmTypeLabel">Description copied from interface:&nbsp;<code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/ShipperListener.html#beforeShipped--">ShipperListener</a></code></span></div>
 <div class="block">The action that needs to be performed before <a href="../../../../../../org/apache/hadoop/hbase/regionserver/Shipper.html#shipped--"><code>Shipper.shipped()</code></a> is performed</div>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/NewVersionBehaviorTracker.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/NewVersionBehaviorTracker.html b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/NewVersionBehaviorTracker.html
index aa5d1f6..9ebc99e 100644
--- a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/NewVersionBehaviorTracker.html
+++ b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/NewVersionBehaviorTracker.html
@@ -372,6 +372,13 @@ implements <a href="../../../../../../org/apache/hadoop/hbase/regionserver/query
 <h3>Methods inherited from class&nbsp;java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a></h3>
 <code><a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#clone--" title="class or interface in java.lang">clone</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#equals-java.lang.Object-" title="class or interface in java.lang">equals</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#finalize--" title="class or interface in java.lang">finalize</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#getClass--" title="class or interface in java.lang">getClass</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#hashCode--" title="class or interface in java.lang">hashCode</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#notify--" title="class or interface in java.lang">notify</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang
 /Object.html?is-external=true#notifyAll--" title="class or interface in java.lang">notifyAll</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#toString--" title="class or interface in java.lang">toString</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#wait--" title="class or interface in java.lang">wait</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#wait-long-" title="class or interface in java.lang">wait</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#wait-long-int-" title="class or interface in java.lang">wait</a></code></li>
 </ul>
+<ul class="blockList">
+<li class="blockList"><a name="methods.inherited.from.class.org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker">
+<!--   -->
+</a>
+<h3>Methods inherited from interface&nbsp;org.apache.hadoop.hbase.regionserver.querymatcher.<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html" title="interface in org.apache.hadoop.hbase.regionserver.querymatcher">ColumnTracker</a></h3>
+<code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">doneWithColumn</a></code></li>
+</ul>
 </li>
 </ul>
 </li>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ScanWildcardColumnTracker.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ScanWildcardColumnTracker.html b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ScanWildcardColumnTracker.html
index 8eb4463..7b9ba28 100644
--- a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ScanWildcardColumnTracker.html
+++ b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ScanWildcardColumnTracker.html
@@ -297,6 +297,13 @@ implements <a href="../../../../../../org/apache/hadoop/hbase/regionserver/query
 <h3>Methods inherited from class&nbsp;java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a></h3>
 <code><a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#clone--" title="class or interface in java.lang">clone</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#equals-java.lang.Object-" title="class or interface in java.lang">equals</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#finalize--" title="class or interface in java.lang">finalize</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#getClass--" title="class or interface in java.lang">getClass</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#hashCode--" title="class or interface in java.lang">hashCode</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#notify--" title="class or interface in java.lang">notify</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang
 /Object.html?is-external=true#notifyAll--" title="class or interface in java.lang">notifyAll</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#toString--" title="class or interface in java.lang">toString</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#wait--" title="class or interface in java.lang">wait</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#wait-long-" title="class or interface in java.lang">wait</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#wait-long-int-" title="class or interface in java.lang">wait</a></code></li>
 </ul>
+<ul class="blockList">
+<li class="blockList"><a name="methods.inherited.from.class.org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker">
+<!--   -->
+</a>
+<h3>Methods inherited from interface&nbsp;org.apache.hadoop.hbase.regionserver.querymatcher.<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html" title="interface in org.apache.hadoop.hbase.regionserver.querymatcher">ColumnTracker</a></h3>
+<code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">doneWithColumn</a></code></li>
+</ul>
 </li>
 </ul>
 </li>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html
index cdc9c11..7de810c 100644
--- a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html
+++ b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html
@@ -548,7 +548,7 @@ extends <a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymat
 <ul class="blockList">
 <li class="blockList">
 <h4>isGet</h4>
-<pre>protected abstract&nbsp;boolean&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#line.241">isGet</a>()</pre>
+<pre>protected abstract&nbsp;boolean&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#line.244">isGet</a>()</pre>
 </li>
 </ul>
 <a name="moreRowsMayExistsAfter-int-">
@@ -557,7 +557,7 @@ extends <a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymat
 <ul class="blockList">
 <li class="blockList">
 <h4>moreRowsMayExistsAfter</h4>
-<pre>protected abstract&nbsp;boolean&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#line.243">moreRowsMayExistsAfter</a>(int&nbsp;cmpToStopRow)</pre>
+<pre>protected abstract&nbsp;boolean&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#line.246">moreRowsMayExistsAfter</a>(int&nbsp;cmpToStopRow)</pre>
 </li>
 </ul>
 <a name="moreRowsMayExistAfter-org.apache.hadoop.hbase.Cell-">
@@ -566,7 +566,7 @@ extends <a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymat
 <ul class="blockList">
 <li class="blockList">
 <h4>moreRowsMayExistAfter</h4>
-<pre>public&nbsp;boolean&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#line.246">moreRowsMayExistAfter</a>(<a href="../../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</pre>
+<pre>public&nbsp;boolean&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#line.249">moreRowsMayExistAfter</a>(<a href="../../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</pre>
 <dl>
 <dt><span class="overrideSpecifyLabel">Specified by:</span></dt>
 <dd><code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.html#moreRowsMayExistAfter-org.apache.hadoop.hbase.Cell-">moreRowsMayExistAfter</a></code>&nbsp;in class&nbsp;<code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.html" title="class in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher</a></code></dd>
@@ -583,7 +583,7 @@ extends <a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymat
 <ul class="blockListLast">
 <li class="blockList">
 <h4>create</h4>
-<pre>public static&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html" title="class in org.apache.hadoop.hbase.regionserver.querymatcher">UserScanQueryMatcher</a>&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#line.262">create</a>(<a href="../../../../../../org/apache/hadoop/hbase/client/Scan.html" title="class in org.apache.hadoop.hbase.client">Scan</a>&nbsp;scan,
+<pre>public static&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html" title="class in org.apache.hadoop.hbase.regionserver.querymatcher">UserScanQueryMatcher</a>&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#line.265">create</a>(<a href="../../../../../../org/apache/hadoop/hbase/client/Scan.html" title="class in org.apache.hadoop.hbase.client">Scan</a>&nbsp;scan,
                                           <a href="../../../../../../org/apache/hadoop/hbase/regionserver/ScanInfo.html" title="class in org.apache.hadoop.hbase.regionserver">ScanInfo</a>&nbsp;scanInfo,
                                           <a href="http://docs.oracle.com/javase/8/docs/api/java/util/NavigableSet.html?is-external=true" title="class or interface in java.util">NavigableSet</a>&lt;byte[]&gt;&nbsp;columns,
                                           long&nbsp;oldestUnexpiredTS,

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/package-tree.html b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/package-tree.html
index 6e98708..c2cf4f9 100644
--- a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/package-tree.html
@@ -130,9 +130,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.regionserver.querymatcher.<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/DeleteTracker.DeleteResult.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher"><span class="typeNameLink">DeleteTracker.DeleteResult</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.regionserver.querymatcher.<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher"><span class="typeNameLink">ScanQueryMatcher.MatchCode</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.querymatcher.<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/StripeCompactionScanQueryMatcher.DropDeletesInOutput.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher"><span class="typeNameLink">StripeCompactionScanQueryMatcher.DropDeletesInOutput</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.querymatcher.<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher"><span class="typeNameLink">ScanQueryMatcher.MatchCode</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.querymatcher.<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/DeleteTracker.DeleteResult.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher"><span class="typeNameLink">DeleteTracker.DeleteResult</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/security/access/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/security/access/package-tree.html b/devapidocs/org/apache/hadoop/hbase/security/access/package-tree.html
index a42c95d..60ffc1f 100644
--- a/devapidocs/org/apache/hadoop/hbase/security/access/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/security/access/package-tree.html
@@ -136,9 +136,9 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
+<li type="circle">org.apache.hadoop.hbase.security.access.<a href="../../../../../../org/apache/hadoop/hbase/security/access/AccessController.OpType.html" title="enum in org.apache.hadoop.hbase.security.access"><span class="typeNameLink">AccessController.OpType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.security.access.<a href="../../../../../../org/apache/hadoop/hbase/security/access/Permission.Action.html" title="enum in org.apache.hadoop.hbase.security.access"><span class="typeNameLink">Permission.Action</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.security.access.<a href="../../../../../../org/apache/hadoop/hbase/security/access/AccessControlFilter.Strategy.html" title="enum in org.apache.hadoop.hbase.security.access"><span class="typeNameLink">AccessControlFilter.Strategy</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.security.access.<a href="../../../../../../org/apache/hadoop/hbase/security/access/AccessController.OpType.html" title="enum in org.apache.hadoop.hbase.security.access"><span class="typeNameLink">AccessController.OpType</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/security/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/security/package-tree.html b/devapidocs/org/apache/hadoop/hbase/security/package-tree.html
index acf9832..2539fbd 100644
--- a/devapidocs/org/apache/hadoop/hbase/security/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/security/package-tree.html
@@ -191,9 +191,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.security.<a href="../../../../../org/apache/hadoop/hbase/security/SaslStatus.html" title="enum in org.apache.hadoop.hbase.security"><span class="typeNameLink">SaslStatus</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.security.<a href="../../../../../org/apache/hadoop/hbase/security/AuthMethod.html" title="enum in org.apache.hadoop.hbase.security"><span class="typeNameLink">AuthMethod</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.security.<a href="../../../../../org/apache/hadoop/hbase/security/SaslUtil.QualityOfProtection.html" title="enum in org.apache.hadoop.hbase.security"><span class="typeNameLink">SaslUtil.QualityOfProtection</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.security.<a href="../../../../../org/apache/hadoop/hbase/security/SaslStatus.html" title="enum in org.apache.hadoop.hbase.security"><span class="typeNameLink">SaslStatus</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/security/visibility/VisibilityNewVersionBehaivorTracker.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/security/visibility/VisibilityNewVersionBehaivorTracker.html b/devapidocs/org/apache/hadoop/hbase/security/visibility/VisibilityNewVersionBehaivorTracker.html
index fc5c2cf..768ca95 100644
--- a/devapidocs/org/apache/hadoop/hbase/security/visibility/VisibilityNewVersionBehaivorTracker.html
+++ b/devapidocs/org/apache/hadoop/hbase/security/visibility/VisibilityNewVersionBehaivorTracker.html
@@ -261,6 +261,13 @@ extends <a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymat
 <h3>Methods inherited from class&nbsp;java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a></h3>
 <code><a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#clone--" title="class or interface in java.lang">clone</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#equals-java.lang.Object-" title="class or interface in java.lang">equals</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#finalize--" title="class or interface in java.lang">finalize</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#getClass--" title="class or interface in java.lang">getClass</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#hashCode--" title="class or interface in java.lang">hashCode</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#notify--" title="class or interface in java.lang">notify</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang
 /Object.html?is-external=true#notifyAll--" title="class or interface in java.lang">notifyAll</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#toString--" title="class or interface in java.lang">toString</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#wait--" title="class or interface in java.lang">wait</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#wait-long-" title="class or interface in java.lang">wait</a>, <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true#wait-long-int-" title="class or interface in java.lang">wait</a></code></li>
 </ul>
+<ul class="blockList">
+<li class="blockList"><a name="methods.inherited.from.class.org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker">
+<!--   -->
+</a>
+<h3>Methods inherited from interface&nbsp;org.apache.hadoop.hbase.regionserver.querymatcher.<a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html" title="interface in org.apache.hadoop.hbase.regionserver.querymatcher">ColumnTracker</a></h3>
+<code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">doneWithColumn</a></code></li>
+</ul>
 </li>
 </ul>
 </li>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/thrift/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/thrift/package-tree.html b/devapidocs/org/apache/hadoop/hbase/thrift/package-tree.html
index e924839..3279176 100644
--- a/devapidocs/org/apache/hadoop/hbase/thrift/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/thrift/package-tree.html
@@ -198,9 +198,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.thrift.<a href="../../../../../org/apache/hadoop/hbase/thrift/ThriftServerRunner.ImplType.html" title="enum in org.apache.hadoop.hbase.thrift"><span class="typeNameLink">ThriftServerRunner.ImplType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.thrift.<a href="../../../../../org/apache/hadoop/hbase/thrift/ThriftMetrics.ThriftServerType.html" title="enum in org.apache.hadoop.hbase.thrift"><span class="typeNameLink">ThriftMetrics.ThriftServerType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.thrift.<a href="../../../../../org/apache/hadoop/hbase/thrift/MetricsThriftServerSourceFactoryImpl.FactoryStorage.html" title="enum in org.apache.hadoop.hbase.thrift"><span class="typeNameLink">MetricsThriftServerSourceFactoryImpl.FactoryStorage</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.thrift.<a href="../../../../../org/apache/hadoop/hbase/thrift/ThriftMetrics.ThriftServerType.html" title="enum in org.apache.hadoop.hbase.thrift"><span class="typeNameLink">ThriftMetrics.ThriftServerType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.thrift.<a href="../../../../../org/apache/hadoop/hbase/thrift/ThriftServerRunner.ImplType.html" title="enum in org.apache.hadoop.hbase.thrift"><span class="typeNameLink">ThriftServerRunner.ImplType</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/util/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/util/package-tree.html b/devapidocs/org/apache/hadoop/hbase/util/package-tree.html
index 24bd89b..43c86d3 100644
--- a/devapidocs/org/apache/hadoop/hbase/util/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/util/package-tree.html
@@ -535,14 +535,14 @@
 <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.util.<a href="../../../../../org/apache/hadoop/hbase/util/HBaseFsck.ErrorReporter.ERROR_CODE.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">HBaseFsck.ErrorReporter.ERROR_CODE</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/Bytes.LexicographicalComparerHolder.UnsafeComparer.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">Bytes.LexicographicalComparerHolder.UnsafeComparer</span></a> (implements org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/Bytes.Comparer.html" title="interface in org.apache.hadoop.hbase.util">Bytes.Comparer</a>&lt;T&gt;)</li>
+<li type="circle">org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/PoolMap.PoolType.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">PoolMap.PoolType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/ChecksumType.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">ChecksumType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/IdReadWriteLock.ReferenceType.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">IdReadWriteLock.ReferenceType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/HBaseFsck.ErrorReporter.ERROR_CODE.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">HBaseFsck.ErrorReporter.ERROR_CODE</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/PrettyPrinter.Unit.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">PrettyPrinter.Unit</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/PoolMap.PoolType.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">PoolMap.PoolType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/Bytes.LexicographicalComparerHolder.PureJavaComparer.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">Bytes.LexicographicalComparerHolder.PureJavaComparer</span></a> (implements org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/Bytes.Comparer.html" title="interface in org.apache.hadoop.hbase.util">Bytes.Comparer</a>&lt;T&gt;)</li>
 <li type="circle">org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/Order.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">Order</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/Bytes.LexicographicalComparerHolder.UnsafeComparer.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">Bytes.LexicographicalComparerHolder.UnsafeComparer</span></a> (implements org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/Bytes.Comparer.html" title="interface in org.apache.hadoop.hbase.util">Bytes.Comparer</a>&lt;T&gt;)</li>
+<li type="circle">org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/Bytes.LexicographicalComparerHolder.PureJavaComparer.html" title="enum in org.apache.hadoop.hbase.util"><span class="typeNameLink">Bytes.LexicographicalComparerHolder.PureJavaComparer</span></a> (implements org.apache.hadoop.hbase.util.<a href="../../../../../org/apache/hadoop/hbase/util/Bytes.Comparer.html" title="interface in org.apache.hadoop.hbase.util">Bytes.Comparer</a>&lt;T&gt;)</li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/wal/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/wal/package-tree.html b/devapidocs/org/apache/hadoop/hbase/wal/package-tree.html
index bfa7220..a29ad5c 100644
--- a/devapidocs/org/apache/hadoop/hbase/wal/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/wal/package-tree.html
@@ -189,8 +189,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.wal.<a href="../../../../../org/apache/hadoop/hbase/wal/RegionGroupingProvider.Strategies.html" title="enum in org.apache.hadoop.hbase.wal"><span class="typeNameLink">RegionGroupingProvider.Strategies</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.wal.<a href="../../../../../org/apache/hadoop/hbase/wal/WALFactory.Providers.html" title="enum in org.apache.hadoop.hbase.wal"><span class="typeNameLink">WALFactory.Providers</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.wal.<a href="../../../../../org/apache/hadoop/hbase/wal/RegionGroupingProvider.Strategies.html" title="enum in org.apache.hadoop.hbase.wal"><span class="typeNameLink">RegionGroupingProvider.Strategies</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 ccab400..a126215 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 = "8ae2a2150b517123cde214bb5543557b562c4c01";<a name="line.11"></a>
+<span class="sourceLineNo">011</span>  public static final String revision = "afc2cdbaffca6cb1f8495451a0b0940ad1fc4be0";<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 Jan  7 14:43:00 UTC 2018";<a name="line.13"></a>
+<span class="sourceLineNo">013</span>  public static final String date = "Mon Jan  8 14:42:49 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 = "8254324d460162e9c8d1041940c3ed82";<a name="line.15"></a>
+<span class="sourceLineNo">015</span>  public static final String srcChecksum = "468663e6dd7dacd9c2be13c6e5d55570";<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/123d826c/devapidocs/src-html/org/apache/hadoop/hbase/io/hfile/BlockCacheKey.html
----------------------------------------------------------------------
diff --git a/devapidocs/src-html/org/apache/hadoop/hbase/io/hfile/BlockCacheKey.html b/devapidocs/src-html/org/apache/hadoop/hbase/io/hfile/BlockCacheKey.html
index 17346f5..abe496e 100644
--- a/devapidocs/src-html/org/apache/hadoop/hbase/io/hfile/BlockCacheKey.html
+++ b/devapidocs/src-html/org/apache/hadoop/hbase/io/hfile/BlockCacheKey.html
@@ -76,7 +76,7 @@
 <span class="sourceLineNo">068</span><a name="line.68"></a>
 <span class="sourceLineNo">069</span>  @Override<a name="line.69"></a>
 <span class="sourceLineNo">070</span>  public String toString() {<a name="line.70"></a>
-<span class="sourceLineNo">071</span>    return String.format("%s_%d", hfileName, offset);<a name="line.71"></a>
+<span class="sourceLineNo">071</span>    return this.hfileName + '_' + this.offset;<a name="line.71"></a>
 <span class="sourceLineNo">072</span>  }<a name="line.72"></a>
 <span class="sourceLineNo">073</span><a name="line.73"></a>
 <span class="sourceLineNo">074</span>  public static final long FIXED_OVERHEAD = ClassSize.align(<a name="line.74"></a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html
----------------------------------------------------------------------
diff --git a/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html b/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html
index 883a9b7..31ba835 100644
--- a/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html
+++ b/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html
@@ -134,7 +134,16 @@
 <span class="sourceLineNo">126</span>   * @return &lt;code&gt;true&lt;/code&gt; to early out based on timestamp.<a name="line.126"></a>
 <span class="sourceLineNo">127</span>   */<a name="line.127"></a>
 <span class="sourceLineNo">128</span>  boolean isDone(long timestamp);<a name="line.128"></a>
-<span class="sourceLineNo">129</span>}<a name="line.129"></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>   * This method is used to inform the column tracker that we are done with this column. We may get<a name="line.131"></a>
+<span class="sourceLineNo">132</span>   * this information from external filters or timestamp range and we then need to indicate this<a name="line.132"></a>
+<span class="sourceLineNo">133</span>   * information to tracker. It is currently implemented for ExplicitColumnTracker.<a name="line.133"></a>
+<span class="sourceLineNo">134</span>   * @param cell<a name="line.134"></a>
+<span class="sourceLineNo">135</span>   */<a name="line.135"></a>
+<span class="sourceLineNo">136</span>  default void doneWithColumn(Cell cell) {<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>
 
 
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html
----------------------------------------------------------------------
diff --git a/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html b/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html
index 4d2f9a0..900e07d 100644
--- a/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html
+++ b/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html
@@ -215,53 +215,48 @@
 <span class="sourceLineNo">207</span>    return timestamp &lt; oldestStamp;<a name="line.207"></a>
 <span class="sourceLineNo">208</span>  }<a name="line.208"></a>
 <span class="sourceLineNo">209</span><a name="line.209"></a>
-<span class="sourceLineNo">210</span>  /**<a name="line.210"></a>
-<span class="sourceLineNo">211</span>   * This method is used to inform the column tracker that we are done with this column. We may get<a name="line.211"></a>
-<span class="sourceLineNo">212</span>   * this information from external filters or timestamp range and we then need to indicate this<a name="line.212"></a>
-<span class="sourceLineNo">213</span>   * information to tracker. It is required only in case of ExplicitColumnTracker.<a name="line.213"></a>
-<span class="sourceLineNo">214</span>   * @param cell<a name="line.214"></a>
-<span class="sourceLineNo">215</span>   */<a name="line.215"></a>
-<span class="sourceLineNo">216</span>  public void doneWithColumn(Cell cell) {<a name="line.216"></a>
-<span class="sourceLineNo">217</span>    while (this.column != null) {<a name="line.217"></a>
-<span class="sourceLineNo">218</span>      int compare = CellUtil.compareQualifiers(cell, column.getBuffer(), column.getOffset(),<a name="line.218"></a>
-<span class="sourceLineNo">219</span>        column.getLength());<a name="line.219"></a>
-<span class="sourceLineNo">220</span>      resetTS();<a name="line.220"></a>
-<span class="sourceLineNo">221</span>      if (compare &gt;= 0) {<a name="line.221"></a>
-<span class="sourceLineNo">222</span>        ++this.index;<a name="line.222"></a>
-<span class="sourceLineNo">223</span>        if (done()) {<a name="line.223"></a>
-<span class="sourceLineNo">224</span>          // Will not hit any more columns in this storefile<a name="line.224"></a>
-<span class="sourceLineNo">225</span>          this.column = null;<a name="line.225"></a>
-<span class="sourceLineNo">226</span>        } else {<a name="line.226"></a>
-<span class="sourceLineNo">227</span>          this.column = this.columns[this.index];<a name="line.227"></a>
-<span class="sourceLineNo">228</span>        }<a name="line.228"></a>
-<span class="sourceLineNo">229</span>        if (compare &gt; 0) {<a name="line.229"></a>
-<span class="sourceLineNo">230</span>          continue;<a name="line.230"></a>
-<span class="sourceLineNo">231</span>        }<a name="line.231"></a>
-<span class="sourceLineNo">232</span>      }<a name="line.232"></a>
-<span class="sourceLineNo">233</span>      return;<a name="line.233"></a>
-<span class="sourceLineNo">234</span>    }<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>  @Override<a name="line.237"></a>
-<span class="sourceLineNo">238</span>  public MatchCode getNextRowOrNextColumn(Cell cell) {<a name="line.238"></a>
-<span class="sourceLineNo">239</span>    doneWithColumn(cell);<a name="line.239"></a>
-<span class="sourceLineNo">240</span><a name="line.240"></a>
-<span class="sourceLineNo">241</span>    if (getColumnHint() == null) {<a name="line.241"></a>
-<span class="sourceLineNo">242</span>      return MatchCode.SEEK_NEXT_ROW;<a name="line.242"></a>
-<span class="sourceLineNo">243</span>    } else {<a name="line.243"></a>
-<span class="sourceLineNo">244</span>      return MatchCode.SEEK_NEXT_COL;<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><a name="line.247"></a>
-<span class="sourceLineNo">248</span>  public boolean isDone(long timestamp) {<a name="line.248"></a>
-<span class="sourceLineNo">249</span>    return minVersions &lt;= 0 &amp;&amp; isExpired(timestamp);<a name="line.249"></a>
+<span class="sourceLineNo">210</span>  @Override<a name="line.210"></a>
+<span class="sourceLineNo">211</span>  public void doneWithColumn(Cell cell) {<a name="line.211"></a>
+<span class="sourceLineNo">212</span>    while (this.column != null) {<a name="line.212"></a>
+<span class="sourceLineNo">213</span>      int compare = CellUtil.compareQualifiers(cell, column.getBuffer(), column.getOffset(),<a name="line.213"></a>
+<span class="sourceLineNo">214</span>        column.getLength());<a name="line.214"></a>
+<span class="sourceLineNo">215</span>      resetTS();<a name="line.215"></a>
+<span class="sourceLineNo">216</span>      if (compare &gt;= 0) {<a name="line.216"></a>
+<span class="sourceLineNo">217</span>        ++this.index;<a name="line.217"></a>
+<span class="sourceLineNo">218</span>        if (done()) {<a name="line.218"></a>
+<span class="sourceLineNo">219</span>          // Will not hit any more columns in this storefile<a name="line.219"></a>
+<span class="sourceLineNo">220</span>          this.column = null;<a name="line.220"></a>
+<span class="sourceLineNo">221</span>        } else {<a name="line.221"></a>
+<span class="sourceLineNo">222</span>          this.column = this.columns[this.index];<a name="line.222"></a>
+<span class="sourceLineNo">223</span>        }<a name="line.223"></a>
+<span class="sourceLineNo">224</span>        if (compare &gt; 0) {<a name="line.224"></a>
+<span class="sourceLineNo">225</span>          continue;<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>      return;<a name="line.228"></a>
+<span class="sourceLineNo">229</span>    }<a name="line.229"></a>
+<span class="sourceLineNo">230</span>  }<a name="line.230"></a>
+<span class="sourceLineNo">231</span><a name="line.231"></a>
+<span class="sourceLineNo">232</span>  @Override<a name="line.232"></a>
+<span class="sourceLineNo">233</span>  public MatchCode getNextRowOrNextColumn(Cell cell) {<a name="line.233"></a>
+<span class="sourceLineNo">234</span>    doneWithColumn(cell);<a name="line.234"></a>
+<span class="sourceLineNo">235</span><a name="line.235"></a>
+<span class="sourceLineNo">236</span>    if (getColumnHint() == null) {<a name="line.236"></a>
+<span class="sourceLineNo">237</span>      return MatchCode.SEEK_NEXT_ROW;<a name="line.237"></a>
+<span class="sourceLineNo">238</span>    } else {<a name="line.238"></a>
+<span class="sourceLineNo">239</span>      return MatchCode.SEEK_NEXT_COL;<a name="line.239"></a>
+<span class="sourceLineNo">240</span>    }<a name="line.240"></a>
+<span class="sourceLineNo">241</span>  }<a name="line.241"></a>
+<span class="sourceLineNo">242</span><a name="line.242"></a>
+<span class="sourceLineNo">243</span>  public boolean isDone(long timestamp) {<a name="line.243"></a>
+<span class="sourceLineNo">244</span>    return minVersions &lt;= 0 &amp;&amp; isExpired(timestamp);<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>  @Override<a name="line.247"></a>
+<span class="sourceLineNo">248</span>  public void beforeShipped() throws IOException {<a name="line.248"></a>
+<span class="sourceLineNo">249</span>    // do nothing<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>  @Override<a name="line.252"></a>
-<span class="sourceLineNo">253</span>  public void beforeShipped() throws IOException {<a name="line.253"></a>
-<span class="sourceLineNo">254</span>    // do nothing<a name="line.254"></a>
-<span class="sourceLineNo">255</span>  }<a name="line.255"></a>
-<span class="sourceLineNo">256</span>}<a name="line.256"></a>
+<span class="sourceLineNo">251</span>}<a name="line.251"></a>
 
 
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html
----------------------------------------------------------------------
diff --git a/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html b/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html
index 8182063..b375879 100644
--- a/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html
+++ b/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html
@@ -220,71 +220,74 @@
 <span class="sourceLineNo">212</span>      case INCLUDE_AND_NEXT_COL:<a name="line.212"></a>
 <span class="sourceLineNo">213</span>        if (matchCode == MatchCode.INCLUDE) {<a name="line.213"></a>
 <span class="sourceLineNo">214</span>          matchCode = MatchCode.INCLUDE_AND_SEEK_NEXT_COL;<a name="line.214"></a>
-<span class="sourceLineNo">215</span>        }<a name="line.215"></a>
-<span class="sourceLineNo">216</span>        break;<a name="line.216"></a>
-<span class="sourceLineNo">217</span>      case INCLUDE_AND_SEEK_NEXT_ROW:<a name="line.217"></a>
-<span class="sourceLineNo">218</span>        break;<a name="line.218"></a>
-<span class="sourceLineNo">219</span>      default:<a name="line.219"></a>
-<span class="sourceLineNo">220</span>        throw new RuntimeException("UNEXPECTED");<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>    // It means it is INCLUDE, INCLUDE_AND_SEEK_NEXT_COL or INCLUDE_AND_SEEK_NEXT_ROW.<a name="line.223"></a>
-<span class="sourceLineNo">224</span>    assert matchCode == MatchCode.INCLUDE || matchCode == MatchCode.INCLUDE_AND_SEEK_NEXT_COL<a name="line.224"></a>
-<span class="sourceLineNo">225</span>        || matchCode == MatchCode.INCLUDE_AND_SEEK_NEXT_ROW;<a name="line.225"></a>
-<span class="sourceLineNo">226</span><a name="line.226"></a>
-<span class="sourceLineNo">227</span>    if (matchCode == MatchCode.INCLUDE_AND_SEEK_NEXT_COL<a name="line.227"></a>
-<span class="sourceLineNo">228</span>        || matchCode == MatchCode.INCLUDE_AND_SEEK_NEXT_ROW) {<a name="line.228"></a>
-<span class="sourceLineNo">229</span>      return matchCode;<a name="line.229"></a>
-<span class="sourceLineNo">230</span>    }<a name="line.230"></a>
-<span class="sourceLineNo">231</span><a name="line.231"></a>
-<span class="sourceLineNo">232</span>    // Now we will check versions again.<a name="line.232"></a>
-<span class="sourceLineNo">233</span>    if (curColCell == null || !CellUtil.matchingRowColumn(cell, curColCell)) {<a name="line.233"></a>
-<span class="sourceLineNo">234</span>      count = 0;<a name="line.234"></a>
-<span class="sourceLineNo">235</span>      curColCell = cell;<a name="line.235"></a>
-<span class="sourceLineNo">236</span>    }<a name="line.236"></a>
-<span class="sourceLineNo">237</span>    count += 1;<a name="line.237"></a>
-<span class="sourceLineNo">238</span>    return count &gt; versionsAfterFilter ? MatchCode.SEEK_NEXT_COL : MatchCode.INCLUDE;<a name="line.238"></a>
-<span class="sourceLineNo">239</span>  }<a name="line.239"></a>
-<span class="sourceLineNo">240</span><a name="line.240"></a>
-<span class="sourceLineNo">241</span>  protected abstract boolean isGet();<a name="line.241"></a>
-<span class="sourceLineNo">242</span><a name="line.242"></a>
-<span class="sourceLineNo">243</span>  protected abstract boolean moreRowsMayExistsAfter(int cmpToStopRow);<a name="line.243"></a>
-<span class="sourceLineNo">244</span><a name="line.244"></a>
-<span class="sourceLineNo">245</span>  @Override<a name="line.245"></a>
-<span class="sourceLineNo">246</span>  public boolean moreRowsMayExistAfter(Cell cell) {<a name="line.246"></a>
-<span class="sourceLineNo">247</span>    // If a 'get' Scan -- we are doing a Get (every Get is a single-row Scan in implementation) --<a name="line.247"></a>
-<span class="sourceLineNo">248</span>    // then we are looking at one row only, the one specified in the Get coordinate..so we know<a name="line.248"></a>
-<span class="sourceLineNo">249</span>    // for sure that there are no more rows on this Scan<a name="line.249"></a>
-<span class="sourceLineNo">250</span>    if (isGet()) {<a name="line.250"></a>
-<span class="sourceLineNo">251</span>      return false;<a name="line.251"></a>
-<span class="sourceLineNo">252</span>    }<a name="line.252"></a>
-<span class="sourceLineNo">253</span>    // If no stopRow, return that there may be more rows. The tests that follow depend on a<a name="line.253"></a>
-<span class="sourceLineNo">254</span>    // non-empty, non-default stopRow so this little test below short-circuits out doing the<a name="line.254"></a>
-<span class="sourceLineNo">255</span>    // following compares.<a name="line.255"></a>
-<span class="sourceLineNo">256</span>    if (this.stopRow == null || this.stopRow.length == 0) {<a name="line.256"></a>
-<span class="sourceLineNo">257</span>      return true;<a name="line.257"></a>
-<span class="sourceLineNo">258</span>    }<a name="line.258"></a>
-<span class="sourceLineNo">259</span>    return moreRowsMayExistsAfter(rowComparator.compareRows(cell, stopRow, 0, stopRow.length));<a name="line.259"></a>
-<span class="sourceLineNo">260</span>  }<a name="line.260"></a>
-<span class="sourceLineNo">261</span><a name="line.261"></a>
-<span class="sourceLineNo">262</span>  public static UserScanQueryMatcher create(Scan scan, ScanInfo scanInfo,<a name="line.262"></a>
-<span class="sourceLineNo">263</span>      NavigableSet&lt;byte[]&gt; columns, long oldestUnexpiredTS, long now,<a name="line.263"></a>
-<span class="sourceLineNo">264</span>      RegionCoprocessorHost regionCoprocessorHost) throws IOException {<a name="line.264"></a>
-<span class="sourceLineNo">265</span>    boolean hasNullColumn =<a name="line.265"></a>
-<span class="sourceLineNo">266</span>        !(columns != null &amp;&amp; columns.size() != 0 &amp;&amp; columns.first().length != 0);<a name="line.266"></a>
-<span class="sourceLineNo">267</span>    Pair&lt;DeleteTracker, ColumnTracker&gt; trackers = getTrackers(regionCoprocessorHost, columns,<a name="line.267"></a>
-<span class="sourceLineNo">268</span>        scanInfo, oldestUnexpiredTS, scan);<a name="line.268"></a>
-<span class="sourceLineNo">269</span>    DeleteTracker deleteTracker = trackers.getFirst();<a name="line.269"></a>
-<span class="sourceLineNo">270</span>    ColumnTracker columnTracker = trackers.getSecond();<a name="line.270"></a>
-<span class="sourceLineNo">271</span>    if (scan.isRaw()) {<a name="line.271"></a>
-<span class="sourceLineNo">272</span>      return RawScanQueryMatcher.create(scan, scanInfo, columnTracker, hasNullColumn,<a name="line.272"></a>
-<span class="sourceLineNo">273</span>        oldestUnexpiredTS, now);<a name="line.273"></a>
-<span class="sourceLineNo">274</span>    } else {<a name="line.274"></a>
-<span class="sourceLineNo">275</span>      return NormalUserScanQueryMatcher.create(scan, scanInfo, columnTracker, deleteTracker,<a name="line.275"></a>
-<span class="sourceLineNo">276</span>          hasNullColumn, oldestUnexpiredTS, now);<a name="line.276"></a>
-<span class="sourceLineNo">277</span>    }<a name="line.277"></a>
-<span class="sourceLineNo">278</span>  }<a name="line.278"></a>
-<span class="sourceLineNo">279</span>}<a name="line.279"></a>
+<span class="sourceLineNo">215</span>        // Update column tracker to next column, As we use the column hint from the tracker to seek<a name="line.215"></a>
+<span class="sourceLineNo">216</span>        // to next cell<a name="line.216"></a>
+<span class="sourceLineNo">217</span>          columns.doneWithColumn(cell);<a name="line.217"></a>
+<span class="sourceLineNo">218</span>        }<a name="line.218"></a>
+<span class="sourceLineNo">219</span>        break;<a name="line.219"></a>
+<span class="sourceLineNo">220</span>      case INCLUDE_AND_SEEK_NEXT_ROW:<a name="line.220"></a>
+<span class="sourceLineNo">221</span>        break;<a name="line.221"></a>
+<span class="sourceLineNo">222</span>      default:<a name="line.222"></a>
+<span class="sourceLineNo">223</span>        throw new RuntimeException("UNEXPECTED");<a name="line.223"></a>
+<span class="sourceLineNo">224</span>    }<a name="line.224"></a>
+<span class="sourceLineNo">225</span><a name="line.225"></a>
+<span class="sourceLineNo">226</span>    // It means it is INCLUDE, INCLUDE_AND_SEEK_NEXT_COL or INCLUDE_AND_SEEK_NEXT_ROW.<a name="line.226"></a>
+<span class="sourceLineNo">227</span>    assert matchCode == MatchCode.INCLUDE || matchCode == MatchCode.INCLUDE_AND_SEEK_NEXT_COL<a name="line.227"></a>
+<span class="sourceLineNo">228</span>        || matchCode == MatchCode.INCLUDE_AND_SEEK_NEXT_ROW;<a name="line.228"></a>
+<span class="sourceLineNo">229</span><a name="line.229"></a>
+<span class="sourceLineNo">230</span>    if (matchCode == MatchCode.INCLUDE_AND_SEEK_NEXT_COL<a name="line.230"></a>
+<span class="sourceLineNo">231</span>        || matchCode == MatchCode.INCLUDE_AND_SEEK_NEXT_ROW) {<a name="line.231"></a>
+<span class="sourceLineNo">232</span>      return matchCode;<a name="line.232"></a>
+<span class="sourceLineNo">233</span>    }<a name="line.233"></a>
+<span class="sourceLineNo">234</span><a name="line.234"></a>
+<span class="sourceLineNo">235</span>    // Now we will check versions again.<a name="line.235"></a>
+<span class="sourceLineNo">236</span>    if (curColCell == null || !CellUtil.matchingRowColumn(cell, curColCell)) {<a name="line.236"></a>
+<span class="sourceLineNo">237</span>      count = 0;<a name="line.237"></a>
+<span class="sourceLineNo">238</span>      curColCell = cell;<a name="line.238"></a>
+<span class="sourceLineNo">239</span>    }<a name="line.239"></a>
+<span class="sourceLineNo">240</span>    count += 1;<a name="line.240"></a>
+<span class="sourceLineNo">241</span>    return count &gt; versionsAfterFilter ? MatchCode.SEEK_NEXT_COL : MatchCode.INCLUDE;<a name="line.241"></a>
+<span class="sourceLineNo">242</span>  }<a name="line.242"></a>
+<span class="sourceLineNo">243</span><a name="line.243"></a>
+<span class="sourceLineNo">244</span>  protected abstract boolean isGet();<a name="line.244"></a>
+<span class="sourceLineNo">245</span><a name="line.245"></a>
+<span class="sourceLineNo">246</span>  protected abstract boolean moreRowsMayExistsAfter(int cmpToStopRow);<a name="line.246"></a>
+<span class="sourceLineNo">247</span><a name="line.247"></a>
+<span class="sourceLineNo">248</span>  @Override<a name="line.248"></a>
+<span class="sourceLineNo">249</span>  public boolean moreRowsMayExistAfter(Cell cell) {<a name="line.249"></a>
+<span class="sourceLineNo">250</span>    // If a 'get' Scan -- we are doing a Get (every Get is a single-row Scan in implementation) --<a name="line.250"></a>
+<span class="sourceLineNo">251</span>    // then we are looking at one row only, the one specified in the Get coordinate..so we know<a name="line.251"></a>
+<span class="sourceLineNo">252</span>    // for sure that there are no more rows on this Scan<a name="line.252"></a>
+<span class="sourceLineNo">253</span>    if (isGet()) {<a name="line.253"></a>
+<span class="sourceLineNo">254</span>      return false;<a name="line.254"></a>
+<span class="sourceLineNo">255</span>    }<a name="line.255"></a>
+<span class="sourceLineNo">256</span>    // If no stopRow, return that there may be more rows. The tests that follow depend on a<a name="line.256"></a>
+<span class="sourceLineNo">257</span>    // non-empty, non-default stopRow so this little test below short-circuits out doing the<a name="line.257"></a>
+<span class="sourceLineNo">258</span>    // following compares.<a name="line.258"></a>
+<span class="sourceLineNo">259</span>    if (this.stopRow == null || this.stopRow.length == 0) {<a name="line.259"></a>
+<span class="sourceLineNo">260</span>      return true;<a name="line.260"></a>
+<span class="sourceLineNo">261</span>    }<a name="line.261"></a>
+<span class="sourceLineNo">262</span>    return moreRowsMayExistsAfter(rowComparator.compareRows(cell, stopRow, 0, stopRow.length));<a name="line.262"></a>
+<span class="sourceLineNo">263</span>  }<a name="line.263"></a>
+<span class="sourceLineNo">264</span><a name="line.264"></a>
+<span class="sourceLineNo">265</span>  public static UserScanQueryMatcher create(Scan scan, ScanInfo scanInfo,<a name="line.265"></a>
+<span class="sourceLineNo">266</span>      NavigableSet&lt;byte[]&gt; columns, long oldestUnexpiredTS, long now,<a name="line.266"></a>
+<span class="sourceLineNo">267</span>      RegionCoprocessorHost regionCoprocessorHost) throws IOException {<a name="line.267"></a>
+<span class="sourceLineNo">268</span>    boolean hasNullColumn =<a name="line.268"></a>
+<span class="sourceLineNo">269</span>        !(columns != null &amp;&amp; columns.size() != 0 &amp;&amp; columns.first().length != 0);<a name="line.269"></a>
+<span class="sourceLineNo">270</span>    Pair&lt;DeleteTracker, ColumnTracker&gt; trackers = getTrackers(regionCoprocessorHost, columns,<a name="line.270"></a>
+<span class="sourceLineNo">271</span>        scanInfo, oldestUnexpiredTS, scan);<a name="line.271"></a>
+<span class="sourceLineNo">272</span>    DeleteTracker deleteTracker = trackers.getFirst();<a name="line.272"></a>
+<span class="sourceLineNo">273</span>    ColumnTracker columnTracker = trackers.getSecond();<a name="line.273"></a>
+<span class="sourceLineNo">274</span>    if (scan.isRaw()) {<a name="line.274"></a>
+<span class="sourceLineNo">275</span>      return RawScanQueryMatcher.create(scan, scanInfo, columnTracker, hasNullColumn,<a name="line.275"></a>
+<span class="sourceLineNo">276</span>        oldestUnexpiredTS, now);<a name="line.276"></a>
+<span class="sourceLineNo">277</span>    } else {<a name="line.277"></a>
+<span class="sourceLineNo">278</span>      return NormalUserScanQueryMatcher.create(scan, scanInfo, columnTracker, deleteTracker,<a name="line.278"></a>
+<span class="sourceLineNo">279</span>          hasNullColumn, oldestUnexpiredTS, now);<a name="line.279"></a>
+<span class="sourceLineNo">280</span>    }<a name="line.280"></a>
+<span class="sourceLineNo">281</span>  }<a name="line.281"></a>
+<span class="sourceLineNo">282</span>}<a name="line.282"></a>
 
 
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/export_control.html
----------------------------------------------------------------------
diff --git a/export_control.html b/export_control.html
index 1e4eebf..e23b56d 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/checkstyle.html b/hbase-annotations/checkstyle.html
index f7e4a8d..a6e6baf 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependencies.html b/hbase-annotations/dependencies.html
index 893486a..6b551b8 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-convergence.html b/hbase-annotations/dependency-convergence.html
index 2503074..0460b65 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-info.html b/hbase-annotations/dependency-info.html
index 847ce1c..e08a063 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-management.html b/hbase-annotations/dependency-management.html
index 8d71d80..ef87906 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/index.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/index.html b/hbase-annotations/index.html
index 9808edd..24b5a6e 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/integration.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/integration.html b/hbase-annotations/integration.html
index 07fa31f..4c76fa4 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/issue-tracking.html b/hbase-annotations/issue-tracking.html
index 4e790b4..bc2b789 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/license.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/license.html b/hbase-annotations/license.html
index 2971eb6..6c39d3c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/mail-lists.html b/hbase-annotations/mail-lists.html
index 6e890bf..c392f28 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugin-management.html b/hbase-annotations/plugin-management.html
index 5ae1d91..82ae5ef 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugins.html b/hbase-annotations/plugins.html
index e5afe36..3a6f9b0 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-info.html b/hbase-annotations/project-info.html
index a23bc2e..f30b272 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/project-reports.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-reports.html b/hbase-annotations/project-reports.html
index 0355f9a..a0dafa4 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-summary.html b/hbase-annotations/project-summary.html
index 71e556b..48de0eb 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/source-repository.html b/hbase-annotations/source-repository.html
index 28b3fad..6d40083 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-annotations/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/team-list.html b/hbase-annotations/team-list.html
index 443dfb8..ca47cae 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependencies.html b/hbase-build-configuration/dependencies.html
index f3402d2..7bc2d3d 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.html
index a6c7150..e93a01d 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.html
@@ -150,2012 +150,2072 @@
 <span class="sourceLineNo">142</span>  @Before<a name="line.142"></a>
 <span class="sourceLineNo">143</span>  public void setUp() throws Exception {<a name="line.143"></a>
 <span class="sourceLineNo">144</span>    HTableDescriptor htd = new HTableDescriptor(TableName.valueOf("TestFilter"));<a name="line.144"></a>
-<span class="sourceLineNo">145</span>    htd.addFamily(new HColumnDescriptor(FAMILIES[0]));<a name="line.145"></a>
-<span class="sourceLineNo">146</span>    htd.addFamily(new HColumnDescriptor(FAMILIES[1]));<a name="line.146"></a>
-<span class="sourceLineNo">147</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[0]));<a name="line.147"></a>
-<span class="sourceLineNo">148</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[1]));<a name="line.148"></a>
-<span class="sourceLineNo">149</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[0]));<a name="line.149"></a>
-<span class="sourceLineNo">150</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[1]));<a name="line.150"></a>
-<span class="sourceLineNo">151</span>    HRegionInfo info = new HRegionInfo(htd.getTableName(), null, null, false);<a name="line.151"></a>
-<span class="sourceLineNo">152</span>    this.region = HBaseTestingUtility.createRegionAndWAL(info, TEST_UTIL.getDataTestDir(),<a name="line.152"></a>
-<span class="sourceLineNo">153</span>        TEST_UTIL.getConfiguration(), htd);<a name="line.153"></a>
-<span class="sourceLineNo">154</span><a name="line.154"></a>
-<span class="sourceLineNo">155</span>    // Insert first half<a name="line.155"></a>
-<span class="sourceLineNo">156</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.156"></a>
-<span class="sourceLineNo">157</span>      Put p = new Put(ROW);<a name="line.157"></a>
-<span class="sourceLineNo">158</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.158"></a>
-<span class="sourceLineNo">159</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.159"></a>
-<span class="sourceLineNo">160</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.160"></a>
-<span class="sourceLineNo">161</span>      }<a name="line.161"></a>
-<span class="sourceLineNo">162</span>      this.region.put(p);<a name="line.162"></a>
-<span class="sourceLineNo">163</span>    }<a name="line.163"></a>
-<span class="sourceLineNo">164</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.164"></a>
-<span class="sourceLineNo">165</span>      Put p = new Put(ROW);<a name="line.165"></a>
-<span class="sourceLineNo">166</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.166"></a>
-<span class="sourceLineNo">167</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.167"></a>
-<span class="sourceLineNo">168</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.168"></a>
-<span class="sourceLineNo">169</span>      }<a name="line.169"></a>
-<span class="sourceLineNo">170</span>      this.region.put(p);<a name="line.170"></a>
-<span class="sourceLineNo">171</span>    }<a name="line.171"></a>
-<span class="sourceLineNo">172</span><a name="line.172"></a>
-<span class="sourceLineNo">173</span>    // Flush<a name="line.173"></a>
-<span class="sourceLineNo">174</span>    this.region.flush(true);<a name="line.174"></a>
-<span class="sourceLineNo">175</span><a name="line.175"></a>
-<span class="sourceLineNo">176</span>    // Insert second half (reverse families)<a name="line.176"></a>
-<span class="sourceLineNo">177</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.177"></a>
-<span class="sourceLineNo">178</span>      Put p = new Put(ROW);<a name="line.178"></a>
-<span class="sourceLineNo">179</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.179"></a>
-<span class="sourceLineNo">180</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.180"></a>
-<span class="sourceLineNo">181</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.181"></a>
-<span class="sourceLineNo">182</span>      }<a name="line.182"></a>
-<span class="sourceLineNo">183</span>      this.region.put(p);<a name="line.183"></a>
-<span class="sourceLineNo">184</span>    }<a name="line.184"></a>
-<span class="sourceLineNo">185</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.185"></a>
-<span class="sourceLineNo">186</span>      Put p = new Put(ROW);<a name="line.186"></a>
-<span class="sourceLineNo">187</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.187"></a>
-<span class="sourceLineNo">188</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.188"></a>
-<span class="sourceLineNo">189</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.189"></a>
-<span class="sourceLineNo">190</span>      }<a name="line.190"></a>
-<span class="sourceLineNo">191</span>      this.region.put(p);<a name="line.191"></a>
-<span class="sourceLineNo">192</span>    }<a name="line.192"></a>
-<span class="sourceLineNo">193</span><a name="line.193"></a>
-<span class="sourceLineNo">194</span>    // Delete the second qualifier from all rows and families<a name="line.194"></a>
-<span class="sourceLineNo">195</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.195"></a>
-<span class="sourceLineNo">196</span>      Delete d = new Delete(ROW);<a name="line.196"></a>
-<span class="sourceLineNo">197</span>      d.addColumns(FAMILIES[0], QUALIFIERS_ONE[1]);<a name="line.197"></a>
-<span class="sourceLineNo">198</span>      d.addColumns(FAMILIES[1], QUALIFIERS_ONE[1]);<a name="line.198"></a>
-<span class="sourceLineNo">199</span>      this.region.delete(d);<a name="line.199"></a>
-<span class="sourceLineNo">200</span>    }<a name="line.200"></a>
-<span class="sourceLineNo">201</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.201"></a>
-<span class="sourceLineNo">202</span>      Delete d = new Delete(ROW);<a name="line.202"></a>
-<span class="sourceLineNo">203</span>      d.addColumns(FAMILIES[0], QUALIFIERS_TWO[1]);<a name="line.203"></a>
-<span class="sourceLineNo">204</span>      d.addColumns(FAMILIES[1], QUALIFIERS_TWO[1]);<a name="line.204"></a>
-<span class="sourceLineNo">205</span>      this.region.delete(d);<a name="line.205"></a>
-<span class="sourceLineNo">206</span>    }<a name="line.206"></a>
-<span class="sourceLineNo">207</span>    colsPerRow -= 2;<a name="line.207"></a>
-<span class="sourceLineNo">208</span><a name="line.208"></a>
-<span class="sourceLineNo">209</span>    // Delete the second rows from both groups, one column at a time<a name="line.209"></a>
-<span class="sourceLineNo">210</span>    for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.210"></a>
-<span class="sourceLineNo">211</span>      Delete d = new Delete(ROWS_ONE[1]);<a name="line.211"></a>
-<span class="sourceLineNo">212</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.212"></a>
-<span class="sourceLineNo">213</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.213"></a>
-<span class="sourceLineNo">214</span>      this.region.delete(d);<a name="line.214"></a>
-<span class="sourceLineNo">215</span>    }<a name="line.215"></a>
-<span class="sourceLineNo">216</span>    for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.216"></a>
-<span class="sourceLineNo">217</span>      Delete d = new Delete(ROWS_TWO[1]);<a name="line.217"></a>
-<span class="sourceLineNo">218</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.218"></a>
-<span class="sourceLineNo">219</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.219"></a>
-<span class="sourceLineNo">220</span>      this.region.delete(d);<a name="line.220"></a>
-<span class="sourceLineNo">221</span>    }<a name="line.221"></a>
-<span class="sourceLineNo">222</span>    numRows -= 2;<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>  @After<a name="line.225"></a>
-<span class="sourceLineNo">226</span>  public void tearDown() throws Exception {<a name="line.226"></a>
-<span class="sourceLineNo">227</span>    HBaseTestingUtility.closeRegionAndWAL(region);<a name="line.227"></a>
-<span class="sourceLineNo">228</span>  }<a name="line.228"></a>
-<span class="sourceLineNo">229</span><a name="line.229"></a>
-<span class="sourceLineNo">230</span>  @Test<a name="line.230"></a>
-<span class="sourceLineNo">231</span>  public void testRegionScannerReseek() throws Exception {<a name="line.231"></a>
-<span class="sourceLineNo">232</span>    // create new rows and column family to show how reseek works..<a name="line.232"></a>
-<span class="sourceLineNo">233</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.233"></a>
-<span class="sourceLineNo">234</span>      Put p = new Put(ROW);<a name="line.234"></a>
-<span class="sourceLineNo">235</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.235"></a>
-<span class="sourceLineNo">236</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.236"></a>
-<span class="sourceLineNo">237</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.237"></a>
-<span class="sourceLineNo">238</span><a name="line.238"></a>
-<span class="sourceLineNo">239</span>      }<a name="line.239"></a>
-<span class="sourceLineNo">240</span>      this.region.put(p);<a name="line.240"></a>
-<span class="sourceLineNo">241</span>    }<a name="line.241"></a>
-<span class="sourceLineNo">242</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.242"></a>
-<span class="sourceLineNo">243</span>      Put p = new Put(ROW);<a name="line.243"></a>
-<span class="sourceLineNo">244</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.244"></a>
-<span class="sourceLineNo">245</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.245"></a>
-<span class="sourceLineNo">246</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.246"></a>
-<span class="sourceLineNo">247</span>      }<a name="line.247"></a>
-<span class="sourceLineNo">248</span>      this.region.put(p);<a name="line.248"></a>
-<span class="sourceLineNo">249</span>    }<a name="line.249"></a>
-<span class="sourceLineNo">250</span>    // Flush<a name="line.250"></a>
-<span class="sourceLineNo">251</span>    this.region.flush(true);<a name="line.251"></a>
-<span class="sourceLineNo">252</span><a name="line.252"></a>
-<span class="sourceLineNo">253</span>    // Insert second half (reverse families)<a name="line.253"></a>
-<span class="sourceLineNo">254</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.254"></a>
-<span class="sourceLineNo">255</span>      Put p = new Put(ROW);<a name="line.255"></a>
-<span class="sourceLineNo">256</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.256"></a>
-<span class="sourceLineNo">257</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.257"></a>
-<span class="sourceLineNo">258</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.258"></a>
-<span class="sourceLineNo">259</span>      }<a name="line.259"></a>
-<span class="sourceLineNo">260</span>      this.region.put(p);<a name="line.260"></a>
-<span class="sourceLineNo">261</span>    }<a name="line.261"></a>
-<span class="sourceLineNo">262</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.262"></a>
-<span class="sourceLineNo">263</span>      Put p = new Put(ROW);<a name="line.263"></a>
-<span class="sourceLineNo">264</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.264"></a>
-<span class="sourceLineNo">265</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.265"></a>
-<span class="sourceLineNo">266</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.266"></a>
-<span class="sourceLineNo">267</span>      }<a name="line.267"></a>
-<span class="sourceLineNo">268</span>      this.region.put(p);<a name="line.268"></a>
-<span class="sourceLineNo">269</span>    }<a name="line.269"></a>
-<span class="sourceLineNo">270</span><a name="line.270"></a>
-<span class="sourceLineNo">271</span>    Scan s = new Scan();<a name="line.271"></a>
-<span class="sourceLineNo">272</span>    // set a start row<a name="line.272"></a>
-<span class="sourceLineNo">273</span>    s.setStartRow(ROWS_FOUR[1]);<a name="line.273"></a>
-<span class="sourceLineNo">274</span>    RegionScanner scanner = region.getScanner(s);<a name="line.274"></a>
-<span class="sourceLineNo">275</span><a name="line.275"></a>
-<span class="sourceLineNo">276</span>    // reseek to row three.<a name="line.276"></a>
-<span class="sourceLineNo">277</span>    scanner.reseek(ROWS_THREE[1]);<a name="line.277"></a>
-<span class="sourceLineNo">278</span>    List&lt;Cell&gt; results = new ArrayList&lt;&gt;();<a name="line.278"></a>
-<span class="sourceLineNo">279</span><a name="line.279"></a>
-<span class="sourceLineNo">280</span>    // the results should belong to ROWS_THREE[1]<a name="line.280"></a>
-<span class="sourceLineNo">281</span>    scanner.next(results);<a name="line.281"></a>
-<span class="sourceLineNo">282</span>    for (Cell keyValue : results) {<a name="line.282"></a>
-<span class="sourceLineNo">283</span>      assertTrue("The rows with ROWS_TWO as row key should be appearing.",<a name="line.283"></a>
-<span class="sourceLineNo">284</span>          CellUtil.matchingRows(keyValue, ROWS_THREE[1]));<a name="line.284"></a>
-<span class="sourceLineNo">285</span>    }<a name="line.285"></a>
-<span class="sourceLineNo">286</span>    // again try to reseek to a value before ROWS_THREE[1]<a name="line.286"></a>
-<span class="sourceLineNo">287</span>    scanner.reseek(ROWS_ONE[1]);<a name="line.287"></a>
-<span class="sourceLineNo">288</span>    results = new ArrayList&lt;&gt;();<a name="line.288"></a>
-<span class="sourceLineNo">289</span>    // This time no seek would have been done to ROWS_ONE[1]<a name="line.289"></a>
-<span class="sourceLineNo">290</span>    scanner.next(results);<a name="line.290"></a>
-<span class="sourceLineNo">291</span>    for (Cell keyValue : results) {<a name="line.291"></a>
-<span class="sourceLineNo">292</span>      assertFalse("Cannot rewind back to a value less than previous reseek.",<a name="line.292"></a>
-<span class="sourceLineNo">293</span>          Bytes.toString(CellUtil.cloneRow(keyValue)).contains("testRowOne"));<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>  @Test<a name="line.297"></a>
-<span class="sourceLineNo">298</span>  public void testNoFilter() throws Exception {<a name="line.298"></a>
-<span class="sourceLineNo">299</span>    // No filter<a name="line.299"></a>
-<span class="sourceLineNo">300</span>    long expectedRows = this.numRows;<a name="line.300"></a>
-<span class="sourceLineNo">301</span>    long expectedKeys = this.colsPerRow;<a name="line.301"></a>
-<span class="sourceLineNo">302</span><a name="line.302"></a>
-<span class="sourceLineNo">303</span>    // Both families<a name="line.303"></a>
-<span class="sourceLineNo">304</span>    Scan s = new Scan();<a name="line.304"></a>
-<span class="sourceLineNo">305</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.305"></a>
-<span class="sourceLineNo">306</span><a name="line.306"></a>
-<span class="sourceLineNo">307</span>    // One family<a name="line.307"></a>
-<span class="sourceLineNo">308</span>    s = new Scan();<a name="line.308"></a>
-<span class="sourceLineNo">309</span>    s.addFamily(FAMILIES[0]);<a name="line.309"></a>
-<span class="sourceLineNo">310</span>    verifyScan(s, expectedRows, expectedKeys/2);<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<a name="line.313"></a>
-<span class="sourceLineNo">314</span>  public void testPrefixFilter() throws Exception {<a name="line.314"></a>
-<span class="sourceLineNo">315</span>    // Grab rows from group one (half of total)<a name="line.315"></a>
-<span class="sourceLineNo">316</span>    long expectedRows = this.numRows / 2;<a name="line.316"></a>
-<span class="sourceLineNo">317</span>    long expectedKeys = this.colsPerRow;<a name="line.317"></a>
-<span class="sourceLineNo">318</span>    Scan s = new Scan();<a name="line.318"></a>
-<span class="sourceLineNo">319</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.319"></a>
-<span class="sourceLineNo">320</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.320"></a>
-<span class="sourceLineNo">321</span>  }<a name="line.321"></a>
-<span class="sourceLineNo">322</span><a name="line.322"></a>
-<span class="sourceLineNo">323</span>  @Test<a name="line.323"></a>
-<span class="sourceLineNo">324</span>  public void testPrefixFilterWithReverseScan() throws Exception {<a name="line.324"></a>
-<span class="sourceLineNo">325</span>    // Grab rows from group one (half of total)<a name="line.325"></a>
-<span class="sourceLineNo">326</span>    long expectedRows = this.numRows / 2;<a name="line.326"></a>
-<span class="sourceLineNo">327</span>    long expectedKeys = this.colsPerRow;<a name="line.327"></a>
-<span class="sourceLineNo">328</span>    Scan s = new Scan();<a name="line.328"></a>
-<span class="sourceLineNo">329</span>    s.setReversed(true);<a name="line.329"></a>
-<span class="sourceLineNo">330</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.330"></a>
-<span class="sourceLineNo">331</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.331"></a>
-<span class="sourceLineNo">332</span>  }<a name="line.332"></a>
-<span class="sourceLineNo">333</span><a name="line.333"></a>
-<span class="sourceLineNo">334</span>  @Test<a name="line.334"></a>
-<span class="sourceLineNo">335</span>  public void testPageFilter() throws Exception {<a name="line.335"></a>
-<span class="sourceLineNo">336</span><a name="line.336"></a>
-<span class="sourceLineNo">337</span>    // KVs in first 6 rows<a name="line.337"></a>
-<span class="sourceLineNo">338</span>    KeyValue [] expectedKVs = {<a name="line.338"></a>
-<span class="sourceLineNo">339</span>      // testRowOne-0<a name="line.339"></a>
-<span class="sourceLineNo">340</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.340"></a>
-<span class="sourceLineNo">341</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.341"></a>
-<span class="sourceLineNo">342</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.342"></a>
-<span class="sourceLineNo">343</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.343"></a>
-<span class="sourceLineNo">344</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.344"></a>
-<span class="sourceLineNo">345</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.345"></a>
-<span class="sourceLineNo">346</span>      // testRowOne-2<a name="line.346"></a>
-<span class="sourceLineNo">347</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.347"></a>
-<span class="sourceLineNo">348</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.348"></a>
-<span class="sourceLineNo">349</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.349"></a>
-<span class="sourceLineNo">350</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.350"></a>
-<span class="sourceLineNo">351</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.351"></a>
-<span class="sourceLineNo">352</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.352"></a>
-<span class="sourceLineNo">353</span>      // testRowOne-3<a name="line.353"></a>
-<span class="sourceLineNo">354</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.354"></a>
-<span class="sourceLineNo">355</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.355"></a>
-<span class="sourceLineNo">356</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.356"></a>
-<span class="sourceLineNo">357</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.357"></a>
-<span class="sourceLineNo">358</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.358"></a>
-<span class="sourceLineNo">359</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.359"></a>
-<span class="sourceLineNo">360</span>      // testRowTwo-0<a name="line.360"></a>
-<span class="sourceLineNo">361</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.361"></a>
-<span class="sourceLineNo">362</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.362"></a>
-<span class="sourceLineNo">363</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.363"></a>
-<span class="sourceLineNo">364</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.364"></a>
-<span class="sourceLineNo">365</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.365"></a>
-<span class="sourceLineNo">366</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.366"></a>
-<span class="sourceLineNo">367</span>      // testRowTwo-2<a name="line.367"></a>
-<span class="sourceLineNo">368</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.368"></a>
-<span class="sourceLineNo">369</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.369"></a>
-<span class="sourceLineNo">370</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.370"></a>
-<span class="sourceLineNo">371</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.371"></a>
-<span class="sourceLineNo">372</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.372"></a>
-<span class="sourceLineNo">373</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.373"></a>
-<span class="sourceLineNo">374</span>      // testRowTwo-3<a name="line.374"></a>
-<span class="sourceLineNo">375</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.375"></a>
-<span class="sourceLineNo">376</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.376"></a>
-<span class="sourceLineNo">377</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.377"></a>
-<span class="sourceLineNo">378</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.378"></a>
-<span class="sourceLineNo">379</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.379"></a>
-<span class="sourceLineNo">380</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1])<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>    // Grab all 6 rows<a name="line.383"></a>
-<span class="sourceLineNo">384</span>    long expectedRows = 6;<a name="line.384"></a>
-<span class="sourceLineNo">385</span>    long expectedKeys = this.colsPerRow;<a name="line.385"></a>
-<span class="sourceLineNo">386</span>    Scan s = new Scan();<a name="line.386"></a>
-<span class="sourceLineNo">387</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.387"></a>
-<span class="sourceLineNo">388</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.388"></a>
-<span class="sourceLineNo">389</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.389"></a>
-<span class="sourceLineNo">390</span>    verifyScanFull(s, expectedKVs);<a name="line.390"></a>
-<span class="sourceLineNo">391</span><a name="line.391"></a>
-<span class="sourceLineNo">392</span>    // Grab first 4 rows (6 cols per row)<a name="line.392"></a>
-<span class="sourceLineNo">393</span>    expectedRows = 4;<a name="line.393"></a>
-<span class="sourceLineNo">394</span>    expectedKeys = this.colsPerRow;<a name="line.394"></a>
-<span class="sourceLineNo">395</span>    s = new Scan();<a name="line.395"></a>
-<span class="sourceLineNo">396</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.396"></a>
-<span class="sourceLineNo">397</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.397"></a>
-<span class="sourceLineNo">398</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.398"></a>
-<span class="sourceLineNo">399</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 24));<a name="line.399"></a>
-<span class="sourceLineNo">400</span><a name="line.400"></a>
-<span class="sourceLineNo">401</span>    // Grab first 2 rows<a name="line.401"></a>
-<span class="sourceLineNo">402</span>    expectedRows = 2;<a name="line.402"></a>
-<span class="sourceLineNo">403</span>    expectedKeys = this.colsPerRow;<a name="line.403"></a>
-<span class="sourceLineNo">404</span>    s = new Scan();<a name="line.404"></a>
-<span class="sourceLineNo">405</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.405"></a>
-<span class="sourceLineNo">406</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.406"></a>
-<span class="sourceLineNo">407</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.407"></a>
-<span class="sourceLineNo">408</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 12));<a name="line.408"></a>
-<span class="sourceLineNo">409</span><a name="line.409"></a>
-<span class="sourceLineNo">410</span>    // Grab first row<a name="line.410"></a>
-<span class="sourceLineNo">411</span>    expectedRows = 1;<a name="line.411"></a>
-<span class="sourceLineNo">412</span>    expectedKeys = this.colsPerRow;<a name="line.412"></a>
-<span class="sourceLineNo">413</span>    s = new Scan();<a name="line.413"></a>
-<span class="sourceLineNo">414</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.414"></a>
-<span class="sourceLineNo">415</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.415"></a>
-<span class="sourceLineNo">416</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.416"></a>
-<span class="sourceLineNo">417</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 6));<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><a name="line.420"></a>
-<span class="sourceLineNo">421</span>  @Test<a name="line.421"></a>
-<span class="sourceLineNo">422</span>  public void testPageFilterWithReverseScan() throws Exception {<a name="line.422"></a>
-<span class="sourceLineNo">423</span>    // KVs in first 6 rows<a name="line.423"></a>
-<span class="sourceLineNo">424</span>    KeyValue[] expectedKVs = {<a name="line.424"></a>
-<span class="sourceLineNo">425</span>        // testRowOne-0<a name="line.425"></a>
-<span class="sourceLineNo">426</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.426"></a>
-<span class="sourceLineNo">427</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.427"></a>
-<span class="sourceLineNo">428</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.428"></a>
-<span class="sourceLineNo">429</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.429"></a>
-<span class="sourceLineNo">430</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.430"></a>
-<span class="sourceLineNo">431</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.431"></a>
-<span class="sourceLineNo">432</span>        // testRowOne-2<a name="line.432"></a>
-<span class="sourceLineNo">433</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.433"></a>
-<span class="sourceLineNo">434</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.434"></a>
-<span class="sourceLineNo">435</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.435"></a>
-<span class="sourceLineNo">436</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.436"></a>
-<span class="sourceLineNo">437</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.437"></a>
-<span class="sourceLineNo">438</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.438"></a>
-<span class="sourceLineNo">439</span>        // testRowOne-3<a name="line.439"></a>
-<span class="sourceLineNo">440</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.440"></a>
-<span class="sourceLineNo">441</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.441"></a>
-<span class="sourceLineNo">442</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.442"></a>
-<span class="sourceLineNo">443</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.443"></a>
-<span class="sourceLineNo">444</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.444"></a>
-<span class="sourceLineNo">445</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.445"></a>
-<span class="sourceLineNo">446</span>        // testRowTwo-0<a name="line.446"></a>
-<span class="sourceLineNo">447</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.447"></a>
-<span class="sourceLineNo">448</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.448"></a>
-<span class="sourceLineNo">449</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.449"></a>
-<span class="sourceLineNo">450</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.450"></a>
-<span class="sourceLineNo">451</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.451"></a>
-<span class="sourceLineNo">452</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.452"></a>
-<span class="sourceLineNo">453</span>        // testRowTwo-2<a name="line.453"></a>
-<span class="sourceLineNo">454</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.454"></a>
-<span class="sourceLineNo">455</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.455"></a>
-<span class="sourceLineNo">456</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.456"></a>
-<span class="sourceLineNo">457</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.457"></a>
-<span class="sourceLineNo">458</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.458"></a>
-<span class="sourceLineNo">459</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.459"></a>
-<span class="sourceLineNo">460</span>        // testRowTwo-3<a name="line.460"></a>
-<span class="sourceLineNo">461</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.461"></a>
-<span class="sourceLineNo">462</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.462"></a>
-<span class="sourceLineNo">463</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.463"></a>
-<span class="sourceLineNo">464</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.464"></a>
-<span class="sourceLineNo">465</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.465"></a>
-<span class="sourceLineNo">466</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]) };<a name="line.466"></a>
-<span class="sourceLineNo">467</span><a name="line.467"></a>
-<span class="sourceLineNo">468</span>    // Grab all 6 rows<a name="line.468"></a>
-<span class="sourceLineNo">469</span>    long expectedRows = 6;<a name="line.469"></a>
-<span class="sourceLineNo">470</span>    long expectedKeys = this.colsPerRow;<a name="line.470"></a>
-<span class="sourceLineNo">471</span>    Scan s = new Scan();<a name="line.471"></a>
-<span class="sourceLineNo">472</span>    s.setReversed(true);<a name="line.472"></a>
-<span class="sourceLineNo">473</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.473"></a>
-<span class="sourceLineNo">474</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.474"></a>
-<span class="sourceLineNo">475</span><a name="line.475"></a>
-<span class="sourceLineNo">476</span>    // Grab first 4 rows (6 cols per row)<a name="line.476"></a>
-<span class="sourceLineNo">477</span>    expectedRows = 4;<a name="line.477"></a>
-<span class="sourceLineNo">478</span>    expectedKeys = this.colsPerRow;<a name="line.478"></a>
-<span class="sourceLineNo">479</span>    s = new Scan();<a name="line.479"></a>
-<span class="sourceLineNo">480</span>    s.setReversed(true);<a name="line.480"></a>
-<span class="sourceLineNo">481</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.481"></a>
-<span class="sourceLineNo">482</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.482"></a>
-<span class="sourceLineNo">483</span><a name="line.483"></a>
-<span class="sourceLineNo">484</span>    // Grab first 2 rows<a name="line.484"></a>
-<span class="sourceLineNo">485</span>    expectedRows = 2;<a name="line.485"></a>
-<span class="sourceLineNo">486</span>    expectedKeys = this.colsPerRow;<a name="line.486"></a>
-<span class="sourceLineNo">487</span>    s = new Scan();<a name="line.487"></a>
-<span class="sourceLineNo">488</span>    s.setReversed(true);<a name="line.488"></a>
-<span class="sourceLineNo">489</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.489"></a>
-<span class="sourceLineNo">490</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.490"></a>
-<span class="sourceLineNo">491</span><a name="line.491"></a>
-<span class="sourceLineNo">492</span>    // Grab first row<a name="line.492"></a>
-<span class="sourceLineNo">493</span>    expectedRows = 1;<a name="line.493"></a>
-<span class="sourceLineNo">494</span>    expectedKeys = this.colsPerRow;<a name="line.494"></a>
-<span class="sourceLineNo">495</span>    s = new Scan();<a name="line.495"></a>
-<span class="sourceLineNo">496</span>    s.setReversed(true);<a name="line.496"></a>
-<span class="sourceLineNo">497</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.497"></a>
-<span class="sourceLineNo">498</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.498"></a>
-<span class="sourceLineNo">499</span>  }<a name="line.499"></a>
-<span class="sourceLineNo">500</span><a name="line.500"></a>
-<span class="sourceLineNo">501</span>  @Test<a name="line.501"></a>
-<span class="sourceLineNo">502</span>  public void testWhileMatchFilterWithFilterRowWithReverseScan()<a name="line.502"></a>
-<span class="sourceLineNo">503</span>      throws Exception {<a name="line.503"></a>
-<span class="sourceLineNo">504</span>    final int pageSize = 4;<a name="line.504"></a>
-<span class="sourceLineNo">505</span><a name="line.505"></a>
-<span class="sourceLineNo">506</span>    Scan s = new Scan();<a name="line.506"></a>
-<span class="sourceLineNo">507</span>    s.setReversed(true);<a name="line.507"></a>
-<span class="sourceLineNo">508</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.508"></a>
-<span class="sourceLineNo">509</span>    s.setFilter(filter);<a name="line.509"></a>
-<span class="sourceLineNo">510</span><a name="line.510"></a>
-<span class="sourceLineNo">511</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.511"></a>
-<span class="sourceLineNo">512</span>    int scannerCounter = 0;<a name="line.512"></a>
-<span class="sourceLineNo">513</span>    while (true) {<a name="line.513"></a>
-<span class="sourceLineNo">514</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.514"></a>
-<span class="sourceLineNo">515</span>      scannerCounter++;<a name="line.515"></a>
-<span class="sourceLineNo">516</span><a name="line.516"></a>
-<span class="sourceLineNo">517</span>      if (scannerCounter &gt;= pageSize) {<a name="line.517"></a>
-<span class="sourceLineNo">518</span>        Assert.assertTrue(<a name="line.518"></a>
-<span class="sourceLineNo">519</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.519"></a>
-<span class="sourceLineNo">520</span>            filter.filterAllRemaining());<a name="line.520"></a>
-<span class="sourceLineNo">521</span>      }<a name="line.521"></a>
-<span class="sourceLineNo">522</span>      if (!isMoreResults) {<a name="line.522"></a>
-<span class="sourceLineNo">523</span>        break;<a name="line.523"></a>
-<span class="sourceLineNo">524</span>      }<a name="line.524"></a>
-<span class="sourceLineNo">525</span>    }<a name="line.525"></a>
-<span class="sourceLineNo">526</span>    scanner.close();<a name="line.526"></a>
-<span class="sourceLineNo">527</span>    Assert.assertEquals("The page filter returned more rows than expected",<a name="line.527"></a>
-<span class="sourceLineNo">528</span>        pageSize, scannerCounter);<a name="line.528"></a>
-<span class="sourceLineNo">529</span>  }<a name="line.529"></a>
-<span class="sourceLineNo">530</span><a name="line.530"></a>
-<span class="sourceLineNo">531</span>  @Test<a name="line.531"></a>
-<span class="sourceLineNo">532</span>  public void testWhileMatchFilterWithFilterRowKeyWithReverseScan()<a name="line.532"></a>
-<span class="sourceLineNo">533</span>      throws Exception {<a name="line.533"></a>
-<span class="sourceLineNo">534</span>    Scan s = new Scan();<a name="line.534"></a>
-<span class="sourceLineNo">535</span>    String prefix = "testRowOne";<a name="line.535"></a>
-<span class="sourceLineNo">536</span>    WhileMatchFilter filter = new WhileMatchFilter(new PrefixFilter(<a name="line.536"></a>
-<span class="sourceLineNo">537</span>        Bytes.toBytes(prefix)));<a name="line.537"></a>
-<span class="sourceLineNo">538</span>    s.setFilter(filter);<a name="line.538"></a>
-<span class="sourceLineNo">539</span>    s.setReversed(true);<a name="line.539"></a>
-<span class="sourceLineNo">540</span><a name="line.540"></a>
-<span class="sourceLineNo">541</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.541"></a>
-<span class="sourceLineNo">542</span>    while (true) {<a name="line.542"></a>
-<span class="sourceLineNo">543</span>      ArrayList&lt;Cell&gt; values = new ArrayList&lt;&gt;();<a name="line.543"></a>
-<span class="sourceLineNo">544</span>      boolean isMoreResults = scanner.next(values);<a name="line.544"></a>
-<span class="sourceLineNo">545</span>      if (!isMoreResults<a name="line.545"></a>
-<span class="sourceLineNo">546</span>          || !Bytes.toString(CellUtil.cloneRow(values.get(0))).startsWith(prefix)) {<a name="line.546"></a>
-<span class="sourceLineNo">547</span>        Assert.assertTrue(<a name="line.547"></a>
-<span class="sourceLineNo">548</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.548"></a>
-<span class="sourceLineNo">549</span>            filter.filterAllRemaining());<a name="line.549"></a>
-<span class="sourceLineNo">550</span>      }<a name="line.550"></a>
-<span class="sourceLineNo">551</span>      if (!isMoreResults) {<a name="line.551"></a>
-<span class="sourceLineNo">552</span>        break;<a name="line.552"></a>
-<span class="sourceLineNo">553</span>      }<a name="line.553"></a>
-<span class="sourceLineNo">554</span>    }<a name="line.554"></a>
-<span class="sourceLineNo">555</span>    scanner.close();<a name="line.555"></a>
-<span class="sourceLineNo">556</span>  }<a name="line.556"></a>
-<span class="sourceLineNo">557</span><a name="line.557"></a>
-<span class="sourceLineNo">558</span>  /**<a name="line.558"></a>
-<span class="sourceLineNo">559</span>   * Tests the the {@link WhileMatchFilter} works in combination with a<a name="line.559"></a>
-<span class="sourceLineNo">560</span>   * {@link Filter} that uses the<a name="line.560"></a>
-<span class="sourceLineNo">561</span>   * {@link Filter#filterRow()} method.<a name="line.561"></a>
-<span class="sourceLineNo">562</span>   *<a name="line.562"></a>
-<span class="sourceLineNo">563</span>   * See HBASE-2258.<a name="line.563"></a>
-<span class="sourceLineNo">564</span>   *<a name="line.564"></a>
-<span class="sourceLineNo">565</span>   * @throws Exception<a name="line.565"></a>
-<span class="sourceLineNo">566</span>   */<a name="line.566"></a>
-<span class="sourceLineNo">567</span>  @Test<a name="line.567"></a>
-<span class="sourceLineNo">568</span>  public void testWhileMatchFilterWithFilterRow() throws Exception {<a name="line.568"></a>
-<span class="sourceLineNo">569</span>    final int pageSize = 4;<a name="line.569"></a>
-<span class="sourceLineNo">570</span><a name="line.570"></a>
-<span class="sourceLineNo">571</span>    Scan s = new Scan();<a name="line.571"></a>
-<span class="sourceLineNo">572</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.572"></a>
-<span class="sourceLineNo">573</span>    s.setFilter(filter);<a name="line.573"></a>
-<span class="sourceLineNo">574</span><a name="line.574"></a>
-<span class="sourceLineNo">575</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.575"></a>
-<span class="sourceLineNo">576</span>    int scannerCounter = 0;<a name="line.576"></a>
-<span class="sourceLineNo">577</span>    while (true) {<a name="line.577"></a>
-<span class="sourceLineNo">578</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.578"></a>
-<span class="sourceLineNo">579</span>      scannerCounter++;<a name="line.579"></a>
-<span class="sourceLineNo">580</span><a name="line.580"></a>
-<span class="sourceLineNo">581</span>      if (scannerCounter &gt;= pageSize) {<a name="line.581"></a>
-<span class="sourceLineNo">582</span>        assertTrue("The WhileMatchFilter should now filter all remaining", filter.filterAllRemaining());<a name="line.582"></a>
-<span class="sourceLineNo">583</span>      }<a name="line.583"></a>
-<span class="sourceLineNo">584</span>      if (!isMoreResults) {<a name="line.584"></a>
-<span class="sourceLineNo">585</span>        break;<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>    assertEquals("The page filter returned more rows than expected", pageSize, scannerCounter);<a name="line.588"></a>
-<span class="sourceLineNo">589</span>  }<a name="line.589"></a>
-<span class="sourceLineNo">590</span><a name="line.590"></a>
+<span class="sourceLineNo">145</span>    HColumnDescriptor family0 = new HColumnDescriptor(FAMILIES[0]).setVersions(100, 100);<a name="line.145"></a>
+<span class="sourceLineNo">146</span>    htd.addFamily(family0);<a name="line.146"></a>
+<span class="sourceLineNo">147</span>    htd.addFamily(new HColumnDescriptor(FAMILIES[1]));<a name="line.147"></a>
+<span class="sourceLineNo">148</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[0]));<a name="line.148"></a>
+<span class="sourceLineNo">149</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[1]));<a name="line.149"></a>
+<span class="sourceLineNo">150</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[0]));<a name="line.150"></a>
+<span class="sourceLineNo">151</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[1]));<a name="line.151"></a>
+<span class="sourceLineNo">152</span>    HRegionInfo info = new HRegionInfo(htd.getTableName(), null, null, false);<a name="line.152"></a>
+<span class="sourceLineNo">153</span>    this.region = HBaseTestingUtility.createRegionAndWAL(info, TEST_UTIL.getDataTestDir(),<a name="line.153"></a>
+<span class="sourceLineNo">154</span>        TEST_UTIL.getConfiguration(), htd);<a name="line.154"></a>
+<span class="sourceLineNo">155</span><a name="line.155"></a>
+<span class="sourceLineNo">156</span>    // Insert first half<a name="line.156"></a>
+<span class="sourceLineNo">157</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.157"></a>
+<span class="sourceLineNo">158</span>      Put p = new Put(ROW);<a name="line.158"></a>
+<span class="sourceLineNo">159</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.159"></a>
+<span class="sourceLineNo">160</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.160"></a>
+<span class="sourceLineNo">161</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.161"></a>
+<span class="sourceLineNo">162</span>      }<a name="line.162"></a>
+<span class="sourceLineNo">163</span>      this.region.put(p);<a name="line.163"></a>
+<span class="sourceLineNo">164</span>    }<a name="line.164"></a>
+<span class="sourceLineNo">165</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.165"></a>
+<span class="sourceLineNo">166</span>      Put p = new Put(ROW);<a name="line.166"></a>
+<span class="sourceLineNo">167</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.167"></a>
+<span class="sourceLineNo">168</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.168"></a>
+<span class="sourceLineNo">169</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.169"></a>
+<span class="sourceLineNo">170</span>      }<a name="line.170"></a>
+<span class="sourceLineNo">171</span>      this.region.put(p);<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>    // Flush<a name="line.174"></a>
+<span class="sourceLineNo">175</span>    this.region.flush(true);<a name="line.175"></a>
+<span class="sourceLineNo">176</span><a name="line.176"></a>
+<span class="sourceLineNo">177</span>    // Insert second half (reverse families)<a name="line.177"></a>
+<span class="sourceLineNo">178</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.178"></a>
+<span class="sourceLineNo">179</span>      Put p = new Put(ROW);<a name="line.179"></a>
+<span class="sourceLineNo">180</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.180"></a>
+<span class="sourceLineNo">181</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.181"></a>
+<span class="sourceLineNo">182</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.182"></a>
+<span class="sourceLineNo">183</span>      }<a name="line.183"></a>
+<span class="sourceLineNo">184</span>      this.region.put(p);<a name="line.184"></a>
+<span class="sourceLineNo">185</span>    }<a name="line.185"></a>
+<span class="sourceLineNo">186</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.186"></a>
+<span class="sourceLineNo">187</span>      Put p = new Put(ROW);<a name="line.187"></a>
+<span class="sourceLineNo">188</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.188"></a>
+<span class="sourceLineNo">189</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.189"></a>
+<span class="sourceLineNo">190</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.190"></a>
+<span class="sourceLineNo">191</span>      }<a name="line.191"></a>
+<span class="sourceLineNo">192</span>      this.region.put(p);<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>    // Delete the second qualifier from all rows and families<a name="line.195"></a>
+<span class="sourceLineNo">196</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.196"></a>
+<span class="sourceLineNo">197</span>      Delete d = new Delete(ROW);<a name="line.197"></a>
+<span class="sourceLineNo">198</span>      d.addColumns(FAMILIES[0], QUALIFIERS_ONE[1]);<a name="line.198"></a>
+<span class="sourceLineNo">199</span>      d.addColumns(FAMILIES[1], QUALIFIERS_ONE[1]);<a name="line.199"></a>
+<span class="sourceLineNo">200</span>      this.region.delete(d);<a name="line.200"></a>
+<span class="sourceLineNo">201</span>    }<a name="line.201"></a>
+<span class="sourceLineNo">202</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.202"></a>
+<span class="sourceLineNo">203</span>      Delete d = new Delete(ROW);<a name="line.203"></a>
+<span class="sourceLineNo">204</span>      d.addColumns(FAMILIES[0], QUALIFIERS_TWO[1]);<a name="line.204"></a>
+<span class="sourceLineNo">205</span>      d.addColumns(FAMILIES[1], QUALIFIERS_TWO[1]);<a name="line.205"></a>
+<span class="sourceLineNo">206</span>      this.region.delete(d);<a name="line.206"></a>
+<span class="sourceLineNo">207</span>    }<a name="line.207"></a>
+<span class="sourceLineNo">208</span>    colsPerRow -= 2;<a name="line.208"></a>
+<span class="sourceLineNo">209</span><a name="line.209"></a>
+<span class="sourceLineNo">210</span>    // Delete the second rows from both groups, one column at a time<a name="line.210"></a>
+<span class="sourceLineNo">211</span>    for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.211"></a>
+<span class="sourceLineNo">212</span>      Delete d = new Delete(ROWS_ONE[1]);<a name="line.212"></a>
+<span class="sourceLineNo">213</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.213"></a>
+<span class="sourceLineNo">214</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.214"></a>
+<span class="sourceLineNo">215</span>      this.region.delete(d);<a name="line.215"></a>
+<span class="sourceLineNo">216</span>    }<a name="line.216"></a>
+<span class="sourceLineNo">217</span>    for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.217"></a>
+<span class="sourceLineNo">218</span>      Delete d = new Delete(ROWS_TWO[1]);<a name="line.218"></a>
+<span class="sourceLineNo">219</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.219"></a>
+<span class="sourceLineNo">220</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.220"></a>
+<span class="sourceLineNo">221</span>      this.region.delete(d);<a name="line.221"></a>
+<span class="sourceLineNo">222</span>    }<a name="line.222"></a>
+<span class="sourceLineNo">223</span>    numRows -= 2;<a name="line.223"></a>
+<span class="sourceLineNo">224</span>  }<a name="line.224"></a>
+<span class="sourceLineNo">225</span><a name="line.225"></a>
+<span class="sourceLineNo">226</span>  @After<a name="line.226"></a>
+<span class="sourceLineNo">227</span>  public void tearDown() throws Exception {<a name="line.227"></a>
+<span class="sourceLineNo">228</span>    HBaseTestingUtility.closeRegionAndWAL(region);<a name="line.228"></a>
+<span class="sourceLineNo">229</span>  }<a name="line.229"></a>
+<span class="sourceLineNo">230</span><a name="line.230"></a>
+<span class="sourceLineNo">231</span>  @Test<a name="line.231"></a>
+<span class="sourceLineNo">232</span>  public void testRegionScannerReseek() throws Exception {<a name="line.232"></a>
+<span class="sourceLineNo">233</span>    // create new rows and column family to show how reseek works..<a name="line.233"></a>
+<span class="sourceLineNo">234</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.234"></a>
+<span class="sourceLineNo">235</span>      Put p = new Put(ROW);<a name="line.235"></a>
+<span class="sourceLineNo">236</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.236"></a>
+<span class="sourceLineNo">237</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.237"></a>
+<span class="sourceLineNo">238</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.238"></a>
+<span class="sourceLineNo">239</span><a name="line.239"></a>
+<span class="sourceLineNo">240</span>      }<a name="line.240"></a>
+<span class="sourceLineNo">241</span>      this.region.put(p);<a name="line.241"></a>
+<span class="sourceLineNo">242</span>    }<a name="line.242"></a>
+<span class="sourceLineNo">243</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.243"></a>
+<span class="sourceLineNo">244</span>      Put p = new Put(ROW);<a name="line.244"></a>
+<span class="sourceLineNo">245</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.245"></a>
+<span class="sourceLineNo">246</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.246"></a>
+<span class="sourceLineNo">247</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.247"></a>
+<span class="sourceLineNo">248</span>      }<a name="line.248"></a>
+<span class="sourceLineNo">249</span>      this.region.put(p);<a name="line.249"></a>
+<span class="sourceLineNo">250</span>    }<a name="line.250"></a>
+<span class="sourceLineNo">251</span>    // Flush<a name="line.251"></a>
+<span class="sourceLineNo">252</span>    this.region.flush(true);<a name="line.252"></a>
+<span class="sourceLineNo">253</span><a name="line.253"></a>
+<span class="sourceLineNo">254</span>    // Insert second half (reverse families)<a name="line.254"></a>
+<span class="sourceLineNo">255</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.255"></a>
+<span class="sourceLineNo">256</span>      Put p = new Put(ROW);<a name="line.256"></a>
+<span class="sourceLineNo">257</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.257"></a>
+<span class="sourceLineNo">258</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.258"></a>
+<span class="sourceLineNo">259</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.259"></a>
+<span class="sourceLineNo">260</span>      }<a name="line.260"></a>
+<span class="sourceLineNo">261</span>      this.region.put(p);<a name="line.261"></a>
+<span class="sourceLineNo">262</span>    }<a name="line.262"></a>
+<span class="sourceLineNo">263</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.263"></a>
+<span class="sourceLineNo">264</span>      Put p = new Put(ROW);<a name="line.264"></a>
+<span class="sourceLineNo">265</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.265"></a>
+<span class="sourceLineNo">266</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.266"></a>
+<span class="sourceLineNo">267</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.267"></a>
+<span class="sourceLineNo">268</span>      }<a name="line.268"></a>
+<span class="sourceLineNo">269</span>      this.region.put(p);<a name="line.269"></a>
+<span class="sourceLineNo">270</span>    }<a name="line.270"></a>
+<span class="sourceLineNo">271</span><a name="line.271"></a>
+<span class="sourceLineNo">272</span>    Scan s = new Scan();<a name="line.272"></a>
+<span class="sourceLineNo">273</span>    // set a start row<a name="line.273"></a>
+<span class="sourceLineNo">274</span>    s.setStartRow(ROWS_FOUR[1]);<a name="line.274"></a>
+<span class="sourceLineNo">275</span>    RegionScanner scanner = region.getScanner(s);<a name="line.275"></a>
+<span class="sourceLineNo">276</span><a name="line.276"></a>
+<span class="sourceLineNo">277</span>    // reseek to row three.<a name="line.277"></a>
+<span class="sourceLineNo">278</span>    scanner.reseek(ROWS_THREE[1]);<a name="line.278"></a>
+<span class="sourceLineNo">279</span>    List&lt;Cell&gt; results = new ArrayList&lt;&gt;();<a name="line.279"></a>
+<span class="sourceLineNo">280</span><a name="line.280"></a>
+<span class="sourceLineNo">281</span>    // the results should belong to ROWS_THREE[1]<a name="line.281"></a>
+<span class="sourceLineNo">282</span>    scanner.next(results);<a name="line.282"></a>
+<span class="sourceLineNo">283</span>    for (Cell keyValue : results) {<a name="line.283"></a>
+<span class="sourceLineNo">284</span>      assertTrue("The rows with ROWS_TWO as row key should be appearing.",<a name="line.284"></a>
+<span class="sourceLineNo">285</span>          CellUtil.matchingRows(keyValue, ROWS_THREE[1]));<a name="line.285"></a>
+<span class="sourceLineNo">286</span>    }<a name="line.286"></a>
+<span class="sourceLineNo">287</span>    // again try to reseek to a value before ROWS_THREE[1]<a name="line.287"></a>
+<span class="sourceLineNo">288</span>    scanner.reseek(ROWS_ONE[1]);<a name="line.288"></a>
+<span class="sourceLineNo">289</span>    results = new ArrayList&lt;&gt;();<a name="line.289"></a>
+<span class="sourceLineNo">290</span>    // This time no seek would have been done to ROWS_ONE[1]<a name="line.290"></a>
+<span class="sourceLineNo">291</span>    scanner.next(results);<a name="line.291"></a>
+<span class="sourceLineNo">292</span>    for (Cell keyValue : results) {<a name="line.292"></a>
+<span class="sourceLineNo">293</span>      assertFalse("Cannot rewind back to a value less than previous reseek.",<a name="line.293"></a>
+<span class="sourceLineNo">294</span>          Bytes.toString(CellUtil.cloneRow(keyValue)).contains("testRowOne"));<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>  @Test<a name="line.298"></a>
+<span class="sourceLineNo">299</span>  public void testNoFilter() throws Exception {<a name="line.299"></a>
+<span class="sourceLineNo">300</span>    // No filter<a name="line.300"></a>
+<span class="sourceLineNo">301</span>    long expectedRows = this.numRows;<a name="line.301"></a>
+<span class="sourceLineNo">302</span>    long expectedKeys = this.colsPerRow;<a name="line.302"></a>
+<span class="sourceLineNo">303</span><a name="line.303"></a>
+<span class="sourceLineNo">304</span>    // Both families<a name="line.304"></a>
+<span class="sourceLineNo">305</span>    Scan s = new Scan();<a name="line.305"></a>
+<span class="sourceLineNo">306</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.306"></a>
+<span class="sourceLineNo">307</span><a name="line.307"></a>
+<span class="sourceLineNo">308</span>    // One family<a name="line.308"></a>
+<span class="sourceLineNo">309</span>    s = new Scan();<a name="line.309"></a>
+<span class="sourceLineNo">310</span>    s.addFamily(FAMILIES[0]);<a name="line.310"></a>
+<span class="sourceLineNo">311</span>    verifyScan(s, expectedRows, expectedKeys/2);<a name="line.311"></a>
+<span class="sourceLineNo">312</span>  }<a name="line.312"></a>
+<span class="sourceLineNo">313</span><a name="line.313"></a>
+<span class="sourceLineNo">314</span>  @Test<a name="line.314"></a>
+<span class="sourceLineNo">315</span>  public void testPrefixFilter() throws Exception {<a name="line.315"></a>
+<span class="sourceLineNo">316</span>    // Grab rows from group one (half of total)<a name="line.316"></a>
+<span class="sourceLineNo">317</span>    long expectedRows = this.numRows / 2;<a name="line.317"></a>
+<span class="sourceLineNo">318</span>    long expectedKeys = this.colsPerRow;<a name="line.318"></a>
+<span class="sourceLineNo">319</span>    Scan s = new Scan();<a name="line.319"></a>
+<span class="sourceLineNo">320</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.320"></a>
+<span class="sourceLineNo">321</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.321"></a>
+<span class="sourceLineNo">322</span>  }<a name="line.322"></a>
+<span class="sourceLineNo">323</span><a name="line.323"></a>
+<span class="sourceLineNo">324</span>  @Test<a name="line.324"></a>
+<span class="sourceLineNo">325</span>  public void testPrefixFilterWithReverseScan() throws Exception {<a name="line.325"></a>
+<span class="sourceLineNo">326</span>    // Grab rows from group one (half of total)<a name="line.326"></a>
+<span class="sourceLineNo">327</span>    long expectedRows = this.numRows / 2;<a name="line.327"></a>
+<span class="sourceLineNo">328</span>    long expectedKeys = this.colsPerRow;<a name="line.328"></a>
+<span class="sourceLineNo">329</span>    Scan s = new Scan();<a name="line.329"></a>
+<span class="sourceLineNo">330</span>    s.setReversed(true);<a name="line.330"></a>
+<span class="sourceLineNo">331</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.331"></a>
+<span class="sourceLineNo">332</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.332"></a>
+<span class="sourceLineNo">333</span>  }<a name="line.333"></a>
+<span class="sourceLineNo">334</span><a name="line.334"></a>
+<span class="sourceLineNo">335</span>  @Test<a name="line.335"></a>
+<span class="sourceLineNo">336</span>  public void testPageFilter() throws Exception {<a name="line.336"></a>
+<span class="sourceLineNo">337</span><a name="line.337"></a>
+<span class="sourceLineNo">338</span>    // KVs in first 6 rows<a name="line.338"></a>
+<span class="sourceLineNo">339</span>    KeyValue [] expectedKVs = {<a name="line.339"></a>
+<span class="sourceLineNo">340</span>      // testRowOne-0<a name="line.340"></a>
+<span class="sourceLineNo">341</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.341"></a>
+<span class="sourceLineNo">342</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.342"></a>
+<span class="sourceLineNo">343</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.343"></a>
+<span class="sourceLineNo">344</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.344"></a>
+<span class="sourceLineNo">345</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.345"></a>
+<span class="sourceLineNo">346</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.346"></a>
+<span class="sourceLineNo">347</span>      // testRowOne-2<a name="line.347"></a>
+<span class="sourceLineNo">348</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.348"></a>
+<span class="sourceLineNo">349</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.349"></a>
+<span class="sourceLineNo">350</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.350"></a>
+<span class="sourceLineNo">351</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.351"></a>
+<span class="sourceLineNo">352</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.352"></a>
+<span class="sourceLineNo">353</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.353"></a>
+<span class="sourceLineNo">354</span>      // testRowOne-3<a name="line.354"></a>
+<span class="sourceLineNo">355</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.355"></a>
+<span class="sourceLineNo">356</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.356"></a>
+<span class="sourceLineNo">357</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.357"></a>
+<span class="sourceLineNo">358</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.358"></a>
+<span class="sourceLineNo">359</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.359"></a>
+<span class="sourceLineNo">360</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.360"></a>
+<span class="sourceLineNo">361</span>      // testRowTwo-0<a name="line.361"></a>
+<span class="sourceLineNo">362</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.362"></a>
+<span class="sourceLineNo">363</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.363"></a>
+<span class="sourceLineNo">364</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.364"></a>
+<span class="sourceLineNo">365</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.365"></a>
+<span class="sourceLineNo">366</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.366"></a>
+<span class="sourceLineNo">367</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.367"></a>
+<span class="sourceLineNo">368</span>      // testRowTwo-2<a name="line.368"></a>
+<span class="sourceLineNo">369</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.369"></a>
+<span class="sourceLineNo">370</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.370"></a>
+<span class="sourceLineNo">371</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.371"></a>
+<span class="sourceLineNo">372</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.372"></a>
+<span class="sourceLineNo">373</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.373"></a>
+<span class="sourceLineNo">374</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.374"></a>
+<span class="sourceLineNo">375</span>      // testRowTwo-3<a name="line.375"></a>
+<span class="sourceLineNo">376</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.376"></a>
+<span class="sourceLineNo">377</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.377"></a>
+<span class="sourceLineNo">378</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.378"></a>
+<span class="sourceLineNo">379</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.379"></a>
+<span class="sourceLineNo">380</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.380"></a>
+<span class="sourceLineNo">381</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1])<a name="line.381"></a>
+<span class="sourceLineNo">382</span>    };<a name="line.382"></a>
+<span class="sourceLineNo">383</span><a name="line.383"></a>
+<span class="sourceLineNo">384</span>    // Grab all 6 rows<a name="line.384"></a>
+<span class="sourceLineNo">385</span>    long expectedRows = 6;<a name="line.385"></a>
+<span class="sourceLineNo">386</span>    long expectedKeys = this.colsPerRow;<a name="line.386"></a>
+<span class="sourceLineNo">387</span>    Scan s = new Scan();<a name="line.387"></a>
+<span class="sourceLineNo">388</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.388"></a>
+<span class="sourceLineNo">389</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.389"></a>
+<span class="sourceLineNo">390</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.390"></a>
+<span class="sourceLineNo">391</span>    verifyScanFull(s, expectedKVs);<a name="line.391"></a>
+<span class="sourceLineNo">392</span><a name="line.392"></a>
+<span class="sourceLineNo">393</span>    // Grab first 4 rows (6 cols per row)<a name="line.393"></a>
+<span class="sourceLineNo">394</span>    expectedRows = 4;<a name="line.394"></a>
+<span class="sourceLineNo">395</span>    expectedKeys = this.colsPerRow;<a name="line.395"></a>
+<span class="sourceLineNo">396</span>    s = new Scan();<a name="line.396"></a>
+<span class="sourceLineNo">397</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.397"></a>
+<span class="sourceLineNo">398</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.398"></a>
+<span class="sourceLineNo">399</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.399"></a>
+<span class="sourceLineNo">400</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 24));<a name="line.400"></a>
+<span class="sourceLineNo">401</span><a name="line.401"></a>
+<span class="sourceLineNo">402</span>    // Grab first 2 rows<a name="line.402"></a>
+<span class="sourceLineNo">403</span>    expectedRows = 2;<a name="line.403"></a>
+<span class="sourceLineNo">404</span>    expectedKeys = this.colsPerRow;<a name="line.404"></a>
+<span class="sourceLineNo">405</span>    s = new Scan();<a name="line.405"></a>
+<span class="sourceLineNo">406</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.406"></a>
+<span class="sourceLineNo">407</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.407"></a>
+<span class="sourceLineNo">408</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.408"></a>
+<span class="sourceLineNo">409</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 12));<a name="line.409"></a>
+<span class="sourceLineNo">410</span><a name="line.410"></a>
+<span class="sourceLineNo">411</span>    // Grab first row<a name="line.411"></a>
+<span class="sourceLineNo">412</span>    expectedRows = 1;<a name="line.412"></a>
+<span class="sourceLineNo">413</span>    expectedKeys = this.colsPerRow;<a name="line.413"></a>
+<span class="sourceLineNo">414</span>    s = new Scan();<a name="line.414"></a>
+<span class="sourceLineNo">415</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.415"></a>
+<span class="sourceLineNo">416</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.416"></a>
+<span class="sourceLineNo">417</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.417"></a>
+<span class="sourceLineNo">418</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 6));<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><a name="line.421"></a>
+<span class="sourceLineNo">422</span>  @Test<a name="line.422"></a>
+<span class="sourceLineNo">423</span>  public void testPageFilterWithReverseScan() throws Exception {<a name="line.423"></a>
+<span class="sourceLineNo">424</span>    // KVs in first 6 rows<a name="line.424"></a>
+<span class="sourceLineNo">425</span>    KeyValue[] expectedKVs = {<a name="line.425"></a>
+<span class="sourceLineNo">426</span>        // testRowOne-0<a name="line.426"></a>
+<span class="sourceLineNo">427</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.427"></a>
+<span class="sourceLineNo">428</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.428"></a>
+<span class="sourceLineNo">429</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.429"></a>
+<span class="sourceLineNo">430</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.430"></a>
+<span class="sourceLineNo">431</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.431"></a>
+<span class="sourceLineNo">432</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.432"></a>
+<span class="sourceLineNo">433</span>        // testRowOne-2<a name="line.433"></a>
+<span class="sourceLineNo">434</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.434"></a>
+<span class="sourceLineNo">435</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.435"></a>
+<span class="sourceLineNo">436</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.436"></a>
+<span class="sourceLineNo">437</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.437"></a>
+<span class="sourceLineNo">438</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.438"></a>
+<span class="sourceLineNo">439</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.439"></a>
+<span class="sourceLineNo">440</span>        // testRowOne-3<a name="line.440"></a>
+<span class="sourceLineNo">441</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.441"></a>
+<span class="sourceLineNo">442</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.442"></a>
+<span class="sourceLineNo">443</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.443"></a>
+<span class="sourceLineNo">444</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.444"></a>
+<span class="sourceLineNo">445</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.445"></a>
+<span class="sourceLineNo">446</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.446"></a>
+<span class="sourceLineNo">447</span>        // testRowTwo-0<a name="line.447"></a>
+<span class="sourceLineNo">448</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.448"></a>
+<span class="sourceLineNo">449</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.449"></a>
+<span class="sourceLineNo">450</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.450"></a>
+<span class="sourceLineNo">451</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.451"></a>
+<span class="sourceLineNo">452</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.452"></a>
+<span class="sourceLineNo">453</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.453"></a>
+<span class="sourceLineNo">454</span>        // testRowTwo-2<a name="line.454"></a>
+<span class="sourceLineNo">455</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.455"></a>
+<span class="sourceLineNo">456</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.456"></a>
+<span class="sourceLineNo">457</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.457"></a>
+<span class="sourceLineNo">458</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.458"></a>
+<span class="sourceLineNo">459</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.459"></a>
+<span class="sourceLineNo">460</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.460"></a>
+<span class="sourceLineNo">461</span>        // testRowTwo-3<a name="line.461"></a>
+<span class="sourceLineNo">462</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.462"></a>
+<span class="sourceLineNo">463</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.463"></a>
+<span class="sourceLineNo">464</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.464"></a>
+<span class="sourceLineNo">465</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.465"></a>
+<span class="sourceLineNo">466</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.466"></a>
+<span class="sourceLineNo">467</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]) };<a name="line.467"></a>
+<span class="sourceLineNo">468</span><a name="line.468"></a>
+<span class="sourceLineNo">469</span>    // Grab all 6 rows<a name="line.469"></a>
+<span class="sourceLineNo">470</span>    long expectedRows = 6;<a name="line.470"></a>
+<span class="sourceLineNo">471</span>    long expectedKeys = this.colsPerRow;<a name="line.471"></a>
+<span class="sourceLineNo">472</span>    Scan s = new Scan();<a name="line.472"></a>
+<span class="sourceLineNo">473</span>    s.setReversed(true);<a name="line.473"></a>
+<span class="sourceLineNo">474</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.474"></a>
+<span class="sourceLineNo">475</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.475"></a>
+<span class="sourceLineNo">476</span><a name="line.476"></a>
+<span class="sourceLineNo">477</span>    // Grab first 4 rows (6 cols per row)<a name="line.477"></a>
+<span class="sourceLineNo">478</span>    expectedRows = 4;<a name="line.478"></a>
+<span class="sourceLineNo">479</span>    expectedKeys = this.colsPerRow;<a name="line.479"></a>
+<span class="sourceLineNo">480</span>    s = new Scan();<a name="line.480"></a>
+<span class="sourceLineNo">481</span>    s.setReversed(true);<a name="line.481"></a>
+<span class="sourceLineNo">482</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.482"></a>
+<span class="sourceLineNo">483</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.483"></a>
+<span class="sourceLineNo">484</span><a name="line.484"></a>
+<span class="sourceLineNo">485</span>    // Grab first 2 rows<a name="line.485"></a>
+<span class="sourceLineNo">486</span>    expectedRows = 2;<a name="line.486"></a>
+<span class="sourceLineNo">487</span>    expectedKeys = this.colsPerRow;<a name="line.487"></a>
+<span class="sourceLineNo">488</span>    s = new Scan();<a name="line.488"></a>
+<span class="sourceLineNo">489</span>    s.setReversed(true);<a name="line.489"></a>
+<span class="sourceLineNo">490</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.490"></a>
+<span class="sourceLineNo">491</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.491"></a>
+<span class="sourceLineNo">492</span><a name="line.492"></a>
+<span class="sourceLineNo">493</span>    // Grab first row<a name="line.493"></a>
+<span class="sourceLineNo">494</span>    expectedRows = 1;<a name="line.494"></a>
+<span class="sourceLineNo">495</span>    expectedKeys = this.colsPerRow;<a name="line.495"></a>
+<span class="sourceLineNo">496</span>    s = new Scan();<a name="line.496"></a>
+<span class="sourceLineNo">497</span>    s.setReversed(true);<a name="line.497"></a>
+<span class="sourceLineNo">498</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.498"></a>
+<span class="sourceLineNo">499</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.499"></a>
+<span class="sourceLineNo">500</span>  }<a name="line.500"></a>
+<span class="sourceLineNo">501</span><a name="line.501"></a>
+<span class="sourceLineNo">502</span>  @Test<a name="line.502"></a>
+<span class="sourceLineNo">503</span>  public void testWhileMatchFilterWithFilterRowWithReverseScan()<a name="line.503"></a>
+<span class="sourceLineNo">504</span>      throws Exception {<a name="line.504"></a>
+<span class="sourceLineNo">505</span>    final int pageSize = 4;<a name="line.505"></a>
+<span class="sourceLineNo">506</span><a name="line.506"></a>
+<span class="sourceLineNo">507</span>    Scan s = new Scan();<a name="line.507"></a>
+<span class="sourceLineNo">508</span>    s.setReversed(true);<a name="line.508"></a>
+<span class="sourceLineNo">509</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.509"></a>
+<span class="sourceLineNo">510</span>    s.setFilter(filter);<a name="line.510"></a>
+<span class="sourceLineNo">511</span><a name="line.511"></a>
+<span class="sourceLineNo">512</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.512"></a>
+<span class="sourceLineNo">513</span>    int scannerCounter = 0;<a name="line.513"></a>
+<span class="sourceLineNo">514</span>    while (true) {<a name="line.514"></a>
+<span class="sourceLineNo">515</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.515"></a>
+<span class="sourceLineNo">516</span>      scannerCounter++;<a name="line.516"></a>
+<span class="sourceLineNo">517</span><a name="line.517"></a>
+<span class="sourceLineNo">518</span>      if (scannerCounter &gt;= pageSize) {<a name="line.518"></a>
+<span class="sourceLineNo">519</span>        Assert.assertTrue(<a name="line.519"></a>
+<span class="sourceLineNo">520</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.520"></a>
+<span class="sourceLineNo">521</span>            filter.filterAllRemaining());<a name="line.521"></a>
+<span class="sourceLineNo">522</span>      }<a name="line.522"></a>
+<span class="sourceLineNo">523</span>      if (!isMoreResults) {<a name="line.523"></a>
+<span class="sourceLineNo">524</span>        break;<a name="line.524"></a>
+<span class="sourceLineNo">525</span>      }<a name="line.525"></a>
+<span class="sourceLineNo">526</span>    }<a name="line.526"></a>
+<span class="sourceLineNo">527</span>    scanner.close();<a name="line.527"></a>
+<span class="sourceLineNo">528</span>    Assert.assertEquals("The page filter returned more rows than expected",<a name="line.528"></a>
+<span class="sourceLineNo">529</span>        pageSize, scannerCounter);<a name="line.529"></a>
+<span class="sourceLineNo">530</span>  }<a name="line.530"></a>
+<span class="sourceLineNo">531</span><a name="line.531"></a>
+<span class="sourceLineNo">532</span>  @Test<a name="line.532"></a>
+<span class="sourceLineNo">533</span>  public void testWhileMatchFilterWithFilterRowKeyWithReverseScan()<a name="line.533"></a>
+<span class="sourceLineNo">534</span>      throws Exception {<a name="line.534"></a>
+<span class="sourceLineNo">535</span>    Scan s = new Scan();<a name="line.535"></a>
+<span class="sourceLineNo">536</span>    String prefix = "testRowOne";<a name="line.536"></a>
+<span class="sourceLineNo">537</span>    WhileMatchFilter filter = new WhileMatchFilter(new PrefixFilter(<a name="line.537"></a>
+<span class="sourceLineNo">538</span>        Bytes.toBytes(prefix)));<a name="line.538"></a>
+<span class="sourceLineNo">539</span>    s.setFilter(filter);<a name="line.539"></a>
+<span class="sourceLineNo">540</span>    s.setReversed(true);<a name="line.540"></a>
+<span class="sourceLineNo">541</span><a name="line.541"></a>
+<span class="sourceLineNo">542</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.542"></a>
+<span class="sourceLineNo">543</span>    while (true) {<a name="line.543"></a>
+<span class="sourceLineNo">544</span>      ArrayList&lt;Cell&gt; values = new ArrayList&lt;&gt;();<a name="line.544"></a>
+<span class="sourceLineNo">545</span>      boolean isMoreResults = scanner.next(values);<a name="line.545"></a>
+<span class="sourceLineNo">546</span>      if (!isMoreResults<a name="line.546"></a>
+<span class="sourceLineNo">547</span>          || !Bytes.toString(CellUtil.cloneRow(values.get(0))).startsWith(prefix)) {<a name="line.547"></a>
+<span class="sourceLineNo">548</span>        Assert.assertTrue(<a name="line.548"></a>
+<span class="sourceLineNo">549</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.549"></a>
+<span class="sourceLineNo">550</span>            filter.filterAllRemaining());<a name="line.550"></a>
+<span class="sourceLineNo">551</span>      }<a name="line.551"></a>
+<span class="sourceLineNo">552</span>      if (!isMoreResults) {<a name="line.552"></a>
+<span class="sourceLineNo">553</span>        break;<a name="line.553"></a>
+<span class="sourceLineNo">554</span>      }<a name="line.554"></a>
+<span class="sourceLineNo">555</span>    }<a name="line.555"></a>
+<span class="sourceLineNo">556</span>    scanner.close();<a name="line.556"></a>
+<span class="sourceLineNo">557</span>  }<a name="line.557"></a>
+<span class="sourceLineNo">558</span><a name="line.558"></a>
+<span class="sourceLineNo">559</span>  /**<a name="line.559"></a>
+<span class="sourceLineNo">560</span>   * Tests the the {@link WhileMatchFilter} works in combination with a<a name="line.560"></a>
+<span class="sourceLineNo">561</span>   * {@link Filter} that uses the<a name="line.561"></a>
+<span class="sourceLineNo">562</span>   * {@link Filter#filterRow()} method.<a name="line.562"></a>
+<span class="sourceLineNo">563</span>   *<a name="line.563"></a>
+<span class="sourceLineNo">564</span>   * See HBASE-2258.<a name="line.564"></a>
+<span class="sourceLineNo">565</span>   *<a name="line.565"></a>
+<span class="sourceLineNo">566</span>   * @throws Exception<a name="line.566"></a>
+<span class="sourceLineNo">567</span>   */<a name="line.567"></a>
+<span class="sourceLineNo">568</span>  @Test<a name="line.568"></a>
+<span class="sourceLineNo">569</span>  public void testWhileMatchFilterWithFilterRow() throws Exception {<a name="line.569"></a>
+<span class="sourceLineNo">570</span>    final int pageSize = 4;<a name="line.570"></a>
+<span class="sourceLineNo">571</span><a name="line.571"></a>
+<span class="sourceLineNo">572</span>    Scan s = new Scan();<a name="line.572"></a>
+<span class="sourceLineNo">573</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.573"></a>
+<span class="sourceLineNo">574</span>    s.setFilter(filter);<a name="line.574"></a>
+<span class="sourceLineNo">575</span><a name="line.575"></a>
+<span class="sourceLineNo">576</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.576"></a>
+<span class="sourceLineNo">577</span>    int scannerCounter = 0;<a name="line.577"></a>
+<span class="sourceLineNo">578</span>    while (true) {<a name="line.578"></a>
+<span class="sourceLineNo">579</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.579"></a>
+<span class="sourceLineNo">580</span>      scannerCounter++;<a name="line.580"></a>
+<span class="sourceLineNo">581</span><a name="line.581"></a>
+<span class="sourceLineNo">582</span>      if (scannerCounter &gt;= pageSize) {<a name="line.582"></a>
+<span class="sourceLineNo">583</span>        assertTrue("The WhileMatchFilter should now filter all remaining", filter.filterAllRemaining());<a name="line.583"></a>
+<span class="sourceLineNo">584</span>      }<a name="line.584"></a>
+<span class="sourceLineNo">585</span>      if (!isMoreResults) {<a name="line.585"></a>
+<span class="sourceLineNo">586</span>        break;<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>    assertEquals("The page filter returned more rows than expected", pageSize, scannerCounter);<a name="line.589"></a>
+<span class="sourceLineNo">590</span>  }<a name="line.590"></a>
 <span class="sourceLineNo">591</span><a name="line.591"></a>
-<span class="sourceLineNo">592</span>  /**<a name="line.592"></a>
-<span class="sourceLineNo">593</span>   * The following filter simulates a pre-0.96 filter where filterRow() is defined while<a name="line.593"></a>
-<span class="sourceLineNo">594</s

<TRUNCATED>

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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html
index a6c7150..e93a01d 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html
@@ -150,2012 +150,2072 @@
 <span class="sourceLineNo">142</span>  @Before<a name="line.142"></a>
 <span class="sourceLineNo">143</span>  public void setUp() throws Exception {<a name="line.143"></a>
 <span class="sourceLineNo">144</span>    HTableDescriptor htd = new HTableDescriptor(TableName.valueOf("TestFilter"));<a name="line.144"></a>
-<span class="sourceLineNo">145</span>    htd.addFamily(new HColumnDescriptor(FAMILIES[0]));<a name="line.145"></a>
-<span class="sourceLineNo">146</span>    htd.addFamily(new HColumnDescriptor(FAMILIES[1]));<a name="line.146"></a>
-<span class="sourceLineNo">147</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[0]));<a name="line.147"></a>
-<span class="sourceLineNo">148</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[1]));<a name="line.148"></a>
-<span class="sourceLineNo">149</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[0]));<a name="line.149"></a>
-<span class="sourceLineNo">150</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[1]));<a name="line.150"></a>
-<span class="sourceLineNo">151</span>    HRegionInfo info = new HRegionInfo(htd.getTableName(), null, null, false);<a name="line.151"></a>
-<span class="sourceLineNo">152</span>    this.region = HBaseTestingUtility.createRegionAndWAL(info, TEST_UTIL.getDataTestDir(),<a name="line.152"></a>
-<span class="sourceLineNo">153</span>        TEST_UTIL.getConfiguration(), htd);<a name="line.153"></a>
-<span class="sourceLineNo">154</span><a name="line.154"></a>
-<span class="sourceLineNo">155</span>    // Insert first half<a name="line.155"></a>
-<span class="sourceLineNo">156</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.156"></a>
-<span class="sourceLineNo">157</span>      Put p = new Put(ROW);<a name="line.157"></a>
-<span class="sourceLineNo">158</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.158"></a>
-<span class="sourceLineNo">159</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.159"></a>
-<span class="sourceLineNo">160</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.160"></a>
-<span class="sourceLineNo">161</span>      }<a name="line.161"></a>
-<span class="sourceLineNo">162</span>      this.region.put(p);<a name="line.162"></a>
-<span class="sourceLineNo">163</span>    }<a name="line.163"></a>
-<span class="sourceLineNo">164</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.164"></a>
-<span class="sourceLineNo">165</span>      Put p = new Put(ROW);<a name="line.165"></a>
-<span class="sourceLineNo">166</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.166"></a>
-<span class="sourceLineNo">167</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.167"></a>
-<span class="sourceLineNo">168</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.168"></a>
-<span class="sourceLineNo">169</span>      }<a name="line.169"></a>
-<span class="sourceLineNo">170</span>      this.region.put(p);<a name="line.170"></a>
-<span class="sourceLineNo">171</span>    }<a name="line.171"></a>
-<span class="sourceLineNo">172</span><a name="line.172"></a>
-<span class="sourceLineNo">173</span>    // Flush<a name="line.173"></a>
-<span class="sourceLineNo">174</span>    this.region.flush(true);<a name="line.174"></a>
-<span class="sourceLineNo">175</span><a name="line.175"></a>
-<span class="sourceLineNo">176</span>    // Insert second half (reverse families)<a name="line.176"></a>
-<span class="sourceLineNo">177</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.177"></a>
-<span class="sourceLineNo">178</span>      Put p = new Put(ROW);<a name="line.178"></a>
-<span class="sourceLineNo">179</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.179"></a>
-<span class="sourceLineNo">180</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.180"></a>
-<span class="sourceLineNo">181</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.181"></a>
-<span class="sourceLineNo">182</span>      }<a name="line.182"></a>
-<span class="sourceLineNo">183</span>      this.region.put(p);<a name="line.183"></a>
-<span class="sourceLineNo">184</span>    }<a name="line.184"></a>
-<span class="sourceLineNo">185</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.185"></a>
-<span class="sourceLineNo">186</span>      Put p = new Put(ROW);<a name="line.186"></a>
-<span class="sourceLineNo">187</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.187"></a>
-<span class="sourceLineNo">188</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.188"></a>
-<span class="sourceLineNo">189</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.189"></a>
-<span class="sourceLineNo">190</span>      }<a name="line.190"></a>
-<span class="sourceLineNo">191</span>      this.region.put(p);<a name="line.191"></a>
-<span class="sourceLineNo">192</span>    }<a name="line.192"></a>
-<span class="sourceLineNo">193</span><a name="line.193"></a>
-<span class="sourceLineNo">194</span>    // Delete the second qualifier from all rows and families<a name="line.194"></a>
-<span class="sourceLineNo">195</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.195"></a>
-<span class="sourceLineNo">196</span>      Delete d = new Delete(ROW);<a name="line.196"></a>
-<span class="sourceLineNo">197</span>      d.addColumns(FAMILIES[0], QUALIFIERS_ONE[1]);<a name="line.197"></a>
-<span class="sourceLineNo">198</span>      d.addColumns(FAMILIES[1], QUALIFIERS_ONE[1]);<a name="line.198"></a>
-<span class="sourceLineNo">199</span>      this.region.delete(d);<a name="line.199"></a>
-<span class="sourceLineNo">200</span>    }<a name="line.200"></a>
-<span class="sourceLineNo">201</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.201"></a>
-<span class="sourceLineNo">202</span>      Delete d = new Delete(ROW);<a name="line.202"></a>
-<span class="sourceLineNo">203</span>      d.addColumns(FAMILIES[0], QUALIFIERS_TWO[1]);<a name="line.203"></a>
-<span class="sourceLineNo">204</span>      d.addColumns(FAMILIES[1], QUALIFIERS_TWO[1]);<a name="line.204"></a>
-<span class="sourceLineNo">205</span>      this.region.delete(d);<a name="line.205"></a>
-<span class="sourceLineNo">206</span>    }<a name="line.206"></a>
-<span class="sourceLineNo">207</span>    colsPerRow -= 2;<a name="line.207"></a>
-<span class="sourceLineNo">208</span><a name="line.208"></a>
-<span class="sourceLineNo">209</span>    // Delete the second rows from both groups, one column at a time<a name="line.209"></a>
-<span class="sourceLineNo">210</span>    for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.210"></a>
-<span class="sourceLineNo">211</span>      Delete d = new Delete(ROWS_ONE[1]);<a name="line.211"></a>
-<span class="sourceLineNo">212</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.212"></a>
-<span class="sourceLineNo">213</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.213"></a>
-<span class="sourceLineNo">214</span>      this.region.delete(d);<a name="line.214"></a>
-<span class="sourceLineNo">215</span>    }<a name="line.215"></a>
-<span class="sourceLineNo">216</span>    for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.216"></a>
-<span class="sourceLineNo">217</span>      Delete d = new Delete(ROWS_TWO[1]);<a name="line.217"></a>
-<span class="sourceLineNo">218</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.218"></a>
-<span class="sourceLineNo">219</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.219"></a>
-<span class="sourceLineNo">220</span>      this.region.delete(d);<a name="line.220"></a>
-<span class="sourceLineNo">221</span>    }<a name="line.221"></a>
-<span class="sourceLineNo">222</span>    numRows -= 2;<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>  @After<a name="line.225"></a>
-<span class="sourceLineNo">226</span>  public void tearDown() throws Exception {<a name="line.226"></a>
-<span class="sourceLineNo">227</span>    HBaseTestingUtility.closeRegionAndWAL(region);<a name="line.227"></a>
-<span class="sourceLineNo">228</span>  }<a name="line.228"></a>
-<span class="sourceLineNo">229</span><a name="line.229"></a>
-<span class="sourceLineNo">230</span>  @Test<a name="line.230"></a>
-<span class="sourceLineNo">231</span>  public void testRegionScannerReseek() throws Exception {<a name="line.231"></a>
-<span class="sourceLineNo">232</span>    // create new rows and column family to show how reseek works..<a name="line.232"></a>
-<span class="sourceLineNo">233</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.233"></a>
-<span class="sourceLineNo">234</span>      Put p = new Put(ROW);<a name="line.234"></a>
-<span class="sourceLineNo">235</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.235"></a>
-<span class="sourceLineNo">236</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.236"></a>
-<span class="sourceLineNo">237</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.237"></a>
-<span class="sourceLineNo">238</span><a name="line.238"></a>
-<span class="sourceLineNo">239</span>      }<a name="line.239"></a>
-<span class="sourceLineNo">240</span>      this.region.put(p);<a name="line.240"></a>
-<span class="sourceLineNo">241</span>    }<a name="line.241"></a>
-<span class="sourceLineNo">242</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.242"></a>
-<span class="sourceLineNo">243</span>      Put p = new Put(ROW);<a name="line.243"></a>
-<span class="sourceLineNo">244</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.244"></a>
-<span class="sourceLineNo">245</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.245"></a>
-<span class="sourceLineNo">246</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.246"></a>
-<span class="sourceLineNo">247</span>      }<a name="line.247"></a>
-<span class="sourceLineNo">248</span>      this.region.put(p);<a name="line.248"></a>
-<span class="sourceLineNo">249</span>    }<a name="line.249"></a>
-<span class="sourceLineNo">250</span>    // Flush<a name="line.250"></a>
-<span class="sourceLineNo">251</span>    this.region.flush(true);<a name="line.251"></a>
-<span class="sourceLineNo">252</span><a name="line.252"></a>
-<span class="sourceLineNo">253</span>    // Insert second half (reverse families)<a name="line.253"></a>
-<span class="sourceLineNo">254</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.254"></a>
-<span class="sourceLineNo">255</span>      Put p = new Put(ROW);<a name="line.255"></a>
-<span class="sourceLineNo">256</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.256"></a>
-<span class="sourceLineNo">257</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.257"></a>
-<span class="sourceLineNo">258</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.258"></a>
-<span class="sourceLineNo">259</span>      }<a name="line.259"></a>
-<span class="sourceLineNo">260</span>      this.region.put(p);<a name="line.260"></a>
-<span class="sourceLineNo">261</span>    }<a name="line.261"></a>
-<span class="sourceLineNo">262</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.262"></a>
-<span class="sourceLineNo">263</span>      Put p = new Put(ROW);<a name="line.263"></a>
-<span class="sourceLineNo">264</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.264"></a>
-<span class="sourceLineNo">265</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.265"></a>
-<span class="sourceLineNo">266</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.266"></a>
-<span class="sourceLineNo">267</span>      }<a name="line.267"></a>
-<span class="sourceLineNo">268</span>      this.region.put(p);<a name="line.268"></a>
-<span class="sourceLineNo">269</span>    }<a name="line.269"></a>
-<span class="sourceLineNo">270</span><a name="line.270"></a>
-<span class="sourceLineNo">271</span>    Scan s = new Scan();<a name="line.271"></a>
-<span class="sourceLineNo">272</span>    // set a start row<a name="line.272"></a>
-<span class="sourceLineNo">273</span>    s.setStartRow(ROWS_FOUR[1]);<a name="line.273"></a>
-<span class="sourceLineNo">274</span>    RegionScanner scanner = region.getScanner(s);<a name="line.274"></a>
-<span class="sourceLineNo">275</span><a name="line.275"></a>
-<span class="sourceLineNo">276</span>    // reseek to row three.<a name="line.276"></a>
-<span class="sourceLineNo">277</span>    scanner.reseek(ROWS_THREE[1]);<a name="line.277"></a>
-<span class="sourceLineNo">278</span>    List&lt;Cell&gt; results = new ArrayList&lt;&gt;();<a name="line.278"></a>
-<span class="sourceLineNo">279</span><a name="line.279"></a>
-<span class="sourceLineNo">280</span>    // the results should belong to ROWS_THREE[1]<a name="line.280"></a>
-<span class="sourceLineNo">281</span>    scanner.next(results);<a name="line.281"></a>
-<span class="sourceLineNo">282</span>    for (Cell keyValue : results) {<a name="line.282"></a>
-<span class="sourceLineNo">283</span>      assertTrue("The rows with ROWS_TWO as row key should be appearing.",<a name="line.283"></a>
-<span class="sourceLineNo">284</span>          CellUtil.matchingRows(keyValue, ROWS_THREE[1]));<a name="line.284"></a>
-<span class="sourceLineNo">285</span>    }<a name="line.285"></a>
-<span class="sourceLineNo">286</span>    // again try to reseek to a value before ROWS_THREE[1]<a name="line.286"></a>
-<span class="sourceLineNo">287</span>    scanner.reseek(ROWS_ONE[1]);<a name="line.287"></a>
-<span class="sourceLineNo">288</span>    results = new ArrayList&lt;&gt;();<a name="line.288"></a>
-<span class="sourceLineNo">289</span>    // This time no seek would have been done to ROWS_ONE[1]<a name="line.289"></a>
-<span class="sourceLineNo">290</span>    scanner.next(results);<a name="line.290"></a>
-<span class="sourceLineNo">291</span>    for (Cell keyValue : results) {<a name="line.291"></a>
-<span class="sourceLineNo">292</span>      assertFalse("Cannot rewind back to a value less than previous reseek.",<a name="line.292"></a>
-<span class="sourceLineNo">293</span>          Bytes.toString(CellUtil.cloneRow(keyValue)).contains("testRowOne"));<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>  @Test<a name="line.297"></a>
-<span class="sourceLineNo">298</span>  public void testNoFilter() throws Exception {<a name="line.298"></a>
-<span class="sourceLineNo">299</span>    // No filter<a name="line.299"></a>
-<span class="sourceLineNo">300</span>    long expectedRows = this.numRows;<a name="line.300"></a>
-<span class="sourceLineNo">301</span>    long expectedKeys = this.colsPerRow;<a name="line.301"></a>
-<span class="sourceLineNo">302</span><a name="line.302"></a>
-<span class="sourceLineNo">303</span>    // Both families<a name="line.303"></a>
-<span class="sourceLineNo">304</span>    Scan s = new Scan();<a name="line.304"></a>
-<span class="sourceLineNo">305</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.305"></a>
-<span class="sourceLineNo">306</span><a name="line.306"></a>
-<span class="sourceLineNo">307</span>    // One family<a name="line.307"></a>
-<span class="sourceLineNo">308</span>    s = new Scan();<a name="line.308"></a>
-<span class="sourceLineNo">309</span>    s.addFamily(FAMILIES[0]);<a name="line.309"></a>
-<span class="sourceLineNo">310</span>    verifyScan(s, expectedRows, expectedKeys/2);<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<a name="line.313"></a>
-<span class="sourceLineNo">314</span>  public void testPrefixFilter() throws Exception {<a name="line.314"></a>
-<span class="sourceLineNo">315</span>    // Grab rows from group one (half of total)<a name="line.315"></a>
-<span class="sourceLineNo">316</span>    long expectedRows = this.numRows / 2;<a name="line.316"></a>
-<span class="sourceLineNo">317</span>    long expectedKeys = this.colsPerRow;<a name="line.317"></a>
-<span class="sourceLineNo">318</span>    Scan s = new Scan();<a name="line.318"></a>
-<span class="sourceLineNo">319</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.319"></a>
-<span class="sourceLineNo">320</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.320"></a>
-<span class="sourceLineNo">321</span>  }<a name="line.321"></a>
-<span class="sourceLineNo">322</span><a name="line.322"></a>
-<span class="sourceLineNo">323</span>  @Test<a name="line.323"></a>
-<span class="sourceLineNo">324</span>  public void testPrefixFilterWithReverseScan() throws Exception {<a name="line.324"></a>
-<span class="sourceLineNo">325</span>    // Grab rows from group one (half of total)<a name="line.325"></a>
-<span class="sourceLineNo">326</span>    long expectedRows = this.numRows / 2;<a name="line.326"></a>
-<span class="sourceLineNo">327</span>    long expectedKeys = this.colsPerRow;<a name="line.327"></a>
-<span class="sourceLineNo">328</span>    Scan s = new Scan();<a name="line.328"></a>
-<span class="sourceLineNo">329</span>    s.setReversed(true);<a name="line.329"></a>
-<span class="sourceLineNo">330</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.330"></a>
-<span class="sourceLineNo">331</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.331"></a>
-<span class="sourceLineNo">332</span>  }<a name="line.332"></a>
-<span class="sourceLineNo">333</span><a name="line.333"></a>
-<span class="sourceLineNo">334</span>  @Test<a name="line.334"></a>
-<span class="sourceLineNo">335</span>  public void testPageFilter() throws Exception {<a name="line.335"></a>
-<span class="sourceLineNo">336</span><a name="line.336"></a>
-<span class="sourceLineNo">337</span>    // KVs in first 6 rows<a name="line.337"></a>
-<span class="sourceLineNo">338</span>    KeyValue [] expectedKVs = {<a name="line.338"></a>
-<span class="sourceLineNo">339</span>      // testRowOne-0<a name="line.339"></a>
-<span class="sourceLineNo">340</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.340"></a>
-<span class="sourceLineNo">341</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.341"></a>
-<span class="sourceLineNo">342</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.342"></a>
-<span class="sourceLineNo">343</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.343"></a>
-<span class="sourceLineNo">344</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.344"></a>
-<span class="sourceLineNo">345</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.345"></a>
-<span class="sourceLineNo">346</span>      // testRowOne-2<a name="line.346"></a>
-<span class="sourceLineNo">347</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.347"></a>
-<span class="sourceLineNo">348</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.348"></a>
-<span class="sourceLineNo">349</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.349"></a>
-<span class="sourceLineNo">350</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.350"></a>
-<span class="sourceLineNo">351</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.351"></a>
-<span class="sourceLineNo">352</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.352"></a>
-<span class="sourceLineNo">353</span>      // testRowOne-3<a name="line.353"></a>
-<span class="sourceLineNo">354</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.354"></a>
-<span class="sourceLineNo">355</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.355"></a>
-<span class="sourceLineNo">356</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.356"></a>
-<span class="sourceLineNo">357</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.357"></a>
-<span class="sourceLineNo">358</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.358"></a>
-<span class="sourceLineNo">359</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.359"></a>
-<span class="sourceLineNo">360</span>      // testRowTwo-0<a name="line.360"></a>
-<span class="sourceLineNo">361</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.361"></a>
-<span class="sourceLineNo">362</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.362"></a>
-<span class="sourceLineNo">363</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.363"></a>
-<span class="sourceLineNo">364</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.364"></a>
-<span class="sourceLineNo">365</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.365"></a>
-<span class="sourceLineNo">366</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.366"></a>
-<span class="sourceLineNo">367</span>      // testRowTwo-2<a name="line.367"></a>
-<span class="sourceLineNo">368</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.368"></a>
-<span class="sourceLineNo">369</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.369"></a>
-<span class="sourceLineNo">370</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.370"></a>
-<span class="sourceLineNo">371</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.371"></a>
-<span class="sourceLineNo">372</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.372"></a>
-<span class="sourceLineNo">373</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.373"></a>
-<span class="sourceLineNo">374</span>      // testRowTwo-3<a name="line.374"></a>
-<span class="sourceLineNo">375</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.375"></a>
-<span class="sourceLineNo">376</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.376"></a>
-<span class="sourceLineNo">377</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.377"></a>
-<span class="sourceLineNo">378</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.378"></a>
-<span class="sourceLineNo">379</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.379"></a>
-<span class="sourceLineNo">380</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1])<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>    // Grab all 6 rows<a name="line.383"></a>
-<span class="sourceLineNo">384</span>    long expectedRows = 6;<a name="line.384"></a>
-<span class="sourceLineNo">385</span>    long expectedKeys = this.colsPerRow;<a name="line.385"></a>
-<span class="sourceLineNo">386</span>    Scan s = new Scan();<a name="line.386"></a>
-<span class="sourceLineNo">387</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.387"></a>
-<span class="sourceLineNo">388</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.388"></a>
-<span class="sourceLineNo">389</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.389"></a>
-<span class="sourceLineNo">390</span>    verifyScanFull(s, expectedKVs);<a name="line.390"></a>
-<span class="sourceLineNo">391</span><a name="line.391"></a>
-<span class="sourceLineNo">392</span>    // Grab first 4 rows (6 cols per row)<a name="line.392"></a>
-<span class="sourceLineNo">393</span>    expectedRows = 4;<a name="line.393"></a>
-<span class="sourceLineNo">394</span>    expectedKeys = this.colsPerRow;<a name="line.394"></a>
-<span class="sourceLineNo">395</span>    s = new Scan();<a name="line.395"></a>
-<span class="sourceLineNo">396</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.396"></a>
-<span class="sourceLineNo">397</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.397"></a>
-<span class="sourceLineNo">398</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.398"></a>
-<span class="sourceLineNo">399</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 24));<a name="line.399"></a>
-<span class="sourceLineNo">400</span><a name="line.400"></a>
-<span class="sourceLineNo">401</span>    // Grab first 2 rows<a name="line.401"></a>
-<span class="sourceLineNo">402</span>    expectedRows = 2;<a name="line.402"></a>
-<span class="sourceLineNo">403</span>    expectedKeys = this.colsPerRow;<a name="line.403"></a>
-<span class="sourceLineNo">404</span>    s = new Scan();<a name="line.404"></a>
-<span class="sourceLineNo">405</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.405"></a>
-<span class="sourceLineNo">406</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.406"></a>
-<span class="sourceLineNo">407</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.407"></a>
-<span class="sourceLineNo">408</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 12));<a name="line.408"></a>
-<span class="sourceLineNo">409</span><a name="line.409"></a>
-<span class="sourceLineNo">410</span>    // Grab first row<a name="line.410"></a>
-<span class="sourceLineNo">411</span>    expectedRows = 1;<a name="line.411"></a>
-<span class="sourceLineNo">412</span>    expectedKeys = this.colsPerRow;<a name="line.412"></a>
-<span class="sourceLineNo">413</span>    s = new Scan();<a name="line.413"></a>
-<span class="sourceLineNo">414</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.414"></a>
-<span class="sourceLineNo">415</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.415"></a>
-<span class="sourceLineNo">416</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.416"></a>
-<span class="sourceLineNo">417</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 6));<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><a name="line.420"></a>
-<span class="sourceLineNo">421</span>  @Test<a name="line.421"></a>
-<span class="sourceLineNo">422</span>  public void testPageFilterWithReverseScan() throws Exception {<a name="line.422"></a>
-<span class="sourceLineNo">423</span>    // KVs in first 6 rows<a name="line.423"></a>
-<span class="sourceLineNo">424</span>    KeyValue[] expectedKVs = {<a name="line.424"></a>
-<span class="sourceLineNo">425</span>        // testRowOne-0<a name="line.425"></a>
-<span class="sourceLineNo">426</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.426"></a>
-<span class="sourceLineNo">427</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.427"></a>
-<span class="sourceLineNo">428</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.428"></a>
-<span class="sourceLineNo">429</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.429"></a>
-<span class="sourceLineNo">430</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.430"></a>
-<span class="sourceLineNo">431</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.431"></a>
-<span class="sourceLineNo">432</span>        // testRowOne-2<a name="line.432"></a>
-<span class="sourceLineNo">433</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.433"></a>
-<span class="sourceLineNo">434</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.434"></a>
-<span class="sourceLineNo">435</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.435"></a>
-<span class="sourceLineNo">436</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.436"></a>
-<span class="sourceLineNo">437</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.437"></a>
-<span class="sourceLineNo">438</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.438"></a>
-<span class="sourceLineNo">439</span>        // testRowOne-3<a name="line.439"></a>
-<span class="sourceLineNo">440</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.440"></a>
-<span class="sourceLineNo">441</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.441"></a>
-<span class="sourceLineNo">442</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.442"></a>
-<span class="sourceLineNo">443</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.443"></a>
-<span class="sourceLineNo">444</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.444"></a>
-<span class="sourceLineNo">445</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.445"></a>
-<span class="sourceLineNo">446</span>        // testRowTwo-0<a name="line.446"></a>
-<span class="sourceLineNo">447</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.447"></a>
-<span class="sourceLineNo">448</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.448"></a>
-<span class="sourceLineNo">449</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.449"></a>
-<span class="sourceLineNo">450</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.450"></a>
-<span class="sourceLineNo">451</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.451"></a>
-<span class="sourceLineNo">452</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.452"></a>
-<span class="sourceLineNo">453</span>        // testRowTwo-2<a name="line.453"></a>
-<span class="sourceLineNo">454</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.454"></a>
-<span class="sourceLineNo">455</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.455"></a>
-<span class="sourceLineNo">456</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.456"></a>
-<span class="sourceLineNo">457</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.457"></a>
-<span class="sourceLineNo">458</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.458"></a>
-<span class="sourceLineNo">459</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.459"></a>
-<span class="sourceLineNo">460</span>        // testRowTwo-3<a name="line.460"></a>
-<span class="sourceLineNo">461</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.461"></a>
-<span class="sourceLineNo">462</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.462"></a>
-<span class="sourceLineNo">463</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.463"></a>
-<span class="sourceLineNo">464</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.464"></a>
-<span class="sourceLineNo">465</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.465"></a>
-<span class="sourceLineNo">466</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]) };<a name="line.466"></a>
-<span class="sourceLineNo">467</span><a name="line.467"></a>
-<span class="sourceLineNo">468</span>    // Grab all 6 rows<a name="line.468"></a>
-<span class="sourceLineNo">469</span>    long expectedRows = 6;<a name="line.469"></a>
-<span class="sourceLineNo">470</span>    long expectedKeys = this.colsPerRow;<a name="line.470"></a>
-<span class="sourceLineNo">471</span>    Scan s = new Scan();<a name="line.471"></a>
-<span class="sourceLineNo">472</span>    s.setReversed(true);<a name="line.472"></a>
-<span class="sourceLineNo">473</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.473"></a>
-<span class="sourceLineNo">474</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.474"></a>
-<span class="sourceLineNo">475</span><a name="line.475"></a>
-<span class="sourceLineNo">476</span>    // Grab first 4 rows (6 cols per row)<a name="line.476"></a>
-<span class="sourceLineNo">477</span>    expectedRows = 4;<a name="line.477"></a>
-<span class="sourceLineNo">478</span>    expectedKeys = this.colsPerRow;<a name="line.478"></a>
-<span class="sourceLineNo">479</span>    s = new Scan();<a name="line.479"></a>
-<span class="sourceLineNo">480</span>    s.setReversed(true);<a name="line.480"></a>
-<span class="sourceLineNo">481</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.481"></a>
-<span class="sourceLineNo">482</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.482"></a>
-<span class="sourceLineNo">483</span><a name="line.483"></a>
-<span class="sourceLineNo">484</span>    // Grab first 2 rows<a name="line.484"></a>
-<span class="sourceLineNo">485</span>    expectedRows = 2;<a name="line.485"></a>
-<span class="sourceLineNo">486</span>    expectedKeys = this.colsPerRow;<a name="line.486"></a>
-<span class="sourceLineNo">487</span>    s = new Scan();<a name="line.487"></a>
-<span class="sourceLineNo">488</span>    s.setReversed(true);<a name="line.488"></a>
-<span class="sourceLineNo">489</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.489"></a>
-<span class="sourceLineNo">490</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.490"></a>
-<span class="sourceLineNo">491</span><a name="line.491"></a>
-<span class="sourceLineNo">492</span>    // Grab first row<a name="line.492"></a>
-<span class="sourceLineNo">493</span>    expectedRows = 1;<a name="line.493"></a>
-<span class="sourceLineNo">494</span>    expectedKeys = this.colsPerRow;<a name="line.494"></a>
-<span class="sourceLineNo">495</span>    s = new Scan();<a name="line.495"></a>
-<span class="sourceLineNo">496</span>    s.setReversed(true);<a name="line.496"></a>
-<span class="sourceLineNo">497</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.497"></a>
-<span class="sourceLineNo">498</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.498"></a>
-<span class="sourceLineNo">499</span>  }<a name="line.499"></a>
-<span class="sourceLineNo">500</span><a name="line.500"></a>
-<span class="sourceLineNo">501</span>  @Test<a name="line.501"></a>
-<span class="sourceLineNo">502</span>  public void testWhileMatchFilterWithFilterRowWithReverseScan()<a name="line.502"></a>
-<span class="sourceLineNo">503</span>      throws Exception {<a name="line.503"></a>
-<span class="sourceLineNo">504</span>    final int pageSize = 4;<a name="line.504"></a>
-<span class="sourceLineNo">505</span><a name="line.505"></a>
-<span class="sourceLineNo">506</span>    Scan s = new Scan();<a name="line.506"></a>
-<span class="sourceLineNo">507</span>    s.setReversed(true);<a name="line.507"></a>
-<span class="sourceLineNo">508</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.508"></a>
-<span class="sourceLineNo">509</span>    s.setFilter(filter);<a name="line.509"></a>
-<span class="sourceLineNo">510</span><a name="line.510"></a>
-<span class="sourceLineNo">511</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.511"></a>
-<span class="sourceLineNo">512</span>    int scannerCounter = 0;<a name="line.512"></a>
-<span class="sourceLineNo">513</span>    while (true) {<a name="line.513"></a>
-<span class="sourceLineNo">514</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.514"></a>
-<span class="sourceLineNo">515</span>      scannerCounter++;<a name="line.515"></a>
-<span class="sourceLineNo">516</span><a name="line.516"></a>
-<span class="sourceLineNo">517</span>      if (scannerCounter &gt;= pageSize) {<a name="line.517"></a>
-<span class="sourceLineNo">518</span>        Assert.assertTrue(<a name="line.518"></a>
-<span class="sourceLineNo">519</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.519"></a>
-<span class="sourceLineNo">520</span>            filter.filterAllRemaining());<a name="line.520"></a>
-<span class="sourceLineNo">521</span>      }<a name="line.521"></a>
-<span class="sourceLineNo">522</span>      if (!isMoreResults) {<a name="line.522"></a>
-<span class="sourceLineNo">523</span>        break;<a name="line.523"></a>
-<span class="sourceLineNo">524</span>      }<a name="line.524"></a>
-<span class="sourceLineNo">525</span>    }<a name="line.525"></a>
-<span class="sourceLineNo">526</span>    scanner.close();<a name="line.526"></a>
-<span class="sourceLineNo">527</span>    Assert.assertEquals("The page filter returned more rows than expected",<a name="line.527"></a>
-<span class="sourceLineNo">528</span>        pageSize, scannerCounter);<a name="line.528"></a>
-<span class="sourceLineNo">529</span>  }<a name="line.529"></a>
-<span class="sourceLineNo">530</span><a name="line.530"></a>
-<span class="sourceLineNo">531</span>  @Test<a name="line.531"></a>
-<span class="sourceLineNo">532</span>  public void testWhileMatchFilterWithFilterRowKeyWithReverseScan()<a name="line.532"></a>
-<span class="sourceLineNo">533</span>      throws Exception {<a name="line.533"></a>
-<span class="sourceLineNo">534</span>    Scan s = new Scan();<a name="line.534"></a>
-<span class="sourceLineNo">535</span>    String prefix = "testRowOne";<a name="line.535"></a>
-<span class="sourceLineNo">536</span>    WhileMatchFilter filter = new WhileMatchFilter(new PrefixFilter(<a name="line.536"></a>
-<span class="sourceLineNo">537</span>        Bytes.toBytes(prefix)));<a name="line.537"></a>
-<span class="sourceLineNo">538</span>    s.setFilter(filter);<a name="line.538"></a>
-<span class="sourceLineNo">539</span>    s.setReversed(true);<a name="line.539"></a>
-<span class="sourceLineNo">540</span><a name="line.540"></a>
-<span class="sourceLineNo">541</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.541"></a>
-<span class="sourceLineNo">542</span>    while (true) {<a name="line.542"></a>
-<span class="sourceLineNo">543</span>      ArrayList&lt;Cell&gt; values = new ArrayList&lt;&gt;();<a name="line.543"></a>
-<span class="sourceLineNo">544</span>      boolean isMoreResults = scanner.next(values);<a name="line.544"></a>
-<span class="sourceLineNo">545</span>      if (!isMoreResults<a name="line.545"></a>
-<span class="sourceLineNo">546</span>          || !Bytes.toString(CellUtil.cloneRow(values.get(0))).startsWith(prefix)) {<a name="line.546"></a>
-<span class="sourceLineNo">547</span>        Assert.assertTrue(<a name="line.547"></a>
-<span class="sourceLineNo">548</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.548"></a>
-<span class="sourceLineNo">549</span>            filter.filterAllRemaining());<a name="line.549"></a>
-<span class="sourceLineNo">550</span>      }<a name="line.550"></a>
-<span class="sourceLineNo">551</span>      if (!isMoreResults) {<a name="line.551"></a>
-<span class="sourceLineNo">552</span>        break;<a name="line.552"></a>
-<span class="sourceLineNo">553</span>      }<a name="line.553"></a>
-<span class="sourceLineNo">554</span>    }<a name="line.554"></a>
-<span class="sourceLineNo">555</span>    scanner.close();<a name="line.555"></a>
-<span class="sourceLineNo">556</span>  }<a name="line.556"></a>
-<span class="sourceLineNo">557</span><a name="line.557"></a>
-<span class="sourceLineNo">558</span>  /**<a name="line.558"></a>
-<span class="sourceLineNo">559</span>   * Tests the the {@link WhileMatchFilter} works in combination with a<a name="line.559"></a>
-<span class="sourceLineNo">560</span>   * {@link Filter} that uses the<a name="line.560"></a>
-<span class="sourceLineNo">561</span>   * {@link Filter#filterRow()} method.<a name="line.561"></a>
-<span class="sourceLineNo">562</span>   *<a name="line.562"></a>
-<span class="sourceLineNo">563</span>   * See HBASE-2258.<a name="line.563"></a>
-<span class="sourceLineNo">564</span>   *<a name="line.564"></a>
-<span class="sourceLineNo">565</span>   * @throws Exception<a name="line.565"></a>
-<span class="sourceLineNo">566</span>   */<a name="line.566"></a>
-<span class="sourceLineNo">567</span>  @Test<a name="line.567"></a>
-<span class="sourceLineNo">568</span>  public void testWhileMatchFilterWithFilterRow() throws Exception {<a name="line.568"></a>
-<span class="sourceLineNo">569</span>    final int pageSize = 4;<a name="line.569"></a>
-<span class="sourceLineNo">570</span><a name="line.570"></a>
-<span class="sourceLineNo">571</span>    Scan s = new Scan();<a name="line.571"></a>
-<span class="sourceLineNo">572</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.572"></a>
-<span class="sourceLineNo">573</span>    s.setFilter(filter);<a name="line.573"></a>
-<span class="sourceLineNo">574</span><a name="line.574"></a>
-<span class="sourceLineNo">575</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.575"></a>
-<span class="sourceLineNo">576</span>    int scannerCounter = 0;<a name="line.576"></a>
-<span class="sourceLineNo">577</span>    while (true) {<a name="line.577"></a>
-<span class="sourceLineNo">578</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.578"></a>
-<span class="sourceLineNo">579</span>      scannerCounter++;<a name="line.579"></a>
-<span class="sourceLineNo">580</span><a name="line.580"></a>
-<span class="sourceLineNo">581</span>      if (scannerCounter &gt;= pageSize) {<a name="line.581"></a>
-<span class="sourceLineNo">582</span>        assertTrue("The WhileMatchFilter should now filter all remaining", filter.filterAllRemaining());<a name="line.582"></a>
-<span class="sourceLineNo">583</span>      }<a name="line.583"></a>
-<span class="sourceLineNo">584</span>      if (!isMoreResults) {<a name="line.584"></a>
-<span class="sourceLineNo">585</span>        break;<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>    assertEquals("The page filter returned more rows than expected", pageSize, scannerCounter);<a name="line.588"></a>
-<span class="sourceLineNo">589</span>  }<a name="line.589"></a>
-<span class="sourceLineNo">590</span><a name="line.590"></a>
+<span class="sourceLineNo">145</span>    HColumnDescriptor family0 = new HColumnDescriptor(FAMILIES[0]).setVersions(100, 100);<a name="line.145"></a>
+<span class="sourceLineNo">146</span>    htd.addFamily(family0);<a name="line.146"></a>
+<span class="sourceLineNo">147</span>    htd.addFamily(new HColumnDescriptor(FAMILIES[1]));<a name="line.147"></a>
+<span class="sourceLineNo">148</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[0]));<a name="line.148"></a>
+<span class="sourceLineNo">149</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[1]));<a name="line.149"></a>
+<span class="sourceLineNo">150</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[0]));<a name="line.150"></a>
+<span class="sourceLineNo">151</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[1]));<a name="line.151"></a>
+<span class="sourceLineNo">152</span>    HRegionInfo info = new HRegionInfo(htd.getTableName(), null, null, false);<a name="line.152"></a>
+<span class="sourceLineNo">153</span>    this.region = HBaseTestingUtility.createRegionAndWAL(info, TEST_UTIL.getDataTestDir(),<a name="line.153"></a>
+<span class="sourceLineNo">154</span>        TEST_UTIL.getConfiguration(), htd);<a name="line.154"></a>
+<span class="sourceLineNo">155</span><a name="line.155"></a>
+<span class="sourceLineNo">156</span>    // Insert first half<a name="line.156"></a>
+<span class="sourceLineNo">157</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.157"></a>
+<span class="sourceLineNo">158</span>      Put p = new Put(ROW);<a name="line.158"></a>
+<span class="sourceLineNo">159</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.159"></a>
+<span class="sourceLineNo">160</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.160"></a>
+<span class="sourceLineNo">161</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.161"></a>
+<span class="sourceLineNo">162</span>      }<a name="line.162"></a>
+<span class="sourceLineNo">163</span>      this.region.put(p);<a name="line.163"></a>
+<span class="sourceLineNo">164</span>    }<a name="line.164"></a>
+<span class="sourceLineNo">165</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.165"></a>
+<span class="sourceLineNo">166</span>      Put p = new Put(ROW);<a name="line.166"></a>
+<span class="sourceLineNo">167</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.167"></a>
+<span class="sourceLineNo">168</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.168"></a>
+<span class="sourceLineNo">169</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.169"></a>
+<span class="sourceLineNo">170</span>      }<a name="line.170"></a>
+<span class="sourceLineNo">171</span>      this.region.put(p);<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>    // Flush<a name="line.174"></a>
+<span class="sourceLineNo">175</span>    this.region.flush(true);<a name="line.175"></a>
+<span class="sourceLineNo">176</span><a name="line.176"></a>
+<span class="sourceLineNo">177</span>    // Insert second half (reverse families)<a name="line.177"></a>
+<span class="sourceLineNo">178</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.178"></a>
+<span class="sourceLineNo">179</span>      Put p = new Put(ROW);<a name="line.179"></a>
+<span class="sourceLineNo">180</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.180"></a>
+<span class="sourceLineNo">181</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.181"></a>
+<span class="sourceLineNo">182</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.182"></a>
+<span class="sourceLineNo">183</span>      }<a name="line.183"></a>
+<span class="sourceLineNo">184</span>      this.region.put(p);<a name="line.184"></a>
+<span class="sourceLineNo">185</span>    }<a name="line.185"></a>
+<span class="sourceLineNo">186</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.186"></a>
+<span class="sourceLineNo">187</span>      Put p = new Put(ROW);<a name="line.187"></a>
+<span class="sourceLineNo">188</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.188"></a>
+<span class="sourceLineNo">189</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.189"></a>
+<span class="sourceLineNo">190</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.190"></a>
+<span class="sourceLineNo">191</span>      }<a name="line.191"></a>
+<span class="sourceLineNo">192</span>      this.region.put(p);<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>    // Delete the second qualifier from all rows and families<a name="line.195"></a>
+<span class="sourceLineNo">196</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.196"></a>
+<span class="sourceLineNo">197</span>      Delete d = new Delete(ROW);<a name="line.197"></a>
+<span class="sourceLineNo">198</span>      d.addColumns(FAMILIES[0], QUALIFIERS_ONE[1]);<a name="line.198"></a>
+<span class="sourceLineNo">199</span>      d.addColumns(FAMILIES[1], QUALIFIERS_ONE[1]);<a name="line.199"></a>
+<span class="sourceLineNo">200</span>      this.region.delete(d);<a name="line.200"></a>
+<span class="sourceLineNo">201</span>    }<a name="line.201"></a>
+<span class="sourceLineNo">202</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.202"></a>
+<span class="sourceLineNo">203</span>      Delete d = new Delete(ROW);<a name="line.203"></a>
+<span class="sourceLineNo">204</span>      d.addColumns(FAMILIES[0], QUALIFIERS_TWO[1]);<a name="line.204"></a>
+<span class="sourceLineNo">205</span>      d.addColumns(FAMILIES[1], QUALIFIERS_TWO[1]);<a name="line.205"></a>
+<span class="sourceLineNo">206</span>      this.region.delete(d);<a name="line.206"></a>
+<span class="sourceLineNo">207</span>    }<a name="line.207"></a>
+<span class="sourceLineNo">208</span>    colsPerRow -= 2;<a name="line.208"></a>
+<span class="sourceLineNo">209</span><a name="line.209"></a>
+<span class="sourceLineNo">210</span>    // Delete the second rows from both groups, one column at a time<a name="line.210"></a>
+<span class="sourceLineNo">211</span>    for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.211"></a>
+<span class="sourceLineNo">212</span>      Delete d = new Delete(ROWS_ONE[1]);<a name="line.212"></a>
+<span class="sourceLineNo">213</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.213"></a>
+<span class="sourceLineNo">214</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.214"></a>
+<span class="sourceLineNo">215</span>      this.region.delete(d);<a name="line.215"></a>
+<span class="sourceLineNo">216</span>    }<a name="line.216"></a>
+<span class="sourceLineNo">217</span>    for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.217"></a>
+<span class="sourceLineNo">218</span>      Delete d = new Delete(ROWS_TWO[1]);<a name="line.218"></a>
+<span class="sourceLineNo">219</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.219"></a>
+<span class="sourceLineNo">220</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.220"></a>
+<span class="sourceLineNo">221</span>      this.region.delete(d);<a name="line.221"></a>
+<span class="sourceLineNo">222</span>    }<a name="line.222"></a>
+<span class="sourceLineNo">223</span>    numRows -= 2;<a name="line.223"></a>
+<span class="sourceLineNo">224</span>  }<a name="line.224"></a>
+<span class="sourceLineNo">225</span><a name="line.225"></a>
+<span class="sourceLineNo">226</span>  @After<a name="line.226"></a>
+<span class="sourceLineNo">227</span>  public void tearDown() throws Exception {<a name="line.227"></a>
+<span class="sourceLineNo">228</span>    HBaseTestingUtility.closeRegionAndWAL(region);<a name="line.228"></a>
+<span class="sourceLineNo">229</span>  }<a name="line.229"></a>
+<span class="sourceLineNo">230</span><a name="line.230"></a>
+<span class="sourceLineNo">231</span>  @Test<a name="line.231"></a>
+<span class="sourceLineNo">232</span>  public void testRegionScannerReseek() throws Exception {<a name="line.232"></a>
+<span class="sourceLineNo">233</span>    // create new rows and column family to show how reseek works..<a name="line.233"></a>
+<span class="sourceLineNo">234</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.234"></a>
+<span class="sourceLineNo">235</span>      Put p = new Put(ROW);<a name="line.235"></a>
+<span class="sourceLineNo">236</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.236"></a>
+<span class="sourceLineNo">237</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.237"></a>
+<span class="sourceLineNo">238</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.238"></a>
+<span class="sourceLineNo">239</span><a name="line.239"></a>
+<span class="sourceLineNo">240</span>      }<a name="line.240"></a>
+<span class="sourceLineNo">241</span>      this.region.put(p);<a name="line.241"></a>
+<span class="sourceLineNo">242</span>    }<a name="line.242"></a>
+<span class="sourceLineNo">243</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.243"></a>
+<span class="sourceLineNo">244</span>      Put p = new Put(ROW);<a name="line.244"></a>
+<span class="sourceLineNo">245</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.245"></a>
+<span class="sourceLineNo">246</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.246"></a>
+<span class="sourceLineNo">247</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.247"></a>
+<span class="sourceLineNo">248</span>      }<a name="line.248"></a>
+<span class="sourceLineNo">249</span>      this.region.put(p);<a name="line.249"></a>
+<span class="sourceLineNo">250</span>    }<a name="line.250"></a>
+<span class="sourceLineNo">251</span>    // Flush<a name="line.251"></a>
+<span class="sourceLineNo">252</span>    this.region.flush(true);<a name="line.252"></a>
+<span class="sourceLineNo">253</span><a name="line.253"></a>
+<span class="sourceLineNo">254</span>    // Insert second half (reverse families)<a name="line.254"></a>
+<span class="sourceLineNo">255</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.255"></a>
+<span class="sourceLineNo">256</span>      Put p = new Put(ROW);<a name="line.256"></a>
+<span class="sourceLineNo">257</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.257"></a>
+<span class="sourceLineNo">258</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.258"></a>
+<span class="sourceLineNo">259</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.259"></a>
+<span class="sourceLineNo">260</span>      }<a name="line.260"></a>
+<span class="sourceLineNo">261</span>      this.region.put(p);<a name="line.261"></a>
+<span class="sourceLineNo">262</span>    }<a name="line.262"></a>
+<span class="sourceLineNo">263</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.263"></a>
+<span class="sourceLineNo">264</span>      Put p = new Put(ROW);<a name="line.264"></a>
+<span class="sourceLineNo">265</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.265"></a>
+<span class="sourceLineNo">266</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.266"></a>
+<span class="sourceLineNo">267</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.267"></a>
+<span class="sourceLineNo">268</span>      }<a name="line.268"></a>
+<span class="sourceLineNo">269</span>      this.region.put(p);<a name="line.269"></a>
+<span class="sourceLineNo">270</span>    }<a name="line.270"></a>
+<span class="sourceLineNo">271</span><a name="line.271"></a>
+<span class="sourceLineNo">272</span>    Scan s = new Scan();<a name="line.272"></a>
+<span class="sourceLineNo">273</span>    // set a start row<a name="line.273"></a>
+<span class="sourceLineNo">274</span>    s.setStartRow(ROWS_FOUR[1]);<a name="line.274"></a>
+<span class="sourceLineNo">275</span>    RegionScanner scanner = region.getScanner(s);<a name="line.275"></a>
+<span class="sourceLineNo">276</span><a name="line.276"></a>
+<span class="sourceLineNo">277</span>    // reseek to row three.<a name="line.277"></a>
+<span class="sourceLineNo">278</span>    scanner.reseek(ROWS_THREE[1]);<a name="line.278"></a>
+<span class="sourceLineNo">279</span>    List&lt;Cell&gt; results = new ArrayList&lt;&gt;();<a name="line.279"></a>
+<span class="sourceLineNo">280</span><a name="line.280"></a>
+<span class="sourceLineNo">281</span>    // the results should belong to ROWS_THREE[1]<a name="line.281"></a>
+<span class="sourceLineNo">282</span>    scanner.next(results);<a name="line.282"></a>
+<span class="sourceLineNo">283</span>    for (Cell keyValue : results) {<a name="line.283"></a>
+<span class="sourceLineNo">284</span>      assertTrue("The rows with ROWS_TWO as row key should be appearing.",<a name="line.284"></a>
+<span class="sourceLineNo">285</span>          CellUtil.matchingRows(keyValue, ROWS_THREE[1]));<a name="line.285"></a>
+<span class="sourceLineNo">286</span>    }<a name="line.286"></a>
+<span class="sourceLineNo">287</span>    // again try to reseek to a value before ROWS_THREE[1]<a name="line.287"></a>
+<span class="sourceLineNo">288</span>    scanner.reseek(ROWS_ONE[1]);<a name="line.288"></a>
+<span class="sourceLineNo">289</span>    results = new ArrayList&lt;&gt;();<a name="line.289"></a>
+<span class="sourceLineNo">290</span>    // This time no seek would have been done to ROWS_ONE[1]<a name="line.290"></a>
+<span class="sourceLineNo">291</span>    scanner.next(results);<a name="line.291"></a>
+<span class="sourceLineNo">292</span>    for (Cell keyValue : results) {<a name="line.292"></a>
+<span class="sourceLineNo">293</span>      assertFalse("Cannot rewind back to a value less than previous reseek.",<a name="line.293"></a>
+<span class="sourceLineNo">294</span>          Bytes.toString(CellUtil.cloneRow(keyValue)).contains("testRowOne"));<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>  @Test<a name="line.298"></a>
+<span class="sourceLineNo">299</span>  public void testNoFilter() throws Exception {<a name="line.299"></a>
+<span class="sourceLineNo">300</span>    // No filter<a name="line.300"></a>
+<span class="sourceLineNo">301</span>    long expectedRows = this.numRows;<a name="line.301"></a>
+<span class="sourceLineNo">302</span>    long expectedKeys = this.colsPerRow;<a name="line.302"></a>
+<span class="sourceLineNo">303</span><a name="line.303"></a>
+<span class="sourceLineNo">304</span>    // Both families<a name="line.304"></a>
+<span class="sourceLineNo">305</span>    Scan s = new Scan();<a name="line.305"></a>
+<span class="sourceLineNo">306</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.306"></a>
+<span class="sourceLineNo">307</span><a name="line.307"></a>
+<span class="sourceLineNo">308</span>    // One family<a name="line.308"></a>
+<span class="sourceLineNo">309</span>    s = new Scan();<a name="line.309"></a>
+<span class="sourceLineNo">310</span>    s.addFamily(FAMILIES[0]);<a name="line.310"></a>
+<span class="sourceLineNo">311</span>    verifyScan(s, expectedRows, expectedKeys/2);<a name="line.311"></a>
+<span class="sourceLineNo">312</span>  }<a name="line.312"></a>
+<span class="sourceLineNo">313</span><a name="line.313"></a>
+<span class="sourceLineNo">314</span>  @Test<a name="line.314"></a>
+<span class="sourceLineNo">315</span>  public void testPrefixFilter() throws Exception {<a name="line.315"></a>
+<span class="sourceLineNo">316</span>    // Grab rows from group one (half of total)<a name="line.316"></a>
+<span class="sourceLineNo">317</span>    long expectedRows = this.numRows / 2;<a name="line.317"></a>
+<span class="sourceLineNo">318</span>    long expectedKeys = this.colsPerRow;<a name="line.318"></a>
+<span class="sourceLineNo">319</span>    Scan s = new Scan();<a name="line.319"></a>
+<span class="sourceLineNo">320</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.320"></a>
+<span class="sourceLineNo">321</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.321"></a>
+<span class="sourceLineNo">322</span>  }<a name="line.322"></a>
+<span class="sourceLineNo">323</span><a name="line.323"></a>
+<span class="sourceLineNo">324</span>  @Test<a name="line.324"></a>
+<span class="sourceLineNo">325</span>  public void testPrefixFilterWithReverseScan() throws Exception {<a name="line.325"></a>
+<span class="sourceLineNo">326</span>    // Grab rows from group one (half of total)<a name="line.326"></a>
+<span class="sourceLineNo">327</span>    long expectedRows = this.numRows / 2;<a name="line.327"></a>
+<span class="sourceLineNo">328</span>    long expectedKeys = this.colsPerRow;<a name="line.328"></a>
+<span class="sourceLineNo">329</span>    Scan s = new Scan();<a name="line.329"></a>
+<span class="sourceLineNo">330</span>    s.setReversed(true);<a name="line.330"></a>
+<span class="sourceLineNo">331</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.331"></a>
+<span class="sourceLineNo">332</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.332"></a>
+<span class="sourceLineNo">333</span>  }<a name="line.333"></a>
+<span class="sourceLineNo">334</span><a name="line.334"></a>
+<span class="sourceLineNo">335</span>  @Test<a name="line.335"></a>
+<span class="sourceLineNo">336</span>  public void testPageFilter() throws Exception {<a name="line.336"></a>
+<span class="sourceLineNo">337</span><a name="line.337"></a>
+<span class="sourceLineNo">338</span>    // KVs in first 6 rows<a name="line.338"></a>
+<span class="sourceLineNo">339</span>    KeyValue [] expectedKVs = {<a name="line.339"></a>
+<span class="sourceLineNo">340</span>      // testRowOne-0<a name="line.340"></a>
+<span class="sourceLineNo">341</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.341"></a>
+<span class="sourceLineNo">342</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.342"></a>
+<span class="sourceLineNo">343</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.343"></a>
+<span class="sourceLineNo">344</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.344"></a>
+<span class="sourceLineNo">345</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.345"></a>
+<span class="sourceLineNo">346</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.346"></a>
+<span class="sourceLineNo">347</span>      // testRowOne-2<a name="line.347"></a>
+<span class="sourceLineNo">348</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.348"></a>
+<span class="sourceLineNo">349</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.349"></a>
+<span class="sourceLineNo">350</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.350"></a>
+<span class="sourceLineNo">351</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.351"></a>
+<span class="sourceLineNo">352</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.352"></a>
+<span class="sourceLineNo">353</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.353"></a>
+<span class="sourceLineNo">354</span>      // testRowOne-3<a name="line.354"></a>
+<span class="sourceLineNo">355</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.355"></a>
+<span class="sourceLineNo">356</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.356"></a>
+<span class="sourceLineNo">357</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.357"></a>
+<span class="sourceLineNo">358</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.358"></a>
+<span class="sourceLineNo">359</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.359"></a>
+<span class="sourceLineNo">360</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.360"></a>
+<span class="sourceLineNo">361</span>      // testRowTwo-0<a name="line.361"></a>
+<span class="sourceLineNo">362</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.362"></a>
+<span class="sourceLineNo">363</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.363"></a>
+<span class="sourceLineNo">364</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.364"></a>
+<span class="sourceLineNo">365</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.365"></a>
+<span class="sourceLineNo">366</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.366"></a>
+<span class="sourceLineNo">367</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.367"></a>
+<span class="sourceLineNo">368</span>      // testRowTwo-2<a name="line.368"></a>
+<span class="sourceLineNo">369</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.369"></a>
+<span class="sourceLineNo">370</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.370"></a>
+<span class="sourceLineNo">371</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.371"></a>
+<span class="sourceLineNo">372</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.372"></a>
+<span class="sourceLineNo">373</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.373"></a>
+<span class="sourceLineNo">374</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.374"></a>
+<span class="sourceLineNo">375</span>      // testRowTwo-3<a name="line.375"></a>
+<span class="sourceLineNo">376</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.376"></a>
+<span class="sourceLineNo">377</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.377"></a>
+<span class="sourceLineNo">378</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.378"></a>
+<span class="sourceLineNo">379</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.379"></a>
+<span class="sourceLineNo">380</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.380"></a>
+<span class="sourceLineNo">381</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1])<a name="line.381"></a>
+<span class="sourceLineNo">382</span>    };<a name="line.382"></a>
+<span class="sourceLineNo">383</span><a name="line.383"></a>
+<span class="sourceLineNo">384</span>    // Grab all 6 rows<a name="line.384"></a>
+<span class="sourceLineNo">385</span>    long expectedRows = 6;<a name="line.385"></a>
+<span class="sourceLineNo">386</span>    long expectedKeys = this.colsPerRow;<a name="line.386"></a>
+<span class="sourceLineNo">387</span>    Scan s = new Scan();<a name="line.387"></a>
+<span class="sourceLineNo">388</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.388"></a>
+<span class="sourceLineNo">389</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.389"></a>
+<span class="sourceLineNo">390</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.390"></a>
+<span class="sourceLineNo">391</span>    verifyScanFull(s, expectedKVs);<a name="line.391"></a>
+<span class="sourceLineNo">392</span><a name="line.392"></a>
+<span class="sourceLineNo">393</span>    // Grab first 4 rows (6 cols per row)<a name="line.393"></a>
+<span class="sourceLineNo">394</span>    expectedRows = 4;<a name="line.394"></a>
+<span class="sourceLineNo">395</span>    expectedKeys = this.colsPerRow;<a name="line.395"></a>
+<span class="sourceLineNo">396</span>    s = new Scan();<a name="line.396"></a>
+<span class="sourceLineNo">397</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.397"></a>
+<span class="sourceLineNo">398</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.398"></a>
+<span class="sourceLineNo">399</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.399"></a>
+<span class="sourceLineNo">400</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 24));<a name="line.400"></a>
+<span class="sourceLineNo">401</span><a name="line.401"></a>
+<span class="sourceLineNo">402</span>    // Grab first 2 rows<a name="line.402"></a>
+<span class="sourceLineNo">403</span>    expectedRows = 2;<a name="line.403"></a>
+<span class="sourceLineNo">404</span>    expectedKeys = this.colsPerRow;<a name="line.404"></a>
+<span class="sourceLineNo">405</span>    s = new Scan();<a name="line.405"></a>
+<span class="sourceLineNo">406</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.406"></a>
+<span class="sourceLineNo">407</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.407"></a>
+<span class="sourceLineNo">408</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.408"></a>
+<span class="sourceLineNo">409</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 12));<a name="line.409"></a>
+<span class="sourceLineNo">410</span><a name="line.410"></a>
+<span class="sourceLineNo">411</span>    // Grab first row<a name="line.411"></a>
+<span class="sourceLineNo">412</span>    expectedRows = 1;<a name="line.412"></a>
+<span class="sourceLineNo">413</span>    expectedKeys = this.colsPerRow;<a name="line.413"></a>
+<span class="sourceLineNo">414</span>    s = new Scan();<a name="line.414"></a>
+<span class="sourceLineNo">415</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.415"></a>
+<span class="sourceLineNo">416</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.416"></a>
+<span class="sourceLineNo">417</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.417"></a>
+<span class="sourceLineNo">418</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 6));<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><a name="line.421"></a>
+<span class="sourceLineNo">422</span>  @Test<a name="line.422"></a>
+<span class="sourceLineNo">423</span>  public void testPageFilterWithReverseScan() throws Exception {<a name="line.423"></a>
+<span class="sourceLineNo">424</span>    // KVs in first 6 rows<a name="line.424"></a>
+<span class="sourceLineNo">425</span>    KeyValue[] expectedKVs = {<a name="line.425"></a>
+<span class="sourceLineNo">426</span>        // testRowOne-0<a name="line.426"></a>
+<span class="sourceLineNo">427</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.427"></a>
+<span class="sourceLineNo">428</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.428"></a>
+<span class="sourceLineNo">429</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.429"></a>
+<span class="sourceLineNo">430</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.430"></a>
+<span class="sourceLineNo">431</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.431"></a>
+<span class="sourceLineNo">432</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.432"></a>
+<span class="sourceLineNo">433</span>        // testRowOne-2<a name="line.433"></a>
+<span class="sourceLineNo">434</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.434"></a>
+<span class="sourceLineNo">435</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.435"></a>
+<span class="sourceLineNo">436</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.436"></a>
+<span class="sourceLineNo">437</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.437"></a>
+<span class="sourceLineNo">438</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.438"></a>
+<span class="sourceLineNo">439</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.439"></a>
+<span class="sourceLineNo">440</span>        // testRowOne-3<a name="line.440"></a>
+<span class="sourceLineNo">441</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.441"></a>
+<span class="sourceLineNo">442</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.442"></a>
+<span class="sourceLineNo">443</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.443"></a>
+<span class="sourceLineNo">444</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.444"></a>
+<span class="sourceLineNo">445</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.445"></a>
+<span class="sourceLineNo">446</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.446"></a>
+<span class="sourceLineNo">447</span>        // testRowTwo-0<a name="line.447"></a>
+<span class="sourceLineNo">448</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.448"></a>
+<span class="sourceLineNo">449</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.449"></a>
+<span class="sourceLineNo">450</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.450"></a>
+<span class="sourceLineNo">451</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.451"></a>
+<span class="sourceLineNo">452</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.452"></a>
+<span class="sourceLineNo">453</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.453"></a>
+<span class="sourceLineNo">454</span>        // testRowTwo-2<a name="line.454"></a>
+<span class="sourceLineNo">455</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.455"></a>
+<span class="sourceLineNo">456</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.456"></a>
+<span class="sourceLineNo">457</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.457"></a>
+<span class="sourceLineNo">458</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.458"></a>
+<span class="sourceLineNo">459</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.459"></a>
+<span class="sourceLineNo">460</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.460"></a>
+<span class="sourceLineNo">461</span>        // testRowTwo-3<a name="line.461"></a>
+<span class="sourceLineNo">462</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.462"></a>
+<span class="sourceLineNo">463</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.463"></a>
+<span class="sourceLineNo">464</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.464"></a>
+<span class="sourceLineNo">465</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.465"></a>
+<span class="sourceLineNo">466</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.466"></a>
+<span class="sourceLineNo">467</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]) };<a name="line.467"></a>
+<span class="sourceLineNo">468</span><a name="line.468"></a>
+<span class="sourceLineNo">469</span>    // Grab all 6 rows<a name="line.469"></a>
+<span class="sourceLineNo">470</span>    long expectedRows = 6;<a name="line.470"></a>
+<span class="sourceLineNo">471</span>    long expectedKeys = this.colsPerRow;<a name="line.471"></a>
+<span class="sourceLineNo">472</span>    Scan s = new Scan();<a name="line.472"></a>
+<span class="sourceLineNo">473</span>    s.setReversed(true);<a name="line.473"></a>
+<span class="sourceLineNo">474</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.474"></a>
+<span class="sourceLineNo">475</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.475"></a>
+<span class="sourceLineNo">476</span><a name="line.476"></a>
+<span class="sourceLineNo">477</span>    // Grab first 4 rows (6 cols per row)<a name="line.477"></a>
+<span class="sourceLineNo">478</span>    expectedRows = 4;<a name="line.478"></a>
+<span class="sourceLineNo">479</span>    expectedKeys = this.colsPerRow;<a name="line.479"></a>
+<span class="sourceLineNo">480</span>    s = new Scan();<a name="line.480"></a>
+<span class="sourceLineNo">481</span>    s.setReversed(true);<a name="line.481"></a>
+<span class="sourceLineNo">482</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.482"></a>
+<span class="sourceLineNo">483</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.483"></a>
+<span class="sourceLineNo">484</span><a name="line.484"></a>
+<span class="sourceLineNo">485</span>    // Grab first 2 rows<a name="line.485"></a>
+<span class="sourceLineNo">486</span>    expectedRows = 2;<a name="line.486"></a>
+<span class="sourceLineNo">487</span>    expectedKeys = this.colsPerRow;<a name="line.487"></a>
+<span class="sourceLineNo">488</span>    s = new Scan();<a name="line.488"></a>
+<span class="sourceLineNo">489</span>    s.setReversed(true);<a name="line.489"></a>
+<span class="sourceLineNo">490</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.490"></a>
+<span class="sourceLineNo">491</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.491"></a>
+<span class="sourceLineNo">492</span><a name="line.492"></a>
+<span class="sourceLineNo">493</span>    // Grab first row<a name="line.493"></a>
+<span class="sourceLineNo">494</span>    expectedRows = 1;<a name="line.494"></a>
+<span class="sourceLineNo">495</span>    expectedKeys = this.colsPerRow;<a name="line.495"></a>
+<span class="sourceLineNo">496</span>    s = new Scan();<a name="line.496"></a>
+<span class="sourceLineNo">497</span>    s.setReversed(true);<a name="line.497"></a>
+<span class="sourceLineNo">498</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.498"></a>
+<span class="sourceLineNo">499</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.499"></a>
+<span class="sourceLineNo">500</span>  }<a name="line.500"></a>
+<span class="sourceLineNo">501</span><a name="line.501"></a>
+<span class="sourceLineNo">502</span>  @Test<a name="line.502"></a>
+<span class="sourceLineNo">503</span>  public void testWhileMatchFilterWithFilterRowWithReverseScan()<a name="line.503"></a>
+<span class="sourceLineNo">504</span>      throws Exception {<a name="line.504"></a>
+<span class="sourceLineNo">505</span>    final int pageSize = 4;<a name="line.505"></a>
+<span class="sourceLineNo">506</span><a name="line.506"></a>
+<span class="sourceLineNo">507</span>    Scan s = new Scan();<a name="line.507"></a>
+<span class="sourceLineNo">508</span>    s.setReversed(true);<a name="line.508"></a>
+<span class="sourceLineNo">509</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.509"></a>
+<span class="sourceLineNo">510</span>    s.setFilter(filter);<a name="line.510"></a>
+<span class="sourceLineNo">511</span><a name="line.511"></a>
+<span class="sourceLineNo">512</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.512"></a>
+<span class="sourceLineNo">513</span>    int scannerCounter = 0;<a name="line.513"></a>
+<span class="sourceLineNo">514</span>    while (true) {<a name="line.514"></a>
+<span class="sourceLineNo">515</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.515"></a>
+<span class="sourceLineNo">516</span>      scannerCounter++;<a name="line.516"></a>
+<span class="sourceLineNo">517</span><a name="line.517"></a>
+<span class="sourceLineNo">518</span>      if (scannerCounter &gt;= pageSize) {<a name="line.518"></a>
+<span class="sourceLineNo">519</span>        Assert.assertTrue(<a name="line.519"></a>
+<span class="sourceLineNo">520</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.520"></a>
+<span class="sourceLineNo">521</span>            filter.filterAllRemaining());<a name="line.521"></a>
+<span class="sourceLineNo">522</span>      }<a name="line.522"></a>
+<span class="sourceLineNo">523</span>      if (!isMoreResults) {<a name="line.523"></a>
+<span class="sourceLineNo">524</span>        break;<a name="line.524"></a>
+<span class="sourceLineNo">525</span>      }<a name="line.525"></a>
+<span class="sourceLineNo">526</span>    }<a name="line.526"></a>
+<span class="sourceLineNo">527</span>    scanner.close();<a name="line.527"></a>
+<span class="sourceLineNo">528</span>    Assert.assertEquals("The page filter returned more rows than expected",<a name="line.528"></a>
+<span class="sourceLineNo">529</span>        pageSize, scannerCounter);<a name="line.529"></a>
+<span class="sourceLineNo">530</span>  }<a name="line.530"></a>
+<span class="sourceLineNo">531</span><a name="line.531"></a>
+<span class="sourceLineNo">532</span>  @Test<a name="line.532"></a>
+<span class="sourceLineNo">533</span>  public void testWhileMatchFilterWithFilterRowKeyWithReverseScan()<a name="line.533"></a>
+<span class="sourceLineNo">534</span>      throws Exception {<a name="line.534"></a>
+<span class="sourceLineNo">535</span>    Scan s = new Scan();<a name="line.535"></a>
+<span class="sourceLineNo">536</span>    String prefix = "testRowOne";<a name="line.536"></a>
+<span class="sourceLineNo">537</span>    WhileMatchFilter filter = new WhileMatchFilter(new PrefixFilter(<a name="line.537"></a>
+<span class="sourceLineNo">538</span>        Bytes.toBytes(prefix)));<a name="line.538"></a>
+<span class="sourceLineNo">539</span>    s.setFilter(filter);<a name="line.539"></a>
+<span class="sourceLineNo">540</span>    s.setReversed(true);<a name="line.540"></a>
+<span class="sourceLineNo">541</span><a name="line.541"></a>
+<span class="sourceLineNo">542</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.542"></a>
+<span class="sourceLineNo">543</span>    while (true) {<a name="line.543"></a>
+<span class="sourceLineNo">544</span>      ArrayList&lt;Cell&gt; values = new ArrayList&lt;&gt;();<a name="line.544"></a>
+<span class="sourceLineNo">545</span>      boolean isMoreResults = scanner.next(values);<a name="line.545"></a>
+<span class="sourceLineNo">546</span>      if (!isMoreResults<a name="line.546"></a>
+<span class="sourceLineNo">547</span>          || !Bytes.toString(CellUtil.cloneRow(values.get(0))).startsWith(prefix)) {<a name="line.547"></a>
+<span class="sourceLineNo">548</span>        Assert.assertTrue(<a name="line.548"></a>
+<span class="sourceLineNo">549</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.549"></a>
+<span class="sourceLineNo">550</span>            filter.filterAllRemaining());<a name="line.550"></a>
+<span class="sourceLineNo">551</span>      }<a name="line.551"></a>
+<span class="sourceLineNo">552</span>      if (!isMoreResults) {<a name="line.552"></a>
+<span class="sourceLineNo">553</span>        break;<a name="line.553"></a>
+<span class="sourceLineNo">554</span>      }<a name="line.554"></a>
+<span class="sourceLineNo">555</span>    }<a name="line.555"></a>
+<span class="sourceLineNo">556</span>    scanner.close();<a name="line.556"></a>
+<span class="sourceLineNo">557</span>  }<a name="line.557"></a>
+<span class="sourceLineNo">558</span><a name="line.558"></a>
+<span class="sourceLineNo">559</span>  /**<a name="line.559"></a>
+<span class="sourceLineNo">560</span>   * Tests the the {@link WhileMatchFilter} works in combination with a<a name="line.560"></a>
+<span class="sourceLineNo">561</span>   * {@link Filter} that uses the<a name="line.561"></a>
+<span class="sourceLineNo">562</span>   * {@link Filter#filterRow()} method.<a name="line.562"></a>
+<span class="sourceLineNo">563</span>   *<a name="line.563"></a>
+<span class="sourceLineNo">564</span>   * See HBASE-2258.<a name="line.564"></a>
+<span class="sourceLineNo">565</span>   *<a name="line.565"></a>
+<span class="sourceLineNo">566</span>   * @throws Exception<a name="line.566"></a>
+<span class="sourceLineNo">567</span>   */<a name="line.567"></a>
+<span class="sourceLineNo">568</span>  @Test<a name="line.568"></a>
+<span class="sourceLineNo">569</span>  public void testWhileMatchFilterWithFilterRow() throws Exception {<a name="line.569"></a>
+<span class="sourceLineNo">570</span>    final int pageSize = 4;<a name="line.570"></a>
+<span class="sourceLineNo">571</span><a name="line.571"></a>
+<span class="sourceLineNo">572</span>    Scan s = new Scan();<a name="line.572"></a>
+<span class="sourceLineNo">573</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.573"></a>
+<span class="sourceLineNo">574</span>    s.setFilter(filter);<a name="line.574"></a>
+<span class="sourceLineNo">575</span><a name="line.575"></a>
+<span class="sourceLineNo">576</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.576"></a>
+<span class="sourceLineNo">577</span>    int scannerCounter = 0;<a name="line.577"></a>
+<span class="sourceLineNo">578</span>    while (true) {<a name="line.578"></a>
+<span class="sourceLineNo">579</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.579"></a>
+<span class="sourceLineNo">580</span>      scannerCounter++;<a name="line.580"></a>
+<span class="sourceLineNo">581</span><a name="line.581"></a>
+<span class="sourceLineNo">582</span>      if (scannerCounter &gt;= pageSize) {<a name="line.582"></a>
+<span class="sourceLineNo">583</span>        assertTrue("The WhileMatchFilter should now filter all remaining", filter.filterAllRemaining());<a name="line.583"></a>
+<span class="sourceLineNo">584</span>      }<a name="line.584"></a>
+<span class="sourceLineNo">585</span>      if (!isMoreResults) {<a name="line.585"></a>
+<span class="sourceLineNo">586</span>        break;<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>    assertEquals("The page filter returned more rows than expected", pageSize, scannerCounter);<a name="line.589"></a>
+<span class="sourceLineNo">590</span>  }<a name="line.590"></a>
 <span class="sourceLineNo">591</span><a name="line.591"></a>
-<span class="sourceLineNo">592</span>  /**<a name="line.592"></a>
-<span class="sourceLineNo">593</span>   * The following filter simulates a pre-0.96 filter where filterRow() is d

<TRUNCATED>

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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-convergence.html b/hbase-build-configuration/dependency-convergence.html
index a912fb2..f122fa5 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-info.html b/hbase-build-configuration/dependency-info.html
index c589191..cbec597 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-management.html b/hbase-build-configuration/dependency-management.html
index 0db3bb8..42f79f4 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 af0e44e..ceced43 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 4caef0e..0e3ea71 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 0546b77..465e00e 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 1a4c19b..bac5863 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 5492767..8ff6b13 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 a9d4ea4..1ea4cb6 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 1ebde33..e631746 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 210805c..0a5047e 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 21055c2..3de874a 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 f10ecd6..f952b1b 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 49bd916..4247b26 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 a63295e..542f4b9 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 43997c5..1a454eb 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 941a7e8..d28d4d1 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 617cd50..75889a6 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -218,7 +218,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 0a7a28f..72890c7 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 273288d..49699e9 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 2cfb73f..cb26ef9 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 4b4c0be..71f6671 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 47313ee..94d4c7b 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 31dccb2..fed6541 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -4168,7 +4168,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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 576fcaf..166d416 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 30ba2ed..74686de 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 8570aa4..24ea4ce 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 d9a2f45..4e5a07f 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 3ee01b1..84defed 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 9f90a97..573d0a7 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 3b0d862..24d7270 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 1198d29..a4ee5be 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 3399357..8073b4a 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 082c942..b4d414c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 3a81411..c12a35a 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 cb31509..51bcdd4 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 1996877..681ed90 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 632c024..8ad1c74 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 bb6da40..2d631dc 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 61c71d3..333e673 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 30c748e..9f22364 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -4193,7 +4193,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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 6917192..9ae25bc 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 c9fe481..f86aaa3 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 d905ab8..e1b3641 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 963da86..956de1f 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 9951c94..0b92b1c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 2c05213..9f768ee 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 728f290..2a2083c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 162f043..2322099 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 3f46b58..c3c4fa3 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 fc37c38..bc01feb 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 e152842..7a10217 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 899c5a2..9e5ffda 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 4d32461..ea88a6c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 6e2a8a6..1d8fcad 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 99dfe51..990ff6b 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 c8b28c5..8a5fabd 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 ab38b6b..265bfed 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 c6c21f9..0bb306b 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 0a507eb..f34f0d9 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html
index a6c7150..e93a01d 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html
@@ -150,2012 +150,2072 @@
 <span class="sourceLineNo">142</span>  @Before<a name="line.142"></a>
 <span class="sourceLineNo">143</span>  public void setUp() throws Exception {<a name="line.143"></a>
 <span class="sourceLineNo">144</span>    HTableDescriptor htd = new HTableDescriptor(TableName.valueOf("TestFilter"));<a name="line.144"></a>
-<span class="sourceLineNo">145</span>    htd.addFamily(new HColumnDescriptor(FAMILIES[0]));<a name="line.145"></a>
-<span class="sourceLineNo">146</span>    htd.addFamily(new HColumnDescriptor(FAMILIES[1]));<a name="line.146"></a>
-<span class="sourceLineNo">147</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[0]));<a name="line.147"></a>
-<span class="sourceLineNo">148</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[1]));<a name="line.148"></a>
-<span class="sourceLineNo">149</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[0]));<a name="line.149"></a>
-<span class="sourceLineNo">150</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[1]));<a name="line.150"></a>
-<span class="sourceLineNo">151</span>    HRegionInfo info = new HRegionInfo(htd.getTableName(), null, null, false);<a name="line.151"></a>
-<span class="sourceLineNo">152</span>    this.region = HBaseTestingUtility.createRegionAndWAL(info, TEST_UTIL.getDataTestDir(),<a name="line.152"></a>
-<span class="sourceLineNo">153</span>        TEST_UTIL.getConfiguration(), htd);<a name="line.153"></a>
-<span class="sourceLineNo">154</span><a name="line.154"></a>
-<span class="sourceLineNo">155</span>    // Insert first half<a name="line.155"></a>
-<span class="sourceLineNo">156</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.156"></a>
-<span class="sourceLineNo">157</span>      Put p = new Put(ROW);<a name="line.157"></a>
-<span class="sourceLineNo">158</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.158"></a>
-<span class="sourceLineNo">159</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.159"></a>
-<span class="sourceLineNo">160</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.160"></a>
-<span class="sourceLineNo">161</span>      }<a name="line.161"></a>
-<span class="sourceLineNo">162</span>      this.region.put(p);<a name="line.162"></a>
-<span class="sourceLineNo">163</span>    }<a name="line.163"></a>
-<span class="sourceLineNo">164</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.164"></a>
-<span class="sourceLineNo">165</span>      Put p = new Put(ROW);<a name="line.165"></a>
-<span class="sourceLineNo">166</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.166"></a>
-<span class="sourceLineNo">167</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.167"></a>
-<span class="sourceLineNo">168</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.168"></a>
-<span class="sourceLineNo">169</span>      }<a name="line.169"></a>
-<span class="sourceLineNo">170</span>      this.region.put(p);<a name="line.170"></a>
-<span class="sourceLineNo">171</span>    }<a name="line.171"></a>
-<span class="sourceLineNo">172</span><a name="line.172"></a>
-<span class="sourceLineNo">173</span>    // Flush<a name="line.173"></a>
-<span class="sourceLineNo">174</span>    this.region.flush(true);<a name="line.174"></a>
-<span class="sourceLineNo">175</span><a name="line.175"></a>
-<span class="sourceLineNo">176</span>    // Insert second half (reverse families)<a name="line.176"></a>
-<span class="sourceLineNo">177</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.177"></a>
-<span class="sourceLineNo">178</span>      Put p = new Put(ROW);<a name="line.178"></a>
-<span class="sourceLineNo">179</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.179"></a>
-<span class="sourceLineNo">180</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.180"></a>
-<span class="sourceLineNo">181</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.181"></a>
-<span class="sourceLineNo">182</span>      }<a name="line.182"></a>
-<span class="sourceLineNo">183</span>      this.region.put(p);<a name="line.183"></a>
-<span class="sourceLineNo">184</span>    }<a name="line.184"></a>
-<span class="sourceLineNo">185</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.185"></a>
-<span class="sourceLineNo">186</span>      Put p = new Put(ROW);<a name="line.186"></a>
-<span class="sourceLineNo">187</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.187"></a>
-<span class="sourceLineNo">188</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.188"></a>
-<span class="sourceLineNo">189</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.189"></a>
-<span class="sourceLineNo">190</span>      }<a name="line.190"></a>
-<span class="sourceLineNo">191</span>      this.region.put(p);<a name="line.191"></a>
-<span class="sourceLineNo">192</span>    }<a name="line.192"></a>
-<span class="sourceLineNo">193</span><a name="line.193"></a>
-<span class="sourceLineNo">194</span>    // Delete the second qualifier from all rows and families<a name="line.194"></a>
-<span class="sourceLineNo">195</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.195"></a>
-<span class="sourceLineNo">196</span>      Delete d = new Delete(ROW);<a name="line.196"></a>
-<span class="sourceLineNo">197</span>      d.addColumns(FAMILIES[0], QUALIFIERS_ONE[1]);<a name="line.197"></a>
-<span class="sourceLineNo">198</span>      d.addColumns(FAMILIES[1], QUALIFIERS_ONE[1]);<a name="line.198"></a>
-<span class="sourceLineNo">199</span>      this.region.delete(d);<a name="line.199"></a>
-<span class="sourceLineNo">200</span>    }<a name="line.200"></a>
-<span class="sourceLineNo">201</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.201"></a>
-<span class="sourceLineNo">202</span>      Delete d = new Delete(ROW);<a name="line.202"></a>
-<span class="sourceLineNo">203</span>      d.addColumns(FAMILIES[0], QUALIFIERS_TWO[1]);<a name="line.203"></a>
-<span class="sourceLineNo">204</span>      d.addColumns(FAMILIES[1], QUALIFIERS_TWO[1]);<a name="line.204"></a>
-<span class="sourceLineNo">205</span>      this.region.delete(d);<a name="line.205"></a>
-<span class="sourceLineNo">206</span>    }<a name="line.206"></a>
-<span class="sourceLineNo">207</span>    colsPerRow -= 2;<a name="line.207"></a>
-<span class="sourceLineNo">208</span><a name="line.208"></a>
-<span class="sourceLineNo">209</span>    // Delete the second rows from both groups, one column at a time<a name="line.209"></a>
-<span class="sourceLineNo">210</span>    for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.210"></a>
-<span class="sourceLineNo">211</span>      Delete d = new Delete(ROWS_ONE[1]);<a name="line.211"></a>
-<span class="sourceLineNo">212</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.212"></a>
-<span class="sourceLineNo">213</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.213"></a>
-<span class="sourceLineNo">214</span>      this.region.delete(d);<a name="line.214"></a>
-<span class="sourceLineNo">215</span>    }<a name="line.215"></a>
-<span class="sourceLineNo">216</span>    for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.216"></a>
-<span class="sourceLineNo">217</span>      Delete d = new Delete(ROWS_TWO[1]);<a name="line.217"></a>
-<span class="sourceLineNo">218</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.218"></a>
-<span class="sourceLineNo">219</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.219"></a>
-<span class="sourceLineNo">220</span>      this.region.delete(d);<a name="line.220"></a>
-<span class="sourceLineNo">221</span>    }<a name="line.221"></a>
-<span class="sourceLineNo">222</span>    numRows -= 2;<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>  @After<a name="line.225"></a>
-<span class="sourceLineNo">226</span>  public void tearDown() throws Exception {<a name="line.226"></a>
-<span class="sourceLineNo">227</span>    HBaseTestingUtility.closeRegionAndWAL(region);<a name="line.227"></a>
-<span class="sourceLineNo">228</span>  }<a name="line.228"></a>
-<span class="sourceLineNo">229</span><a name="line.229"></a>
-<span class="sourceLineNo">230</span>  @Test<a name="line.230"></a>
-<span class="sourceLineNo">231</span>  public void testRegionScannerReseek() throws Exception {<a name="line.231"></a>
-<span class="sourceLineNo">232</span>    // create new rows and column family to show how reseek works..<a name="line.232"></a>
-<span class="sourceLineNo">233</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.233"></a>
-<span class="sourceLineNo">234</span>      Put p = new Put(ROW);<a name="line.234"></a>
-<span class="sourceLineNo">235</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.235"></a>
-<span class="sourceLineNo">236</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.236"></a>
-<span class="sourceLineNo">237</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.237"></a>
-<span class="sourceLineNo">238</span><a name="line.238"></a>
-<span class="sourceLineNo">239</span>      }<a name="line.239"></a>
-<span class="sourceLineNo">240</span>      this.region.put(p);<a name="line.240"></a>
-<span class="sourceLineNo">241</span>    }<a name="line.241"></a>
-<span class="sourceLineNo">242</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.242"></a>
-<span class="sourceLineNo">243</span>      Put p = new Put(ROW);<a name="line.243"></a>
-<span class="sourceLineNo">244</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.244"></a>
-<span class="sourceLineNo">245</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.245"></a>
-<span class="sourceLineNo">246</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.246"></a>
-<span class="sourceLineNo">247</span>      }<a name="line.247"></a>
-<span class="sourceLineNo">248</span>      this.region.put(p);<a name="line.248"></a>
-<span class="sourceLineNo">249</span>    }<a name="line.249"></a>
-<span class="sourceLineNo">250</span>    // Flush<a name="line.250"></a>
-<span class="sourceLineNo">251</span>    this.region.flush(true);<a name="line.251"></a>
-<span class="sourceLineNo">252</span><a name="line.252"></a>
-<span class="sourceLineNo">253</span>    // Insert second half (reverse families)<a name="line.253"></a>
-<span class="sourceLineNo">254</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.254"></a>
-<span class="sourceLineNo">255</span>      Put p = new Put(ROW);<a name="line.255"></a>
-<span class="sourceLineNo">256</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.256"></a>
-<span class="sourceLineNo">257</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.257"></a>
-<span class="sourceLineNo">258</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.258"></a>
-<span class="sourceLineNo">259</span>      }<a name="line.259"></a>
-<span class="sourceLineNo">260</span>      this.region.put(p);<a name="line.260"></a>
-<span class="sourceLineNo">261</span>    }<a name="line.261"></a>
-<span class="sourceLineNo">262</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.262"></a>
-<span class="sourceLineNo">263</span>      Put p = new Put(ROW);<a name="line.263"></a>
-<span class="sourceLineNo">264</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.264"></a>
-<span class="sourceLineNo">265</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.265"></a>
-<span class="sourceLineNo">266</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.266"></a>
-<span class="sourceLineNo">267</span>      }<a name="line.267"></a>
-<span class="sourceLineNo">268</span>      this.region.put(p);<a name="line.268"></a>
-<span class="sourceLineNo">269</span>    }<a name="line.269"></a>
-<span class="sourceLineNo">270</span><a name="line.270"></a>
-<span class="sourceLineNo">271</span>    Scan s = new Scan();<a name="line.271"></a>
-<span class="sourceLineNo">272</span>    // set a start row<a name="line.272"></a>
-<span class="sourceLineNo">273</span>    s.setStartRow(ROWS_FOUR[1]);<a name="line.273"></a>
-<span class="sourceLineNo">274</span>    RegionScanner scanner = region.getScanner(s);<a name="line.274"></a>
-<span class="sourceLineNo">275</span><a name="line.275"></a>
-<span class="sourceLineNo">276</span>    // reseek to row three.<a name="line.276"></a>
-<span class="sourceLineNo">277</span>    scanner.reseek(ROWS_THREE[1]);<a name="line.277"></a>
-<span class="sourceLineNo">278</span>    List&lt;Cell&gt; results = new ArrayList&lt;&gt;();<a name="line.278"></a>
-<span class="sourceLineNo">279</span><a name="line.279"></a>
-<span class="sourceLineNo">280</span>    // the results should belong to ROWS_THREE[1]<a name="line.280"></a>
-<span class="sourceLineNo">281</span>    scanner.next(results);<a name="line.281"></a>
-<span class="sourceLineNo">282</span>    for (Cell keyValue : results) {<a name="line.282"></a>
-<span class="sourceLineNo">283</span>      assertTrue("The rows with ROWS_TWO as row key should be appearing.",<a name="line.283"></a>
-<span class="sourceLineNo">284</span>          CellUtil.matchingRows(keyValue, ROWS_THREE[1]));<a name="line.284"></a>
-<span class="sourceLineNo">285</span>    }<a name="line.285"></a>
-<span class="sourceLineNo">286</span>    // again try to reseek to a value before ROWS_THREE[1]<a name="line.286"></a>
-<span class="sourceLineNo">287</span>    scanner.reseek(ROWS_ONE[1]);<a name="line.287"></a>
-<span class="sourceLineNo">288</span>    results = new ArrayList&lt;&gt;();<a name="line.288"></a>
-<span class="sourceLineNo">289</span>    // This time no seek would have been done to ROWS_ONE[1]<a name="line.289"></a>
-<span class="sourceLineNo">290</span>    scanner.next(results);<a name="line.290"></a>
-<span class="sourceLineNo">291</span>    for (Cell keyValue : results) {<a name="line.291"></a>
-<span class="sourceLineNo">292</span>      assertFalse("Cannot rewind back to a value less than previous reseek.",<a name="line.292"></a>
-<span class="sourceLineNo">293</span>          Bytes.toString(CellUtil.cloneRow(keyValue)).contains("testRowOne"));<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>  @Test<a name="line.297"></a>
-<span class="sourceLineNo">298</span>  public void testNoFilter() throws Exception {<a name="line.298"></a>
-<span class="sourceLineNo">299</span>    // No filter<a name="line.299"></a>
-<span class="sourceLineNo">300</span>    long expectedRows = this.numRows;<a name="line.300"></a>
-<span class="sourceLineNo">301</span>    long expectedKeys = this.colsPerRow;<a name="line.301"></a>
-<span class="sourceLineNo">302</span><a name="line.302"></a>
-<span class="sourceLineNo">303</span>    // Both families<a name="line.303"></a>
-<span class="sourceLineNo">304</span>    Scan s = new Scan();<a name="line.304"></a>
-<span class="sourceLineNo">305</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.305"></a>
-<span class="sourceLineNo">306</span><a name="line.306"></a>
-<span class="sourceLineNo">307</span>    // One family<a name="line.307"></a>
-<span class="sourceLineNo">308</span>    s = new Scan();<a name="line.308"></a>
-<span class="sourceLineNo">309</span>    s.addFamily(FAMILIES[0]);<a name="line.309"></a>
-<span class="sourceLineNo">310</span>    verifyScan(s, expectedRows, expectedKeys/2);<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<a name="line.313"></a>
-<span class="sourceLineNo">314</span>  public void testPrefixFilter() throws Exception {<a name="line.314"></a>
-<span class="sourceLineNo">315</span>    // Grab rows from group one (half of total)<a name="line.315"></a>
-<span class="sourceLineNo">316</span>    long expectedRows = this.numRows / 2;<a name="line.316"></a>
-<span class="sourceLineNo">317</span>    long expectedKeys = this.colsPerRow;<a name="line.317"></a>
-<span class="sourceLineNo">318</span>    Scan s = new Scan();<a name="line.318"></a>
-<span class="sourceLineNo">319</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.319"></a>
-<span class="sourceLineNo">320</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.320"></a>
-<span class="sourceLineNo">321</span>  }<a name="line.321"></a>
-<span class="sourceLineNo">322</span><a name="line.322"></a>
-<span class="sourceLineNo">323</span>  @Test<a name="line.323"></a>
-<span class="sourceLineNo">324</span>  public void testPrefixFilterWithReverseScan() throws Exception {<a name="line.324"></a>
-<span class="sourceLineNo">325</span>    // Grab rows from group one (half of total)<a name="line.325"></a>
-<span class="sourceLineNo">326</span>    long expectedRows = this.numRows / 2;<a name="line.326"></a>
-<span class="sourceLineNo">327</span>    long expectedKeys = this.colsPerRow;<a name="line.327"></a>
-<span class="sourceLineNo">328</span>    Scan s = new Scan();<a name="line.328"></a>
-<span class="sourceLineNo">329</span>    s.setReversed(true);<a name="line.329"></a>
-<span class="sourceLineNo">330</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.330"></a>
-<span class="sourceLineNo">331</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.331"></a>
-<span class="sourceLineNo">332</span>  }<a name="line.332"></a>
-<span class="sourceLineNo">333</span><a name="line.333"></a>
-<span class="sourceLineNo">334</span>  @Test<a name="line.334"></a>
-<span class="sourceLineNo">335</span>  public void testPageFilter() throws Exception {<a name="line.335"></a>
-<span class="sourceLineNo">336</span><a name="line.336"></a>
-<span class="sourceLineNo">337</span>    // KVs in first 6 rows<a name="line.337"></a>
-<span class="sourceLineNo">338</span>    KeyValue [] expectedKVs = {<a name="line.338"></a>
-<span class="sourceLineNo">339</span>      // testRowOne-0<a name="line.339"></a>
-<span class="sourceLineNo">340</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.340"></a>
-<span class="sourceLineNo">341</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.341"></a>
-<span class="sourceLineNo">342</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.342"></a>
-<span class="sourceLineNo">343</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.343"></a>
-<span class="sourceLineNo">344</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.344"></a>
-<span class="sourceLineNo">345</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.345"></a>
-<span class="sourceLineNo">346</span>      // testRowOne-2<a name="line.346"></a>
-<span class="sourceLineNo">347</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.347"></a>
-<span class="sourceLineNo">348</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.348"></a>
-<span class="sourceLineNo">349</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.349"></a>
-<span class="sourceLineNo">350</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.350"></a>
-<span class="sourceLineNo">351</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.351"></a>
-<span class="sourceLineNo">352</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.352"></a>
-<span class="sourceLineNo">353</span>      // testRowOne-3<a name="line.353"></a>
-<span class="sourceLineNo">354</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.354"></a>
-<span class="sourceLineNo">355</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.355"></a>
-<span class="sourceLineNo">356</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.356"></a>
-<span class="sourceLineNo">357</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.357"></a>
-<span class="sourceLineNo">358</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.358"></a>
-<span class="sourceLineNo">359</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.359"></a>
-<span class="sourceLineNo">360</span>      // testRowTwo-0<a name="line.360"></a>
-<span class="sourceLineNo">361</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.361"></a>
-<span class="sourceLineNo">362</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.362"></a>
-<span class="sourceLineNo">363</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.363"></a>
-<span class="sourceLineNo">364</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.364"></a>
-<span class="sourceLineNo">365</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.365"></a>
-<span class="sourceLineNo">366</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.366"></a>
-<span class="sourceLineNo">367</span>      // testRowTwo-2<a name="line.367"></a>
-<span class="sourceLineNo">368</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.368"></a>
-<span class="sourceLineNo">369</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.369"></a>
-<span class="sourceLineNo">370</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.370"></a>
-<span class="sourceLineNo">371</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.371"></a>
-<span class="sourceLineNo">372</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.372"></a>
-<span class="sourceLineNo">373</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.373"></a>
-<span class="sourceLineNo">374</span>      // testRowTwo-3<a name="line.374"></a>
-<span class="sourceLineNo">375</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.375"></a>
-<span class="sourceLineNo">376</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.376"></a>
-<span class="sourceLineNo">377</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.377"></a>
-<span class="sourceLineNo">378</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.378"></a>
-<span class="sourceLineNo">379</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.379"></a>
-<span class="sourceLineNo">380</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1])<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>    // Grab all 6 rows<a name="line.383"></a>
-<span class="sourceLineNo">384</span>    long expectedRows = 6;<a name="line.384"></a>
-<span class="sourceLineNo">385</span>    long expectedKeys = this.colsPerRow;<a name="line.385"></a>
-<span class="sourceLineNo">386</span>    Scan s = new Scan();<a name="line.386"></a>
-<span class="sourceLineNo">387</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.387"></a>
-<span class="sourceLineNo">388</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.388"></a>
-<span class="sourceLineNo">389</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.389"></a>
-<span class="sourceLineNo">390</span>    verifyScanFull(s, expectedKVs);<a name="line.390"></a>
-<span class="sourceLineNo">391</span><a name="line.391"></a>
-<span class="sourceLineNo">392</span>    // Grab first 4 rows (6 cols per row)<a name="line.392"></a>
-<span class="sourceLineNo">393</span>    expectedRows = 4;<a name="line.393"></a>
-<span class="sourceLineNo">394</span>    expectedKeys = this.colsPerRow;<a name="line.394"></a>
-<span class="sourceLineNo">395</span>    s = new Scan();<a name="line.395"></a>
-<span class="sourceLineNo">396</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.396"></a>
-<span class="sourceLineNo">397</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.397"></a>
-<span class="sourceLineNo">398</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.398"></a>
-<span class="sourceLineNo">399</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 24));<a name="line.399"></a>
-<span class="sourceLineNo">400</span><a name="line.400"></a>
-<span class="sourceLineNo">401</span>    // Grab first 2 rows<a name="line.401"></a>
-<span class="sourceLineNo">402</span>    expectedRows = 2;<a name="line.402"></a>
-<span class="sourceLineNo">403</span>    expectedKeys = this.colsPerRow;<a name="line.403"></a>
-<span class="sourceLineNo">404</span>    s = new Scan();<a name="line.404"></a>
-<span class="sourceLineNo">405</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.405"></a>
-<span class="sourceLineNo">406</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.406"></a>
-<span class="sourceLineNo">407</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.407"></a>
-<span class="sourceLineNo">408</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 12));<a name="line.408"></a>
-<span class="sourceLineNo">409</span><a name="line.409"></a>
-<span class="sourceLineNo">410</span>    // Grab first row<a name="line.410"></a>
-<span class="sourceLineNo">411</span>    expectedRows = 1;<a name="line.411"></a>
-<span class="sourceLineNo">412</span>    expectedKeys = this.colsPerRow;<a name="line.412"></a>
-<span class="sourceLineNo">413</span>    s = new Scan();<a name="line.413"></a>
-<span class="sourceLineNo">414</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.414"></a>
-<span class="sourceLineNo">415</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.415"></a>
-<span class="sourceLineNo">416</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.416"></a>
-<span class="sourceLineNo">417</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 6));<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><a name="line.420"></a>
-<span class="sourceLineNo">421</span>  @Test<a name="line.421"></a>
-<span class="sourceLineNo">422</span>  public void testPageFilterWithReverseScan() throws Exception {<a name="line.422"></a>
-<span class="sourceLineNo">423</span>    // KVs in first 6 rows<a name="line.423"></a>
-<span class="sourceLineNo">424</span>    KeyValue[] expectedKVs = {<a name="line.424"></a>
-<span class="sourceLineNo">425</span>        // testRowOne-0<a name="line.425"></a>
-<span class="sourceLineNo">426</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.426"></a>
-<span class="sourceLineNo">427</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.427"></a>
-<span class="sourceLineNo">428</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.428"></a>
-<span class="sourceLineNo">429</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.429"></a>
-<span class="sourceLineNo">430</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.430"></a>
-<span class="sourceLineNo">431</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.431"></a>
-<span class="sourceLineNo">432</span>        // testRowOne-2<a name="line.432"></a>
-<span class="sourceLineNo">433</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.433"></a>
-<span class="sourceLineNo">434</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.434"></a>
-<span class="sourceLineNo">435</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.435"></a>
-<span class="sourceLineNo">436</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.436"></a>
-<span class="sourceLineNo">437</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.437"></a>
-<span class="sourceLineNo">438</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.438"></a>
-<span class="sourceLineNo">439</span>        // testRowOne-3<a name="line.439"></a>
-<span class="sourceLineNo">440</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.440"></a>
-<span class="sourceLineNo">441</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.441"></a>
-<span class="sourceLineNo">442</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.442"></a>
-<span class="sourceLineNo">443</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.443"></a>
-<span class="sourceLineNo">444</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.444"></a>
-<span class="sourceLineNo">445</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.445"></a>
-<span class="sourceLineNo">446</span>        // testRowTwo-0<a name="line.446"></a>
-<span class="sourceLineNo">447</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.447"></a>
-<span class="sourceLineNo">448</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.448"></a>
-<span class="sourceLineNo">449</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.449"></a>
-<span class="sourceLineNo">450</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.450"></a>
-<span class="sourceLineNo">451</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.451"></a>
-<span class="sourceLineNo">452</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.452"></a>
-<span class="sourceLineNo">453</span>        // testRowTwo-2<a name="line.453"></a>
-<span class="sourceLineNo">454</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.454"></a>
-<span class="sourceLineNo">455</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.455"></a>
-<span class="sourceLineNo">456</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.456"></a>
-<span class="sourceLineNo">457</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.457"></a>
-<span class="sourceLineNo">458</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.458"></a>
-<span class="sourceLineNo">459</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.459"></a>
-<span class="sourceLineNo">460</span>        // testRowTwo-3<a name="line.460"></a>
-<span class="sourceLineNo">461</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.461"></a>
-<span class="sourceLineNo">462</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.462"></a>
-<span class="sourceLineNo">463</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.463"></a>
-<span class="sourceLineNo">464</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.464"></a>
-<span class="sourceLineNo">465</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.465"></a>
-<span class="sourceLineNo">466</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]) };<a name="line.466"></a>
-<span class="sourceLineNo">467</span><a name="line.467"></a>
-<span class="sourceLineNo">468</span>    // Grab all 6 rows<a name="line.468"></a>
-<span class="sourceLineNo">469</span>    long expectedRows = 6;<a name="line.469"></a>
-<span class="sourceLineNo">470</span>    long expectedKeys = this.colsPerRow;<a name="line.470"></a>
-<span class="sourceLineNo">471</span>    Scan s = new Scan();<a name="line.471"></a>
-<span class="sourceLineNo">472</span>    s.setReversed(true);<a name="line.472"></a>
-<span class="sourceLineNo">473</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.473"></a>
-<span class="sourceLineNo">474</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.474"></a>
-<span class="sourceLineNo">475</span><a name="line.475"></a>
-<span class="sourceLineNo">476</span>    // Grab first 4 rows (6 cols per row)<a name="line.476"></a>
-<span class="sourceLineNo">477</span>    expectedRows = 4;<a name="line.477"></a>
-<span class="sourceLineNo">478</span>    expectedKeys = this.colsPerRow;<a name="line.478"></a>
-<span class="sourceLineNo">479</span>    s = new Scan();<a name="line.479"></a>
-<span class="sourceLineNo">480</span>    s.setReversed(true);<a name="line.480"></a>
-<span class="sourceLineNo">481</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.481"></a>
-<span class="sourceLineNo">482</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.482"></a>
-<span class="sourceLineNo">483</span><a name="line.483"></a>
-<span class="sourceLineNo">484</span>    // Grab first 2 rows<a name="line.484"></a>
-<span class="sourceLineNo">485</span>    expectedRows = 2;<a name="line.485"></a>
-<span class="sourceLineNo">486</span>    expectedKeys = this.colsPerRow;<a name="line.486"></a>
-<span class="sourceLineNo">487</span>    s = new Scan();<a name="line.487"></a>
-<span class="sourceLineNo">488</span>    s.setReversed(true);<a name="line.488"></a>
-<span class="sourceLineNo">489</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.489"></a>
-<span class="sourceLineNo">490</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.490"></a>
-<span class="sourceLineNo">491</span><a name="line.491"></a>
-<span class="sourceLineNo">492</span>    // Grab first row<a name="line.492"></a>
-<span class="sourceLineNo">493</span>    expectedRows = 1;<a name="line.493"></a>
-<span class="sourceLineNo">494</span>    expectedKeys = this.colsPerRow;<a name="line.494"></a>
-<span class="sourceLineNo">495</span>    s = new Scan();<a name="line.495"></a>
-<span class="sourceLineNo">496</span>    s.setReversed(true);<a name="line.496"></a>
-<span class="sourceLineNo">497</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.497"></a>
-<span class="sourceLineNo">498</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.498"></a>
-<span class="sourceLineNo">499</span>  }<a name="line.499"></a>
-<span class="sourceLineNo">500</span><a name="line.500"></a>
-<span class="sourceLineNo">501</span>  @Test<a name="line.501"></a>
-<span class="sourceLineNo">502</span>  public void testWhileMatchFilterWithFilterRowWithReverseScan()<a name="line.502"></a>
-<span class="sourceLineNo">503</span>      throws Exception {<a name="line.503"></a>
-<span class="sourceLineNo">504</span>    final int pageSize = 4;<a name="line.504"></a>
-<span class="sourceLineNo">505</span><a name="line.505"></a>
-<span class="sourceLineNo">506</span>    Scan s = new Scan();<a name="line.506"></a>
-<span class="sourceLineNo">507</span>    s.setReversed(true);<a name="line.507"></a>
-<span class="sourceLineNo">508</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.508"></a>
-<span class="sourceLineNo">509</span>    s.setFilter(filter);<a name="line.509"></a>
-<span class="sourceLineNo">510</span><a name="line.510"></a>
-<span class="sourceLineNo">511</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.511"></a>
-<span class="sourceLineNo">512</span>    int scannerCounter = 0;<a name="line.512"></a>
-<span class="sourceLineNo">513</span>    while (true) {<a name="line.513"></a>
-<span class="sourceLineNo">514</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.514"></a>
-<span class="sourceLineNo">515</span>      scannerCounter++;<a name="line.515"></a>
-<span class="sourceLineNo">516</span><a name="line.516"></a>
-<span class="sourceLineNo">517</span>      if (scannerCounter &gt;= pageSize) {<a name="line.517"></a>
-<span class="sourceLineNo">518</span>        Assert.assertTrue(<a name="line.518"></a>
-<span class="sourceLineNo">519</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.519"></a>
-<span class="sourceLineNo">520</span>            filter.filterAllRemaining());<a name="line.520"></a>
-<span class="sourceLineNo">521</span>      }<a name="line.521"></a>
-<span class="sourceLineNo">522</span>      if (!isMoreResults) {<a name="line.522"></a>
-<span class="sourceLineNo">523</span>        break;<a name="line.523"></a>
-<span class="sourceLineNo">524</span>      }<a name="line.524"></a>
-<span class="sourceLineNo">525</span>    }<a name="line.525"></a>
-<span class="sourceLineNo">526</span>    scanner.close();<a name="line.526"></a>
-<span class="sourceLineNo">527</span>    Assert.assertEquals("The page filter returned more rows than expected",<a name="line.527"></a>
-<span class="sourceLineNo">528</span>        pageSize, scannerCounter);<a name="line.528"></a>
-<span class="sourceLineNo">529</span>  }<a name="line.529"></a>
-<span class="sourceLineNo">530</span><a name="line.530"></a>
-<span class="sourceLineNo">531</span>  @Test<a name="line.531"></a>
-<span class="sourceLineNo">532</span>  public void testWhileMatchFilterWithFilterRowKeyWithReverseScan()<a name="line.532"></a>
-<span class="sourceLineNo">533</span>      throws Exception {<a name="line.533"></a>
-<span class="sourceLineNo">534</span>    Scan s = new Scan();<a name="line.534"></a>
-<span class="sourceLineNo">535</span>    String prefix = "testRowOne";<a name="line.535"></a>
-<span class="sourceLineNo">536</span>    WhileMatchFilter filter = new WhileMatchFilter(new PrefixFilter(<a name="line.536"></a>
-<span class="sourceLineNo">537</span>        Bytes.toBytes(prefix)));<a name="line.537"></a>
-<span class="sourceLineNo">538</span>    s.setFilter(filter);<a name="line.538"></a>
-<span class="sourceLineNo">539</span>    s.setReversed(true);<a name="line.539"></a>
-<span class="sourceLineNo">540</span><a name="line.540"></a>
-<span class="sourceLineNo">541</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.541"></a>
-<span class="sourceLineNo">542</span>    while (true) {<a name="line.542"></a>
-<span class="sourceLineNo">543</span>      ArrayList&lt;Cell&gt; values = new ArrayList&lt;&gt;();<a name="line.543"></a>
-<span class="sourceLineNo">544</span>      boolean isMoreResults = scanner.next(values);<a name="line.544"></a>
-<span class="sourceLineNo">545</span>      if (!isMoreResults<a name="line.545"></a>
-<span class="sourceLineNo">546</span>          || !Bytes.toString(CellUtil.cloneRow(values.get(0))).startsWith(prefix)) {<a name="line.546"></a>
-<span class="sourceLineNo">547</span>        Assert.assertTrue(<a name="line.547"></a>
-<span class="sourceLineNo">548</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.548"></a>
-<span class="sourceLineNo">549</span>            filter.filterAllRemaining());<a name="line.549"></a>
-<span class="sourceLineNo">550</span>      }<a name="line.550"></a>
-<span class="sourceLineNo">551</span>      if (!isMoreResults) {<a name="line.551"></a>
-<span class="sourceLineNo">552</span>        break;<a name="line.552"></a>
-<span class="sourceLineNo">553</span>      }<a name="line.553"></a>
-<span class="sourceLineNo">554</span>    }<a name="line.554"></a>
-<span class="sourceLineNo">555</span>    scanner.close();<a name="line.555"></a>
-<span class="sourceLineNo">556</span>  }<a name="line.556"></a>
-<span class="sourceLineNo">557</span><a name="line.557"></a>
-<span class="sourceLineNo">558</span>  /**<a name="line.558"></a>
-<span class="sourceLineNo">559</span>   * Tests the the {@link WhileMatchFilter} works in combination with a<a name="line.559"></a>
-<span class="sourceLineNo">560</span>   * {@link Filter} that uses the<a name="line.560"></a>
-<span class="sourceLineNo">561</span>   * {@link Filter#filterRow()} method.<a name="line.561"></a>
-<span class="sourceLineNo">562</span>   *<a name="line.562"></a>
-<span class="sourceLineNo">563</span>   * See HBASE-2258.<a name="line.563"></a>
-<span class="sourceLineNo">564</span>   *<a name="line.564"></a>
-<span class="sourceLineNo">565</span>   * @throws Exception<a name="line.565"></a>
-<span class="sourceLineNo">566</span>   */<a name="line.566"></a>
-<span class="sourceLineNo">567</span>  @Test<a name="line.567"></a>
-<span class="sourceLineNo">568</span>  public void testWhileMatchFilterWithFilterRow() throws Exception {<a name="line.568"></a>
-<span class="sourceLineNo">569</span>    final int pageSize = 4;<a name="line.569"></a>
-<span class="sourceLineNo">570</span><a name="line.570"></a>
-<span class="sourceLineNo">571</span>    Scan s = new Scan();<a name="line.571"></a>
-<span class="sourceLineNo">572</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.572"></a>
-<span class="sourceLineNo">573</span>    s.setFilter(filter);<a name="line.573"></a>
-<span class="sourceLineNo">574</span><a name="line.574"></a>
-<span class="sourceLineNo">575</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.575"></a>
-<span class="sourceLineNo">576</span>    int scannerCounter = 0;<a name="line.576"></a>
-<span class="sourceLineNo">577</span>    while (true) {<a name="line.577"></a>
-<span class="sourceLineNo">578</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.578"></a>
-<span class="sourceLineNo">579</span>      scannerCounter++;<a name="line.579"></a>
-<span class="sourceLineNo">580</span><a name="line.580"></a>
-<span class="sourceLineNo">581</span>      if (scannerCounter &gt;= pageSize) {<a name="line.581"></a>
-<span class="sourceLineNo">582</span>        assertTrue("The WhileMatchFilter should now filter all remaining", filter.filterAllRemaining());<a name="line.582"></a>
-<span class="sourceLineNo">583</span>      }<a name="line.583"></a>
-<span class="sourceLineNo">584</span>      if (!isMoreResults) {<a name="line.584"></a>
-<span class="sourceLineNo">585</span>        break;<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>    assertEquals("The page filter returned more rows than expected", pageSize, scannerCounter);<a name="line.588"></a>
-<span class="sourceLineNo">589</span>  }<a name="line.589"></a>
-<span class="sourceLineNo">590</span><a name="line.590"></a>
+<span class="sourceLineNo">145</span>    HColumnDescriptor family0 = new HColumnDescriptor(FAMILIES[0]).setVersions(100, 100);<a name="line.145"></a>
+<span class="sourceLineNo">146</span>    htd.addFamily(family0);<a name="line.146"></a>
+<span class="sourceLineNo">147</span>    htd.addFamily(new HColumnDescriptor(FAMILIES[1]));<a name="line.147"></a>
+<span class="sourceLineNo">148</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[0]));<a name="line.148"></a>
+<span class="sourceLineNo">149</span>    htd.addFamily(new HColumnDescriptor(FAMILIES_1[1]));<a name="line.149"></a>
+<span class="sourceLineNo">150</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[0]));<a name="line.150"></a>
+<span class="sourceLineNo">151</span>    htd.addFamily(new HColumnDescriptor(NEW_FAMILIES[1]));<a name="line.151"></a>
+<span class="sourceLineNo">152</span>    HRegionInfo info = new HRegionInfo(htd.getTableName(), null, null, false);<a name="line.152"></a>
+<span class="sourceLineNo">153</span>    this.region = HBaseTestingUtility.createRegionAndWAL(info, TEST_UTIL.getDataTestDir(),<a name="line.153"></a>
+<span class="sourceLineNo">154</span>        TEST_UTIL.getConfiguration(), htd);<a name="line.154"></a>
+<span class="sourceLineNo">155</span><a name="line.155"></a>
+<span class="sourceLineNo">156</span>    // Insert first half<a name="line.156"></a>
+<span class="sourceLineNo">157</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.157"></a>
+<span class="sourceLineNo">158</span>      Put p = new Put(ROW);<a name="line.158"></a>
+<span class="sourceLineNo">159</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.159"></a>
+<span class="sourceLineNo">160</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.160"></a>
+<span class="sourceLineNo">161</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.161"></a>
+<span class="sourceLineNo">162</span>      }<a name="line.162"></a>
+<span class="sourceLineNo">163</span>      this.region.put(p);<a name="line.163"></a>
+<span class="sourceLineNo">164</span>    }<a name="line.164"></a>
+<span class="sourceLineNo">165</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.165"></a>
+<span class="sourceLineNo">166</span>      Put p = new Put(ROW);<a name="line.166"></a>
+<span class="sourceLineNo">167</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.167"></a>
+<span class="sourceLineNo">168</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.168"></a>
+<span class="sourceLineNo">169</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.169"></a>
+<span class="sourceLineNo">170</span>      }<a name="line.170"></a>
+<span class="sourceLineNo">171</span>      this.region.put(p);<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>    // Flush<a name="line.174"></a>
+<span class="sourceLineNo">175</span>    this.region.flush(true);<a name="line.175"></a>
+<span class="sourceLineNo">176</span><a name="line.176"></a>
+<span class="sourceLineNo">177</span>    // Insert second half (reverse families)<a name="line.177"></a>
+<span class="sourceLineNo">178</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.178"></a>
+<span class="sourceLineNo">179</span>      Put p = new Put(ROW);<a name="line.179"></a>
+<span class="sourceLineNo">180</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.180"></a>
+<span class="sourceLineNo">181</span>      for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.181"></a>
+<span class="sourceLineNo">182</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.182"></a>
+<span class="sourceLineNo">183</span>      }<a name="line.183"></a>
+<span class="sourceLineNo">184</span>      this.region.put(p);<a name="line.184"></a>
+<span class="sourceLineNo">185</span>    }<a name="line.185"></a>
+<span class="sourceLineNo">186</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.186"></a>
+<span class="sourceLineNo">187</span>      Put p = new Put(ROW);<a name="line.187"></a>
+<span class="sourceLineNo">188</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.188"></a>
+<span class="sourceLineNo">189</span>      for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.189"></a>
+<span class="sourceLineNo">190</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.190"></a>
+<span class="sourceLineNo">191</span>      }<a name="line.191"></a>
+<span class="sourceLineNo">192</span>      this.region.put(p);<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>    // Delete the second qualifier from all rows and families<a name="line.195"></a>
+<span class="sourceLineNo">196</span>    for(byte [] ROW : ROWS_ONE) {<a name="line.196"></a>
+<span class="sourceLineNo">197</span>      Delete d = new Delete(ROW);<a name="line.197"></a>
+<span class="sourceLineNo">198</span>      d.addColumns(FAMILIES[0], QUALIFIERS_ONE[1]);<a name="line.198"></a>
+<span class="sourceLineNo">199</span>      d.addColumns(FAMILIES[1], QUALIFIERS_ONE[1]);<a name="line.199"></a>
+<span class="sourceLineNo">200</span>      this.region.delete(d);<a name="line.200"></a>
+<span class="sourceLineNo">201</span>    }<a name="line.201"></a>
+<span class="sourceLineNo">202</span>    for(byte [] ROW : ROWS_TWO) {<a name="line.202"></a>
+<span class="sourceLineNo">203</span>      Delete d = new Delete(ROW);<a name="line.203"></a>
+<span class="sourceLineNo">204</span>      d.addColumns(FAMILIES[0], QUALIFIERS_TWO[1]);<a name="line.204"></a>
+<span class="sourceLineNo">205</span>      d.addColumns(FAMILIES[1], QUALIFIERS_TWO[1]);<a name="line.205"></a>
+<span class="sourceLineNo">206</span>      this.region.delete(d);<a name="line.206"></a>
+<span class="sourceLineNo">207</span>    }<a name="line.207"></a>
+<span class="sourceLineNo">208</span>    colsPerRow -= 2;<a name="line.208"></a>
+<span class="sourceLineNo">209</span><a name="line.209"></a>
+<span class="sourceLineNo">210</span>    // Delete the second rows from both groups, one column at a time<a name="line.210"></a>
+<span class="sourceLineNo">211</span>    for(byte [] QUALIFIER : QUALIFIERS_ONE) {<a name="line.211"></a>
+<span class="sourceLineNo">212</span>      Delete d = new Delete(ROWS_ONE[1]);<a name="line.212"></a>
+<span class="sourceLineNo">213</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.213"></a>
+<span class="sourceLineNo">214</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.214"></a>
+<span class="sourceLineNo">215</span>      this.region.delete(d);<a name="line.215"></a>
+<span class="sourceLineNo">216</span>    }<a name="line.216"></a>
+<span class="sourceLineNo">217</span>    for(byte [] QUALIFIER : QUALIFIERS_TWO) {<a name="line.217"></a>
+<span class="sourceLineNo">218</span>      Delete d = new Delete(ROWS_TWO[1]);<a name="line.218"></a>
+<span class="sourceLineNo">219</span>      d.addColumns(FAMILIES[0], QUALIFIER);<a name="line.219"></a>
+<span class="sourceLineNo">220</span>      d.addColumns(FAMILIES[1], QUALIFIER);<a name="line.220"></a>
+<span class="sourceLineNo">221</span>      this.region.delete(d);<a name="line.221"></a>
+<span class="sourceLineNo">222</span>    }<a name="line.222"></a>
+<span class="sourceLineNo">223</span>    numRows -= 2;<a name="line.223"></a>
+<span class="sourceLineNo">224</span>  }<a name="line.224"></a>
+<span class="sourceLineNo">225</span><a name="line.225"></a>
+<span class="sourceLineNo">226</span>  @After<a name="line.226"></a>
+<span class="sourceLineNo">227</span>  public void tearDown() throws Exception {<a name="line.227"></a>
+<span class="sourceLineNo">228</span>    HBaseTestingUtility.closeRegionAndWAL(region);<a name="line.228"></a>
+<span class="sourceLineNo">229</span>  }<a name="line.229"></a>
+<span class="sourceLineNo">230</span><a name="line.230"></a>
+<span class="sourceLineNo">231</span>  @Test<a name="line.231"></a>
+<span class="sourceLineNo">232</span>  public void testRegionScannerReseek() throws Exception {<a name="line.232"></a>
+<span class="sourceLineNo">233</span>    // create new rows and column family to show how reseek works..<a name="line.233"></a>
+<span class="sourceLineNo">234</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.234"></a>
+<span class="sourceLineNo">235</span>      Put p = new Put(ROW);<a name="line.235"></a>
+<span class="sourceLineNo">236</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.236"></a>
+<span class="sourceLineNo">237</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.237"></a>
+<span class="sourceLineNo">238</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[0]);<a name="line.238"></a>
+<span class="sourceLineNo">239</span><a name="line.239"></a>
+<span class="sourceLineNo">240</span>      }<a name="line.240"></a>
+<span class="sourceLineNo">241</span>      this.region.put(p);<a name="line.241"></a>
+<span class="sourceLineNo">242</span>    }<a name="line.242"></a>
+<span class="sourceLineNo">243</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.243"></a>
+<span class="sourceLineNo">244</span>      Put p = new Put(ROW);<a name="line.244"></a>
+<span class="sourceLineNo">245</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.245"></a>
+<span class="sourceLineNo">246</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.246"></a>
+<span class="sourceLineNo">247</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[1]);<a name="line.247"></a>
+<span class="sourceLineNo">248</span>      }<a name="line.248"></a>
+<span class="sourceLineNo">249</span>      this.region.put(p);<a name="line.249"></a>
+<span class="sourceLineNo">250</span>    }<a name="line.250"></a>
+<span class="sourceLineNo">251</span>    // Flush<a name="line.251"></a>
+<span class="sourceLineNo">252</span>    this.region.flush(true);<a name="line.252"></a>
+<span class="sourceLineNo">253</span><a name="line.253"></a>
+<span class="sourceLineNo">254</span>    // Insert second half (reverse families)<a name="line.254"></a>
+<span class="sourceLineNo">255</span>    for (byte[] ROW : ROWS_THREE) {<a name="line.255"></a>
+<span class="sourceLineNo">256</span>      Put p = new Put(ROW);<a name="line.256"></a>
+<span class="sourceLineNo">257</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.257"></a>
+<span class="sourceLineNo">258</span>      for (byte[] QUALIFIER : QUALIFIERS_THREE) {<a name="line.258"></a>
+<span class="sourceLineNo">259</span>        p.addColumn(FAMILIES[1], QUALIFIER, VALUES[0]);<a name="line.259"></a>
+<span class="sourceLineNo">260</span>      }<a name="line.260"></a>
+<span class="sourceLineNo">261</span>      this.region.put(p);<a name="line.261"></a>
+<span class="sourceLineNo">262</span>    }<a name="line.262"></a>
+<span class="sourceLineNo">263</span>    for (byte[] ROW : ROWS_FOUR) {<a name="line.263"></a>
+<span class="sourceLineNo">264</span>      Put p = new Put(ROW);<a name="line.264"></a>
+<span class="sourceLineNo">265</span>      p.setDurability(Durability.SKIP_WAL);<a name="line.265"></a>
+<span class="sourceLineNo">266</span>      for (byte[] QUALIFIER : QUALIFIERS_FOUR) {<a name="line.266"></a>
+<span class="sourceLineNo">267</span>        p.addColumn(FAMILIES[0], QUALIFIER, VALUES[1]);<a name="line.267"></a>
+<span class="sourceLineNo">268</span>      }<a name="line.268"></a>
+<span class="sourceLineNo">269</span>      this.region.put(p);<a name="line.269"></a>
+<span class="sourceLineNo">270</span>    }<a name="line.270"></a>
+<span class="sourceLineNo">271</span><a name="line.271"></a>
+<span class="sourceLineNo">272</span>    Scan s = new Scan();<a name="line.272"></a>
+<span class="sourceLineNo">273</span>    // set a start row<a name="line.273"></a>
+<span class="sourceLineNo">274</span>    s.setStartRow(ROWS_FOUR[1]);<a name="line.274"></a>
+<span class="sourceLineNo">275</span>    RegionScanner scanner = region.getScanner(s);<a name="line.275"></a>
+<span class="sourceLineNo">276</span><a name="line.276"></a>
+<span class="sourceLineNo">277</span>    // reseek to row three.<a name="line.277"></a>
+<span class="sourceLineNo">278</span>    scanner.reseek(ROWS_THREE[1]);<a name="line.278"></a>
+<span class="sourceLineNo">279</span>    List&lt;Cell&gt; results = new ArrayList&lt;&gt;();<a name="line.279"></a>
+<span class="sourceLineNo">280</span><a name="line.280"></a>
+<span class="sourceLineNo">281</span>    // the results should belong to ROWS_THREE[1]<a name="line.281"></a>
+<span class="sourceLineNo">282</span>    scanner.next(results);<a name="line.282"></a>
+<span class="sourceLineNo">283</span>    for (Cell keyValue : results) {<a name="line.283"></a>
+<span class="sourceLineNo">284</span>      assertTrue("The rows with ROWS_TWO as row key should be appearing.",<a name="line.284"></a>
+<span class="sourceLineNo">285</span>          CellUtil.matchingRows(keyValue, ROWS_THREE[1]));<a name="line.285"></a>
+<span class="sourceLineNo">286</span>    }<a name="line.286"></a>
+<span class="sourceLineNo">287</span>    // again try to reseek to a value before ROWS_THREE[1]<a name="line.287"></a>
+<span class="sourceLineNo">288</span>    scanner.reseek(ROWS_ONE[1]);<a name="line.288"></a>
+<span class="sourceLineNo">289</span>    results = new ArrayList&lt;&gt;();<a name="line.289"></a>
+<span class="sourceLineNo">290</span>    // This time no seek would have been done to ROWS_ONE[1]<a name="line.290"></a>
+<span class="sourceLineNo">291</span>    scanner.next(results);<a name="line.291"></a>
+<span class="sourceLineNo">292</span>    for (Cell keyValue : results) {<a name="line.292"></a>
+<span class="sourceLineNo">293</span>      assertFalse("Cannot rewind back to a value less than previous reseek.",<a name="line.293"></a>
+<span class="sourceLineNo">294</span>          Bytes.toString(CellUtil.cloneRow(keyValue)).contains("testRowOne"));<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>  @Test<a name="line.298"></a>
+<span class="sourceLineNo">299</span>  public void testNoFilter() throws Exception {<a name="line.299"></a>
+<span class="sourceLineNo">300</span>    // No filter<a name="line.300"></a>
+<span class="sourceLineNo">301</span>    long expectedRows = this.numRows;<a name="line.301"></a>
+<span class="sourceLineNo">302</span>    long expectedKeys = this.colsPerRow;<a name="line.302"></a>
+<span class="sourceLineNo">303</span><a name="line.303"></a>
+<span class="sourceLineNo">304</span>    // Both families<a name="line.304"></a>
+<span class="sourceLineNo">305</span>    Scan s = new Scan();<a name="line.305"></a>
+<span class="sourceLineNo">306</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.306"></a>
+<span class="sourceLineNo">307</span><a name="line.307"></a>
+<span class="sourceLineNo">308</span>    // One family<a name="line.308"></a>
+<span class="sourceLineNo">309</span>    s = new Scan();<a name="line.309"></a>
+<span class="sourceLineNo">310</span>    s.addFamily(FAMILIES[0]);<a name="line.310"></a>
+<span class="sourceLineNo">311</span>    verifyScan(s, expectedRows, expectedKeys/2);<a name="line.311"></a>
+<span class="sourceLineNo">312</span>  }<a name="line.312"></a>
+<span class="sourceLineNo">313</span><a name="line.313"></a>
+<span class="sourceLineNo">314</span>  @Test<a name="line.314"></a>
+<span class="sourceLineNo">315</span>  public void testPrefixFilter() throws Exception {<a name="line.315"></a>
+<span class="sourceLineNo">316</span>    // Grab rows from group one (half of total)<a name="line.316"></a>
+<span class="sourceLineNo">317</span>    long expectedRows = this.numRows / 2;<a name="line.317"></a>
+<span class="sourceLineNo">318</span>    long expectedKeys = this.colsPerRow;<a name="line.318"></a>
+<span class="sourceLineNo">319</span>    Scan s = new Scan();<a name="line.319"></a>
+<span class="sourceLineNo">320</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.320"></a>
+<span class="sourceLineNo">321</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.321"></a>
+<span class="sourceLineNo">322</span>  }<a name="line.322"></a>
+<span class="sourceLineNo">323</span><a name="line.323"></a>
+<span class="sourceLineNo">324</span>  @Test<a name="line.324"></a>
+<span class="sourceLineNo">325</span>  public void testPrefixFilterWithReverseScan() throws Exception {<a name="line.325"></a>
+<span class="sourceLineNo">326</span>    // Grab rows from group one (half of total)<a name="line.326"></a>
+<span class="sourceLineNo">327</span>    long expectedRows = this.numRows / 2;<a name="line.327"></a>
+<span class="sourceLineNo">328</span>    long expectedKeys = this.colsPerRow;<a name="line.328"></a>
+<span class="sourceLineNo">329</span>    Scan s = new Scan();<a name="line.329"></a>
+<span class="sourceLineNo">330</span>    s.setReversed(true);<a name="line.330"></a>
+<span class="sourceLineNo">331</span>    s.setFilter(new PrefixFilter(Bytes.toBytes("testRowOne")));<a name="line.331"></a>
+<span class="sourceLineNo">332</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.332"></a>
+<span class="sourceLineNo">333</span>  }<a name="line.333"></a>
+<span class="sourceLineNo">334</span><a name="line.334"></a>
+<span class="sourceLineNo">335</span>  @Test<a name="line.335"></a>
+<span class="sourceLineNo">336</span>  public void testPageFilter() throws Exception {<a name="line.336"></a>
+<span class="sourceLineNo">337</span><a name="line.337"></a>
+<span class="sourceLineNo">338</span>    // KVs in first 6 rows<a name="line.338"></a>
+<span class="sourceLineNo">339</span>    KeyValue [] expectedKVs = {<a name="line.339"></a>
+<span class="sourceLineNo">340</span>      // testRowOne-0<a name="line.340"></a>
+<span class="sourceLineNo">341</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.341"></a>
+<span class="sourceLineNo">342</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.342"></a>
+<span class="sourceLineNo">343</span>      new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.343"></a>
+<span class="sourceLineNo">344</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.344"></a>
+<span class="sourceLineNo">345</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.345"></a>
+<span class="sourceLineNo">346</span>      new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.346"></a>
+<span class="sourceLineNo">347</span>      // testRowOne-2<a name="line.347"></a>
+<span class="sourceLineNo">348</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.348"></a>
+<span class="sourceLineNo">349</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.349"></a>
+<span class="sourceLineNo">350</span>      new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.350"></a>
+<span class="sourceLineNo">351</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.351"></a>
+<span class="sourceLineNo">352</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.352"></a>
+<span class="sourceLineNo">353</span>      new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.353"></a>
+<span class="sourceLineNo">354</span>      // testRowOne-3<a name="line.354"></a>
+<span class="sourceLineNo">355</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.355"></a>
+<span class="sourceLineNo">356</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.356"></a>
+<span class="sourceLineNo">357</span>      new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.357"></a>
+<span class="sourceLineNo">358</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.358"></a>
+<span class="sourceLineNo">359</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.359"></a>
+<span class="sourceLineNo">360</span>      new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.360"></a>
+<span class="sourceLineNo">361</span>      // testRowTwo-0<a name="line.361"></a>
+<span class="sourceLineNo">362</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.362"></a>
+<span class="sourceLineNo">363</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.363"></a>
+<span class="sourceLineNo">364</span>      new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.364"></a>
+<span class="sourceLineNo">365</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.365"></a>
+<span class="sourceLineNo">366</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.366"></a>
+<span class="sourceLineNo">367</span>      new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.367"></a>
+<span class="sourceLineNo">368</span>      // testRowTwo-2<a name="line.368"></a>
+<span class="sourceLineNo">369</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.369"></a>
+<span class="sourceLineNo">370</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.370"></a>
+<span class="sourceLineNo">371</span>      new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.371"></a>
+<span class="sourceLineNo">372</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.372"></a>
+<span class="sourceLineNo">373</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.373"></a>
+<span class="sourceLineNo">374</span>      new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.374"></a>
+<span class="sourceLineNo">375</span>      // testRowTwo-3<a name="line.375"></a>
+<span class="sourceLineNo">376</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.376"></a>
+<span class="sourceLineNo">377</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.377"></a>
+<span class="sourceLineNo">378</span>      new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.378"></a>
+<span class="sourceLineNo">379</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.379"></a>
+<span class="sourceLineNo">380</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.380"></a>
+<span class="sourceLineNo">381</span>      new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1])<a name="line.381"></a>
+<span class="sourceLineNo">382</span>    };<a name="line.382"></a>
+<span class="sourceLineNo">383</span><a name="line.383"></a>
+<span class="sourceLineNo">384</span>    // Grab all 6 rows<a name="line.384"></a>
+<span class="sourceLineNo">385</span>    long expectedRows = 6;<a name="line.385"></a>
+<span class="sourceLineNo">386</span>    long expectedKeys = this.colsPerRow;<a name="line.386"></a>
+<span class="sourceLineNo">387</span>    Scan s = new Scan();<a name="line.387"></a>
+<span class="sourceLineNo">388</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.388"></a>
+<span class="sourceLineNo">389</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.389"></a>
+<span class="sourceLineNo">390</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.390"></a>
+<span class="sourceLineNo">391</span>    verifyScanFull(s, expectedKVs);<a name="line.391"></a>
+<span class="sourceLineNo">392</span><a name="line.392"></a>
+<span class="sourceLineNo">393</span>    // Grab first 4 rows (6 cols per row)<a name="line.393"></a>
+<span class="sourceLineNo">394</span>    expectedRows = 4;<a name="line.394"></a>
+<span class="sourceLineNo">395</span>    expectedKeys = this.colsPerRow;<a name="line.395"></a>
+<span class="sourceLineNo">396</span>    s = new Scan();<a name="line.396"></a>
+<span class="sourceLineNo">397</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.397"></a>
+<span class="sourceLineNo">398</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.398"></a>
+<span class="sourceLineNo">399</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.399"></a>
+<span class="sourceLineNo">400</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 24));<a name="line.400"></a>
+<span class="sourceLineNo">401</span><a name="line.401"></a>
+<span class="sourceLineNo">402</span>    // Grab first 2 rows<a name="line.402"></a>
+<span class="sourceLineNo">403</span>    expectedRows = 2;<a name="line.403"></a>
+<span class="sourceLineNo">404</span>    expectedKeys = this.colsPerRow;<a name="line.404"></a>
+<span class="sourceLineNo">405</span>    s = new Scan();<a name="line.405"></a>
+<span class="sourceLineNo">406</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.406"></a>
+<span class="sourceLineNo">407</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.407"></a>
+<span class="sourceLineNo">408</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.408"></a>
+<span class="sourceLineNo">409</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 12));<a name="line.409"></a>
+<span class="sourceLineNo">410</span><a name="line.410"></a>
+<span class="sourceLineNo">411</span>    // Grab first row<a name="line.411"></a>
+<span class="sourceLineNo">412</span>    expectedRows = 1;<a name="line.412"></a>
+<span class="sourceLineNo">413</span>    expectedKeys = this.colsPerRow;<a name="line.413"></a>
+<span class="sourceLineNo">414</span>    s = new Scan();<a name="line.414"></a>
+<span class="sourceLineNo">415</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.415"></a>
+<span class="sourceLineNo">416</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.416"></a>
+<span class="sourceLineNo">417</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.417"></a>
+<span class="sourceLineNo">418</span>    verifyScanFull(s, Arrays.copyOf(expectedKVs, 6));<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><a name="line.421"></a>
+<span class="sourceLineNo">422</span>  @Test<a name="line.422"></a>
+<span class="sourceLineNo">423</span>  public void testPageFilterWithReverseScan() throws Exception {<a name="line.423"></a>
+<span class="sourceLineNo">424</span>    // KVs in first 6 rows<a name="line.424"></a>
+<span class="sourceLineNo">425</span>    KeyValue[] expectedKVs = {<a name="line.425"></a>
+<span class="sourceLineNo">426</span>        // testRowOne-0<a name="line.426"></a>
+<span class="sourceLineNo">427</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.427"></a>
+<span class="sourceLineNo">428</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.428"></a>
+<span class="sourceLineNo">429</span>        new KeyValue(ROWS_ONE[0], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.429"></a>
+<span class="sourceLineNo">430</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.430"></a>
+<span class="sourceLineNo">431</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.431"></a>
+<span class="sourceLineNo">432</span>        new KeyValue(ROWS_ONE[0], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.432"></a>
+<span class="sourceLineNo">433</span>        // testRowOne-2<a name="line.433"></a>
+<span class="sourceLineNo">434</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.434"></a>
+<span class="sourceLineNo">435</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.435"></a>
+<span class="sourceLineNo">436</span>        new KeyValue(ROWS_ONE[2], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.436"></a>
+<span class="sourceLineNo">437</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.437"></a>
+<span class="sourceLineNo">438</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.438"></a>
+<span class="sourceLineNo">439</span>        new KeyValue(ROWS_ONE[2], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.439"></a>
+<span class="sourceLineNo">440</span>        // testRowOne-3<a name="line.440"></a>
+<span class="sourceLineNo">441</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.441"></a>
+<span class="sourceLineNo">442</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.442"></a>
+<span class="sourceLineNo">443</span>        new KeyValue(ROWS_ONE[3], FAMILIES[0], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.443"></a>
+<span class="sourceLineNo">444</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[0], VALUES[0]),<a name="line.444"></a>
+<span class="sourceLineNo">445</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[2], VALUES[0]),<a name="line.445"></a>
+<span class="sourceLineNo">446</span>        new KeyValue(ROWS_ONE[3], FAMILIES[1], QUALIFIERS_ONE[3], VALUES[0]),<a name="line.446"></a>
+<span class="sourceLineNo">447</span>        // testRowTwo-0<a name="line.447"></a>
+<span class="sourceLineNo">448</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.448"></a>
+<span class="sourceLineNo">449</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.449"></a>
+<span class="sourceLineNo">450</span>        new KeyValue(ROWS_TWO[0], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.450"></a>
+<span class="sourceLineNo">451</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.451"></a>
+<span class="sourceLineNo">452</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.452"></a>
+<span class="sourceLineNo">453</span>        new KeyValue(ROWS_TWO[0], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.453"></a>
+<span class="sourceLineNo">454</span>        // testRowTwo-2<a name="line.454"></a>
+<span class="sourceLineNo">455</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.455"></a>
+<span class="sourceLineNo">456</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.456"></a>
+<span class="sourceLineNo">457</span>        new KeyValue(ROWS_TWO[2], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.457"></a>
+<span class="sourceLineNo">458</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.458"></a>
+<span class="sourceLineNo">459</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.459"></a>
+<span class="sourceLineNo">460</span>        new KeyValue(ROWS_TWO[2], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.460"></a>
+<span class="sourceLineNo">461</span>        // testRowTwo-3<a name="line.461"></a>
+<span class="sourceLineNo">462</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.462"></a>
+<span class="sourceLineNo">463</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.463"></a>
+<span class="sourceLineNo">464</span>        new KeyValue(ROWS_TWO[3], FAMILIES[0], QUALIFIERS_TWO[3], VALUES[1]),<a name="line.464"></a>
+<span class="sourceLineNo">465</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[0], VALUES[1]),<a name="line.465"></a>
+<span class="sourceLineNo">466</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[2], VALUES[1]),<a name="line.466"></a>
+<span class="sourceLineNo">467</span>        new KeyValue(ROWS_TWO[3], FAMILIES[1], QUALIFIERS_TWO[3], VALUES[1]) };<a name="line.467"></a>
+<span class="sourceLineNo">468</span><a name="line.468"></a>
+<span class="sourceLineNo">469</span>    // Grab all 6 rows<a name="line.469"></a>
+<span class="sourceLineNo">470</span>    long expectedRows = 6;<a name="line.470"></a>
+<span class="sourceLineNo">471</span>    long expectedKeys = this.colsPerRow;<a name="line.471"></a>
+<span class="sourceLineNo">472</span>    Scan s = new Scan();<a name="line.472"></a>
+<span class="sourceLineNo">473</span>    s.setReversed(true);<a name="line.473"></a>
+<span class="sourceLineNo">474</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.474"></a>
+<span class="sourceLineNo">475</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.475"></a>
+<span class="sourceLineNo">476</span><a name="line.476"></a>
+<span class="sourceLineNo">477</span>    // Grab first 4 rows (6 cols per row)<a name="line.477"></a>
+<span class="sourceLineNo">478</span>    expectedRows = 4;<a name="line.478"></a>
+<span class="sourceLineNo">479</span>    expectedKeys = this.colsPerRow;<a name="line.479"></a>
+<span class="sourceLineNo">480</span>    s = new Scan();<a name="line.480"></a>
+<span class="sourceLineNo">481</span>    s.setReversed(true);<a name="line.481"></a>
+<span class="sourceLineNo">482</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.482"></a>
+<span class="sourceLineNo">483</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.483"></a>
+<span class="sourceLineNo">484</span><a name="line.484"></a>
+<span class="sourceLineNo">485</span>    // Grab first 2 rows<a name="line.485"></a>
+<span class="sourceLineNo">486</span>    expectedRows = 2;<a name="line.486"></a>
+<span class="sourceLineNo">487</span>    expectedKeys = this.colsPerRow;<a name="line.487"></a>
+<span class="sourceLineNo">488</span>    s = new Scan();<a name="line.488"></a>
+<span class="sourceLineNo">489</span>    s.setReversed(true);<a name="line.489"></a>
+<span class="sourceLineNo">490</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.490"></a>
+<span class="sourceLineNo">491</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.491"></a>
+<span class="sourceLineNo">492</span><a name="line.492"></a>
+<span class="sourceLineNo">493</span>    // Grab first row<a name="line.493"></a>
+<span class="sourceLineNo">494</span>    expectedRows = 1;<a name="line.494"></a>
+<span class="sourceLineNo">495</span>    expectedKeys = this.colsPerRow;<a name="line.495"></a>
+<span class="sourceLineNo">496</span>    s = new Scan();<a name="line.496"></a>
+<span class="sourceLineNo">497</span>    s.setReversed(true);<a name="line.497"></a>
+<span class="sourceLineNo">498</span>    s.setFilter(new PageFilter(expectedRows));<a name="line.498"></a>
+<span class="sourceLineNo">499</span>    verifyScan(s, expectedRows, expectedKeys);<a name="line.499"></a>
+<span class="sourceLineNo">500</span>  }<a name="line.500"></a>
+<span class="sourceLineNo">501</span><a name="line.501"></a>
+<span class="sourceLineNo">502</span>  @Test<a name="line.502"></a>
+<span class="sourceLineNo">503</span>  public void testWhileMatchFilterWithFilterRowWithReverseScan()<a name="line.503"></a>
+<span class="sourceLineNo">504</span>      throws Exception {<a name="line.504"></a>
+<span class="sourceLineNo">505</span>    final int pageSize = 4;<a name="line.505"></a>
+<span class="sourceLineNo">506</span><a name="line.506"></a>
+<span class="sourceLineNo">507</span>    Scan s = new Scan();<a name="line.507"></a>
+<span class="sourceLineNo">508</span>    s.setReversed(true);<a name="line.508"></a>
+<span class="sourceLineNo">509</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.509"></a>
+<span class="sourceLineNo">510</span>    s.setFilter(filter);<a name="line.510"></a>
+<span class="sourceLineNo">511</span><a name="line.511"></a>
+<span class="sourceLineNo">512</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.512"></a>
+<span class="sourceLineNo">513</span>    int scannerCounter = 0;<a name="line.513"></a>
+<span class="sourceLineNo">514</span>    while (true) {<a name="line.514"></a>
+<span class="sourceLineNo">515</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.515"></a>
+<span class="sourceLineNo">516</span>      scannerCounter++;<a name="line.516"></a>
+<span class="sourceLineNo">517</span><a name="line.517"></a>
+<span class="sourceLineNo">518</span>      if (scannerCounter &gt;= pageSize) {<a name="line.518"></a>
+<span class="sourceLineNo">519</span>        Assert.assertTrue(<a name="line.519"></a>
+<span class="sourceLineNo">520</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.520"></a>
+<span class="sourceLineNo">521</span>            filter.filterAllRemaining());<a name="line.521"></a>
+<span class="sourceLineNo">522</span>      }<a name="line.522"></a>
+<span class="sourceLineNo">523</span>      if (!isMoreResults) {<a name="line.523"></a>
+<span class="sourceLineNo">524</span>        break;<a name="line.524"></a>
+<span class="sourceLineNo">525</span>      }<a name="line.525"></a>
+<span class="sourceLineNo">526</span>    }<a name="line.526"></a>
+<span class="sourceLineNo">527</span>    scanner.close();<a name="line.527"></a>
+<span class="sourceLineNo">528</span>    Assert.assertEquals("The page filter returned more rows than expected",<a name="line.528"></a>
+<span class="sourceLineNo">529</span>        pageSize, scannerCounter);<a name="line.529"></a>
+<span class="sourceLineNo">530</span>  }<a name="line.530"></a>
+<span class="sourceLineNo">531</span><a name="line.531"></a>
+<span class="sourceLineNo">532</span>  @Test<a name="line.532"></a>
+<span class="sourceLineNo">533</span>  public void testWhileMatchFilterWithFilterRowKeyWithReverseScan()<a name="line.533"></a>
+<span class="sourceLineNo">534</span>      throws Exception {<a name="line.534"></a>
+<span class="sourceLineNo">535</span>    Scan s = new Scan();<a name="line.535"></a>
+<span class="sourceLineNo">536</span>    String prefix = "testRowOne";<a name="line.536"></a>
+<span class="sourceLineNo">537</span>    WhileMatchFilter filter = new WhileMatchFilter(new PrefixFilter(<a name="line.537"></a>
+<span class="sourceLineNo">538</span>        Bytes.toBytes(prefix)));<a name="line.538"></a>
+<span class="sourceLineNo">539</span>    s.setFilter(filter);<a name="line.539"></a>
+<span class="sourceLineNo">540</span>    s.setReversed(true);<a name="line.540"></a>
+<span class="sourceLineNo">541</span><a name="line.541"></a>
+<span class="sourceLineNo">542</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.542"></a>
+<span class="sourceLineNo">543</span>    while (true) {<a name="line.543"></a>
+<span class="sourceLineNo">544</span>      ArrayList&lt;Cell&gt; values = new ArrayList&lt;&gt;();<a name="line.544"></a>
+<span class="sourceLineNo">545</span>      boolean isMoreResults = scanner.next(values);<a name="line.545"></a>
+<span class="sourceLineNo">546</span>      if (!isMoreResults<a name="line.546"></a>
+<span class="sourceLineNo">547</span>          || !Bytes.toString(CellUtil.cloneRow(values.get(0))).startsWith(prefix)) {<a name="line.547"></a>
+<span class="sourceLineNo">548</span>        Assert.assertTrue(<a name="line.548"></a>
+<span class="sourceLineNo">549</span>            "The WhileMatchFilter should now filter all remaining",<a name="line.549"></a>
+<span class="sourceLineNo">550</span>            filter.filterAllRemaining());<a name="line.550"></a>
+<span class="sourceLineNo">551</span>      }<a name="line.551"></a>
+<span class="sourceLineNo">552</span>      if (!isMoreResults) {<a name="line.552"></a>
+<span class="sourceLineNo">553</span>        break;<a name="line.553"></a>
+<span class="sourceLineNo">554</span>      }<a name="line.554"></a>
+<span class="sourceLineNo">555</span>    }<a name="line.555"></a>
+<span class="sourceLineNo">556</span>    scanner.close();<a name="line.556"></a>
+<span class="sourceLineNo">557</span>  }<a name="line.557"></a>
+<span class="sourceLineNo">558</span><a name="line.558"></a>
+<span class="sourceLineNo">559</span>  /**<a name="line.559"></a>
+<span class="sourceLineNo">560</span>   * Tests the the {@link WhileMatchFilter} works in combination with a<a name="line.560"></a>
+<span class="sourceLineNo">561</span>   * {@link Filter} that uses the<a name="line.561"></a>
+<span class="sourceLineNo">562</span>   * {@link Filter#filterRow()} method.<a name="line.562"></a>
+<span class="sourceLineNo">563</span>   *<a name="line.563"></a>
+<span class="sourceLineNo">564</span>   * See HBASE-2258.<a name="line.564"></a>
+<span class="sourceLineNo">565</span>   *<a name="line.565"></a>
+<span class="sourceLineNo">566</span>   * @throws Exception<a name="line.566"></a>
+<span class="sourceLineNo">567</span>   */<a name="line.567"></a>
+<span class="sourceLineNo">568</span>  @Test<a name="line.568"></a>
+<span class="sourceLineNo">569</span>  public void testWhileMatchFilterWithFilterRow() throws Exception {<a name="line.569"></a>
+<span class="sourceLineNo">570</span>    final int pageSize = 4;<a name="line.570"></a>
+<span class="sourceLineNo">571</span><a name="line.571"></a>
+<span class="sourceLineNo">572</span>    Scan s = new Scan();<a name="line.572"></a>
+<span class="sourceLineNo">573</span>    WhileMatchFilter filter = new WhileMatchFilter(new PageFilter(pageSize));<a name="line.573"></a>
+<span class="sourceLineNo">574</span>    s.setFilter(filter);<a name="line.574"></a>
+<span class="sourceLineNo">575</span><a name="line.575"></a>
+<span class="sourceLineNo">576</span>    InternalScanner scanner = this.region.getScanner(s);<a name="line.576"></a>
+<span class="sourceLineNo">577</span>    int scannerCounter = 0;<a name="line.577"></a>
+<span class="sourceLineNo">578</span>    while (true) {<a name="line.578"></a>
+<span class="sourceLineNo">579</span>      boolean isMoreResults = scanner.next(new ArrayList&lt;&gt;());<a name="line.579"></a>
+<span class="sourceLineNo">580</span>      scannerCounter++;<a name="line.580"></a>
+<span class="sourceLineNo">581</span><a name="line.581"></a>
+<span class="sourceLineNo">582</span>      if (scannerCounter &gt;= pageSize) {<a name="line.582"></a>
+<span class="sourceLineNo">583</span>        assertTrue("The WhileMatchFilter should now filter all remaining", filter.filterAllRemaining());<a name="line.583"></a>
+<span class="sourceLineNo">584</span>      }<a name="line.584"></a>
+<span class="sourceLineNo">585</span>      if (!isMoreResults) {<a name="line.585"></a>
+<span class="sourceLineNo">586</span>        break;<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>    assertEquals("The page filter returned more rows than expected", pageSize, scannerCounter);<a name="line.589"></a>
+<span class="sourceLineNo">590</span>  }<a name="line.590"></a>
 <span class="sourceLineNo">591</span><a name="line.591"></a>
-<span class="sourceLineNo">592</span>  /**<a name="line.592"></a>
-<span class="sourceLineNo">593</span>   * The following filter simulates a pre-0.96 filter where filterRow()

<TRUNCATED>

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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/checkstyle.rss
----------------------------------------------------------------------
diff --git a/checkstyle.rss b/checkstyle.rss
index e477dcc..d4fb66e 100644
--- a/checkstyle.rss
+++ b/checkstyle.rss
@@ -1329,7 +1329,7 @@ under the License.
                   0
                 </td>
                 <td>
-                  2
+                  1
                 </td>
               </tr>
                           <tr>
@@ -8609,7 +8609,7 @@ under the License.
                   0
                 </td>
                 <td>
-                  3
+                  4
                 </td>
               </tr>
                           <tr>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/coc.html
----------------------------------------------------------------------
diff --git a/coc.html b/coc.html
index 338350c..db97fba 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/cygwin.html
----------------------------------------------------------------------
diff --git a/cygwin.html b/cygwin.html
index 867702e..679ebb9 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/dependencies.html
----------------------------------------------------------------------
diff --git a/dependencies.html b/dependencies.html
index 64071b5..97d49a6 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/dependency-convergence.html b/dependency-convergence.html
index 99b0eed..8dd7b3f 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -1082,7 +1082,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/dependency-info.html
----------------------------------------------------------------------
diff --git a/dependency-info.html b/dependency-info.html
index 5b3efef..42d6fce 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/dependency-management.html
----------------------------------------------------------------------
diff --git a/dependency-management.html b/dependency-management.html
index 1b4abc9..f133174 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/constant-values.html
----------------------------------------------------------------------
diff --git a/devapidocs/constant-values.html b/devapidocs/constant-values.html
index daf6fa6..2d80272 100644
--- a/devapidocs/constant-values.html
+++ b/devapidocs/constant-values.html
@@ -3747,21 +3747,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 Jan  7 14:43:00 UTC 2018"</code></td>
+<td class="colLast"><code>"Mon Jan  8 14:42:49 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>"8ae2a2150b517123cde214bb5543557b562c4c01"</code></td>
+<td class="colLast"><code>"afc2cdbaffca6cb1f8495451a0b0940ad1fc4be0"</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>"8254324d460162e9c8d1041940c3ed82"</code></td>
+<td class="colLast"><code>"468663e6dd7dacd9c2be13c6e5d55570"</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/123d826c/devapidocs/index-all.html
----------------------------------------------------------------------
diff --git a/devapidocs/index-all.html b/devapidocs/index-all.html
index 0e8c8dc..3893be3 100644
--- a/devapidocs/index-all.html
+++ b/devapidocs/index-all.html
@@ -25452,10 +25452,12 @@
 <dd>
 <div class="block">The transaction id that was set in here when we were marked done.</div>
 </dd>
-<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">doneWithColumn(Cell)</a></span> - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.<a href="org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html" title="class in org.apache.hadoop.hbase.regionserver.querymatcher">ExplicitColumnTracker</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">doneWithColumn(Cell)</a></span> - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.<a href="org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html" title="interface in org.apache.hadoop.hbase.regionserver.querymatcher">ColumnTracker</a></dt>
 <dd>
 <div class="block">This method is used to inform the column tracker that we are done with this column.</div>
 </dd>
+<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">doneWithColumn(Cell)</a></span> - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.<a href="org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html" title="class in org.apache.hadoop.hbase.regionserver.querymatcher">ExplicitColumnTracker</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/wal/WALSplitter.EntryBuffers.html#doneWriting-org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer-">doneWriting(WALSplitter.RegionEntryBuffer)</a></span> - Method in class org.apache.hadoop.hbase.wal.<a href="org/apache/hadoop/hbase/wal/WALSplitter.EntryBuffers.html" title="class in org.apache.hadoop.hbase.wal">WALSplitter.EntryBuffers</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/regionserver/RSRpcServices.html#doNonAtomicRegionMutation-org.apache.hadoop.hbase.regionserver.HRegion-org.apache.hadoop.hbase.quotas.OperationQuota-org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionAction-org.apache.hadoop.hbase.CellScanner-org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder-java.util.List-long-org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannersCloseCallBack-org.apache.hadoop.hbase.ipc.RpcCallContext-org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement-">doNonAtomicRegionMutation(HRegion, OperationQuota, ClientProtos.RegionAction, CellScanner, ClientProtos.RegionActionResult.Builder, List&lt;CellScannable&gt;, long, RSRpcServices.RegionScannersCloseCallBack, RpcCallContext, ActivePolicyEnforcement)</a></span> - Method in class org.apache.hadoop.hbase.regionserver.<a href="org/apache/hadoop/hbase/regionserver/RSRpcServices.html" 
 title="class in org.apache.hadoop.hbase.regionserver">RSRpcServices</a></dt>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/backup/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/backup/package-tree.html b/devapidocs/org/apache/hadoop/hbase/backup/package-tree.html
index 6c52348..be58c2a 100644
--- a/devapidocs/org/apache/hadoop/hbase/backup/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/backup/package-tree.html
@@ -167,10 +167,10 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
-<li type="circle">org.apache.hadoop.hbase.backup.<a href="../../../../../org/apache/hadoop/hbase/backup/BackupRestoreConstants.BackupCommand.html" title="enum in org.apache.hadoop.hbase.backup"><span class="typeNameLink">BackupRestoreConstants.BackupCommand</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.backup.<a href="../../../../../org/apache/hadoop/hbase/backup/BackupType.html" title="enum in org.apache.hadoop.hbase.backup"><span class="typeNameLink">BackupType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.backup.<a href="../../../../../org/apache/hadoop/hbase/backup/BackupInfo.BackupPhase.html" title="enum in org.apache.hadoop.hbase.backup"><span class="typeNameLink">BackupInfo.BackupPhase</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.backup.<a href="../../../../../org/apache/hadoop/hbase/backup/BackupInfo.BackupState.html" title="enum in org.apache.hadoop.hbase.backup"><span class="typeNameLink">BackupInfo.BackupState</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.backup.<a href="../../../../../org/apache/hadoop/hbase/backup/BackupInfo.BackupPhase.html" title="enum in org.apache.hadoop.hbase.backup"><span class="typeNameLink">BackupInfo.BackupPhase</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.backup.<a href="../../../../../org/apache/hadoop/hbase/backup/BackupType.html" title="enum in org.apache.hadoop.hbase.backup"><span class="typeNameLink">BackupType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.backup.<a href="../../../../../org/apache/hadoop/hbase/backup/BackupRestoreConstants.BackupCommand.html" title="enum in org.apache.hadoop.hbase.backup"><span class="typeNameLink">BackupRestoreConstants.BackupCommand</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/class-use/Cell.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/class-use/Cell.html b/devapidocs/org/apache/hadoop/hbase/class-use/Cell.html
index 83bdebe..531a7f6 100644
--- a/devapidocs/org/apache/hadoop/hbase/class-use/Cell.html
+++ b/devapidocs/org/apache/hadoop/hbase/class-use/Cell.html
@@ -7554,79 +7554,83 @@ service.</div>
 </tr>
 <tr class="rowColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><span class="typeNameLabel">ExplicitColumnTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">doneWithColumn</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
+<td class="colLast"><span class="typeNameLabel">ExplicitColumnTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">doneWithColumn</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>default void</code></td>
+<td class="colLast"><span class="typeNameLabel">ColumnTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">doneWithColumn</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
 <div class="block">This method is used to inform the column tracker that we are done with this column.</div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a></code></td>
 <td class="colLast"><span class="typeNameLabel">ScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.html#getKeyForNextColumn-org.apache.hadoop.hbase.Cell-">getKeyForNextColumn</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a></code></td>
 <td class="colLast"><span class="typeNameLabel">CompactionScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/CompactionScanQueryMatcher.html#getNextKeyHint-org.apache.hadoop.hbase.Cell-">getNextKeyHint</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>abstract <a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a></code></td>
 <td class="colLast"><span class="typeNameLabel">ScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.html#getNextKeyHint-org.apache.hadoop.hbase.Cell-">getNextKeyHint</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
 <div class="block">Delegate to <a href="../../../../../org/apache/hadoop/hbase/filter/Filter.html#getNextCellHint-org.apache.hadoop.hbase.Cell-"><code>Filter.getNextCellHint(Cell)</code></a>.</div>
 </td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a></code></td>
 <td class="colLast"><span class="typeNameLabel">UserScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#getNextKeyHint-org.apache.hadoop.hbase.Cell-">getNextKeyHint</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">NewVersionBehaviorTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/NewVersionBehaviorTracker.html#getNextRowOrNextColumn-org.apache.hadoop.hbase.Cell-">getNextRowOrNextColumn</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">ExplicitColumnTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ExplicitColumnTracker.html#getNextRowOrNextColumn-org.apache.hadoop.hbase.Cell-">getNextRowOrNextColumn</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">ScanWildcardColumnTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanWildcardColumnTracker.html#getNextRowOrNextColumn-org.apache.hadoop.hbase.Cell-">getNextRowOrNextColumn</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">ColumnTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#getNextRowOrNextColumn-org.apache.hadoop.hbase.Cell-">getNextRowOrNextColumn</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
 <div class="block">Retrieve the MatchCode for the next row or column</div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>private static boolean</code></td>
 <td class="colLast"><span class="typeNameLabel">ScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.html#isCellTTLExpired-org.apache.hadoop.hbase.Cell-long-long-">isCellTTLExpired</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell,
                 long&nbsp;oldestTimestamp,
                 long&nbsp;now)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/DeleteTracker.DeleteResult.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">DeleteTracker.DeleteResult</a></code></td>
 <td class="colLast"><span class="typeNameLabel">NewVersionBehaviorTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/NewVersionBehaviorTracker.html#isDeleted-org.apache.hadoop.hbase.Cell-">isDeleted</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
 <div class="block">This method is not idempotent, we will save some info to judge VERSION_MASKED.</div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/DeleteTracker.DeleteResult.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">DeleteTracker.DeleteResult</a></code></td>
 <td class="colLast"><span class="typeNameLabel">ScanDeleteTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanDeleteTracker.html#isDeleted-org.apache.hadoop.hbase.Cell-">isDeleted</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
 <div class="block">Check if the specified Cell buffer has been deleted by a previously seen delete.</div>
 </td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/DeleteTracker.DeleteResult.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">DeleteTracker.DeleteResult</a></code></td>
 <td class="colLast"><span class="typeNameLabel">DeleteTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/DeleteTracker.html#isDeleted-org.apache.hadoop.hbase.Cell-">isDeleted</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
 <div class="block">Check if the specified cell buffer has been deleted by a previously seen delete.</div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">MajorCompactionScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/MajorCompactionScanQueryMatcher.html#match-org.apache.hadoop.hbase.Cell-">match</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">NormalUserScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/NormalUserScanQueryMatcher.html#match-org.apache.hadoop.hbase.Cell-">match</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>abstract <a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">ScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.html#match-org.apache.hadoop.hbase.Cell-">match</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
 <div class="block">Determines if the caller should do one of several things:
@@ -7639,73 +7643,73 @@ service.</div>
  </div>
 </td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">MinorCompactionScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/MinorCompactionScanQueryMatcher.html#match-org.apache.hadoop.hbase.Cell-">match</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">StripeCompactionScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/StripeCompactionScanQueryMatcher.html#match-org.apache.hadoop.hbase.Cell-">match</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">RawScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/RawScanQueryMatcher.html#match-org.apache.hadoop.hbase.Cell-">match</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">IncludeAllCompactionQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/IncludeAllCompactionQueryMatcher.html#match-org.apache.hadoop.hbase.Cell-">match</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code>protected <a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">UserScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#matchColumn-org.apache.hadoop.hbase.Cell-long-byte-">matchColumn</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell,
            long&nbsp;timestamp,
            byte&nbsp;typeByte)</code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>private <a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">UserScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#mergeFilterResponse-org.apache.hadoop.hbase.Cell-org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode-org.apache.hadoop.hbase.filter.Filter.ReturnCode-">mergeFilterResponse</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell,
                    <a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a>&nbsp;matchCode,
                    <a href="../../../../../org/apache/hadoop/hbase/filter/Filter.ReturnCode.html" title="enum in org.apache.hadoop.hbase.filter">Filter.ReturnCode</a>&nbsp;filterResponse)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code>boolean</code></td>
 <td class="colLast"><span class="typeNameLabel">CompactionScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/CompactionScanQueryMatcher.html#moreRowsMayExistAfter-org.apache.hadoop.hbase.Cell-">moreRowsMayExistAfter</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>abstract boolean</code></td>
 <td class="colLast"><span class="typeNameLabel">ScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.html#moreRowsMayExistAfter-org.apache.hadoop.hbase.Cell-">moreRowsMayExistAfter</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code>boolean</code></td>
 <td class="colLast"><span class="typeNameLabel">UserScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/UserScanQueryMatcher.html#moreRowsMayExistAfter-org.apache.hadoop.hbase.Cell-">moreRowsMayExistAfter</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>protected <a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">ScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.html#preCheck-org.apache.hadoop.hbase.Cell-">preCheck</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
 <div class="block">Check before the delete logic.</div>
 </td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code>protected long</code></td>
 <td class="colLast"><span class="typeNameLabel">NewVersionBehaviorTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/NewVersionBehaviorTracker.html#prepare-org.apache.hadoop.hbase.Cell-">prepare</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
 <div class="block">Reset the map if it is different with the last Cell.</div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>private void</code></td>
 <td class="colLast"><span class="typeNameLabel">ScanWildcardColumnTracker.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanWildcardColumnTracker.html#resetCell-org.apache.hadoop.hbase.Cell-">resetCell</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;columnCell)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><span class="typeNameLabel">ScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.html#setToNewRow-org.apache.hadoop.hbase.Cell-">setToNewRow</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;currentRow)</code>
 <div class="block">Set the row when there is change in row</div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>protected void</code></td>
 <td class="colLast"><span class="typeNameLabel">CompactionScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/CompactionScanQueryMatcher.html#trackDelete-org.apache.hadoop.hbase.Cell-">trackDelete</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code>protected <a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><span class="typeNameLabel">DropDeletesCompactionScanQueryMatcher.</span><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/DropDeletesCompactionScanQueryMatcher.html#tryDropDelete-org.apache.hadoop.hbase.Cell-">tryDropDelete</a></span>(<a href="../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>&nbsp;</td>
 </tr>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/client/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/client/package-tree.html b/devapidocs/org/apache/hadoop/hbase/client/package-tree.html
index 4392064..7c2c41a 100644
--- a/devapidocs/org/apache/hadoop/hbase/client/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/client/package-tree.html
@@ -545,24 +545,24 @@
 <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.client.<a href="../../../../../org/apache/hadoop/hbase/client/RegionLocateType.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">RegionLocateType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/CompactType.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">CompactType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/Scan.ReadType.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">Scan.ReadType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/Durability.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">Durability</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/AsyncScanSingleRegionRpcRetryingCaller.ScanResumerState.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">AsyncScanSingleRegionRpcRetryingCaller.ScanResumerState</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/TableState.State.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">TableState.State</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/Consistency.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">Consistency</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/ScannerCallable.MoreResults.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">ScannerCallable.MoreResults</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/RequestController.ReturnCode.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">RequestController.ReturnCode</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/MasterSwitchType.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">MasterSwitchType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/AsyncProcessTask.SubmittedRows.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">AsyncProcessTask.SubmittedRows</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/Scan.ReadType.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">Scan.ReadType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/IsolationLevel.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">IsolationLevel</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/AbstractResponse.ResponseType.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">AbstractResponse.ResponseType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/SnapshotType.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">SnapshotType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/CompactionState.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">CompactionState</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/CompactType.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">CompactType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/Consistency.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">Consistency</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/AsyncRequestFutureImpl.Retry.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">AsyncRequestFutureImpl.Retry</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/MobCompactPartitionPolicy.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">MobCompactPartitionPolicy</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/RequestController.ReturnCode.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">RequestController.ReturnCode</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/Durability.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">Durability</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/SnapshotType.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">SnapshotType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/AsyncScanSingleRegionRpcRetryingCaller.ScanControllerState.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">AsyncScanSingleRegionRpcRetryingCaller.ScanControllerState</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/RegionLocateType.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">RegionLocateType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/ScannerCallable.MoreResults.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">ScannerCallable.MoreResults</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/AbstractResponse.ResponseType.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">AbstractResponse.ResponseType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/CompactionState.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">CompactionState</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.client.<a href="../../../../../org/apache/hadoop/hbase/client/TableState.State.html" title="enum in org.apache.hadoop.hbase.client"><span class="typeNameLink">TableState.State</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/filter/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/filter/package-tree.html b/devapidocs/org/apache/hadoop/hbase/filter/package-tree.html
index 39e7fc5..53d61d8 100644
--- a/devapidocs/org/apache/hadoop/hbase/filter/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/filter/package-tree.html
@@ -182,14 +182,14 @@
 <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.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/FuzzyRowFilter.Order.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">FuzzyRowFilter.Order</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/RegexStringComparator.EngineType.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">RegexStringComparator.EngineType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/Filter.ReturnCode.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">Filter.ReturnCode</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/CompareFilter.CompareOp.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">CompareFilter.CompareOp</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/FilterList.Operator.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">FilterList.Operator</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/BitComparator.BitwiseOp.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">BitComparator.BitwiseOp</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/FuzzyRowFilter.SatisfiesCode.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">FuzzyRowFilter.SatisfiesCode</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/Filter.ReturnCode.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">Filter.ReturnCode</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/FilterWrapper.FilterRowRetCode.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">FilterWrapper.FilterRowRetCode</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/RegexStringComparator.EngineType.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">RegexStringComparator.EngineType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/FuzzyRowFilter.Order.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">FuzzyRowFilter.Order</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/FilterList.Operator.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">FilterList.Operator</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.filter.<a href="../../../../../org/apache/hadoop/hbase/filter/BitComparator.BitwiseOp.html" title="enum in org.apache.hadoop.hbase.filter"><span class="typeNameLink">BitComparator.BitwiseOp</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html
index ddc3676..cde63fe 100644
--- a/devapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html
@@ -273,10 +273,10 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
-<li type="circle">org.apache.hadoop.hbase.io.hfile.<a href="../../../../../../org/apache/hadoop/hbase/io/hfile/BlockPriority.html" title="enum in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">BlockPriority</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.io.hfile.<a href="../../../../../../org/apache/hadoop/hbase/io/hfile/HFileBlock.Writer.State.html" title="enum in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">HFileBlock.Writer.State</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.io.hfile.<a href="../../../../../../org/apache/hadoop/hbase/io/hfile/CacheConfig.ExternalBlockCaches.html" title="enum in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">CacheConfig.ExternalBlockCaches</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.io.hfile.<a href="../../../../../../org/apache/hadoop/hbase/io/hfile/Cacheable.MemoryType.html" title="enum in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">Cacheable.MemoryType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.io.hfile.<a href="../../../../../../org/apache/hadoop/hbase/io/hfile/BlockPriority.html" title="enum in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">BlockPriority</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.io.hfile.<a href="../../../../../../org/apache/hadoop/hbase/io/hfile/CacheConfig.ExternalBlockCaches.html" title="enum in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">CacheConfig.ExternalBlockCaches</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.io.hfile.<a href="../../../../../../org/apache/hadoop/hbase/io/hfile/BlockType.BlockCategory.html" title="enum in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">BlockType.BlockCategory</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.io.hfile.<a href="../../../../../../org/apache/hadoop/hbase/io/hfile/BlockType.html" title="enum in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">BlockType</span></a></li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/mapreduce/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/mapreduce/package-tree.html b/devapidocs/org/apache/hadoop/hbase/mapreduce/package-tree.html
index 3a510c5..946e0a1 100644
--- a/devapidocs/org/apache/hadoop/hbase/mapreduce/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/mapreduce/package-tree.html
@@ -295,8 +295,8 @@
 <ul>
 <li type="circle">org.apache.hadoop.hbase.mapreduce.<a href="../../../../../org/apache/hadoop/hbase/mapreduce/RowCounter.RowCounterMapper.Counters.html" title="enum in org.apache.hadoop.hbase.mapreduce"><span class="typeNameLink">RowCounter.RowCounterMapper.Counters</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.mapreduce.<a href="../../../../../org/apache/hadoop/hbase/mapreduce/SyncTable.SyncMapper.Counter.html" title="enum in org.apache.hadoop.hbase.mapreduce"><span class="typeNameLink">SyncTable.SyncMapper.Counter</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.mapreduce.<a href="../../../../../org/apache/hadoop/hbase/mapreduce/CellCounter.CellCounterMapper.Counters.html" title="enum in org.apache.hadoop.hbase.mapreduce"><span class="typeNameLink">CellCounter.CellCounterMapper.Counters</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.mapreduce.<a href="../../../../../org/apache/hadoop/hbase/mapreduce/TableSplit.Version.html" title="enum in org.apache.hadoop.hbase.mapreduce"><span class="typeNameLink">TableSplit.Version</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.mapreduce.<a href="../../../../../org/apache/hadoop/hbase/mapreduce/CellCounter.CellCounterMapper.Counters.html" title="enum in org.apache.hadoop.hbase.mapreduce"><span class="typeNameLink">CellCounter.CellCounterMapper.Counters</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/master/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/master/package-tree.html b/devapidocs/org/apache/hadoop/hbase/master/package-tree.html
index 2c7c270..34fddd4 100644
--- a/devapidocs/org/apache/hadoop/hbase/master/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/master/package-tree.html
@@ -333,9 +333,9 @@
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
 <li type="circle">org.apache.hadoop.hbase.master.<a href="../../../../../org/apache/hadoop/hbase/master/RegionState.State.html" title="enum in org.apache.hadoop.hbase.master"><span class="typeNameLink">RegionState.State</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.master.<a href="../../../../../org/apache/hadoop/hbase/master/MasterRpcServices.BalanceSwitchMode.html" title="enum in org.apache.hadoop.hbase.master"><span class="typeNameLink">MasterRpcServices.BalanceSwitchMode</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.master.<a href="../../../../../org/apache/hadoop/hbase/master/SplitLogManager.TerminationStatus.html" title="enum in org.apache.hadoop.hbase.master"><span class="typeNameLink">SplitLogManager.TerminationStatus</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.master.<a href="../../../../../org/apache/hadoop/hbase/master/MetricsMasterSourceFactoryImpl.FactoryStorage.html" title="enum in org.apache.hadoop.hbase.master"><span class="typeNameLink">MetricsMasterSourceFactoryImpl.FactoryStorage</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.master.<a href="../../../../../org/apache/hadoop/hbase/master/SplitLogManager.TerminationStatus.html" title="enum in org.apache.hadoop.hbase.master"><span class="typeNameLink">SplitLogManager.TerminationStatus</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.master.<a href="../../../../../org/apache/hadoop/hbase/master/MasterRpcServices.BalanceSwitchMode.html" title="enum in org.apache.hadoop.hbase.master"><span class="typeNameLink">MasterRpcServices.BalanceSwitchMode</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.master.<a href="../../../../../org/apache/hadoop/hbase/master/SplitLogManager.ResubmitDirective.html" title="enum in org.apache.hadoop.hbase.master"><span class="typeNameLink">SplitLogManager.ResubmitDirective</span></a></li>
 </ul>
 </li>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/package-tree.html b/devapidocs/org/apache/hadoop/hbase/package-tree.html
index 62b604b..417cdc5 100644
--- a/devapidocs/org/apache/hadoop/hbase/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/package-tree.html
@@ -443,20 +443,20 @@
 <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/KeyValue.Type.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">KeyValue.Type</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/CompatibilitySingletonFactory.SingletonStorage.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">CompatibilitySingletonFactory.SingletonStorage</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/Size.Unit.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">Size.Unit</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/ProcedureState.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ProcedureState</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/HealthChecker.HealthCheckerExitStatus.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">HealthChecker.HealthCheckerExitStatus</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/ClusterMetrics.Option.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ClusterMetrics.Option</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/MemoryCompactionPolicy.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">MemoryCompactionPolicy</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/CellBuilderType.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">CellBuilderType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/KeyValue.Type.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">KeyValue.Type</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/CompareOperator.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">CompareOperator</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/MetaTableAccessor.QueryType.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">MetaTableAccessor.QueryType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/HealthChecker.HealthCheckerExitStatus.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">HealthChecker.HealthCheckerExitStatus</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/ProcedureState.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ProcedureState</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/Coprocessor.State.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">Coprocessor.State</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/CompatibilitySingletonFactory.SingletonStorage.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">CompatibilitySingletonFactory.SingletonStorage</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/HConstants.OperationStatusCode.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">HConstants.OperationStatusCode</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/Cell.Type.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">Cell.Type</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/KeepDeletedCells.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">KeepDeletedCells</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/MemoryCompactionPolicy.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">MemoryCompactionPolicy</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/Cell.Type.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">Cell.Type</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/CellBuilderType.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">CellBuilderType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/HConstants.OperationStatusCode.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">HConstants.OperationStatusCode</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/MetaTableAccessor.QueryType.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">MetaTableAccessor.QueryType</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html b/devapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
index 85d7f9f..86d5485 100644
--- a/devapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
@@ -203,10 +203,10 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
-<li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/RootProcedureState.State.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">RootProcedureState.State</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/LockedResourceType.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">LockedResourceType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/LockType.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">LockType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/StateMachineProcedure.Flow.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">StateMachineProcedure.Flow</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/RootProcedureState.State.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">RootProcedureState.State</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/LockedResourceType.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">LockedResourceType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/Procedure.LockState.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">Procedure.LockState</span></a></li>
 </ul>
 </li>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/quotas/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/quotas/package-tree.html b/devapidocs/org/apache/hadoop/hbase/quotas/package-tree.html
index 6eccb2e..23fa181 100644
--- a/devapidocs/org/apache/hadoop/hbase/quotas/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/quotas/package-tree.html
@@ -206,12 +206,12 @@
 <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.quotas.<a href="../../../../../org/apache/hadoop/hbase/quotas/SpaceViolationPolicy.html" title="enum in org.apache.hadoop.hbase.quotas"><span class="typeNameLink">SpaceViolationPolicy</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.quotas.<a href="../../../../../org/apache/hadoop/hbase/quotas/QuotaScope.html" title="enum in org.apache.hadoop.hbase.quotas"><span class="typeNameLink">QuotaScope</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.quotas.<a href="../../../../../org/apache/hadoop/hbase/quotas/OperationQuota.OperationType.html" title="enum in org.apache.hadoop.hbase.quotas"><span class="typeNameLink">OperationQuota.OperationType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.quotas.<a href="../../../../../org/apache/hadoop/hbase/quotas/ThrottleType.html" title="enum in org.apache.hadoop.hbase.quotas"><span class="typeNameLink">ThrottleType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.quotas.<a href="../../../../../org/apache/hadoop/hbase/quotas/QuotaType.html" title="enum in org.apache.hadoop.hbase.quotas"><span class="typeNameLink">QuotaType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.quotas.<a href="../../../../../org/apache/hadoop/hbase/quotas/SpaceViolationPolicy.html" title="enum in org.apache.hadoop.hbase.quotas"><span class="typeNameLink">SpaceViolationPolicy</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.quotas.<a href="../../../../../org/apache/hadoop/hbase/quotas/ThrottlingException.Type.html" title="enum in org.apache.hadoop.hbase.quotas"><span class="typeNameLink">ThrottlingException.Type</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.quotas.<a href="../../../../../org/apache/hadoop/hbase/quotas/QuotaScope.html" title="enum in org.apache.hadoop.hbase.quotas"><span class="typeNameLink">QuotaScope</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.quotas.<a href="../../../../../org/apache/hadoop/hbase/quotas/ThrottleType.html" title="enum in org.apache.hadoop.hbase.quotas"><span class="typeNameLink">ThrottleType</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html b/devapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
index ae6b2a5..90f884d 100644
--- a/devapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
+++ b/devapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
@@ -703,19 +703,19 @@
 <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/BloomType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">BloomType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/SplitLogWorker.TaskExecutor.Status.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">SplitLogWorker.TaskExecutor.Status</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/ScannerContext.LimitScope.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">ScannerContext.LimitScope</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/MetricsRegionServerSourceFactoryImpl.FactoryStorage.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">MetricsRegionServerSourceFactoryImpl.FactoryStorage</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/FlushType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">FlushType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/ScanType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">ScanType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/TimeRangeTracker.Type.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TimeRangeTracker.Type</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/MemStoreCompactionStrategy.Action.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">MemStoreCompactionStrategy.Action</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/ScannerContext.NextState.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">ScannerContext.NextState</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/CompactingMemStore.IndexType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">CompactingMemStore.IndexType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/HRegion.FlushResult.Result.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">HRegion.FlushResult.Result</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/TimeRangeTracker.Type.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TimeRangeTracker.Type</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/BloomType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">BloomType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/DefaultHeapMemoryTuner.StepDirection.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">DefaultHeapMemoryTuner.StepDirection</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/ScannerContext.NextState.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">ScannerContext.NextState</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/FlushType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">FlushType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/ScanType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">ScanType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/Region.Operation.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">Region.Operation</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/HRegion.FlushResult.Result.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">HRegion.FlushResult.Result</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/CompactingMemStore.IndexType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">CompactingMemStore.IndexType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/MetricsRegionServerSourceFactoryImpl.FactoryStorage.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">MetricsRegionServerSourceFactoryImpl.FactoryStorage</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html
index 6957574..369b5ae 100644
--- a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html
+++ b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html
@@ -18,8 +18,8 @@
     catch(err) {
     }
 //-->
-var methods = {"i0":6,"i1":6,"i2":6,"i3":6,"i4":6,"i5":6,"i6":6};
-var tabs = {65535:["t0","All Methods"],2:["t2","Instance Methods"],4:["t3","Abstract Methods"]};
+var methods = {"i0":6,"i1":6,"i2":6,"i3":18,"i4":6,"i5":6,"i6":6,"i7":6};
+var tabs = {65535:["t0","All Methods"],2:["t2","Instance Methods"],4:["t3","Abstract Methods"],16:["t5","Default Methods"]};
 var altColor = "altColor";
 var rowColor = "rowColor";
 var tableTab = "tableTab";
@@ -148,7 +148,7 @@ extends <a href="../../../../../../org/apache/hadoop/hbase/regionserver/ShipperL
 </a>
 <h3>Method Summary</h3>
 <table class="memberSummary" border="0" cellpadding="3" cellspacing="0" summary="Method Summary table, listing methods, and an explanation">
-<caption><span id="t0" class="activeTableTab"><span>All Methods</span><span class="tabEnd">&nbsp;</span></span><span id="t2" class="tableTab"><span><a href="javascript:show(2);">Instance Methods</a></span><span class="tabEnd">&nbsp;</span></span><span id="t3" class="tableTab"><span><a href="javascript:show(4);">Abstract Methods</a></span><span class="tabEnd">&nbsp;</span></span></caption>
+<caption><span id="t0" class="activeTableTab"><span>All Methods</span><span class="tabEnd">&nbsp;</span></span><span id="t2" class="tableTab"><span><a href="javascript:show(2);">Instance Methods</a></span><span class="tabEnd">&nbsp;</span></span><span id="t3" class="tableTab"><span><a href="javascript:show(4);">Abstract Methods</a></span><span class="tabEnd">&nbsp;</span></span><span id="t5" class="tableTab"><span><a href="javascript:show(16);">Default Methods</a></span><span class="tabEnd">&nbsp;</span></span></caption>
 <tr>
 <th class="colFirst" scope="col">Modifier and Type</th>
 <th class="colLast" scope="col">Method and Description</th>
@@ -175,26 +175,32 @@ extends <a href="../../../../../../org/apache/hadoop/hbase/regionserver/ShipperL
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#done--">done</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i3" class="rowColor">
+<td class="colFirst"><code>default void</code></td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#doneWithColumn-org.apache.hadoop.hbase.Cell-">doneWithColumn</a></span>(<a href="../../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
+<div class="block">This method is used to inform the column tracker that we are done with this column.</div>
+</td>
+</tr>
+<tr id="i4" class="altColor">
 <td class="colFirst"><code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnCount.html" title="class in org.apache.hadoop.hbase.regionserver.querymatcher">ColumnCount</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#getColumnHint--">getColumnHint</a></span>()</code>
 <div class="block">Used by matcher and scan/get to get a hint of the next column
  to seek to after checkColumn() returns SKIP.</div>
 </td>
 </tr>
-<tr id="i4" class="altColor">
+<tr id="i5" class="rowColor">
 <td class="colFirst"><code><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ScanQueryMatcher.MatchCode.html" title="enum in org.apache.hadoop.hbase.regionserver.querymatcher">ScanQueryMatcher.MatchCode</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#getNextRowOrNextColumn-org.apache.hadoop.hbase.Cell-">getNextRowOrNextColumn</a></span>(<a href="../../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</code>
 <div class="block">Retrieve the MatchCode for the next row or column</div>
 </td>
 </tr>
-<tr id="i5" class="rowColor">
+<tr id="i6" class="altColor">
 <td class="colFirst"><code>boolean</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#isDone-long-">isDone</a></span>(long&nbsp;timestamp)</code>
 <div class="block">Give the tracker a chance to declare it's done based on only the timestamp
  to allow an early out.</div>
 </td>
 </tr>
-<tr id="i6" class="altColor">
+<tr id="i7" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../../org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#reset--">reset</a></span>()</code>
 <div class="block">Resets the Matcher</div>
@@ -343,7 +349,7 @@ extends <a href="../../../../../../org/apache/hadoop/hbase/regionserver/ShipperL
 <a name="isDone-long-">
 <!--   -->
 </a>
-<ul class="blockListLast">
+<ul class="blockList">
 <li class="blockList">
 <h4>isDone</h4>
 <pre>boolean&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#line.128">isDone</a>(long&nbsp;timestamp)</pre>
@@ -357,6 +363,22 @@ extends <a href="../../../../../../org/apache/hadoop/hbase/regionserver/ShipperL
 </dl>
 </li>
 </ul>
+<a name="doneWithColumn-org.apache.hadoop.hbase.Cell-">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>doneWithColumn</h4>
+<pre>default&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/regionserver/querymatcher/ColumnTracker.html#line.136">doneWithColumn</a>(<a href="../../../../../../org/apache/hadoop/hbase/Cell.html" title="interface in org.apache.hadoop.hbase">Cell</a>&nbsp;cell)</pre>
+<div class="block">This method is used to inform the column tracker that we are done with this column. We may get
+ this information from external filters or timestamp range and we then need to indicate this
+ information to tracker. It is currently implemented for ExplicitColumnTracker.</div>
+<dl>
+<dt><span class="paramLabel">Parameters:</span></dt>
+<dd><code>cell</code> - </dd>
+</dl>
+</li>
+</ul>
 </li>
 </ul>
 </li>


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 8f676ba..0e133d4 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 d0c1afa..69d032a 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 b52f588..d430ef7 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 e697e4e..9e6d7e5 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 9bda866..3655ff2 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 6f72aca..157d8de 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 13ab59c..b600fb8 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 7576282..ced43f2 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 cb98054..7654dfd 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 89024b5..f8b41a4 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 08a1adb..c802ad0 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 c842a5e..63fef7a 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 7e697da..7487cc3 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 b7ef11c..307161b 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 25e169b..2274dd8 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 bc1668b..e9f5423 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 be62da6..3d08c6f 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 caa7fce..91af73e 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 26fbb67..8ac5775 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 b823c60..4eee8c8 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 ce6b1d4..fdd19db 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 105e2c6..0766958 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 cb3bad7..53cb6c1 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 a722a93..4701f7c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/index.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/index.html b/hbase-build-configuration/index.html
index 470e8d5..6c74ec6 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/integration.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/integration.html b/hbase-build-configuration/integration.html
index bffdf28..f794ef2 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/issue-tracking.html b/hbase-build-configuration/issue-tracking.html
index 07b6d95..46308ea 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/license.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/license.html b/hbase-build-configuration/license.html
index 3a92f91..a619711 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/mail-lists.html b/hbase-build-configuration/mail-lists.html
index 200f34e..d4e9259 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/plugin-management.html b/hbase-build-configuration/plugin-management.html
index a9c8390..0b6318a 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/plugins.html b/hbase-build-configuration/plugins.html
index a5d6b5e..67585cc 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/project-info.html b/hbase-build-configuration/project-info.html
index 5cb2a01..11fb21b 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/project-summary.html b/hbase-build-configuration/project-summary.html
index 2c464fa..e0af78d 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/source-repository.html b/hbase-build-configuration/source-repository.html
index e09d569..9c5c262 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-build-configuration/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/team-list.html b/hbase-build-configuration/team-list.html
index 4c21863..25f02b7 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-shaded-check-invariants/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/checkstyle.html b/hbase-shaded-check-invariants/checkstyle.html
index e87a6d6..06332cc 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-shaded-check-invariants/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/dependencies.html b/hbase-shaded-check-invariants/dependencies.html
index 35aca6e..969a954 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 cb04f5e..1e0f85c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 45f0a4d..c41dd9f 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 4208e1a..2633193 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-shaded-check-invariants/index.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/index.html b/hbase-shaded-check-invariants/index.html
index a7868c9..341b194 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-shaded-check-invariants/integration.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/integration.html b/hbase-shaded-check-invariants/integration.html
index 475daf7..0e2c603 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 9fa9daf..8e2f404 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-shaded-check-invariants/license.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/license.html b/hbase-shaded-check-invariants/license.html
index c32a93e..58396fa 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 7271383..fb631a0 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 87b0b34..9b1d7cc 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/hbase-shaded-check-invariants/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/plugins.html b/hbase-shaded-check-invariants/plugins.html
index 61f531d..ef8d599e6 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 07dffe1..07060dc 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 2440922..35a4184 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 bb45290..4af6ccb 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 25661c2..0e63ddd 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 cfea414..f88013c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/index.html
----------------------------------------------------------------------
diff --git a/index.html b/index.html
index 2fc848d..29c56e7 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/integration.html
----------------------------------------------------------------------
diff --git a/integration.html b/integration.html
index acb3c83..fa21f7c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/issue-tracking.html
----------------------------------------------------------------------
diff --git a/issue-tracking.html b/issue-tracking.html
index 1ffb05a..820e0c8 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/license.html
----------------------------------------------------------------------
diff --git a/license.html b/license.html
index 4c946ea..a028eb2 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/mail-lists.html
----------------------------------------------------------------------
diff --git a/mail-lists.html b/mail-lists.html
index 21d2a0d..fda029e 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/metrics.html
----------------------------------------------------------------------
diff --git a/metrics.html b/metrics.html
index deb38a5..4d6f199 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/old_news.html
----------------------------------------------------------------------
diff --git a/old_news.html b/old_news.html
index d90ddbf..5f09079 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/plugin-management.html
----------------------------------------------------------------------
diff --git a/plugin-management.html b/plugin-management.html
index a80ac34..2529a66 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/plugins.html
----------------------------------------------------------------------
diff --git a/plugins.html b/plugins.html
index e6ae301..cc56f34 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/poweredbyhbase.html
----------------------------------------------------------------------
diff --git a/poweredbyhbase.html b/poweredbyhbase.html
index c7343db..19fca55 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/project-info.html
----------------------------------------------------------------------
diff --git a/project-info.html b/project-info.html
index 2f56a58..43950ac 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/project-reports.html
----------------------------------------------------------------------
diff --git a/project-reports.html b/project-reports.html
index fb8a70b..793ee1d 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/project-summary.html
----------------------------------------------------------------------
diff --git a/project-summary.html b/project-summary.html
index 207bccb..29e98b9 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/pseudo-distributed.html
----------------------------------------------------------------------
diff --git a/pseudo-distributed.html b/pseudo-distributed.html
index 6eb1fb1..1be6e19 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/replication.html
----------------------------------------------------------------------
diff --git a/replication.html b/replication.html
index 68ddfa8..4345b4c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/resources.html
----------------------------------------------------------------------
diff --git a/resources.html b/resources.html
index 2c61ebe..a37e510 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/source-repository.html
----------------------------------------------------------------------
diff --git a/source-repository.html b/source-repository.html
index 98832c9..b275f7c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/sponsors.html
----------------------------------------------------------------------
diff --git a/sponsors.html b/sponsors.html
index f9413a5..0c0ecd3 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/supportingprojects.html
----------------------------------------------------------------------
diff --git a/supportingprojects.html b/supportingprojects.html
index e12cab3..139435e 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/team-list.html
----------------------------------------------------------------------
diff --git a/team-list.html b/team-list.html
index 3127b13..21efb8c 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/index-all.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/index-all.html b/testdevapidocs/index-all.html
index 61e6b11..a1806f8 100644
--- a/testdevapidocs/index-all.html
+++ b/testdevapidocs/index-all.html
@@ -48143,6 +48143,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/rest/TestGetAndPutResource.html#testLatestCellGetJSON--">testLatestCellGetJSON()</a></span> - Method in class org.apache.hadoop.hbase.rest.<a href="org/apache/hadoop/hbase/rest/TestGetAndPutResource.html" title="class in org.apache.hadoop.hbase.rest">TestGetAndPutResource</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/filter/TestFilter.html#testLatestVersionFilterWithExplicitColumn--">testLatestVersionFilterWithExplicitColumn()</a></span> - Method in class org.apache.hadoop.hbase.filter.<a href="org/apache/hadoop/hbase/filter/TestFilter.html" title="class in org.apache.hadoop.hbase.filter">TestFilter</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/hadoop/hbase/io/hfile/TestLazyDataBlockDecompression.html" title="class in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">TestLazyDataBlockDecompression</span></a> - Class in <a href="org/apache/hadoop/hbase/io/hfile/package-summary.html">org.apache.hadoop.hbase.io.hfile</a></dt>
 <dd>
 <div class="block">A kind of integration test at the intersection of <code>HFileBlock</code>, <code>CacheConfig</code>,

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html b/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html
index 8823edf..4644a85 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html
@@ -123,7 +123,7 @@ var activeTableTab = "activeTableTab";
 </dl>
 <hr>
 <br>
-<pre>static class <a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.596">TestFilter.OldTestFilter</a>
+<pre>static class <a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.597">TestFilter.OldTestFilter</a>
 extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <div class="block">The following filter simulates a pre-0.96 filter where filterRow() is defined while
  hasFilterRow() returns false</div>
@@ -250,7 +250,7 @@ extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <ul class="blockListLast">
 <li class="blockList">
 <h4>OldTestFilter</h4>
-<pre><a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html#line.596">OldTestFilter</a>()</pre>
+<pre><a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html#line.597">OldTestFilter</a>()</pre>
 </li>
 </ul>
 </li>
@@ -267,7 +267,7 @@ extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <ul class="blockList">
 <li class="blockList">
 <h4>toByteArray</h4>
-<pre>public&nbsp;byte[]&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html#line.598">toByteArray</a>()</pre>
+<pre>public&nbsp;byte[]&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html#line.599">toByteArray</a>()</pre>
 <dl>
 <dt><span class="overrideSpecifyLabel">Overrides:</span></dt>
 <dd><code>toByteArray</code>&nbsp;in class&nbsp;<code>org.apache.hadoop.hbase.filter.FilterBase</code></dd>
@@ -280,7 +280,7 @@ extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <ul class="blockList">
 <li class="blockList">
 <h4>hasFilterRow</h4>
-<pre>public&nbsp;boolean&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html#line.601">hasFilterRow</a>()</pre>
+<pre>public&nbsp;boolean&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html#line.602">hasFilterRow</a>()</pre>
 <dl>
 <dt><span class="overrideSpecifyLabel">Overrides:</span></dt>
 <dd><code>hasFilterRow</code>&nbsp;in class&nbsp;<code>org.apache.hadoop.hbase.filter.FilterBase</code></dd>
@@ -293,7 +293,7 @@ extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <ul class="blockList">
 <li class="blockList">
 <h4>filterRow</h4>
-<pre>public&nbsp;boolean&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html#line.606">filterRow</a>()</pre>
+<pre>public&nbsp;boolean&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html#line.607">filterRow</a>()</pre>
 <dl>
 <dt><span class="overrideSpecifyLabel">Overrides:</span></dt>
 <dd><code>filterRow</code>&nbsp;in class&nbsp;<code>org.apache.hadoop.hbase.filter.FilterBase</code></dd>
@@ -306,7 +306,7 @@ extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <ul class="blockListLast">
 <li class="blockList">
 <h4>filterCell</h4>
-<pre>public&nbsp;org.apache.hadoop.hbase.filter.Filter.ReturnCode&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html#line.612">filterCell</a>(org.apache.hadoop.hbase.Cell&nbsp;ignored)
+<pre>public&nbsp;org.apache.hadoop.hbase.filter.Filter.ReturnCode&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.OldTestFilter.html#line.613">filterCell</a>(org.apache.hadoop.hbase.Cell&nbsp;ignored)
                                                             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="overrideSpecifyLabel">Overrides:</span></dt>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html b/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html
index c6c6a7b..81492a0 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html
@@ -123,7 +123,7 @@ var activeTableTab = "activeTableTab";
 </dl>
 <hr>
 <br>
-<pre>public static class <a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.2031">TestFilter.SlowScanFilter</a>
+<pre>public static class <a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.2091">TestFilter.SlowScanFilter</a>
 extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <div class="block">Filter which makes sleeps for a second between each row of a scan.
  This can be useful for manual testing of bugs like HBASE-5973. For example:
@@ -263,7 +263,7 @@ extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <ul class="blockListLast">
 <li class="blockList">
 <h4>ipcHandlerThread</h4>
-<pre>private static&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Thread.html?is-external=true" title="class or interface in java.lang">Thread</a> <a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html#line.2032">ipcHandlerThread</a></pre>
+<pre>private static&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Thread.html?is-external=true" title="class or interface in java.lang">Thread</a> <a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html#line.2092">ipcHandlerThread</a></pre>
 </li>
 </ul>
 </li>
@@ -280,7 +280,7 @@ extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <ul class="blockListLast">
 <li class="blockList">
 <h4>SlowScanFilter</h4>
-<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html#line.2031">SlowScanFilter</a>()</pre>
+<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html#line.2091">SlowScanFilter</a>()</pre>
 </li>
 </ul>
 </li>
@@ -297,7 +297,7 @@ extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <ul class="blockList">
 <li class="blockList">
 <h4>toByteArray</h4>
-<pre>public&nbsp;byte[]&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html#line.2035">toByteArray</a>()</pre>
+<pre>public&nbsp;byte[]&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html#line.2095">toByteArray</a>()</pre>
 <dl>
 <dt><span class="overrideSpecifyLabel">Overrides:</span></dt>
 <dd><code>toByteArray</code>&nbsp;in class&nbsp;<code>org.apache.hadoop.hbase.filter.FilterBase</code></dd>
@@ -310,7 +310,7 @@ extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <ul class="blockList">
 <li class="blockList">
 <h4>filterCell</h4>
-<pre>public&nbsp;org.apache.hadoop.hbase.filter.Filter.ReturnCode&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html#line.2038">filterCell</a>(org.apache.hadoop.hbase.Cell&nbsp;ignored)
+<pre>public&nbsp;org.apache.hadoop.hbase.filter.Filter.ReturnCode&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html#line.2098">filterCell</a>(org.apache.hadoop.hbase.Cell&nbsp;ignored)
                                                             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="overrideSpecifyLabel">Overrides:</span></dt>
@@ -326,7 +326,7 @@ extends org.apache.hadoop.hbase.filter.FilterBase</pre>
 <ul class="blockListLast">
 <li class="blockList">
 <h4>filterRow</h4>
-<pre>public&nbsp;boolean&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html#line.2043">filterRow</a>()
+<pre>public&nbsp;boolean&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.SlowScanFilter.html#line.2103">filterRow</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="overrideSpecifyLabel">Overrides:</span></dt>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.html b/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.html
index 9694c5f..a48cef1 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/filter/TestFilter.html
@@ -18,7 +18,7 @@
     catch(err) {
     }
 //-->
-var methods = {"i0":10,"i1":10,"i2":10,"i3":10,"i4":10,"i5":10,"i6":10,"i7":10,"i8":10,"i9":10,"i10":10,"i11":10,"i12":10,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":10,"i21":10,"i22":10,"i23":10,"i24":10,"i25":10,"i26":10,"i27":10,"i28":10,"i29":10,"i30":10,"i31":10,"i32":10,"i33":10};
+var methods = {"i0":10,"i1":10,"i2":10,"i3":10,"i4":10,"i5":10,"i6":10,"i7":10,"i8":10,"i9":10,"i10":10,"i11":10,"i12":10,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":10,"i21":10,"i22":10,"i23":10,"i24":10,"i25":10,"i26":10,"i27":10,"i28":10,"i29":10,"i30":10,"i31":10,"i32":10,"i33":10,"i34":10};
 var tabs = {65535:["t0","All Methods"],2:["t2","Instance Methods"],8:["t4","Concrete Methods"]};
 var altColor = "altColor";
 var rowColor = "rowColor";
@@ -319,60 +319,64 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 </tr>
 <tr id="i13" class="rowColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testNestedFilterListWithSCVF--">testNestedFilterListWithSCVF</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testLatestVersionFilterWithExplicitColumn--">testLatestVersionFilterWithExplicitColumn</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i14" class="altColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testNoFilter--">testNoFilter</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testNestedFilterListWithSCVF--">testNestedFilterListWithSCVF</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i15" class="rowColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testPageFilter--">testPageFilter</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testNoFilter--">testNoFilter</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i16" class="altColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testPageFilterWithReverseScan--">testPageFilterWithReverseScan</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testPageFilter--">testPageFilter</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i17" class="rowColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testPrefixFilter--">testPrefixFilter</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testPageFilterWithReverseScan--">testPageFilterWithReverseScan</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i18" class="altColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testPrefixFilterWithReverseScan--">testPrefixFilterWithReverseScan</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testPrefixFilter--">testPrefixFilter</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i19" class="rowColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testQualifierFilter--">testQualifierFilter</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testPrefixFilterWithReverseScan--">testPrefixFilterWithReverseScan</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i20" class="altColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testRegionScannerReseek--">testRegionScannerReseek</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testQualifierFilter--">testQualifierFilter</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i21" class="rowColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testRowFilter--">testRowFilter</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testRegionScannerReseek--">testRegionScannerReseek</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i22" class="altColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testSingleColumnValueFilter--">testSingleColumnValueFilter</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testRowFilter--">testRowFilter</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i23" class="rowColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testSkipFilter--">testSkipFilter</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testSingleColumnValueFilter--">testSingleColumnValueFilter</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i24" class="altColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testValueFilter--">testValueFilter</a></span>()</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testSkipFilter--">testSkipFilter</a></span>()</code>&nbsp;</td>
 </tr>
 <tr id="i25" class="rowColor">
 <td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testValueFilter--">testValueFilter</a></span>()</code>&nbsp;</td>
+</tr>
+<tr id="i26" class="altColor">
+<td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testWhileMatchFilterWithFilterCell--">testWhileMatchFilterWithFilterCell</a></span>()</code>
 <div class="block">Tests the the <code>WhileMatchFilter</code> works in combination with a
  <code>Filter</code> that uses the <code>Filter.filterCell(Cell)</code> method.</div>
 </td>
 </tr>
-<tr id="i26" class="altColor">
+<tr id="i27" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testWhileMatchFilterWithFilterRow--">testWhileMatchFilterWithFilterRow</a></span>()</code>
 <div class="block">Tests the the <code>WhileMatchFilter</code> works in combination with a
@@ -380,7 +384,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
  <code>Filter.filterRow()</code> method.</div>
 </td>
 </tr>
-<tr id="i27" class="rowColor">
+<tr id="i28" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testWhileMatchFilterWithFilterRowKey--">testWhileMatchFilterWithFilterRowKey</a></span>()</code>
 <div class="block">Tests the the <code>WhileMatchFilter</code> works in combination with a
@@ -388,32 +392,32 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
  <code>Filter.filterRowKey(Cell)</code> method.</div>
 </td>
 </tr>
-<tr id="i28" class="altColor">
+<tr id="i29" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testWhileMatchFilterWithFilterRowKeyWithReverseScan--">testWhileMatchFilterWithFilterRowKeyWithReverseScan</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i29" class="rowColor">
+<tr id="i30" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#testWhileMatchFilterWithFilterRowWithReverseScan--">testWhileMatchFilterWithFilterRowWithReverseScan</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i30" class="altColor">
+<tr id="i31" class="rowColor">
 <td class="colFirst"><code>private void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#verifyScan-org.apache.hadoop.hbase.client.Scan-long-long-">verifyScan</a></span>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
           long&nbsp;expectedRows,
           long&nbsp;expectedKeys)</code>&nbsp;</td>
 </tr>
-<tr id="i31" class="rowColor">
+<tr id="i32" class="altColor">
 <td class="colFirst"><code>private void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#verifyScanFull-org.apache.hadoop.hbase.client.Scan-org.apache.hadoop.hbase.KeyValue:A-">verifyScanFull</a></span>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
               org.apache.hadoop.hbase.KeyValue[]&nbsp;kvs)</code>&nbsp;</td>
 </tr>
-<tr id="i32" class="altColor">
+<tr id="i33" class="rowColor">
 <td class="colFirst"><code>private void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#verifyScanFullNoValues-org.apache.hadoop.hbase.client.Scan-org.apache.hadoop.hbase.KeyValue:A-boolean-">verifyScanFullNoValues</a></span>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
                       org.apache.hadoop.hbase.KeyValue[]&nbsp;kvs,
                       boolean&nbsp;useLen)</code>&nbsp;</td>
 </tr>
-<tr id="i33" class="rowColor">
+<tr id="i34" class="altColor">
 <td class="colFirst"><code>private void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/filter/TestFilter.html#verifyScanNoEarlyOut-org.apache.hadoop.hbase.client.Scan-long-long-">verifyScanNoEarlyOut</a></span>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
                     long&nbsp;expectedRows,
@@ -648,7 +652,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>tearDown</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.226">tearDown</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.227">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>
@@ -662,7 +666,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testRegionScannerReseek</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.231">testRegionScannerReseek</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.232">testRegionScannerReseek</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>
@@ -676,7 +680,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testNoFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.298">testNoFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.299">testNoFilter</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>
@@ -690,7 +694,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testPrefixFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.314">testPrefixFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.315">testPrefixFilter</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>
@@ -704,7 +708,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testPrefixFilterWithReverseScan</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.324">testPrefixFilterWithReverseScan</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.325">testPrefixFilterWithReverseScan</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>
@@ -718,7 +722,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testPageFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.335">testPageFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.336">testPageFilter</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>
@@ -732,7 +736,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testPageFilterWithReverseScan</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.422">testPageFilterWithReverseScan</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.423">testPageFilterWithReverseScan</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>
@@ -746,7 +750,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testWhileMatchFilterWithFilterRowWithReverseScan</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.502">testWhileMatchFilterWithFilterRowWithReverseScan</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.503">testWhileMatchFilterWithFilterRowWithReverseScan</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>
@@ -760,7 +764,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testWhileMatchFilterWithFilterRowKeyWithReverseScan</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.532">testWhileMatchFilterWithFilterRowKeyWithReverseScan</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.533">testWhileMatchFilterWithFilterRowKeyWithReverseScan</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>
@@ -774,7 +778,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testWhileMatchFilterWithFilterRow</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.568">testWhileMatchFilterWithFilterRow</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.569">testWhileMatchFilterWithFilterRow</a>()
                                        throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <div class="block">Tests the the <code>WhileMatchFilter</code> works in combination with a
  <code>Filter</code> that uses the
@@ -793,7 +797,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>test94FilterRowCompatibility</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.626">test94FilterRowCompatibility</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.627">test94FilterRowCompatibility</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 following test is to ensure old(such as hbase0.94) filterRow() can be correctly fired in
  0.96+ code base.
@@ -811,7 +815,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testWhileMatchFilterWithFilterRowKey</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.647">testWhileMatchFilterWithFilterRowKey</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.648">testWhileMatchFilterWithFilterRowKey</a>()
                                           throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <div class="block">Tests the the <code>WhileMatchFilter</code> works in combination with a
  <code>Filter</code> that uses the
@@ -830,7 +834,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testWhileMatchFilterWithFilterCell</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.675">testWhileMatchFilterWithFilterCell</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.676">testWhileMatchFilterWithFilterCell</a>()
                                         throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <div class="block">Tests the the <code>WhileMatchFilter</code> works in combination with a
  <code>Filter</code> that uses the <code>Filter.filterCell(Cell)</code> method.
@@ -848,7 +852,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testInclusiveStopFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.694">testInclusiveStopFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.695">testInclusiveStopFilter</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>
@@ -862,7 +866,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testInclusiveStopFilterWithReverseScan</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.729">testInclusiveStopFilterWithReverseScan</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.730">testInclusiveStopFilterWithReverseScan</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>
@@ -876,7 +880,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testQualifierFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.766">testQualifierFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.767">testQualifierFilter</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>
@@ -890,7 +894,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testFamilyFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.924">testFamilyFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.925">testFamilyFilter</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>
@@ -904,7 +908,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testRowFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1059">testRowFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1060">testRowFilter</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>
@@ -918,7 +922,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testValueFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1206">testValueFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1207">testValueFilter</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>
@@ -932,7 +936,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testSkipFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1330">testSkipFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1331">testSkipFilter</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>
@@ -946,7 +950,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testFilterList</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1368">testFilterList</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1369">testFilterList</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>
@@ -960,7 +964,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testFirstKeyOnlyFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1401">testFirstKeyOnlyFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1402">testFirstKeyOnlyFilter</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>
@@ -974,7 +978,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testFilterListWithSingleColumnValueFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1417">testFilterListWithSingleColumnValueFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1418">testFilterListWithSingleColumnValueFilter</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>
@@ -988,7 +992,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testFilterListWithPrefixFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1495">testFilterListWithPrefixFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1496">testFilterListWithPrefixFilter</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>
@@ -1002,7 +1006,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testSingleColumnValueFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1542">testSingleColumnValueFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1543">testSingleColumnValueFilter</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>
@@ -1016,7 +1020,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>verifyScan</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1661">verifyScan</a>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1662">verifyScan</a>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
                         long&nbsp;expectedRows,
                         long&nbsp;expectedKeys)
                  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>
@@ -1032,7 +1036,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>verifyScanNoEarlyOut</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1681">verifyScanNoEarlyOut</a>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1682">verifyScanNoEarlyOut</a>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
                                   long&nbsp;expectedRows,
                                   long&nbsp;expectedKeys)
                            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>
@@ -1048,7 +1052,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>verifyScanFull</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1703">verifyScanFull</a>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1704">verifyScanFull</a>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
                             org.apache.hadoop.hbase.KeyValue[]&nbsp;kvs)
                      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>
@@ -1063,7 +1067,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>verifyScanFullNoValues</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1734">verifyScanFullNoValues</a>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1735">verifyScanFullNoValues</a>(org.apache.hadoop.hbase.client.Scan&nbsp;s,
                                     org.apache.hadoop.hbase.KeyValue[]&nbsp;kvs,
                                     boolean&nbsp;useLen)
                              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>
@@ -1079,7 +1083,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testColumnPaginationFilterColumnOffset</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1778">testColumnPaginationFilterColumnOffset</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1779">testColumnPaginationFilterColumnOffset</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>
@@ -1087,13 +1091,27 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 </dl>
 </li>
 </ul>
+<a name="testLatestVersionFilterWithExplicitColumn--">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testLatestVersionFilterWithExplicitColumn</h4>
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1865">testLatestVersionFilterWithExplicitColumn</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="testColumnPaginationFilter--">
 <!--   -->
 </a>
 <ul class="blockList">
 <li class="blockList">
 <h4>testColumnPaginationFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1864">testColumnPaginationFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1924">testColumnPaginationFilter</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>
@@ -1107,7 +1125,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testKeyOnlyFilter</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.1962">testKeyOnlyFilter</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.2022">testKeyOnlyFilter</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>
@@ -1121,7 +1139,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>testNestedFilterListWithSCVF</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.2057">testNestedFilterListWithSCVF</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/filter/TestFilter.html#line.2117">testNestedFilterListWithSCVF</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>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 0d308cd..b7e36eb 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
@@ -584,15 +584,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/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/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/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/RESTApiClusterManager.RoleCommand.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">RESTApiClusterManager.RoleCommand</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/IntegrationTestDDLMasterFailover.ACTION.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">IntegrationTestDDLMasterFailover.ACTION</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/IntegrationTestRegionReplicaPerf.Stat.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">IntegrationTestRegionReplicaPerf.Stat</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/RESTApiClusterManager.Service.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">RESTApiClusterManager.Service</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/ScanPerformanceEvaluation.ScanCounter.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ScanPerformanceEvaluation.ScanCounter</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/ResourceChecker.Phase.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ResourceChecker.Phase</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/IntegrationTestRegionReplicaPerf.Stat.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">IntegrationTestRegionReplicaPerf.Stat</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/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/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>
 </ul>
 </li>
 </ul>

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

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html b/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
index b17704e..d249622 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
@@ -206,8 +206,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.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/TestProcedureRecovery.TestStateMachineProcedure.State.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">TestProcedureRecovery.TestStateMachineProcedure.State</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/TestYieldProcedures.TestStateMachineProcedure.State.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">TestYieldProcedures.TestStateMachineProcedure.State</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/TestStateMachineProcedure.TestSMProcedureState.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">TestStateMachineProcedure.TestSMProcedureState</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/TestYieldProcedures.TestStateMachineProcedure.State.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">TestYieldProcedures.TestStateMachineProcedure.State</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html b/testdevapidocs/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html
index 0064697..1582f72 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html
@@ -110,7 +110,7 @@ var activeTableTab = "activeTableTab";
 <hr>
 <br>
 <pre><a href="http://docs.oracle.com/javase/8/docs/api/java/lang/FunctionalInterface.html?is-external=true" title="class or interface in java.lang">@FunctionalInterface</a>
-private static interface <a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.355">TestSnapshotQuotaObserverChore.IOThrowingRunnable</a></pre>
+private static interface <a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.360">TestSnapshotQuotaObserverChore.IOThrowingRunnable</a></pre>
 </li>
 </ul>
 </div>
@@ -154,7 +154,7 @@ private static interface <a href="../../../../../src-html/org/apache/hadoop/hbas
 <ul class="blockListLast">
 <li class="blockList">
 <h4>run</h4>
-<pre>void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html#line.356">run</a>()
+<pre>void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html#line.361">run</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>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/testdevapidocs/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html b/testdevapidocs/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html
index 6793438..f9a6bbc 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html
@@ -504,7 +504,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testPersistingSnapshotsForNamespaces</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.302">testPersistingSnapshotsForNamespaces</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.307">testPersistingSnapshotsForNamespaces</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>
@@ -518,7 +518,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>count</h4>
-<pre>private&nbsp;long&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.323">count</a>(org.apache.hadoop.hbase.client.Table&nbsp;t)
+<pre>private&nbsp;long&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.328">count</a>(org.apache.hadoop.hbase.client.Table&nbsp;t)
             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>
@@ -532,7 +532,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>extractSnapshotSize</h4>
-<pre>private&nbsp;long&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.335">extractSnapshotSize</a>(org.apache.hadoop.hbase.client.Table&nbsp;quotaTable,
+<pre>private&nbsp;long&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.340">extractSnapshotSize</a>(org.apache.hadoop.hbase.client.Table&nbsp;quotaTable,
                                  org.apache.hadoop.hbase.TableName&nbsp;tn,
                                  <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;snapshot)
                           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>
@@ -548,7 +548,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>verify</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.348">verify</a>(org.apache.hadoop.hbase.client.Table&nbsp;t,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.353">verify</a>(org.apache.hadoop.hbase.client.Table&nbsp;t,
                     <a href="../../../../../org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.IOThrowingRunnable.html" title="interface in org.apache.hadoop.hbase.quotas">TestSnapshotQuotaObserverChore.IOThrowingRunnable</a>&nbsp;test)
              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>
@@ -563,7 +563,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>closeInSize</h4>
-<pre>boolean&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.362">closeInSize</a>(long&nbsp;size1,
+<pre>boolean&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/quotas/TestSnapshotQuotaObserverChore.html#line.367">closeInSize</a>(long&nbsp;size1,
                     long&nbsp;size2,
                     long&nbsp;delta)</pre>
 <div class="block">Computes if <code>size2</code> is within <code>delta</code> of <code>size1</code>, inclusive.</div>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/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 1a79a5d..337e137 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
@@ -630,9 +630,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.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/TestAtomicOperation.TestStep.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TestAtomicOperation.TestStep</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/DataBlockEncodingTool.Manipulation.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">DataBlockEncodingTool.Manipulation</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/TestRegionServerReadRequestMetrics.Metric.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TestRegionServerReadRequestMetrics.Metric</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/TestCacheOnWriteInSchema.CacheOnWriteType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TestCacheOnWriteInSchema.CacheOnWriteType</span></a></li>
 <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>
 </ul>

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

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


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

Branch: refs/heads/asf-site
Commit: 123d826c862808ab07a53d101bdf9d7a11956ad1
Parents: a4ad3e6
Author: jenkins <bu...@apache.org>
Authored: Mon Jan 8 15:30:59 2018 +0000
Committer: jenkins <bu...@apache.org>
Committed: Mon Jan 8 15:30:59 2018 +0000

----------------------------------------------------------------------
 acid-semantics.html                             |    4 +-
 apache_hbase_reference_guide.pdf                |    4 +-
 book.html                                       |    2 +-
 bulk-loads.html                                 |    4 +-
 checkstyle-aggregate.html                       |  736 ++--
 checkstyle.rss                                  |    4 +-
 coc.html                                        |    4 +-
 cygwin.html                                     |    4 +-
 dependencies.html                               |    4 +-
 dependency-convergence.html                     |    4 +-
 dependency-info.html                            |    4 +-
 dependency-management.html                      |    4 +-
 devapidocs/constant-values.html                 |    6 +-
 devapidocs/index-all.html                       |    4 +-
 .../hadoop/hbase/backup/package-tree.html       |    6 +-
 .../org/apache/hadoop/hbase/class-use/Cell.html |   66 +-
 .../hadoop/hbase/client/package-tree.html       |   22 +-
 .../hadoop/hbase/filter/package-tree.html       |   10 +-
 .../hadoop/hbase/io/hfile/package-tree.html     |    4 +-
 .../hadoop/hbase/mapreduce/package-tree.html    |    2 +-
 .../hadoop/hbase/master/package-tree.html       |    4 +-
 .../org/apache/hadoop/hbase/package-tree.html   |   18 +-
 .../hadoop/hbase/procedure2/package-tree.html   |    4 +-
 .../hadoop/hbase/quotas/package-tree.html       |    6 +-
 .../hadoop/hbase/regionserver/package-tree.html |   16 +-
 .../querymatcher/ColumnTracker.html             |   36 +-
 .../querymatcher/ExplicitColumnTracker.html     |   15 +-
 .../querymatcher/NewVersionBehaviorTracker.html |    7 +
 .../querymatcher/ScanWildcardColumnTracker.html |    7 +
 .../querymatcher/UserScanQueryMatcher.html      |    8 +-
 .../regionserver/querymatcher/package-tree.html |    4 +-
 .../hbase/security/access/package-tree.html     |    2 +-
 .../hadoop/hbase/security/package-tree.html     |    2 +-
 .../VisibilityNewVersionBehaivorTracker.html    |    7 +
 .../hadoop/hbase/thrift/package-tree.html       |    4 +-
 .../apache/hadoop/hbase/util/package-tree.html  |    8 +-
 .../apache/hadoop/hbase/wal/package-tree.html   |    2 +-
 .../org/apache/hadoop/hbase/Version.html        |    6 +-
 .../hadoop/hbase/io/hfile/BlockCacheKey.html    |    2 +-
 .../querymatcher/ColumnTracker.html             |   11 +-
 .../querymatcher/ExplicitColumnTracker.html     |   87 +-
 .../querymatcher/UserScanQueryMatcher.html      |  133 +-
 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 +
 .../hbase/filter/TestFilter.OldTestFilter.html  |   12 +-
 .../hbase/filter/TestFilter.SlowScanFilter.html |   12 +-
 .../apache/hadoop/hbase/filter/TestFilter.html  |  126 +-
 .../org/apache/hadoop/hbase/package-tree.html   |   10 +-
 .../hadoop/hbase/procedure/package-tree.html    |    8 +-
 .../hadoop/hbase/procedure2/package-tree.html   |    2 +-
 ...otQuotaObserverChore.IOThrowingRunnable.html |    4 +-
 .../quotas/TestSnapshotQuotaObserverChore.html  |   10 +-
 .../hadoop/hbase/regionserver/package-tree.html |    2 +-
 .../apache/hadoop/hbase/test/package-tree.html  |    4 +-
 .../apache/hadoop/hbase/wal/package-tree.html   |    2 +-
 .../hbase/filter/TestFilter.OldTestFilter.html  | 4052 +++++++++---------
 .../hbase/filter/TestFilter.SlowScanFilter.html | 4052 +++++++++---------
 .../apache/hadoop/hbase/filter/TestFilter.html  | 4052 +++++++++---------
 ...otQuotaObserverChore.IOThrowingRunnable.html |  319 +-
 .../quotas/TestSnapshotQuotaObserverChore.html  |  319 +-
 210 files changed, 7573 insertions(+), 7306 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/acid-semantics.html
----------------------------------------------------------------------
diff --git a/acid-semantics.html b/acid-semantics.html
index bd0e4d4..5ef04c5 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/apache_hbase_reference_guide.pdf
----------------------------------------------------------------------
diff --git a/apache_hbase_reference_guide.pdf b/apache_hbase_reference_guide.pdf
index a8a3623..d7a50ee 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:20180107144850+00'00')
-/CreationDate (D:20180107144850+00'00')
+/ModDate (D:20180108144840+00'00')
+/CreationDate (D:20180108144840+00'00')
 >>
 endobj
 2 0 obj

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/book.html
----------------------------------------------------------------------
diff --git a/book.html b/book.html
index 87f4833..6fd821f 100644
--- a/book.html
+++ b/book.html
@@ -37140,7 +37140,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-01-07 14:29:49 UTC
+Last updated 2018-01-08 14:29:39 UTC
 </div>
 </div>
 </body>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/123d826c/bulk-loads.html
----------------------------------------------------------------------
diff --git a/bulk-loads.html b/bulk-loads.html
index 682ff01..cff9129 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="20180107" />
+    <meta name="Date-Revision-yyyymmdd" content="20180108" />
     <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-01-07</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-08</li>
             </p>
                 </div>