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

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

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/devapidocs/src-html/org/apache/hadoop/hbase/AsyncMetaTableAccessor.html
----------------------------------------------------------------------
diff --git a/devapidocs/src-html/org/apache/hadoop/hbase/AsyncMetaTableAccessor.html b/devapidocs/src-html/org/apache/hadoop/hbase/AsyncMetaTableAccessor.html
index 4eae350..dc27b36 100644
--- a/devapidocs/src-html/org/apache/hadoop/hbase/AsyncMetaTableAccessor.html
+++ b/devapidocs/src-html/org/apache/hadoop/hbase/AsyncMetaTableAccessor.html
@@ -311,8 +311,8 @@
 <span class="sourceLineNo">303</span>    startRow.ifPresent(scan::withStartRow);<a name="line.303"></a>
 <span class="sourceLineNo">304</span>    stopRow.ifPresent(scan::withStopRow);<a name="line.304"></a>
 <span class="sourceLineNo">305</span><a name="line.305"></a>
-<span class="sourceLineNo">306</span>    if (LOG.isTraceEnabled()) {<a name="line.306"></a>
-<span class="sourceLineNo">307</span>      LOG.trace("Scanning META" + " starting at row=" + Bytes.toStringBinary(scan.getStartRow())<a name="line.307"></a>
+<span class="sourceLineNo">306</span>    if (LOG.isDebugEnabled()) {<a name="line.306"></a>
+<span class="sourceLineNo">307</span>      LOG.debug("Scanning META" + " starting at row=" + Bytes.toStringBinary(scan.getStartRow())<a name="line.307"></a>
 <span class="sourceLineNo">308</span>          + " stopping at row=" + Bytes.toStringBinary(scan.getStopRow()) + " for max="<a name="line.308"></a>
 <span class="sourceLineNo">309</span>          + rowUpperLimit + " with caching=" + scan.getCaching());<a name="line.309"></a>
 <span class="sourceLineNo">310</span>    }<a name="line.310"></a>
@@ -354,287 +354,294 @@
 <span class="sourceLineNo">346</span><a name="line.346"></a>
 <span class="sourceLineNo">347</span>    @Override<a name="line.347"></a>
 <span class="sourceLineNo">348</span>    public void onNext(Result[] results, ScanController controller) {<a name="line.348"></a>
-<span class="sourceLineNo">349</span>      for (Result result : results) {<a name="line.349"></a>
-<span class="sourceLineNo">350</span>        try {<a name="line.350"></a>
-<span class="sourceLineNo">351</span>          if (!visitor.visit(result)) {<a name="line.351"></a>
-<span class="sourceLineNo">352</span>            controller.terminate();<a name="line.352"></a>
-<span class="sourceLineNo">353</span>          }<a name="line.353"></a>
-<span class="sourceLineNo">354</span>        } catch (IOException e) {<a name="line.354"></a>
-<span class="sourceLineNo">355</span>          future.completeExceptionally(e);<a name="line.355"></a>
-<span class="sourceLineNo">356</span>          controller.terminate();<a name="line.356"></a>
-<span class="sourceLineNo">357</span>        }<a name="line.357"></a>
-<span class="sourceLineNo">358</span>        if (++currentRowCount &gt;= rowUpperLimit) {<a name="line.358"></a>
-<span class="sourceLineNo">359</span>          controller.terminate();<a name="line.359"></a>
+<span class="sourceLineNo">349</span>      boolean terminateScan = false;<a name="line.349"></a>
+<span class="sourceLineNo">350</span>      for (Result result : results) {<a name="line.350"></a>
+<span class="sourceLineNo">351</span>        try {<a name="line.351"></a>
+<span class="sourceLineNo">352</span>          if (!visitor.visit(result)) {<a name="line.352"></a>
+<span class="sourceLineNo">353</span>            terminateScan = true;<a name="line.353"></a>
+<span class="sourceLineNo">354</span>            break;<a name="line.354"></a>
+<span class="sourceLineNo">355</span>          }<a name="line.355"></a>
+<span class="sourceLineNo">356</span>        } catch (Exception e) {<a name="line.356"></a>
+<span class="sourceLineNo">357</span>          future.completeExceptionally(e);<a name="line.357"></a>
+<span class="sourceLineNo">358</span>          terminateScan = true;<a name="line.358"></a>
+<span class="sourceLineNo">359</span>          break;<a name="line.359"></a>
 <span class="sourceLineNo">360</span>        }<a name="line.360"></a>
-<span class="sourceLineNo">361</span>      }<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>  private static Scan getMetaScan(AsyncTable&lt;?&gt; metaTable, int rowUpperLimit) {<a name="line.365"></a>
-<span class="sourceLineNo">366</span>    Scan scan = new Scan();<a name="line.366"></a>
-<span class="sourceLineNo">367</span>    int scannerCaching = metaTable.getConfiguration().getInt(HConstants.HBASE_META_SCANNER_CACHING,<a name="line.367"></a>
-<span class="sourceLineNo">368</span>      HConstants.DEFAULT_HBASE_META_SCANNER_CACHING);<a name="line.368"></a>
-<span class="sourceLineNo">369</span>    if (metaTable.getConfiguration().getBoolean(HConstants.USE_META_REPLICAS,<a name="line.369"></a>
-<span class="sourceLineNo">370</span>      HConstants.DEFAULT_USE_META_REPLICAS)) {<a name="line.370"></a>
-<span class="sourceLineNo">371</span>      scan.setConsistency(Consistency.TIMELINE);<a name="line.371"></a>
-<span class="sourceLineNo">372</span>    }<a name="line.372"></a>
-<span class="sourceLineNo">373</span>    if (rowUpperLimit &lt;= scannerCaching) {<a name="line.373"></a>
-<span class="sourceLineNo">374</span>      scan.setLimit(rowUpperLimit);<a name="line.374"></a>
-<span class="sourceLineNo">375</span>    }<a name="line.375"></a>
-<span class="sourceLineNo">376</span>    int rows = Math.min(rowUpperLimit, scannerCaching);<a name="line.376"></a>
-<span class="sourceLineNo">377</span>    scan.setCaching(rows);<a name="line.377"></a>
-<span class="sourceLineNo">378</span>    return scan;<a name="line.378"></a>
-<span class="sourceLineNo">379</span>  }<a name="line.379"></a>
-<span class="sourceLineNo">380</span><a name="line.380"></a>
-<span class="sourceLineNo">381</span>  /**<a name="line.381"></a>
-<span class="sourceLineNo">382</span>   * Returns an HRegionLocationList extracted from the result.<a name="line.382"></a>
-<span class="sourceLineNo">383</span>   * @return an HRegionLocationList containing all locations for the region range or null if we<a name="line.383"></a>
-<span class="sourceLineNo">384</span>   *         can't deserialize the result.<a name="line.384"></a>
-<span class="sourceLineNo">385</span>   */<a name="line.385"></a>
-<span class="sourceLineNo">386</span>  private static Optional&lt;RegionLocations&gt; getRegionLocations(final Result r) {<a name="line.386"></a>
-<span class="sourceLineNo">387</span>    if (r == null) return Optional.empty();<a name="line.387"></a>
-<span class="sourceLineNo">388</span>    Optional&lt;RegionInfo&gt; regionInfo = getHRegionInfo(r, getRegionInfoColumn());<a name="line.388"></a>
-<span class="sourceLineNo">389</span>    if (!regionInfo.isPresent()) return Optional.empty();<a name="line.389"></a>
-<span class="sourceLineNo">390</span><a name="line.390"></a>
-<span class="sourceLineNo">391</span>    List&lt;HRegionLocation&gt; locations = new ArrayList&lt;HRegionLocation&gt;(1);<a name="line.391"></a>
-<span class="sourceLineNo">392</span>    NavigableMap&lt;byte[], NavigableMap&lt;byte[], byte[]&gt;&gt; familyMap = r.getNoVersionMap();<a name="line.392"></a>
-<span class="sourceLineNo">393</span><a name="line.393"></a>
-<span class="sourceLineNo">394</span>    locations.add(getRegionLocation(r, regionInfo.get(), 0));<a name="line.394"></a>
-<span class="sourceLineNo">395</span><a name="line.395"></a>
-<span class="sourceLineNo">396</span>    NavigableMap&lt;byte[], byte[]&gt; infoMap = familyMap.get(getCatalogFamily());<a name="line.396"></a>
-<span class="sourceLineNo">397</span>    if (infoMap == null) return Optional.of(new RegionLocations(locations));<a name="line.397"></a>
-<span class="sourceLineNo">398</span><a name="line.398"></a>
-<span class="sourceLineNo">399</span>    // iterate until all serverName columns are seen<a name="line.399"></a>
-<span class="sourceLineNo">400</span>    int replicaId = 0;<a name="line.400"></a>
-<span class="sourceLineNo">401</span>    byte[] serverColumn = getServerColumn(replicaId);<a name="line.401"></a>
-<span class="sourceLineNo">402</span>    SortedMap&lt;byte[], byte[]&gt; serverMap = null;<a name="line.402"></a>
-<span class="sourceLineNo">403</span>    serverMap = infoMap.tailMap(serverColumn, false);<a name="line.403"></a>
-<span class="sourceLineNo">404</span><a name="line.404"></a>
-<span class="sourceLineNo">405</span>    if (serverMap.isEmpty()) return Optional.of(new RegionLocations(locations));<a name="line.405"></a>
-<span class="sourceLineNo">406</span><a name="line.406"></a>
-<span class="sourceLineNo">407</span>    for (Map.Entry&lt;byte[], byte[]&gt; entry : serverMap.entrySet()) {<a name="line.407"></a>
-<span class="sourceLineNo">408</span>      replicaId = parseReplicaIdFromServerColumn(entry.getKey());<a name="line.408"></a>
-<span class="sourceLineNo">409</span>      if (replicaId &lt; 0) {<a name="line.409"></a>
-<span class="sourceLineNo">410</span>        break;<a name="line.410"></a>
-<span class="sourceLineNo">411</span>      }<a name="line.411"></a>
-<span class="sourceLineNo">412</span>      HRegionLocation location = getRegionLocation(r, regionInfo.get(), replicaId);<a name="line.412"></a>
-<span class="sourceLineNo">413</span>      // In case the region replica is newly created, it's location might be null. We usually do not<a name="line.413"></a>
-<span class="sourceLineNo">414</span>      // have HRL's in RegionLocations object with null ServerName. They are handled as null HRLs.<a name="line.414"></a>
-<span class="sourceLineNo">415</span>      if (location == null || location.getServerName() == null) {<a name="line.415"></a>
-<span class="sourceLineNo">416</span>        locations.add(null);<a name="line.416"></a>
-<span class="sourceLineNo">417</span>      } else {<a name="line.417"></a>
-<span class="sourceLineNo">418</span>        locations.add(location);<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>    return Optional.of(new RegionLocations(locations));<a name="line.422"></a>
-<span class="sourceLineNo">423</span>  }<a name="line.423"></a>
-<span class="sourceLineNo">424</span><a name="line.424"></a>
-<span class="sourceLineNo">425</span>  /**<a name="line.425"></a>
-<span class="sourceLineNo">426</span>   * Returns the HRegionLocation parsed from the given meta row Result<a name="line.426"></a>
-<span class="sourceLineNo">427</span>   * for the given regionInfo and replicaId. The regionInfo can be the default region info<a name="line.427"></a>
-<span class="sourceLineNo">428</span>   * for the replica.<a name="line.428"></a>
-<span class="sourceLineNo">429</span>   * @param r the meta row result<a name="line.429"></a>
-<span class="sourceLineNo">430</span>   * @param regionInfo RegionInfo for default replica<a name="line.430"></a>
-<span class="sourceLineNo">431</span>   * @param replicaId the replicaId for the HRegionLocation<a name="line.431"></a>
-<span class="sourceLineNo">432</span>   * @return HRegionLocation parsed from the given meta row Result for the given replicaId<a name="line.432"></a>
-<span class="sourceLineNo">433</span>   */<a name="line.433"></a>
-<span class="sourceLineNo">434</span>  private static HRegionLocation getRegionLocation(final Result r, final RegionInfo regionInfo,<a name="line.434"></a>
-<span class="sourceLineNo">435</span>      final int replicaId) {<a name="line.435"></a>
-<span class="sourceLineNo">436</span>    Optional&lt;ServerName&gt; serverName = getServerName(r, replicaId);<a name="line.436"></a>
-<span class="sourceLineNo">437</span>    long seqNum = getSeqNumDuringOpen(r, replicaId);<a name="line.437"></a>
-<span class="sourceLineNo">438</span>    RegionInfo replicaInfo = RegionReplicaUtil.getRegionInfoForReplica(regionInfo, replicaId);<a name="line.438"></a>
-<span class="sourceLineNo">439</span>    return new HRegionLocation(replicaInfo, serverName.orElse(null), seqNum);<a name="line.439"></a>
-<span class="sourceLineNo">440</span>  }<a name="line.440"></a>
-<span class="sourceLineNo">441</span><a name="line.441"></a>
-<span class="sourceLineNo">442</span>  /**<a name="line.442"></a>
-<span class="sourceLineNo">443</span>   * Returns a {@link ServerName} from catalog table {@link Result}.<a name="line.443"></a>
-<span class="sourceLineNo">444</span>   * @param r Result to pull from<a name="line.444"></a>
-<span class="sourceLineNo">445</span>   * @return A ServerName instance.<a name="line.445"></a>
-<span class="sourceLineNo">446</span>   */<a name="line.446"></a>
-<span class="sourceLineNo">447</span>  private static Optional&lt;ServerName&gt; getServerName(final Result r, final int replicaId) {<a name="line.447"></a>
-<span class="sourceLineNo">448</span>    byte[] serverColumn = getServerColumn(replicaId);<a name="line.448"></a>
-<span class="sourceLineNo">449</span>    Cell cell = r.getColumnLatestCell(getCatalogFamily(), serverColumn);<a name="line.449"></a>
-<span class="sourceLineNo">450</span>    if (cell == null || cell.getValueLength() == 0) return Optional.empty();<a name="line.450"></a>
-<span class="sourceLineNo">451</span>    String hostAndPort = Bytes.toString(cell.getValueArray(), cell.getValueOffset(),<a name="line.451"></a>
-<span class="sourceLineNo">452</span>      cell.getValueLength());<a name="line.452"></a>
-<span class="sourceLineNo">453</span>    byte[] startcodeColumn = getStartCodeColumn(replicaId);<a name="line.453"></a>
-<span class="sourceLineNo">454</span>    cell = r.getColumnLatestCell(getCatalogFamily(), startcodeColumn);<a name="line.454"></a>
-<span class="sourceLineNo">455</span>    if (cell == null || cell.getValueLength() == 0) return Optional.empty();<a name="line.455"></a>
-<span class="sourceLineNo">456</span>    try {<a name="line.456"></a>
-<span class="sourceLineNo">457</span>      return Optional.of(ServerName.valueOf(hostAndPort,<a name="line.457"></a>
-<span class="sourceLineNo">458</span>        Bytes.toLong(cell.getValueArray(), cell.getValueOffset(), cell.getValueLength())));<a name="line.458"></a>
-<span class="sourceLineNo">459</span>    } catch (IllegalArgumentException e) {<a name="line.459"></a>
-<span class="sourceLineNo">460</span>      LOG.error("Ignoring invalid region for server " + hostAndPort + "; cell=" + cell, e);<a name="line.460"></a>
-<span class="sourceLineNo">461</span>      return Optional.empty();<a name="line.461"></a>
-<span class="sourceLineNo">462</span>    }<a name="line.462"></a>
-<span class="sourceLineNo">463</span>  }<a name="line.463"></a>
-<span class="sourceLineNo">464</span><a name="line.464"></a>
-<span class="sourceLineNo">465</span>  /**<a name="line.465"></a>
-<span class="sourceLineNo">466</span>   * The latest seqnum that the server writing to meta observed when opening the region.<a name="line.466"></a>
-<span class="sourceLineNo">467</span>   * E.g. the seqNum when the result of {@link #getServerName(Result, int)} was written.<a name="line.467"></a>
-<span class="sourceLineNo">468</span>   * @param r Result to pull the seqNum from<a name="line.468"></a>
-<span class="sourceLineNo">469</span>   * @return SeqNum, or HConstants.NO_SEQNUM if there's no value written.<a name="line.469"></a>
-<span class="sourceLineNo">470</span>   */<a name="line.470"></a>
-<span class="sourceLineNo">471</span>  private static long getSeqNumDuringOpen(final Result r, final int replicaId) {<a name="line.471"></a>
-<span class="sourceLineNo">472</span>    Cell cell = r.getColumnLatestCell(getCatalogFamily(), getSeqNumColumn(replicaId));<a name="line.472"></a>
-<span class="sourceLineNo">473</span>    if (cell == null || cell.getValueLength() == 0) return HConstants.NO_SEQNUM;<a name="line.473"></a>
-<span class="sourceLineNo">474</span>    return Bytes.toLong(cell.getValueArray(), cell.getValueOffset(), cell.getValueLength());<a name="line.474"></a>
-<span class="sourceLineNo">475</span>  }<a name="line.475"></a>
-<span class="sourceLineNo">476</span><a name="line.476"></a>
-<span class="sourceLineNo">477</span>  /**<a name="line.477"></a>
-<span class="sourceLineNo">478</span>   * @param tableName table we're working with<a name="line.478"></a>
-<span class="sourceLineNo">479</span>   * @return start row for scanning META according to query type<a name="line.479"></a>
-<span class="sourceLineNo">480</span>   */<a name="line.480"></a>
-<span class="sourceLineNo">481</span>  private static Optional&lt;byte[]&gt; getTableStartRowForMeta(Optional&lt;TableName&gt; tableName,<a name="line.481"></a>
-<span class="sourceLineNo">482</span>      QueryType type) {<a name="line.482"></a>
-<span class="sourceLineNo">483</span>    return tableName.map((table) -&gt; {<a name="line.483"></a>
-<span class="sourceLineNo">484</span>      switch (type) {<a name="line.484"></a>
-<span class="sourceLineNo">485</span>      case REGION:<a name="line.485"></a>
-<span class="sourceLineNo">486</span>        byte[] startRow = new byte[table.getName().length + 2];<a name="line.486"></a>
-<span class="sourceLineNo">487</span>        System.arraycopy(table.getName(), 0, startRow, 0, table.getName().length);<a name="line.487"></a>
-<span class="sourceLineNo">488</span>        startRow[startRow.length - 2] = HConstants.DELIMITER;<a name="line.488"></a>
-<span class="sourceLineNo">489</span>        startRow[startRow.length - 1] = HConstants.DELIMITER;<a name="line.489"></a>
-<span class="sourceLineNo">490</span>        return startRow;<a name="line.490"></a>
-<span class="sourceLineNo">491</span>      case ALL:<a name="line.491"></a>
-<span class="sourceLineNo">492</span>      case TABLE:<a name="line.492"></a>
-<span class="sourceLineNo">493</span>      default:<a name="line.493"></a>
-<span class="sourceLineNo">494</span>        return table.getName();<a name="line.494"></a>
-<span class="sourceLineNo">495</span>      }<a name="line.495"></a>
-<span class="sourceLineNo">496</span>    });<a name="line.496"></a>
-<span class="sourceLineNo">497</span>  }<a name="line.497"></a>
-<span class="sourceLineNo">498</span><a name="line.498"></a>
-<span class="sourceLineNo">499</span>  /**<a name="line.499"></a>
-<span class="sourceLineNo">500</span>   * @param tableName table we're working with<a name="line.500"></a>
-<span class="sourceLineNo">501</span>   * @return stop row for scanning META according to query type<a name="line.501"></a>
-<span class="sourceLineNo">502</span>   */<a name="line.502"></a>
-<span class="sourceLineNo">503</span>  private static Optional&lt;byte[]&gt; getTableStopRowForMeta(Optional&lt;TableName&gt; tableName,<a name="line.503"></a>
-<span class="sourceLineNo">504</span>      QueryType type) {<a name="line.504"></a>
-<span class="sourceLineNo">505</span>    return tableName.map((table) -&gt; {<a name="line.505"></a>
-<span class="sourceLineNo">506</span>      final byte[] stopRow;<a name="line.506"></a>
-<span class="sourceLineNo">507</span>      switch (type) {<a name="line.507"></a>
-<span class="sourceLineNo">508</span>      case REGION:<a name="line.508"></a>
-<span class="sourceLineNo">509</span>        stopRow = new byte[table.getName().length + 3];<a name="line.509"></a>
-<span class="sourceLineNo">510</span>        System.arraycopy(table.getName(), 0, stopRow, 0, table.getName().length);<a name="line.510"></a>
-<span class="sourceLineNo">511</span>        stopRow[stopRow.length - 3] = ' ';<a name="line.511"></a>
-<span class="sourceLineNo">512</span>        stopRow[stopRow.length - 2] = HConstants.DELIMITER;<a name="line.512"></a>
-<span class="sourceLineNo">513</span>        stopRow[stopRow.length - 1] = HConstants.DELIMITER;<a name="line.513"></a>
-<span class="sourceLineNo">514</span>        break;<a name="line.514"></a>
-<span class="sourceLineNo">515</span>      case ALL:<a name="line.515"></a>
-<span class="sourceLineNo">516</span>      case TABLE:<a name="line.516"></a>
-<span class="sourceLineNo">517</span>      default:<a name="line.517"></a>
-<span class="sourceLineNo">518</span>        stopRow = new byte[table.getName().length + 1];<a name="line.518"></a>
-<span class="sourceLineNo">519</span>        System.arraycopy(table.getName(), 0, stopRow, 0, table.getName().length);<a name="line.519"></a>
-<span class="sourceLineNo">520</span>        stopRow[stopRow.length - 1] = ' ';<a name="line.520"></a>
+<span class="sourceLineNo">361</span>        if (++currentRowCount &gt;= rowUpperLimit) {<a name="line.361"></a>
+<span class="sourceLineNo">362</span>          terminateScan = true;<a name="line.362"></a>
+<span class="sourceLineNo">363</span>          break;<a name="line.363"></a>
+<span class="sourceLineNo">364</span>        }<a name="line.364"></a>
+<span class="sourceLineNo">365</span>      }<a name="line.365"></a>
+<span class="sourceLineNo">366</span>      if (terminateScan) {<a name="line.366"></a>
+<span class="sourceLineNo">367</span>        controller.terminate();<a name="line.367"></a>
+<span class="sourceLineNo">368</span>      }<a name="line.368"></a>
+<span class="sourceLineNo">369</span>    }<a name="line.369"></a>
+<span class="sourceLineNo">370</span>  }<a name="line.370"></a>
+<span class="sourceLineNo">371</span><a name="line.371"></a>
+<span class="sourceLineNo">372</span>  private static Scan getMetaScan(AsyncTable&lt;?&gt; metaTable, int rowUpperLimit) {<a name="line.372"></a>
+<span class="sourceLineNo">373</span>    Scan scan = new Scan();<a name="line.373"></a>
+<span class="sourceLineNo">374</span>    int scannerCaching = metaTable.getConfiguration().getInt(HConstants.HBASE_META_SCANNER_CACHING,<a name="line.374"></a>
+<span class="sourceLineNo">375</span>      HConstants.DEFAULT_HBASE_META_SCANNER_CACHING);<a name="line.375"></a>
+<span class="sourceLineNo">376</span>    if (metaTable.getConfiguration().getBoolean(HConstants.USE_META_REPLICAS,<a name="line.376"></a>
+<span class="sourceLineNo">377</span>      HConstants.DEFAULT_USE_META_REPLICAS)) {<a name="line.377"></a>
+<span class="sourceLineNo">378</span>      scan.setConsistency(Consistency.TIMELINE);<a name="line.378"></a>
+<span class="sourceLineNo">379</span>    }<a name="line.379"></a>
+<span class="sourceLineNo">380</span>    if (rowUpperLimit &lt;= scannerCaching) {<a name="line.380"></a>
+<span class="sourceLineNo">381</span>      scan.setLimit(rowUpperLimit);<a name="line.381"></a>
+<span class="sourceLineNo">382</span>    }<a name="line.382"></a>
+<span class="sourceLineNo">383</span>    int rows = Math.min(rowUpperLimit, scannerCaching);<a name="line.383"></a>
+<span class="sourceLineNo">384</span>    scan.setCaching(rows);<a name="line.384"></a>
+<span class="sourceLineNo">385</span>    return scan;<a name="line.385"></a>
+<span class="sourceLineNo">386</span>  }<a name="line.386"></a>
+<span class="sourceLineNo">387</span><a name="line.387"></a>
+<span class="sourceLineNo">388</span>  /**<a name="line.388"></a>
+<span class="sourceLineNo">389</span>   * Returns an HRegionLocationList extracted from the result.<a name="line.389"></a>
+<span class="sourceLineNo">390</span>   * @return an HRegionLocationList containing all locations for the region range or null if we<a name="line.390"></a>
+<span class="sourceLineNo">391</span>   *         can't deserialize the result.<a name="line.391"></a>
+<span class="sourceLineNo">392</span>   */<a name="line.392"></a>
+<span class="sourceLineNo">393</span>  private static Optional&lt;RegionLocations&gt; getRegionLocations(final Result r) {<a name="line.393"></a>
+<span class="sourceLineNo">394</span>    if (r == null) return Optional.empty();<a name="line.394"></a>
+<span class="sourceLineNo">395</span>    Optional&lt;RegionInfo&gt; regionInfo = getHRegionInfo(r, getRegionInfoColumn());<a name="line.395"></a>
+<span class="sourceLineNo">396</span>    if (!regionInfo.isPresent()) return Optional.empty();<a name="line.396"></a>
+<span class="sourceLineNo">397</span><a name="line.397"></a>
+<span class="sourceLineNo">398</span>    List&lt;HRegionLocation&gt; locations = new ArrayList&lt;HRegionLocation&gt;(1);<a name="line.398"></a>
+<span class="sourceLineNo">399</span>    NavigableMap&lt;byte[], NavigableMap&lt;byte[], byte[]&gt;&gt; familyMap = r.getNoVersionMap();<a name="line.399"></a>
+<span class="sourceLineNo">400</span><a name="line.400"></a>
+<span class="sourceLineNo">401</span>    locations.add(getRegionLocation(r, regionInfo.get(), 0));<a name="line.401"></a>
+<span class="sourceLineNo">402</span><a name="line.402"></a>
+<span class="sourceLineNo">403</span>    NavigableMap&lt;byte[], byte[]&gt; infoMap = familyMap.get(getCatalogFamily());<a name="line.403"></a>
+<span class="sourceLineNo">404</span>    if (infoMap == null) return Optional.of(new RegionLocations(locations));<a name="line.404"></a>
+<span class="sourceLineNo">405</span><a name="line.405"></a>
+<span class="sourceLineNo">406</span>    // iterate until all serverName columns are seen<a name="line.406"></a>
+<span class="sourceLineNo">407</span>    int replicaId = 0;<a name="line.407"></a>
+<span class="sourceLineNo">408</span>    byte[] serverColumn = getServerColumn(replicaId);<a name="line.408"></a>
+<span class="sourceLineNo">409</span>    SortedMap&lt;byte[], byte[]&gt; serverMap = null;<a name="line.409"></a>
+<span class="sourceLineNo">410</span>    serverMap = infoMap.tailMap(serverColumn, false);<a name="line.410"></a>
+<span class="sourceLineNo">411</span><a name="line.411"></a>
+<span class="sourceLineNo">412</span>    if (serverMap.isEmpty()) return Optional.of(new RegionLocations(locations));<a name="line.412"></a>
+<span class="sourceLineNo">413</span><a name="line.413"></a>
+<span class="sourceLineNo">414</span>    for (Map.Entry&lt;byte[], byte[]&gt; entry : serverMap.entrySet()) {<a name="line.414"></a>
+<span class="sourceLineNo">415</span>      replicaId = parseReplicaIdFromServerColumn(entry.getKey());<a name="line.415"></a>
+<span class="sourceLineNo">416</span>      if (replicaId &lt; 0) {<a name="line.416"></a>
+<span class="sourceLineNo">417</span>        break;<a name="line.417"></a>
+<span class="sourceLineNo">418</span>      }<a name="line.418"></a>
+<span class="sourceLineNo">419</span>      HRegionLocation location = getRegionLocation(r, regionInfo.get(), replicaId);<a name="line.419"></a>
+<span class="sourceLineNo">420</span>      // In case the region replica is newly created, it's location might be null. We usually do not<a name="line.420"></a>
+<span class="sourceLineNo">421</span>      // have HRL's in RegionLocations object with null ServerName. They are handled as null HRLs.<a name="line.421"></a>
+<span class="sourceLineNo">422</span>      if (location == null || location.getServerName() == null) {<a name="line.422"></a>
+<span class="sourceLineNo">423</span>        locations.add(null);<a name="line.423"></a>
+<span class="sourceLineNo">424</span>      } else {<a name="line.424"></a>
+<span class="sourceLineNo">425</span>        locations.add(location);<a name="line.425"></a>
+<span class="sourceLineNo">426</span>      }<a name="line.426"></a>
+<span class="sourceLineNo">427</span>    }<a name="line.427"></a>
+<span class="sourceLineNo">428</span><a name="line.428"></a>
+<span class="sourceLineNo">429</span>    return Optional.of(new RegionLocations(locations));<a name="line.429"></a>
+<span class="sourceLineNo">430</span>  }<a name="line.430"></a>
+<span class="sourceLineNo">431</span><a name="line.431"></a>
+<span class="sourceLineNo">432</span>  /**<a name="line.432"></a>
+<span class="sourceLineNo">433</span>   * Returns the HRegionLocation parsed from the given meta row Result<a name="line.433"></a>
+<span class="sourceLineNo">434</span>   * for the given regionInfo and replicaId. The regionInfo can be the default region info<a name="line.434"></a>
+<span class="sourceLineNo">435</span>   * for the replica.<a name="line.435"></a>
+<span class="sourceLineNo">436</span>   * @param r the meta row result<a name="line.436"></a>
+<span class="sourceLineNo">437</span>   * @param regionInfo RegionInfo for default replica<a name="line.437"></a>
+<span class="sourceLineNo">438</span>   * @param replicaId the replicaId for the HRegionLocation<a name="line.438"></a>
+<span class="sourceLineNo">439</span>   * @return HRegionLocation parsed from the given meta row Result for the given replicaId<a name="line.439"></a>
+<span class="sourceLineNo">440</span>   */<a name="line.440"></a>
+<span class="sourceLineNo">441</span>  private static HRegionLocation getRegionLocation(final Result r, final RegionInfo regionInfo,<a name="line.441"></a>
+<span class="sourceLineNo">442</span>      final int replicaId) {<a name="line.442"></a>
+<span class="sourceLineNo">443</span>    Optional&lt;ServerName&gt; serverName = getServerName(r, replicaId);<a name="line.443"></a>
+<span class="sourceLineNo">444</span>    long seqNum = getSeqNumDuringOpen(r, replicaId);<a name="line.444"></a>
+<span class="sourceLineNo">445</span>    RegionInfo replicaInfo = RegionReplicaUtil.getRegionInfoForReplica(regionInfo, replicaId);<a name="line.445"></a>
+<span class="sourceLineNo">446</span>    return new HRegionLocation(replicaInfo, serverName.orElse(null), seqNum);<a name="line.446"></a>
+<span class="sourceLineNo">447</span>  }<a name="line.447"></a>
+<span class="sourceLineNo">448</span><a name="line.448"></a>
+<span class="sourceLineNo">449</span>  /**<a name="line.449"></a>
+<span class="sourceLineNo">450</span>   * Returns a {@link ServerName} from catalog table {@link Result}.<a name="line.450"></a>
+<span class="sourceLineNo">451</span>   * @param r Result to pull from<a name="line.451"></a>
+<span class="sourceLineNo">452</span>   * @return A ServerName instance.<a name="line.452"></a>
+<span class="sourceLineNo">453</span>   */<a name="line.453"></a>
+<span class="sourceLineNo">454</span>  private static Optional&lt;ServerName&gt; getServerName(final Result r, final int replicaId) {<a name="line.454"></a>
+<span class="sourceLineNo">455</span>    byte[] serverColumn = getServerColumn(replicaId);<a name="line.455"></a>
+<span class="sourceLineNo">456</span>    Cell cell = r.getColumnLatestCell(getCatalogFamily(), serverColumn);<a name="line.456"></a>
+<span class="sourceLineNo">457</span>    if (cell == null || cell.getValueLength() == 0) return Optional.empty();<a name="line.457"></a>
+<span class="sourceLineNo">458</span>    String hostAndPort = Bytes.toString(cell.getValueArray(), cell.getValueOffset(),<a name="line.458"></a>
+<span class="sourceLineNo">459</span>      cell.getValueLength());<a name="line.459"></a>
+<span class="sourceLineNo">460</span>    byte[] startcodeColumn = getStartCodeColumn(replicaId);<a name="line.460"></a>
+<span class="sourceLineNo">461</span>    cell = r.getColumnLatestCell(getCatalogFamily(), startcodeColumn);<a name="line.461"></a>
+<span class="sourceLineNo">462</span>    if (cell == null || cell.getValueLength() == 0) return Optional.empty();<a name="line.462"></a>
+<span class="sourceLineNo">463</span>    try {<a name="line.463"></a>
+<span class="sourceLineNo">464</span>      return Optional.of(ServerName.valueOf(hostAndPort,<a name="line.464"></a>
+<span class="sourceLineNo">465</span>        Bytes.toLong(cell.getValueArray(), cell.getValueOffset(), cell.getValueLength())));<a name="line.465"></a>
+<span class="sourceLineNo">466</span>    } catch (IllegalArgumentException e) {<a name="line.466"></a>
+<span class="sourceLineNo">467</span>      LOG.error("Ignoring invalid region for server " + hostAndPort + "; cell=" + cell, e);<a name="line.467"></a>
+<span class="sourceLineNo">468</span>      return Optional.empty();<a name="line.468"></a>
+<span class="sourceLineNo">469</span>    }<a name="line.469"></a>
+<span class="sourceLineNo">470</span>  }<a name="line.470"></a>
+<span class="sourceLineNo">471</span><a name="line.471"></a>
+<span class="sourceLineNo">472</span>  /**<a name="line.472"></a>
+<span class="sourceLineNo">473</span>   * The latest seqnum that the server writing to meta observed when opening the region.<a name="line.473"></a>
+<span class="sourceLineNo">474</span>   * E.g. the seqNum when the result of {@link #getServerName(Result, int)} was written.<a name="line.474"></a>
+<span class="sourceLineNo">475</span>   * @param r Result to pull the seqNum from<a name="line.475"></a>
+<span class="sourceLineNo">476</span>   * @return SeqNum, or HConstants.NO_SEQNUM if there's no value written.<a name="line.476"></a>
+<span class="sourceLineNo">477</span>   */<a name="line.477"></a>
+<span class="sourceLineNo">478</span>  private static long getSeqNumDuringOpen(final Result r, final int replicaId) {<a name="line.478"></a>
+<span class="sourceLineNo">479</span>    Cell cell = r.getColumnLatestCell(getCatalogFamily(), getSeqNumColumn(replicaId));<a name="line.479"></a>
+<span class="sourceLineNo">480</span>    if (cell == null || cell.getValueLength() == 0) return HConstants.NO_SEQNUM;<a name="line.480"></a>
+<span class="sourceLineNo">481</span>    return Bytes.toLong(cell.getValueArray(), cell.getValueOffset(), cell.getValueLength());<a name="line.481"></a>
+<span class="sourceLineNo">482</span>  }<a name="line.482"></a>
+<span class="sourceLineNo">483</span><a name="line.483"></a>
+<span class="sourceLineNo">484</span>  /**<a name="line.484"></a>
+<span class="sourceLineNo">485</span>   * @param tableName table we're working with<a name="line.485"></a>
+<span class="sourceLineNo">486</span>   * @return start row for scanning META according to query type<a name="line.486"></a>
+<span class="sourceLineNo">487</span>   */<a name="line.487"></a>
+<span class="sourceLineNo">488</span>  private static Optional&lt;byte[]&gt; getTableStartRowForMeta(Optional&lt;TableName&gt; tableName,<a name="line.488"></a>
+<span class="sourceLineNo">489</span>      QueryType type) {<a name="line.489"></a>
+<span class="sourceLineNo">490</span>    return tableName.map((table) -&gt; {<a name="line.490"></a>
+<span class="sourceLineNo">491</span>      switch (type) {<a name="line.491"></a>
+<span class="sourceLineNo">492</span>      case REGION:<a name="line.492"></a>
+<span class="sourceLineNo">493</span>        byte[] startRow = new byte[table.getName().length + 2];<a name="line.493"></a>
+<span class="sourceLineNo">494</span>        System.arraycopy(table.getName(), 0, startRow, 0, table.getName().length);<a name="line.494"></a>
+<span class="sourceLineNo">495</span>        startRow[startRow.length - 2] = HConstants.DELIMITER;<a name="line.495"></a>
+<span class="sourceLineNo">496</span>        startRow[startRow.length - 1] = HConstants.DELIMITER;<a name="line.496"></a>
+<span class="sourceLineNo">497</span>        return startRow;<a name="line.497"></a>
+<span class="sourceLineNo">498</span>      case ALL:<a name="line.498"></a>
+<span class="sourceLineNo">499</span>      case TABLE:<a name="line.499"></a>
+<span class="sourceLineNo">500</span>      default:<a name="line.500"></a>
+<span class="sourceLineNo">501</span>        return table.getName();<a name="line.501"></a>
+<span class="sourceLineNo">502</span>      }<a name="line.502"></a>
+<span class="sourceLineNo">503</span>    });<a name="line.503"></a>
+<span class="sourceLineNo">504</span>  }<a name="line.504"></a>
+<span class="sourceLineNo">505</span><a name="line.505"></a>
+<span class="sourceLineNo">506</span>  /**<a name="line.506"></a>
+<span class="sourceLineNo">507</span>   * @param tableName table we're working with<a name="line.507"></a>
+<span class="sourceLineNo">508</span>   * @return stop row for scanning META according to query type<a name="line.508"></a>
+<span class="sourceLineNo">509</span>   */<a name="line.509"></a>
+<span class="sourceLineNo">510</span>  private static Optional&lt;byte[]&gt; getTableStopRowForMeta(Optional&lt;TableName&gt; tableName,<a name="line.510"></a>
+<span class="sourceLineNo">511</span>      QueryType type) {<a name="line.511"></a>
+<span class="sourceLineNo">512</span>    return tableName.map((table) -&gt; {<a name="line.512"></a>
+<span class="sourceLineNo">513</span>      final byte[] stopRow;<a name="line.513"></a>
+<span class="sourceLineNo">514</span>      switch (type) {<a name="line.514"></a>
+<span class="sourceLineNo">515</span>      case REGION:<a name="line.515"></a>
+<span class="sourceLineNo">516</span>        stopRow = new byte[table.getName().length + 3];<a name="line.516"></a>
+<span class="sourceLineNo">517</span>        System.arraycopy(table.getName(), 0, stopRow, 0, table.getName().length);<a name="line.517"></a>
+<span class="sourceLineNo">518</span>        stopRow[stopRow.length - 3] = ' ';<a name="line.518"></a>
+<span class="sourceLineNo">519</span>        stopRow[stopRow.length - 2] = HConstants.DELIMITER;<a name="line.519"></a>
+<span class="sourceLineNo">520</span>        stopRow[stopRow.length - 1] = HConstants.DELIMITER;<a name="line.520"></a>
 <span class="sourceLineNo">521</span>        break;<a name="line.521"></a>
-<span class="sourceLineNo">522</span>      }<a name="line.522"></a>
-<span class="sourceLineNo">523</span>      return stopRow;<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><a name="line.526"></a>
-<span class="sourceLineNo">527</span>  /**<a name="line.527"></a>
-<span class="sourceLineNo">528</span>   * Returns the RegionInfo object from the column {@link HConstants#CATALOG_FAMILY} and<a name="line.528"></a>
-<span class="sourceLineNo">529</span>   * &lt;code&gt;qualifier&lt;/code&gt; of the catalog table result.<a name="line.529"></a>
-<span class="sourceLineNo">530</span>   * @param r a Result object from the catalog table scan<a name="line.530"></a>
-<span class="sourceLineNo">531</span>   * @param qualifier Column family qualifier<a name="line.531"></a>
-<span class="sourceLineNo">532</span>   * @return An RegionInfo instance.<a name="line.532"></a>
-<span class="sourceLineNo">533</span>   */<a name="line.533"></a>
-<span class="sourceLineNo">534</span>  private static Optional&lt;RegionInfo&gt; getHRegionInfo(final Result r, byte[] qualifier) {<a name="line.534"></a>
-<span class="sourceLineNo">535</span>    Cell cell = r.getColumnLatestCell(getCatalogFamily(), qualifier);<a name="line.535"></a>
-<span class="sourceLineNo">536</span>    if (cell == null) return Optional.empty();<a name="line.536"></a>
-<span class="sourceLineNo">537</span>    return Optional.ofNullable(RegionInfo.parseFromOrNull(cell.getValueArray(),<a name="line.537"></a>
-<span class="sourceLineNo">538</span>      cell.getValueOffset(), cell.getValueLength()));<a name="line.538"></a>
-<span class="sourceLineNo">539</span>  }<a name="line.539"></a>
-<span class="sourceLineNo">540</span><a name="line.540"></a>
-<span class="sourceLineNo">541</span>  /**<a name="line.541"></a>
-<span class="sourceLineNo">542</span>   * Returns the column family used for meta columns.<a name="line.542"></a>
-<span class="sourceLineNo">543</span>   * @return HConstants.CATALOG_FAMILY.<a name="line.543"></a>
-<span class="sourceLineNo">544</span>   */<a name="line.544"></a>
-<span class="sourceLineNo">545</span>  private static byte[] getCatalogFamily() {<a name="line.545"></a>
-<span class="sourceLineNo">546</span>    return HConstants.CATALOG_FAMILY;<a name="line.546"></a>
-<span class="sourceLineNo">547</span>  }<a name="line.547"></a>
-<span class="sourceLineNo">548</span><a name="line.548"></a>
-<span class="sourceLineNo">549</span>  /**<a name="line.549"></a>
-<span class="sourceLineNo">550</span>   * Returns the column family used for table columns.<a name="line.550"></a>
-<span class="sourceLineNo">551</span>   * @return HConstants.TABLE_FAMILY.<a name="line.551"></a>
-<span class="sourceLineNo">552</span>   */<a name="line.552"></a>
-<span class="sourceLineNo">553</span>  private static byte[] getTableFamily() {<a name="line.553"></a>
-<span class="sourceLineNo">554</span>    return HConstants.TABLE_FAMILY;<a name="line.554"></a>
-<span class="sourceLineNo">555</span>  }<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>   * Returns the column qualifier for serialized region info<a name="line.558"></a>
-<span class="sourceLineNo">559</span>   * @return HConstants.REGIONINFO_QUALIFIER<a name="line.559"></a>
-<span class="sourceLineNo">560</span>   */<a name="line.560"></a>
-<span class="sourceLineNo">561</span>  private static byte[] getRegionInfoColumn() {<a name="line.561"></a>
-<span class="sourceLineNo">562</span>    return HConstants.REGIONINFO_QUALIFIER;<a name="line.562"></a>
-<span class="sourceLineNo">563</span>  }<a name="line.563"></a>
-<span class="sourceLineNo">564</span><a name="line.564"></a>
-<span class="sourceLineNo">565</span>  /**<a name="line.565"></a>
-<span class="sourceLineNo">566</span>   * Returns the column qualifier for serialized table state<a name="line.566"></a>
-<span class="sourceLineNo">567</span>   * @return HConstants.TABLE_STATE_QUALIFIER<a name="line.567"></a>
-<span class="sourceLineNo">568</span>   */<a name="line.568"></a>
-<span class="sourceLineNo">569</span>  private static byte[] getStateColumn() {<a name="line.569"></a>
-<span class="sourceLineNo">570</span>    return HConstants.TABLE_STATE_QUALIFIER;<a name="line.570"></a>
-<span class="sourceLineNo">571</span>  }<a name="line.571"></a>
-<span class="sourceLineNo">572</span><a name="line.572"></a>
-<span class="sourceLineNo">573</span>  /**<a name="line.573"></a>
-<span class="sourceLineNo">574</span>   * Returns the column qualifier for server column for replicaId<a name="line.574"></a>
-<span class="sourceLineNo">575</span>   * @param replicaId the replicaId of the region<a name="line.575"></a>
-<span class="sourceLineNo">576</span>   * @return a byte[] for server column qualifier<a name="line.576"></a>
-<span class="sourceLineNo">577</span>   */<a name="line.577"></a>
-<span class="sourceLineNo">578</span>  private static byte[] getServerColumn(int replicaId) {<a name="line.578"></a>
-<span class="sourceLineNo">579</span>    return replicaId == 0<a name="line.579"></a>
-<span class="sourceLineNo">580</span>      ? HConstants.SERVER_QUALIFIER<a name="line.580"></a>
-<span class="sourceLineNo">581</span>      : Bytes.toBytes(HConstants.SERVER_QUALIFIER_STR + META_REPLICA_ID_DELIMITER<a name="line.581"></a>
-<span class="sourceLineNo">582</span>      + String.format(RegionInfo.REPLICA_ID_FORMAT, replicaId));<a name="line.582"></a>
-<span class="sourceLineNo">583</span>  }<a name="line.583"></a>
-<span class="sourceLineNo">584</span><a name="line.584"></a>
-<span class="sourceLineNo">585</span>  /**<a name="line.585"></a>
-<span class="sourceLineNo">586</span>   * Returns the column qualifier for server start code column for replicaId<a name="line.586"></a>
-<span class="sourceLineNo">587</span>   * @param replicaId the replicaId of the region<a name="line.587"></a>
-<span class="sourceLineNo">588</span>   * @return a byte[] for server start code column qualifier<a name="line.588"></a>
-<span class="sourceLineNo">589</span>   */<a name="line.589"></a>
-<span class="sourceLineNo">590</span>  private static byte[] getStartCodeColumn(int replicaId) {<a name="line.590"></a>
-<span class="sourceLineNo">591</span>    return replicaId == 0<a name="line.591"></a>
-<span class="sourceLineNo">592</span>      ? HConstants.STARTCODE_QUALIFIER<a name="line.592"></a>
-<span class="sourceLineNo">593</span>      : Bytes.toBytes(HConstants.STARTCODE_QUALIFIER_STR + META_REPLICA_ID_DELIMITER<a name="line.593"></a>
-<span class="sourceLineNo">594</span>      + String.format(RegionInfo.REPLICA_ID_FORMAT, replicaId));<a name="line.594"></a>
-<span class="sourceLineNo">595</span>  }<a name="line.595"></a>
-<span class="sourceLineNo">596</span><a name="line.596"></a>
-<span class="sourceLineNo">597</span>  /**<a name="line.597"></a>
-<span class="sourceLineNo">598</span>   * Returns the column qualifier for seqNum column for replicaId<a name="line.598"></a>
-<span class="sourceLineNo">599</span>   * @param replicaId the replicaId of the region<a name="line.599"></a>
-<span class="sourceLineNo">600</span>   * @return a byte[] for seqNum column qualifier<a name="line.600"></a>
-<span class="sourceLineNo">601</span>   */<a name="line.601"></a>
-<span class="sourceLineNo">602</span>  private static byte[] getSeqNumColumn(int replicaId) {<a name="line.602"></a>
-<span class="sourceLineNo">603</span>    return replicaId == 0<a name="line.603"></a>
-<span class="sourceLineNo">604</span>      ? HConstants.SEQNUM_QUALIFIER<a name="line.604"></a>
-<span class="sourceLineNo">605</span>      : Bytes.toBytes(HConstants.SEQNUM_QUALIFIER_STR + META_REPLICA_ID_DELIMITER<a name="line.605"></a>
-<span class="sourceLineNo">606</span>      + String.format(RegionInfo.REPLICA_ID_FORMAT, replicaId));<a name="line.606"></a>
-<span class="sourceLineNo">607</span>  }<a name="line.607"></a>
-<span class="sourceLineNo">608</span><a name="line.608"></a>
-<span class="sourceLineNo">609</span>  /**<a name="line.609"></a>
-<span class="sourceLineNo">610</span>   * Parses the replicaId from the server column qualifier. See top of the class javadoc<a name="line.610"></a>
-<span class="sourceLineNo">611</span>   * for the actual meta layout<a name="line.611"></a>
-<span class="sourceLineNo">612</span>   * @param serverColumn the column qualifier<a name="line.612"></a>
-<span class="sourceLineNo">613</span>   * @return an int for the replicaId<a name="line.613"></a>
-<span class="sourceLineNo">614</span>   */<a name="line.614"></a>
-<span class="sourceLineNo">615</span>  private static int parseReplicaIdFromServerColumn(byte[] serverColumn) {<a name="line.615"></a>
-<span class="sourceLineNo">616</span>    String serverStr = Bytes.toString(serverColumn);<a name="line.616"></a>
-<span class="sourceLineNo">617</span><a name="line.617"></a>
-<span class="sourceLineNo">618</span>    Matcher matcher = SERVER_COLUMN_PATTERN.matcher(serverStr);<a name="line.618"></a>
-<span class="sourceLineNo">619</span>    if (matcher.matches() &amp;&amp; matcher.groupCount() &gt; 0) {<a name="line.619"></a>
-<span class="sourceLineNo">620</span>      String group = matcher.group(1);<a name="line.620"></a>
-<span class="sourceLineNo">621</span>      if (group != null &amp;&amp; group.length() &gt; 0) {<a name="line.621"></a>
-<span class="sourceLineNo">622</span>        return Integer.parseInt(group.substring(1), 16);<a name="line.622"></a>
-<span class="sourceLineNo">623</span>      } else {<a name="line.623"></a>
-<span class="sourceLineNo">624</span>        return 0;<a name="line.624"></a>
-<span class="sourceLineNo">625</span>      }<a name="line.625"></a>
-<span class="sourceLineNo">626</span>    }<a name="line.626"></a>
-<span class="sourceLineNo">627</span>    return -1;<a name="line.627"></a>
-<span class="sourceLineNo">628</span>  }<a name="line.628"></a>
-<span class="sourceLineNo">629</span>}<a name="line.629"></a>
+<span class="sourceLineNo">522</span>      case ALL:<a name="line.522"></a>
+<span class="sourceLineNo">523</span>      case TABLE:<a name="line.523"></a>
+<span class="sourceLineNo">524</span>      default:<a name="line.524"></a>
+<span class="sourceLineNo">525</span>        stopRow = new byte[table.getName().length + 1];<a name="line.525"></a>
+<span class="sourceLineNo">526</span>        System.arraycopy(table.getName(), 0, stopRow, 0, table.getName().length);<a name="line.526"></a>
+<span class="sourceLineNo">527</span>        stopRow[stopRow.length - 1] = ' ';<a name="line.527"></a>
+<span class="sourceLineNo">528</span>        break;<a name="line.528"></a>
+<span class="sourceLineNo">529</span>      }<a name="line.529"></a>
+<span class="sourceLineNo">530</span>      return stopRow;<a name="line.530"></a>
+<span class="sourceLineNo">531</span>    });<a name="line.531"></a>
+<span class="sourceLineNo">532</span>  }<a name="line.532"></a>
+<span class="sourceLineNo">533</span><a name="line.533"></a>
+<span class="sourceLineNo">534</span>  /**<a name="line.534"></a>
+<span class="sourceLineNo">535</span>   * Returns the RegionInfo object from the column {@link HConstants#CATALOG_FAMILY} and<a name="line.535"></a>
+<span class="sourceLineNo">536</span>   * &lt;code&gt;qualifier&lt;/code&gt; of the catalog table result.<a name="line.536"></a>
+<span class="sourceLineNo">537</span>   * @param r a Result object from the catalog table scan<a name="line.537"></a>
+<span class="sourceLineNo">538</span>   * @param qualifier Column family qualifier<a name="line.538"></a>
+<span class="sourceLineNo">539</span>   * @return An RegionInfo instance.<a name="line.539"></a>
+<span class="sourceLineNo">540</span>   */<a name="line.540"></a>
+<span class="sourceLineNo">541</span>  private static Optional&lt;RegionInfo&gt; getHRegionInfo(final Result r, byte[] qualifier) {<a name="line.541"></a>
+<span class="sourceLineNo">542</span>    Cell cell = r.getColumnLatestCell(getCatalogFamily(), qualifier);<a name="line.542"></a>
+<span class="sourceLineNo">543</span>    if (cell == null) return Optional.empty();<a name="line.543"></a>
+<span class="sourceLineNo">544</span>    return Optional.ofNullable(RegionInfo.parseFromOrNull(cell.getValueArray(),<a name="line.544"></a>
+<span class="sourceLineNo">545</span>      cell.getValueOffset(), cell.getValueLength()));<a name="line.545"></a>
+<span class="sourceLineNo">546</span>  }<a name="line.546"></a>
+<span class="sourceLineNo">547</span><a name="line.547"></a>
+<span class="sourceLineNo">548</span>  /**<a name="line.548"></a>
+<span class="sourceLineNo">549</span>   * Returns the column family used for meta columns.<a name="line.549"></a>
+<span class="sourceLineNo">550</span>   * @return HConstants.CATALOG_FAMILY.<a name="line.550"></a>
+<span class="sourceLineNo">551</span>   */<a name="line.551"></a>
+<span class="sourceLineNo">552</span>  private static byte[] getCatalogFamily() {<a name="line.552"></a>
+<span class="sourceLineNo">553</span>    return HConstants.CATALOG_FAMILY;<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>  /**<a name="line.556"></a>
+<span class="sourceLineNo">557</span>   * Returns the column family used for table columns.<a name="line.557"></a>
+<span class="sourceLineNo">558</span>   * @return HConstants.TABLE_FAMILY.<a name="line.558"></a>
+<span class="sourceLineNo">559</span>   */<a name="line.559"></a>
+<span class="sourceLineNo">560</span>  private static byte[] getTableFamily() {<a name="line.560"></a>
+<span class="sourceLineNo">561</span>    return HConstants.TABLE_FAMILY;<a name="line.561"></a>
+<span class="sourceLineNo">562</span>  }<a name="line.562"></a>
+<span class="sourceLineNo">563</span><a name="line.563"></a>
+<span class="sourceLineNo">564</span>  /**<a name="line.564"></a>
+<span class="sourceLineNo">565</span>   * Returns the column qualifier for serialized region info<a name="line.565"></a>
+<span class="sourceLineNo">566</span>   * @return HConstants.REGIONINFO_QUALIFIER<a name="line.566"></a>
+<span class="sourceLineNo">567</span>   */<a name="line.567"></a>
+<span class="sourceLineNo">568</span>  private static byte[] getRegionInfoColumn() {<a name="line.568"></a>
+<span class="sourceLineNo">569</span>    return HConstants.REGIONINFO_QUALIFIER;<a name="line.569"></a>
+<span class="sourceLineNo">570</span>  }<a name="line.570"></a>
+<span class="sourceLineNo">571</span><a name="line.571"></a>
+<span class="sourceLineNo">572</span>  /**<a name="line.572"></a>
+<span class="sourceLineNo">573</span>   * Returns the column qualifier for serialized table state<a name="line.573"></a>
+<span class="sourceLineNo">574</span>   * @return HConstants.TABLE_STATE_QUALIFIER<a name="line.574"></a>
+<span class="sourceLineNo">575</span>   */<a name="line.575"></a>
+<span class="sourceLineNo">576</span>  private static byte[] getStateColumn() {<a name="line.576"></a>
+<span class="sourceLineNo">577</span>    return HConstants.TABLE_STATE_QUALIFIER;<a name="line.577"></a>
+<span class="sourceLineNo">578</span>  }<a name="line.578"></a>
+<span class="sourceLineNo">579</span><a name="line.579"></a>
+<span class="sourceLineNo">580</span>  /**<a name="line.580"></a>
+<span class="sourceLineNo">581</span>   * Returns the column qualifier for server column for replicaId<a name="line.581"></a>
+<span class="sourceLineNo">582</span>   * @param replicaId the replicaId of the region<a name="line.582"></a>
+<span class="sourceLineNo">583</span>   * @return a byte[] for server column qualifier<a name="line.583"></a>
+<span class="sourceLineNo">584</span>   */<a name="line.584"></a>
+<span class="sourceLineNo">585</span>  private static byte[] getServerColumn(int replicaId) {<a name="line.585"></a>
+<span class="sourceLineNo">586</span>    return replicaId == 0<a name="line.586"></a>
+<span class="sourceLineNo">587</span>      ? HConstants.SERVER_QUALIFIER<a name="line.587"></a>
+<span class="sourceLineNo">588</span>      : Bytes.toBytes(HConstants.SERVER_QUALIFIER_STR + META_REPLICA_ID_DELIMITER<a name="line.588"></a>
+<span class="sourceLineNo">589</span>      + String.format(RegionInfo.REPLICA_ID_FORMAT, replicaId));<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>   * Returns the column qualifier for server start code column for replicaId<a name="line.593"></a>
+<span class="sourceLineNo">594</span>   * @param replicaId the replicaId of the region<a name="line.594"></a>
+<span class="sourceLineNo">595</span>   * @return a byte[] for server start code column qualifier<a name="line.595"></a>
+<span class="sourceLineNo">596</span>   */<a name="line.596"></a>
+<span class="sourceLineNo">597</span>  private static byte[] getStartCodeColumn(int replicaId) {<a name="line.597"></a>
+<span class="sourceLineNo">598</span>    return replicaId == 0<a name="line.598"></a>
+<span class="sourceLineNo">599</span>      ? HConstants.STARTCODE_QUALIFIER<a name="line.599"></a>
+<span class="sourceLineNo">600</span>      : Bytes.toBytes(HConstants.STARTCODE_QUALIFIER_STR + META_REPLICA_ID_DELIMITER<a name="line.600"></a>
+<span class="sourceLineNo">601</span>      + String.format(RegionInfo.REPLICA_ID_FORMAT, replicaId));<a name="line.601"></a>
+<span class="sourceLineNo">602</span>  }<a name="line.602"></a>
+<span class="sourceLineNo">603</span><a name="line.603"></a>
+<span class="sourceLineNo">604</span>  /**<a name="line.604"></a>
+<span class="sourceLineNo">605</span>   * Returns the column qualifier for seqNum column for replicaId<a name="line.605"></a>
+<span class="sourceLineNo">606</span>   * @param replicaId the replicaId of the region<a name="line.606"></a>
+<span class="sourceLineNo">607</span>   * @return a byte[] for seqNum column qualifier<a name="line.607"></a>
+<span class="sourceLineNo">608</span>   */<a name="line.608"></a>
+<span class="sourceLineNo">609</span>  private static byte[] getSeqNumColumn(int replicaId) {<a name="line.609"></a>
+<span class="sourceLineNo">610</span>    return replicaId == 0<a name="line.610"></a>
+<span class="sourceLineNo">611</span>      ? HConstants.SEQNUM_QUALIFIER<a name="line.611"></a>
+<span class="sourceLineNo">612</span>      : Bytes.toBytes(HConstants.SEQNUM_QUALIFIER_STR + META_REPLICA_ID_DELIMITER<a name="line.612"></a>
+<span class="sourceLineNo">613</span>      + String.format(RegionInfo.REPLICA_ID_FORMAT, replicaId));<a name="line.613"></a>
+<span class="sourceLineNo">614</span>  }<a name="line.614"></a>
+<span class="sourceLineNo">615</span><a name="line.615"></a>
+<span class="sourceLineNo">616</span>  /**<a name="line.616"></a>
+<span class="sourceLineNo">617</span>   * Parses the replicaId from the server column qualifier. See top of the class javadoc<a name="line.617"></a>
+<span class="sourceLineNo">618</span>   * for the actual meta layout<a name="line.618"></a>
+<span class="sourceLineNo">619</span>   * @param serverColumn the column qualifier<a name="line.619"></a>
+<span class="sourceLineNo">620</span>   * @return an int for the replicaId<a name="line.620"></a>
+<span class="sourceLineNo">621</span>   */<a name="line.621"></a>
+<span class="sourceLineNo">622</span>  private static int parseReplicaIdFromServerColumn(byte[] serverColumn) {<a name="line.622"></a>
+<span class="sourceLineNo">623</span>    String serverStr = Bytes.toString(serverColumn);<a name="line.623"></a>
+<span class="sourceLineNo">624</span><a name="line.624"></a>
+<span class="sourceLineNo">625</span>    Matcher matcher = SERVER_COLUMN_PATTERN.matcher(serverStr);<a name="line.625"></a>
+<span class="sourceLineNo">626</span>    if (matcher.matches() &amp;&amp; matcher.groupCount() &gt; 0) {<a name="line.626"></a>
+<span class="sourceLineNo">627</span>      String group = matcher.group(1);<a name="line.627"></a>
+<span class="sourceLineNo">628</span>      if (group != null &amp;&amp; group.length() &gt; 0) {<a name="line.628"></a>
+<span class="sourceLineNo">629</span>        return Integer.parseInt(group.substring(1), 16);<a name="line.629"></a>
+<span class="sourceLineNo">630</span>      } else {<a name="line.630"></a>
+<span class="sourceLineNo">631</span>        return 0;<a name="line.631"></a>
+<span class="sourceLineNo">632</span>      }<a name="line.632"></a>
+<span class="sourceLineNo">633</span>    }<a name="line.633"></a>
+<span class="sourceLineNo">634</span>    return -1;<a name="line.634"></a>
+<span class="sourceLineNo">635</span>  }<a name="line.635"></a>
+<span class="sourceLineNo">636</span>}<a name="line.636"></a>
 
 
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/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 efb9a1b..79ad260 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 = "73e3af00e94f0be12dd6e399d5e72966311ae3fe";<a name="line.11"></a>
+<span class="sourceLineNo">011</span>  public static final String revision = "f521000d7883e83943b948989f05bfe49d78f5db";<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 = "Fri Nov 24 14:42:48 UTC 2017";<a name="line.13"></a>
+<span class="sourceLineNo">013</span>  public static final String date = "Sat Nov 25 14:41:57 UTC 2017";<a name="line.13"></a>
 <span class="sourceLineNo">014</span>  public static final String url = "git://asf920.gq1.ygridcore.net/home/jenkins/jenkins-slave/workspace/hbase_generate_website/hbase";<a name="line.14"></a>
-<span class="sourceLineNo">015</span>  public static final String srcChecksum = "b8e6f4997084f7a67c52d4307241b12b";<a name="line.15"></a>
+<span class="sourceLineNo">015</span>  public static final String srcChecksum = "d04c67139edba8edda937528db64605e";<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/7a3208bd/export_control.html
----------------------------------------------------------------------
diff --git a/export_control.html b/export_control.html
index b689def..c6e4aeb 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; 
       Export Control
@@ -336,7 +336,7 @@ for more details.</p>
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/checkstyle.html b/hbase-annotations/checkstyle.html
index 39beb99..c05bfdb 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Checkstyle Results</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -178,7 +178,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependencies.html b/hbase-annotations/dependencies.html
index 5825eaf..3a57944 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -272,7 +272,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-convergence.html b/hbase-annotations/dependency-convergence.html
index 86eedd9..ce62b58 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -838,7 +838,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-info.html b/hbase-annotations/dependency-info.html
index 32bdd9e..f8f321a 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -147,7 +147,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-management.html b/hbase-annotations/dependency-management.html
index e49fe4f..482822c 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -804,7 +804,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/index.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/index.html b/hbase-annotations/index.html
index d26dfaf..6caf2c7 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; About</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -119,7 +119,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/integration.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/integration.html b/hbase-annotations/integration.html
index bac273c..effdb9a 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -126,7 +126,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/issue-tracking.html b/hbase-annotations/issue-tracking.html
index 365ba4b..a7e9856 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -123,7 +123,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/license.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/license.html b/hbase-annotations/license.html
index 48e7f78..372c6cd 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -326,7 +326,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/mail-lists.html b/hbase-annotations/mail-lists.html
index 5c1a886..56557e8 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -176,7 +176,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugin-management.html b/hbase-annotations/plugin-management.html
index d6becc4..3adc50e 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -271,7 +271,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugins.html b/hbase-annotations/plugins.html
index 856b0a7..016bd6c 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -222,7 +222,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-info.html b/hbase-annotations/project-info.html
index 5477395..25feed8 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -167,7 +167,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/project-reports.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-reports.html b/hbase-annotations/project-reports.html
index ea659d9..9773966 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Generated Reports</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -128,7 +128,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-summary.html b/hbase-annotations/project-summary.html
index cbc2a39..fb1e254 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Summary</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -166,7 +166,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/source-repository.html b/hbase-annotations/source-repository.html
index b4ad824..18353c0 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Source Code Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -134,7 +134,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-annotations/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/team-list.html b/hbase-annotations/team-list.html
index ed8b608..dedc26e 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Team</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -547,7 +547,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-build-configuration/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependencies.html b/hbase-build-configuration/dependencies.html
index f423231..6fcd7a8 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -330,7 +330,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-build-configuration/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-convergence.html b/hbase-build-configuration/dependency-convergence.html
index 52bda6a..f6283be 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -838,7 +838,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-build-configuration/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-info.html b/hbase-build-configuration/dependency-info.html
index ded1a33..460bf1f 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -148,7 +148,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/hbase-build-configuration/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-management.html b/hbase-build-configuration/dependency-management.html
index 375a63b..271accb 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -804,7 +804,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7a3208bd/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 318d4d2..7d34911 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="20171124" />
+    <meta name="Date-Revision-yyyymmdd" content="20171125" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -330,7 +330,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-11-24</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-11-25</li>
             </p>
                 </div>