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/12/13 14:53:07 UTC

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

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/MemStoreFlusher.html
----------------------------------------------------------------------
diff --git a/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/MemStoreFlusher.html b/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/MemStoreFlusher.html
index 42dc187..6557d2d 100644
--- a/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/MemStoreFlusher.html
+++ b/devapidocs/src-html/org/apache/hadoop/hbase/regionserver/MemStoreFlusher.html
@@ -711,247 +711,251 @@
 <span class="sourceLineNo">703</span>    if (flushType != FlushType.NORMAL) {<a name="line.703"></a>
 <span class="sourceLineNo">704</span>      TraceUtil.addTimelineAnnotation("Force Flush. We're above high water mark.");<a name="line.704"></a>
 <span class="sourceLineNo">705</span>      long start = EnvironmentEdgeManager.currentTime();<a name="line.705"></a>
-<span class="sourceLineNo">706</span>      synchronized (this.blockSignal) {<a name="line.706"></a>
-<span class="sourceLineNo">707</span>        boolean blocked = false;<a name="line.707"></a>
-<span class="sourceLineNo">708</span>        long startTime = 0;<a name="line.708"></a>
-<span class="sourceLineNo">709</span>        boolean interrupted = false;<a name="line.709"></a>
-<span class="sourceLineNo">710</span>        try {<a name="line.710"></a>
-<span class="sourceLineNo">711</span>          flushType = isAboveHighWaterMark();<a name="line.711"></a>
-<span class="sourceLineNo">712</span>          while (flushType != FlushType.NORMAL &amp;&amp; !server.isStopped()) {<a name="line.712"></a>
-<span class="sourceLineNo">713</span>            server.cacheFlusher.setFlushType(flushType);<a name="line.713"></a>
-<span class="sourceLineNo">714</span>            if (!blocked) {<a name="line.714"></a>
-<span class="sourceLineNo">715</span>              startTime = EnvironmentEdgeManager.currentTime();<a name="line.715"></a>
-<span class="sourceLineNo">716</span>              if (!server.getRegionServerAccounting().isOffheap()) {<a name="line.716"></a>
-<span class="sourceLineNo">717</span>                logMsg("global memstore heapsize",<a name="line.717"></a>
-<span class="sourceLineNo">718</span>                    server.getRegionServerAccounting().getGlobalMemStoreHeapSize(),<a name="line.718"></a>
-<span class="sourceLineNo">719</span>                    server.getRegionServerAccounting().getGlobalMemStoreLimit());<a name="line.719"></a>
-<span class="sourceLineNo">720</span>              } else {<a name="line.720"></a>
-<span class="sourceLineNo">721</span>                switch (flushType) {<a name="line.721"></a>
-<span class="sourceLineNo">722</span>                case ABOVE_OFFHEAP_HIGHER_MARK:<a name="line.722"></a>
-<span class="sourceLineNo">723</span>                  logMsg("the global offheap memstore datasize",<a name="line.723"></a>
-<span class="sourceLineNo">724</span>                      server.getRegionServerAccounting().getGlobalMemStoreOffHeapSize(),<a name="line.724"></a>
-<span class="sourceLineNo">725</span>                      server.getRegionServerAccounting().getGlobalMemStoreLimit());<a name="line.725"></a>
-<span class="sourceLineNo">726</span>                  break;<a name="line.726"></a>
-<span class="sourceLineNo">727</span>                case ABOVE_ONHEAP_HIGHER_MARK:<a name="line.727"></a>
-<span class="sourceLineNo">728</span>                  logMsg("global memstore heapsize",<a name="line.728"></a>
-<span class="sourceLineNo">729</span>                      server.getRegionServerAccounting().getGlobalMemStoreHeapSize(),<a name="line.729"></a>
-<span class="sourceLineNo">730</span>                      server.getRegionServerAccounting().getGlobalOnHeapMemStoreLimit());<a name="line.730"></a>
-<span class="sourceLineNo">731</span>                  break;<a name="line.731"></a>
-<span class="sourceLineNo">732</span>                default:<a name="line.732"></a>
-<span class="sourceLineNo">733</span>                  break;<a name="line.733"></a>
-<span class="sourceLineNo">734</span>                }<a name="line.734"></a>
-<span class="sourceLineNo">735</span>              }<a name="line.735"></a>
-<span class="sourceLineNo">736</span>            }<a name="line.736"></a>
-<span class="sourceLineNo">737</span>            blocked = true;<a name="line.737"></a>
-<span class="sourceLineNo">738</span>            wakeupFlushThread();<a name="line.738"></a>
-<span class="sourceLineNo">739</span>            try {<a name="line.739"></a>
-<span class="sourceLineNo">740</span>              // we should be able to wait forever, but we've seen a bug where<a name="line.740"></a>
-<span class="sourceLineNo">741</span>              // we miss a notify, so put a 5 second bound on it at least.<a name="line.741"></a>
-<span class="sourceLineNo">742</span>              blockSignal.wait(5 * 1000);<a name="line.742"></a>
-<span class="sourceLineNo">743</span>            } catch (InterruptedException ie) {<a name="line.743"></a>
-<span class="sourceLineNo">744</span>              LOG.warn("Interrupted while waiting");<a name="line.744"></a>
-<span class="sourceLineNo">745</span>              interrupted = true;<a name="line.745"></a>
-<span class="sourceLineNo">746</span>            }<a name="line.746"></a>
-<span class="sourceLineNo">747</span>            long took = EnvironmentEdgeManager.currentTime() - start;<a name="line.747"></a>
-<span class="sourceLineNo">748</span>            LOG.warn("Memstore is above high water mark and block " + took + "ms");<a name="line.748"></a>
-<span class="sourceLineNo">749</span>            flushType = isAboveHighWaterMark();<a name="line.749"></a>
-<span class="sourceLineNo">750</span>          }<a name="line.750"></a>
-<span class="sourceLineNo">751</span>        } finally {<a name="line.751"></a>
-<span class="sourceLineNo">752</span>          if (interrupted) {<a name="line.752"></a>
-<span class="sourceLineNo">753</span>            Thread.currentThread().interrupt();<a name="line.753"></a>
+<span class="sourceLineNo">706</span>      long nextLogTimeMs = start;<a name="line.706"></a>
+<span class="sourceLineNo">707</span>      synchronized (this.blockSignal) {<a name="line.707"></a>
+<span class="sourceLineNo">708</span>        boolean blocked = false;<a name="line.708"></a>
+<span class="sourceLineNo">709</span>        long startTime = 0;<a name="line.709"></a>
+<span class="sourceLineNo">710</span>        boolean interrupted = false;<a name="line.710"></a>
+<span class="sourceLineNo">711</span>        try {<a name="line.711"></a>
+<span class="sourceLineNo">712</span>          flushType = isAboveHighWaterMark();<a name="line.712"></a>
+<span class="sourceLineNo">713</span>          while (flushType != FlushType.NORMAL &amp;&amp; !server.isStopped()) {<a name="line.713"></a>
+<span class="sourceLineNo">714</span>            server.cacheFlusher.setFlushType(flushType);<a name="line.714"></a>
+<span class="sourceLineNo">715</span>            if (!blocked) {<a name="line.715"></a>
+<span class="sourceLineNo">716</span>              startTime = EnvironmentEdgeManager.currentTime();<a name="line.716"></a>
+<span class="sourceLineNo">717</span>              if (!server.getRegionServerAccounting().isOffheap()) {<a name="line.717"></a>
+<span class="sourceLineNo">718</span>                logMsg("global memstore heapsize",<a name="line.718"></a>
+<span class="sourceLineNo">719</span>                    server.getRegionServerAccounting().getGlobalMemStoreHeapSize(),<a name="line.719"></a>
+<span class="sourceLineNo">720</span>                    server.getRegionServerAccounting().getGlobalMemStoreLimit());<a name="line.720"></a>
+<span class="sourceLineNo">721</span>              } else {<a name="line.721"></a>
+<span class="sourceLineNo">722</span>                switch (flushType) {<a name="line.722"></a>
+<span class="sourceLineNo">723</span>                case ABOVE_OFFHEAP_HIGHER_MARK:<a name="line.723"></a>
+<span class="sourceLineNo">724</span>                  logMsg("the global offheap memstore datasize",<a name="line.724"></a>
+<span class="sourceLineNo">725</span>                      server.getRegionServerAccounting().getGlobalMemStoreOffHeapSize(),<a name="line.725"></a>
+<span class="sourceLineNo">726</span>                      server.getRegionServerAccounting().getGlobalMemStoreLimit());<a name="line.726"></a>
+<span class="sourceLineNo">727</span>                  break;<a name="line.727"></a>
+<span class="sourceLineNo">728</span>                case ABOVE_ONHEAP_HIGHER_MARK:<a name="line.728"></a>
+<span class="sourceLineNo">729</span>                  logMsg("global memstore heapsize",<a name="line.729"></a>
+<span class="sourceLineNo">730</span>                      server.getRegionServerAccounting().getGlobalMemStoreHeapSize(),<a name="line.730"></a>
+<span class="sourceLineNo">731</span>                      server.getRegionServerAccounting().getGlobalOnHeapMemStoreLimit());<a name="line.731"></a>
+<span class="sourceLineNo">732</span>                  break;<a name="line.732"></a>
+<span class="sourceLineNo">733</span>                default:<a name="line.733"></a>
+<span class="sourceLineNo">734</span>                  break;<a name="line.734"></a>
+<span class="sourceLineNo">735</span>                }<a name="line.735"></a>
+<span class="sourceLineNo">736</span>              }<a name="line.736"></a>
+<span class="sourceLineNo">737</span>            }<a name="line.737"></a>
+<span class="sourceLineNo">738</span>            blocked = true;<a name="line.738"></a>
+<span class="sourceLineNo">739</span>            wakeupFlushThread();<a name="line.739"></a>
+<span class="sourceLineNo">740</span>            try {<a name="line.740"></a>
+<span class="sourceLineNo">741</span>              // we should be able to wait forever, but we've seen a bug where<a name="line.741"></a>
+<span class="sourceLineNo">742</span>              // we miss a notify, so put a 5 second bound on it at least.<a name="line.742"></a>
+<span class="sourceLineNo">743</span>              blockSignal.wait(5 * 1000);<a name="line.743"></a>
+<span class="sourceLineNo">744</span>            } catch (InterruptedException ie) {<a name="line.744"></a>
+<span class="sourceLineNo">745</span>              LOG.warn("Interrupted while waiting");<a name="line.745"></a>
+<span class="sourceLineNo">746</span>              interrupted = true;<a name="line.746"></a>
+<span class="sourceLineNo">747</span>            }<a name="line.747"></a>
+<span class="sourceLineNo">748</span>            long nowMs = EnvironmentEdgeManager.currentTime();<a name="line.748"></a>
+<span class="sourceLineNo">749</span>            if (nowMs &gt;= nextLogTimeMs) {<a name="line.749"></a>
+<span class="sourceLineNo">750</span>              LOG.warn("Memstore is above high water mark and block {} ms", nowMs - start);<a name="line.750"></a>
+<span class="sourceLineNo">751</span>              nextLogTimeMs = nowMs + 1000;<a name="line.751"></a>
+<span class="sourceLineNo">752</span>            }<a name="line.752"></a>
+<span class="sourceLineNo">753</span>            flushType = isAboveHighWaterMark();<a name="line.753"></a>
 <span class="sourceLineNo">754</span>          }<a name="line.754"></a>
-<span class="sourceLineNo">755</span>        }<a name="line.755"></a>
-<span class="sourceLineNo">756</span><a name="line.756"></a>
-<span class="sourceLineNo">757</span>        if(blocked){<a name="line.757"></a>
-<span class="sourceLineNo">758</span>          final long totalTime = EnvironmentEdgeManager.currentTime() - startTime;<a name="line.758"></a>
-<span class="sourceLineNo">759</span>          if(totalTime &gt; 0){<a name="line.759"></a>
-<span class="sourceLineNo">760</span>            this.updatesBlockedMsHighWater.add(totalTime);<a name="line.760"></a>
-<span class="sourceLineNo">761</span>          }<a name="line.761"></a>
-<span class="sourceLineNo">762</span>          LOG.info("Unblocking updates for server " + server.toString());<a name="line.762"></a>
-<span class="sourceLineNo">763</span>        }<a name="line.763"></a>
-<span class="sourceLineNo">764</span>      }<a name="line.764"></a>
-<span class="sourceLineNo">765</span>    } else {<a name="line.765"></a>
-<span class="sourceLineNo">766</span>      flushType = isAboveLowWaterMark();<a name="line.766"></a>
-<span class="sourceLineNo">767</span>      if (flushType != FlushType.NORMAL) {<a name="line.767"></a>
-<span class="sourceLineNo">768</span>        server.cacheFlusher.setFlushType(flushType);<a name="line.768"></a>
-<span class="sourceLineNo">769</span>        wakeupFlushThread();<a name="line.769"></a>
-<span class="sourceLineNo">770</span>      }<a name="line.770"></a>
-<span class="sourceLineNo">771</span>    }<a name="line.771"></a>
-<span class="sourceLineNo">772</span>    if(scope!= null) {<a name="line.772"></a>
-<span class="sourceLineNo">773</span>      scope.close();<a name="line.773"></a>
-<span class="sourceLineNo">774</span>    }<a name="line.774"></a>
-<span class="sourceLineNo">775</span>  }<a name="line.775"></a>
-<span class="sourceLineNo">776</span><a name="line.776"></a>
-<span class="sourceLineNo">777</span>  private void logMsg(String type, long val, long max) {<a name="line.777"></a>
-<span class="sourceLineNo">778</span>    LOG.info("Blocking updates: {} {} is &gt;= blocking {}", type,<a name="line.778"></a>
-<span class="sourceLineNo">779</span>        TraditionalBinaryPrefix.long2String(val, "", 1),<a name="line.779"></a>
-<span class="sourceLineNo">780</span>        TraditionalBinaryPrefix.long2String(max, "", 1));<a name="line.780"></a>
-<span class="sourceLineNo">781</span>  }<a name="line.781"></a>
-<span class="sourceLineNo">782</span><a name="line.782"></a>
-<span class="sourceLineNo">783</span>  @Override<a name="line.783"></a>
-<span class="sourceLineNo">784</span>  public String toString() {<a name="line.784"></a>
-<span class="sourceLineNo">785</span>    return "flush_queue="<a name="line.785"></a>
-<span class="sourceLineNo">786</span>        + flushQueue.size();<a name="line.786"></a>
-<span class="sourceLineNo">787</span>  }<a name="line.787"></a>
-<span class="sourceLineNo">788</span><a name="line.788"></a>
-<span class="sourceLineNo">789</span>  public String dumpQueue() {<a name="line.789"></a>
-<span class="sourceLineNo">790</span>    StringBuilder queueList = new StringBuilder();<a name="line.790"></a>
-<span class="sourceLineNo">791</span>    queueList.append("Flush Queue Queue dump:\n");<a name="line.791"></a>
-<span class="sourceLineNo">792</span>    queueList.append("  Flush Queue:\n");<a name="line.792"></a>
-<span class="sourceLineNo">793</span>    java.util.Iterator&lt;FlushQueueEntry&gt; it = flushQueue.iterator();<a name="line.793"></a>
-<span class="sourceLineNo">794</span><a name="line.794"></a>
-<span class="sourceLineNo">795</span>    while(it.hasNext()){<a name="line.795"></a>
-<span class="sourceLineNo">796</span>      queueList.append("    "+it.next().toString());<a name="line.796"></a>
-<span class="sourceLineNo">797</span>      queueList.append("\n");<a name="line.797"></a>
-<span class="sourceLineNo">798</span>    }<a name="line.798"></a>
-<span class="sourceLineNo">799</span><a name="line.799"></a>
-<span class="sourceLineNo">800</span>    return queueList.toString();<a name="line.800"></a>
-<span class="sourceLineNo">801</span>  }<a name="line.801"></a>
-<span class="sourceLineNo">802</span><a name="line.802"></a>
-<span class="sourceLineNo">803</span>  /**<a name="line.803"></a>
-<span class="sourceLineNo">804</span>   * Register a MemstoreFlushListener<a name="line.804"></a>
-<span class="sourceLineNo">805</span>   * @param listener<a name="line.805"></a>
-<span class="sourceLineNo">806</span>   */<a name="line.806"></a>
-<span class="sourceLineNo">807</span>  @Override<a name="line.807"></a>
-<span class="sourceLineNo">808</span>  public void registerFlushRequestListener(final FlushRequestListener listener) {<a name="line.808"></a>
-<span class="sourceLineNo">809</span>    this.flushRequestListeners.add(listener);<a name="line.809"></a>
-<span class="sourceLineNo">810</span>  }<a name="line.810"></a>
-<span class="sourceLineNo">811</span><a name="line.811"></a>
-<span class="sourceLineNo">812</span>  /**<a name="line.812"></a>
-<span class="sourceLineNo">813</span>   * Unregister the listener from MemstoreFlushListeners<a name="line.813"></a>
-<span class="sourceLineNo">814</span>   * @param listener<a name="line.814"></a>
-<span class="sourceLineNo">815</span>   * @return true when passed listener is unregistered successfully.<a name="line.815"></a>
-<span class="sourceLineNo">816</span>   */<a name="line.816"></a>
-<span class="sourceLineNo">817</span>  @Override<a name="line.817"></a>
-<span class="sourceLineNo">818</span>  public boolean unregisterFlushRequestListener(final FlushRequestListener listener) {<a name="line.818"></a>
-<span class="sourceLineNo">819</span>    return this.flushRequestListeners.remove(listener);<a name="line.819"></a>
-<span class="sourceLineNo">820</span>  }<a name="line.820"></a>
-<span class="sourceLineNo">821</span><a name="line.821"></a>
-<span class="sourceLineNo">822</span>  /**<a name="line.822"></a>
-<span class="sourceLineNo">823</span>   * Sets the global memstore limit to a new size.<a name="line.823"></a>
-<span class="sourceLineNo">824</span>   * @param globalMemStoreSize<a name="line.824"></a>
-<span class="sourceLineNo">825</span>   */<a name="line.825"></a>
-<span class="sourceLineNo">826</span>  @Override<a name="line.826"></a>
-<span class="sourceLineNo">827</span>  public void setGlobalMemStoreLimit(long globalMemStoreSize) {<a name="line.827"></a>
-<span class="sourceLineNo">828</span>    this.server.getRegionServerAccounting().setGlobalMemStoreLimits(globalMemStoreSize);<a name="line.828"></a>
-<span class="sourceLineNo">829</span>    reclaimMemStoreMemory();<a name="line.829"></a>
-<span class="sourceLineNo">830</span>  }<a name="line.830"></a>
-<span class="sourceLineNo">831</span><a name="line.831"></a>
-<span class="sourceLineNo">832</span>  interface FlushQueueEntry extends Delayed {<a name="line.832"></a>
-<span class="sourceLineNo">833</span>  }<a name="line.833"></a>
-<span class="sourceLineNo">834</span><a name="line.834"></a>
-<span class="sourceLineNo">835</span>  /**<a name="line.835"></a>
-<span class="sourceLineNo">836</span>   * Datastructure used in the flush queue.  Holds region and retry count.<a name="line.836"></a>
-<span class="sourceLineNo">837</span>   * Keeps tabs on how old this object is.  Implements {@link Delayed}.  On<a name="line.837"></a>
-<span class="sourceLineNo">838</span>   * construction, the delay is zero. When added to a delay queue, we'll come<a name="line.838"></a>
-<span class="sourceLineNo">839</span>   * out near immediately.  Call {@link #requeue(long)} passing delay in<a name="line.839"></a>
-<span class="sourceLineNo">840</span>   * milliseconds before readding to delay queue if you want it to stay there<a name="line.840"></a>
-<span class="sourceLineNo">841</span>   * a while.<a name="line.841"></a>
-<span class="sourceLineNo">842</span>   */<a name="line.842"></a>
-<span class="sourceLineNo">843</span>  static class FlushRegionEntry implements FlushQueueEntry {<a name="line.843"></a>
-<span class="sourceLineNo">844</span>    private final HRegion region;<a name="line.844"></a>
-<span class="sourceLineNo">845</span><a name="line.845"></a>
-<span class="sourceLineNo">846</span>    private final long createTime;<a name="line.846"></a>
-<span class="sourceLineNo">847</span>    private long whenToExpire;<a name="line.847"></a>
-<span class="sourceLineNo">848</span>    private int requeueCount = 0;<a name="line.848"></a>
+<span class="sourceLineNo">755</span>        } finally {<a name="line.755"></a>
+<span class="sourceLineNo">756</span>          if (interrupted) {<a name="line.756"></a>
+<span class="sourceLineNo">757</span>            Thread.currentThread().interrupt();<a name="line.757"></a>
+<span class="sourceLineNo">758</span>          }<a name="line.758"></a>
+<span class="sourceLineNo">759</span>        }<a name="line.759"></a>
+<span class="sourceLineNo">760</span><a name="line.760"></a>
+<span class="sourceLineNo">761</span>        if(blocked){<a name="line.761"></a>
+<span class="sourceLineNo">762</span>          final long totalTime = EnvironmentEdgeManager.currentTime() - startTime;<a name="line.762"></a>
+<span class="sourceLineNo">763</span>          if(totalTime &gt; 0){<a name="line.763"></a>
+<span class="sourceLineNo">764</span>            this.updatesBlockedMsHighWater.add(totalTime);<a name="line.764"></a>
+<span class="sourceLineNo">765</span>          }<a name="line.765"></a>
+<span class="sourceLineNo">766</span>          LOG.info("Unblocking updates for server " + server.toString());<a name="line.766"></a>
+<span class="sourceLineNo">767</span>        }<a name="line.767"></a>
+<span class="sourceLineNo">768</span>      }<a name="line.768"></a>
+<span class="sourceLineNo">769</span>    } else {<a name="line.769"></a>
+<span class="sourceLineNo">770</span>      flushType = isAboveLowWaterMark();<a name="line.770"></a>
+<span class="sourceLineNo">771</span>      if (flushType != FlushType.NORMAL) {<a name="line.771"></a>
+<span class="sourceLineNo">772</span>        server.cacheFlusher.setFlushType(flushType);<a name="line.772"></a>
+<span class="sourceLineNo">773</span>        wakeupFlushThread();<a name="line.773"></a>
+<span class="sourceLineNo">774</span>      }<a name="line.774"></a>
+<span class="sourceLineNo">775</span>    }<a name="line.775"></a>
+<span class="sourceLineNo">776</span>    if(scope!= null) {<a name="line.776"></a>
+<span class="sourceLineNo">777</span>      scope.close();<a name="line.777"></a>
+<span class="sourceLineNo">778</span>    }<a name="line.778"></a>
+<span class="sourceLineNo">779</span>  }<a name="line.779"></a>
+<span class="sourceLineNo">780</span><a name="line.780"></a>
+<span class="sourceLineNo">781</span>  private void logMsg(String type, long val, long max) {<a name="line.781"></a>
+<span class="sourceLineNo">782</span>    LOG.info("Blocking updates: {} {} is &gt;= blocking {}", type,<a name="line.782"></a>
+<span class="sourceLineNo">783</span>        TraditionalBinaryPrefix.long2String(val, "", 1),<a name="line.783"></a>
+<span class="sourceLineNo">784</span>        TraditionalBinaryPrefix.long2String(max, "", 1));<a name="line.784"></a>
+<span class="sourceLineNo">785</span>  }<a name="line.785"></a>
+<span class="sourceLineNo">786</span><a name="line.786"></a>
+<span class="sourceLineNo">787</span>  @Override<a name="line.787"></a>
+<span class="sourceLineNo">788</span>  public String toString() {<a name="line.788"></a>
+<span class="sourceLineNo">789</span>    return "flush_queue="<a name="line.789"></a>
+<span class="sourceLineNo">790</span>        + flushQueue.size();<a name="line.790"></a>
+<span class="sourceLineNo">791</span>  }<a name="line.791"></a>
+<span class="sourceLineNo">792</span><a name="line.792"></a>
+<span class="sourceLineNo">793</span>  public String dumpQueue() {<a name="line.793"></a>
+<span class="sourceLineNo">794</span>    StringBuilder queueList = new StringBuilder();<a name="line.794"></a>
+<span class="sourceLineNo">795</span>    queueList.append("Flush Queue Queue dump:\n");<a name="line.795"></a>
+<span class="sourceLineNo">796</span>    queueList.append("  Flush Queue:\n");<a name="line.796"></a>
+<span class="sourceLineNo">797</span>    java.util.Iterator&lt;FlushQueueEntry&gt; it = flushQueue.iterator();<a name="line.797"></a>
+<span class="sourceLineNo">798</span><a name="line.798"></a>
+<span class="sourceLineNo">799</span>    while(it.hasNext()){<a name="line.799"></a>
+<span class="sourceLineNo">800</span>      queueList.append("    "+it.next().toString());<a name="line.800"></a>
+<span class="sourceLineNo">801</span>      queueList.append("\n");<a name="line.801"></a>
+<span class="sourceLineNo">802</span>    }<a name="line.802"></a>
+<span class="sourceLineNo">803</span><a name="line.803"></a>
+<span class="sourceLineNo">804</span>    return queueList.toString();<a name="line.804"></a>
+<span class="sourceLineNo">805</span>  }<a name="line.805"></a>
+<span class="sourceLineNo">806</span><a name="line.806"></a>
+<span class="sourceLineNo">807</span>  /**<a name="line.807"></a>
+<span class="sourceLineNo">808</span>   * Register a MemstoreFlushListener<a name="line.808"></a>
+<span class="sourceLineNo">809</span>   * @param listener<a name="line.809"></a>
+<span class="sourceLineNo">810</span>   */<a name="line.810"></a>
+<span class="sourceLineNo">811</span>  @Override<a name="line.811"></a>
+<span class="sourceLineNo">812</span>  public void registerFlushRequestListener(final FlushRequestListener listener) {<a name="line.812"></a>
+<span class="sourceLineNo">813</span>    this.flushRequestListeners.add(listener);<a name="line.813"></a>
+<span class="sourceLineNo">814</span>  }<a name="line.814"></a>
+<span class="sourceLineNo">815</span><a name="line.815"></a>
+<span class="sourceLineNo">816</span>  /**<a name="line.816"></a>
+<span class="sourceLineNo">817</span>   * Unregister the listener from MemstoreFlushListeners<a name="line.817"></a>
+<span class="sourceLineNo">818</span>   * @param listener<a name="line.818"></a>
+<span class="sourceLineNo">819</span>   * @return true when passed listener is unregistered successfully.<a name="line.819"></a>
+<span class="sourceLineNo">820</span>   */<a name="line.820"></a>
+<span class="sourceLineNo">821</span>  @Override<a name="line.821"></a>
+<span class="sourceLineNo">822</span>  public boolean unregisterFlushRequestListener(final FlushRequestListener listener) {<a name="line.822"></a>
+<span class="sourceLineNo">823</span>    return this.flushRequestListeners.remove(listener);<a name="line.823"></a>
+<span class="sourceLineNo">824</span>  }<a name="line.824"></a>
+<span class="sourceLineNo">825</span><a name="line.825"></a>
+<span class="sourceLineNo">826</span>  /**<a name="line.826"></a>
+<span class="sourceLineNo">827</span>   * Sets the global memstore limit to a new size.<a name="line.827"></a>
+<span class="sourceLineNo">828</span>   * @param globalMemStoreSize<a name="line.828"></a>
+<span class="sourceLineNo">829</span>   */<a name="line.829"></a>
+<span class="sourceLineNo">830</span>  @Override<a name="line.830"></a>
+<span class="sourceLineNo">831</span>  public void setGlobalMemStoreLimit(long globalMemStoreSize) {<a name="line.831"></a>
+<span class="sourceLineNo">832</span>    this.server.getRegionServerAccounting().setGlobalMemStoreLimits(globalMemStoreSize);<a name="line.832"></a>
+<span class="sourceLineNo">833</span>    reclaimMemStoreMemory();<a name="line.833"></a>
+<span class="sourceLineNo">834</span>  }<a name="line.834"></a>
+<span class="sourceLineNo">835</span><a name="line.835"></a>
+<span class="sourceLineNo">836</span>  interface FlushQueueEntry extends Delayed {<a name="line.836"></a>
+<span class="sourceLineNo">837</span>  }<a name="line.837"></a>
+<span class="sourceLineNo">838</span><a name="line.838"></a>
+<span class="sourceLineNo">839</span>  /**<a name="line.839"></a>
+<span class="sourceLineNo">840</span>   * Datastructure used in the flush queue.  Holds region and retry count.<a name="line.840"></a>
+<span class="sourceLineNo">841</span>   * Keeps tabs on how old this object is.  Implements {@link Delayed}.  On<a name="line.841"></a>
+<span class="sourceLineNo">842</span>   * construction, the delay is zero. When added to a delay queue, we'll come<a name="line.842"></a>
+<span class="sourceLineNo">843</span>   * out near immediately.  Call {@link #requeue(long)} passing delay in<a name="line.843"></a>
+<span class="sourceLineNo">844</span>   * milliseconds before readding to delay queue if you want it to stay there<a name="line.844"></a>
+<span class="sourceLineNo">845</span>   * a while.<a name="line.845"></a>
+<span class="sourceLineNo">846</span>   */<a name="line.846"></a>
+<span class="sourceLineNo">847</span>  static class FlushRegionEntry implements FlushQueueEntry {<a name="line.847"></a>
+<span class="sourceLineNo">848</span>    private final HRegion region;<a name="line.848"></a>
 <span class="sourceLineNo">849</span><a name="line.849"></a>
-<span class="sourceLineNo">850</span>    private final boolean forceFlushAllStores;<a name="line.850"></a>
-<span class="sourceLineNo">851</span><a name="line.851"></a>
-<span class="sourceLineNo">852</span>    private final FlushLifeCycleTracker tracker;<a name="line.852"></a>
+<span class="sourceLineNo">850</span>    private final long createTime;<a name="line.850"></a>
+<span class="sourceLineNo">851</span>    private long whenToExpire;<a name="line.851"></a>
+<span class="sourceLineNo">852</span>    private int requeueCount = 0;<a name="line.852"></a>
 <span class="sourceLineNo">853</span><a name="line.853"></a>
-<span class="sourceLineNo">854</span>    FlushRegionEntry(final HRegion r, boolean forceFlushAllStores, FlushLifeCycleTracker tracker) {<a name="line.854"></a>
-<span class="sourceLineNo">855</span>      this.region = r;<a name="line.855"></a>
-<span class="sourceLineNo">856</span>      this.createTime = EnvironmentEdgeManager.currentTime();<a name="line.856"></a>
-<span class="sourceLineNo">857</span>      this.whenToExpire = this.createTime;<a name="line.857"></a>
-<span class="sourceLineNo">858</span>      this.forceFlushAllStores = forceFlushAllStores;<a name="line.858"></a>
-<span class="sourceLineNo">859</span>      this.tracker = tracker;<a name="line.859"></a>
-<span class="sourceLineNo">860</span>    }<a name="line.860"></a>
-<span class="sourceLineNo">861</span><a name="line.861"></a>
-<span class="sourceLineNo">862</span>    /**<a name="line.862"></a>
-<span class="sourceLineNo">863</span>     * @param maximumWait<a name="line.863"></a>
-<span class="sourceLineNo">864</span>     * @return True if we have been delayed &gt; &lt;code&gt;maximumWait&lt;/code&gt; milliseconds.<a name="line.864"></a>
-<span class="sourceLineNo">865</span>     */<a name="line.865"></a>
-<span class="sourceLineNo">866</span>    public boolean isMaximumWait(final long maximumWait) {<a name="line.866"></a>
-<span class="sourceLineNo">867</span>      return (EnvironmentEdgeManager.currentTime() - this.createTime) &gt; maximumWait;<a name="line.867"></a>
-<span class="sourceLineNo">868</span>    }<a name="line.868"></a>
-<span class="sourceLineNo">869</span><a name="line.869"></a>
-<span class="sourceLineNo">870</span>    /**<a name="line.870"></a>
-<span class="sourceLineNo">871</span>     * @return Count of times {@link #requeue(long)} was called; i.e this is<a name="line.871"></a>
-<span class="sourceLineNo">872</span>     * number of times we've been requeued.<a name="line.872"></a>
-<span class="sourceLineNo">873</span>     */<a name="line.873"></a>
-<span class="sourceLineNo">874</span>    public int getRequeueCount() {<a name="line.874"></a>
-<span class="sourceLineNo">875</span>      return this.requeueCount;<a name="line.875"></a>
-<span class="sourceLineNo">876</span>    }<a name="line.876"></a>
-<span class="sourceLineNo">877</span><a name="line.877"></a>
-<span class="sourceLineNo">878</span>    /**<a name="line.878"></a>
-<span class="sourceLineNo">879</span>     * @return whether we need to flush all stores.<a name="line.879"></a>
-<span class="sourceLineNo">880</span>     */<a name="line.880"></a>
-<span class="sourceLineNo">881</span>    public boolean isForceFlushAllStores() {<a name="line.881"></a>
-<span class="sourceLineNo">882</span>      return forceFlushAllStores;<a name="line.882"></a>
-<span class="sourceLineNo">883</span>    }<a name="line.883"></a>
-<span class="sourceLineNo">884</span><a name="line.884"></a>
-<span class="sourceLineNo">885</span>    public FlushLifeCycleTracker getTracker() {<a name="line.885"></a>
-<span class="sourceLineNo">886</span>      return tracker;<a name="line.886"></a>
+<span class="sourceLineNo">854</span>    private final boolean forceFlushAllStores;<a name="line.854"></a>
+<span class="sourceLineNo">855</span><a name="line.855"></a>
+<span class="sourceLineNo">856</span>    private final FlushLifeCycleTracker tracker;<a name="line.856"></a>
+<span class="sourceLineNo">857</span><a name="line.857"></a>
+<span class="sourceLineNo">858</span>    FlushRegionEntry(final HRegion r, boolean forceFlushAllStores, FlushLifeCycleTracker tracker) {<a name="line.858"></a>
+<span class="sourceLineNo">859</span>      this.region = r;<a name="line.859"></a>
+<span class="sourceLineNo">860</span>      this.createTime = EnvironmentEdgeManager.currentTime();<a name="line.860"></a>
+<span class="sourceLineNo">861</span>      this.whenToExpire = this.createTime;<a name="line.861"></a>
+<span class="sourceLineNo">862</span>      this.forceFlushAllStores = forceFlushAllStores;<a name="line.862"></a>
+<span class="sourceLineNo">863</span>      this.tracker = tracker;<a name="line.863"></a>
+<span class="sourceLineNo">864</span>    }<a name="line.864"></a>
+<span class="sourceLineNo">865</span><a name="line.865"></a>
+<span class="sourceLineNo">866</span>    /**<a name="line.866"></a>
+<span class="sourceLineNo">867</span>     * @param maximumWait<a name="line.867"></a>
+<span class="sourceLineNo">868</span>     * @return True if we have been delayed &gt; &lt;code&gt;maximumWait&lt;/code&gt; milliseconds.<a name="line.868"></a>
+<span class="sourceLineNo">869</span>     */<a name="line.869"></a>
+<span class="sourceLineNo">870</span>    public boolean isMaximumWait(final long maximumWait) {<a name="line.870"></a>
+<span class="sourceLineNo">871</span>      return (EnvironmentEdgeManager.currentTime() - this.createTime) &gt; maximumWait;<a name="line.871"></a>
+<span class="sourceLineNo">872</span>    }<a name="line.872"></a>
+<span class="sourceLineNo">873</span><a name="line.873"></a>
+<span class="sourceLineNo">874</span>    /**<a name="line.874"></a>
+<span class="sourceLineNo">875</span>     * @return Count of times {@link #requeue(long)} was called; i.e this is<a name="line.875"></a>
+<span class="sourceLineNo">876</span>     * number of times we've been requeued.<a name="line.876"></a>
+<span class="sourceLineNo">877</span>     */<a name="line.877"></a>
+<span class="sourceLineNo">878</span>    public int getRequeueCount() {<a name="line.878"></a>
+<span class="sourceLineNo">879</span>      return this.requeueCount;<a name="line.879"></a>
+<span class="sourceLineNo">880</span>    }<a name="line.880"></a>
+<span class="sourceLineNo">881</span><a name="line.881"></a>
+<span class="sourceLineNo">882</span>    /**<a name="line.882"></a>
+<span class="sourceLineNo">883</span>     * @return whether we need to flush all stores.<a name="line.883"></a>
+<span class="sourceLineNo">884</span>     */<a name="line.884"></a>
+<span class="sourceLineNo">885</span>    public boolean isForceFlushAllStores() {<a name="line.885"></a>
+<span class="sourceLineNo">886</span>      return forceFlushAllStores;<a name="line.886"></a>
 <span class="sourceLineNo">887</span>    }<a name="line.887"></a>
 <span class="sourceLineNo">888</span><a name="line.888"></a>
-<span class="sourceLineNo">889</span>    /**<a name="line.889"></a>
-<span class="sourceLineNo">890</span>     * @param when When to expire, when to come up out of the queue.<a name="line.890"></a>
-<span class="sourceLineNo">891</span>     * Specify in milliseconds.  This method adds EnvironmentEdgeManager.currentTime()<a name="line.891"></a>
-<span class="sourceLineNo">892</span>     * to whatever you pass.<a name="line.892"></a>
-<span class="sourceLineNo">893</span>     * @return This.<a name="line.893"></a>
-<span class="sourceLineNo">894</span>     */<a name="line.894"></a>
-<span class="sourceLineNo">895</span>    public FlushRegionEntry requeue(final long when) {<a name="line.895"></a>
-<span class="sourceLineNo">896</span>      this.whenToExpire = EnvironmentEdgeManager.currentTime() + when;<a name="line.896"></a>
-<span class="sourceLineNo">897</span>      this.requeueCount++;<a name="line.897"></a>
-<span class="sourceLineNo">898</span>      return this;<a name="line.898"></a>
-<span class="sourceLineNo">899</span>    }<a name="line.899"></a>
-<span class="sourceLineNo">900</span><a name="line.900"></a>
-<span class="sourceLineNo">901</span>    @Override<a name="line.901"></a>
-<span class="sourceLineNo">902</span>    public long getDelay(TimeUnit unit) {<a name="line.902"></a>
-<span class="sourceLineNo">903</span>      return unit.convert(this.whenToExpire - EnvironmentEdgeManager.currentTime(),<a name="line.903"></a>
-<span class="sourceLineNo">904</span>          TimeUnit.MILLISECONDS);<a name="line.904"></a>
-<span class="sourceLineNo">905</span>    }<a name="line.905"></a>
-<span class="sourceLineNo">906</span><a name="line.906"></a>
-<span class="sourceLineNo">907</span>    @Override<a name="line.907"></a>
-<span class="sourceLineNo">908</span>    public int compareTo(Delayed other) {<a name="line.908"></a>
-<span class="sourceLineNo">909</span>      // Delay is compared first. If there is a tie, compare region's hash code<a name="line.909"></a>
-<span class="sourceLineNo">910</span>      int ret = Long.valueOf(getDelay(TimeUnit.MILLISECONDS) -<a name="line.910"></a>
-<span class="sourceLineNo">911</span>        other.getDelay(TimeUnit.MILLISECONDS)).intValue();<a name="line.911"></a>
-<span class="sourceLineNo">912</span>      if (ret != 0) {<a name="line.912"></a>
-<span class="sourceLineNo">913</span>        return ret;<a name="line.913"></a>
-<span class="sourceLineNo">914</span>      }<a name="line.914"></a>
-<span class="sourceLineNo">915</span>      FlushQueueEntry otherEntry = (FlushQueueEntry) other;<a name="line.915"></a>
-<span class="sourceLineNo">916</span>      return hashCode() - otherEntry.hashCode();<a name="line.916"></a>
-<span class="sourceLineNo">917</span>    }<a name="line.917"></a>
-<span class="sourceLineNo">918</span><a name="line.918"></a>
-<span class="sourceLineNo">919</span>    @Override<a name="line.919"></a>
-<span class="sourceLineNo">920</span>    public String toString() {<a name="line.920"></a>
-<span class="sourceLineNo">921</span>      return "[flush region "+Bytes.toStringBinary(region.getRegionInfo().getRegionName())+"]";<a name="line.921"></a>
-<span class="sourceLineNo">922</span>    }<a name="line.922"></a>
-<span class="sourceLineNo">923</span><a name="line.923"></a>
-<span class="sourceLineNo">924</span>    @Override<a name="line.924"></a>
-<span class="sourceLineNo">925</span>    public int hashCode() {<a name="line.925"></a>
-<span class="sourceLineNo">926</span>      int hash = (int) getDelay(TimeUnit.MILLISECONDS);<a name="line.926"></a>
-<span class="sourceLineNo">927</span>      return hash ^ region.hashCode();<a name="line.927"></a>
-<span class="sourceLineNo">928</span>    }<a name="line.928"></a>
-<span class="sourceLineNo">929</span><a name="line.929"></a>
-<span class="sourceLineNo">930</span>   @Override<a name="line.930"></a>
-<span class="sourceLineNo">931</span>    public boolean equals(Object obj) {<a name="line.931"></a>
-<span class="sourceLineNo">932</span>      if (this == obj) {<a name="line.932"></a>
-<span class="sourceLineNo">933</span>        return true;<a name="line.933"></a>
-<span class="sourceLineNo">934</span>      }<a name="line.934"></a>
-<span class="sourceLineNo">935</span>      if (obj == null || getClass() != obj.getClass()) {<a name="line.935"></a>
-<span class="sourceLineNo">936</span>        return false;<a name="line.936"></a>
-<span class="sourceLineNo">937</span>      }<a name="line.937"></a>
-<span class="sourceLineNo">938</span>      FlushRegionEntry other = (FlushRegionEntry) obj;<a name="line.938"></a>
-<span class="sourceLineNo">939</span>      if (!Bytes.equals(this.region.getRegionInfo().getRegionName(),<a name="line.939"></a>
-<span class="sourceLineNo">940</span>          other.region.getRegionInfo().getRegionName())) {<a name="line.940"></a>
-<span class="sourceLineNo">941</span>        return false;<a name="line.941"></a>
-<span class="sourceLineNo">942</span>      }<a name="line.942"></a>
-<span class="sourceLineNo">943</span>      return compareTo(other) == 0;<a name="line.943"></a>
-<span class="sourceLineNo">944</span>    }<a name="line.944"></a>
-<span class="sourceLineNo">945</span>  }<a name="line.945"></a>
-<span class="sourceLineNo">946</span>}<a name="line.946"></a>
+<span class="sourceLineNo">889</span>    public FlushLifeCycleTracker getTracker() {<a name="line.889"></a>
+<span class="sourceLineNo">890</span>      return tracker;<a name="line.890"></a>
+<span class="sourceLineNo">891</span>    }<a name="line.891"></a>
+<span class="sourceLineNo">892</span><a name="line.892"></a>
+<span class="sourceLineNo">893</span>    /**<a name="line.893"></a>
+<span class="sourceLineNo">894</span>     * @param when When to expire, when to come up out of the queue.<a name="line.894"></a>
+<span class="sourceLineNo">895</span>     * Specify in milliseconds.  This method adds EnvironmentEdgeManager.currentTime()<a name="line.895"></a>
+<span class="sourceLineNo">896</span>     * to whatever you pass.<a name="line.896"></a>
+<span class="sourceLineNo">897</span>     * @return This.<a name="line.897"></a>
+<span class="sourceLineNo">898</span>     */<a name="line.898"></a>
+<span class="sourceLineNo">899</span>    public FlushRegionEntry requeue(final long when) {<a name="line.899"></a>
+<span class="sourceLineNo">900</span>      this.whenToExpire = EnvironmentEdgeManager.currentTime() + when;<a name="line.900"></a>
+<span class="sourceLineNo">901</span>      this.requeueCount++;<a name="line.901"></a>
+<span class="sourceLineNo">902</span>      return this;<a name="line.902"></a>
+<span class="sourceLineNo">903</span>    }<a name="line.903"></a>
+<span class="sourceLineNo">904</span><a name="line.904"></a>
+<span class="sourceLineNo">905</span>    @Override<a name="line.905"></a>
+<span class="sourceLineNo">906</span>    public long getDelay(TimeUnit unit) {<a name="line.906"></a>
+<span class="sourceLineNo">907</span>      return unit.convert(this.whenToExpire - EnvironmentEdgeManager.currentTime(),<a name="line.907"></a>
+<span class="sourceLineNo">908</span>          TimeUnit.MILLISECONDS);<a name="line.908"></a>
+<span class="sourceLineNo">909</span>    }<a name="line.909"></a>
+<span class="sourceLineNo">910</span><a name="line.910"></a>
+<span class="sourceLineNo">911</span>    @Override<a name="line.911"></a>
+<span class="sourceLineNo">912</span>    public int compareTo(Delayed other) {<a name="line.912"></a>
+<span class="sourceLineNo">913</span>      // Delay is compared first. If there is a tie, compare region's hash code<a name="line.913"></a>
+<span class="sourceLineNo">914</span>      int ret = Long.valueOf(getDelay(TimeUnit.MILLISECONDS) -<a name="line.914"></a>
+<span class="sourceLineNo">915</span>        other.getDelay(TimeUnit.MILLISECONDS)).intValue();<a name="line.915"></a>
+<span class="sourceLineNo">916</span>      if (ret != 0) {<a name="line.916"></a>
+<span class="sourceLineNo">917</span>        return ret;<a name="line.917"></a>
+<span class="sourceLineNo">918</span>      }<a name="line.918"></a>
+<span class="sourceLineNo">919</span>      FlushQueueEntry otherEntry = (FlushQueueEntry) other;<a name="line.919"></a>
+<span class="sourceLineNo">920</span>      return hashCode() - otherEntry.hashCode();<a name="line.920"></a>
+<span class="sourceLineNo">921</span>    }<a name="line.921"></a>
+<span class="sourceLineNo">922</span><a name="line.922"></a>
+<span class="sourceLineNo">923</span>    @Override<a name="line.923"></a>
+<span class="sourceLineNo">924</span>    public String toString() {<a name="line.924"></a>
+<span class="sourceLineNo">925</span>      return "[flush region "+Bytes.toStringBinary(region.getRegionInfo().getRegionName())+"]";<a name="line.925"></a>
+<span class="sourceLineNo">926</span>    }<a name="line.926"></a>
+<span class="sourceLineNo">927</span><a name="line.927"></a>
+<span class="sourceLineNo">928</span>    @Override<a name="line.928"></a>
+<span class="sourceLineNo">929</span>    public int hashCode() {<a name="line.929"></a>
+<span class="sourceLineNo">930</span>      int hash = (int) getDelay(TimeUnit.MILLISECONDS);<a name="line.930"></a>
+<span class="sourceLineNo">931</span>      return hash ^ region.hashCode();<a name="line.931"></a>
+<span class="sourceLineNo">932</span>    }<a name="line.932"></a>
+<span class="sourceLineNo">933</span><a name="line.933"></a>
+<span class="sourceLineNo">934</span>   @Override<a name="line.934"></a>
+<span class="sourceLineNo">935</span>    public boolean equals(Object obj) {<a name="line.935"></a>
+<span class="sourceLineNo">936</span>      if (this == obj) {<a name="line.936"></a>
+<span class="sourceLineNo">937</span>        return true;<a name="line.937"></a>
+<span class="sourceLineNo">938</span>      }<a name="line.938"></a>
+<span class="sourceLineNo">939</span>      if (obj == null || getClass() != obj.getClass()) {<a name="line.939"></a>
+<span class="sourceLineNo">940</span>        return false;<a name="line.940"></a>
+<span class="sourceLineNo">941</span>      }<a name="line.941"></a>
+<span class="sourceLineNo">942</span>      FlushRegionEntry other = (FlushRegionEntry) obj;<a name="line.942"></a>
+<span class="sourceLineNo">943</span>      if (!Bytes.equals(this.region.getRegionInfo().getRegionName(),<a name="line.943"></a>
+<span class="sourceLineNo">944</span>          other.region.getRegionInfo().getRegionName())) {<a name="line.944"></a>
+<span class="sourceLineNo">945</span>        return false;<a name="line.945"></a>
+<span class="sourceLineNo">946</span>      }<a name="line.946"></a>
+<span class="sourceLineNo">947</span>      return compareTo(other) == 0;<a name="line.947"></a>
+<span class="sourceLineNo">948</span>    }<a name="line.948"></a>
+<span class="sourceLineNo">949</span>  }<a name="line.949"></a>
+<span class="sourceLineNo">950</span>}<a name="line.950"></a>
 
 
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/downloads.html
----------------------------------------------------------------------
diff --git a/downloads.html b/downloads.html
index 0bffa73..a64ca9b 100644
--- a/downloads.html
+++ b/downloads.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Apache HBase Downloads</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -463,7 +463,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-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/export_control.html
----------------------------------------------------------------------
diff --git a/export_control.html b/export_control.html
index d81a697..6fef896 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; 
       Export Control
@@ -341,7 +341,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-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/index.html
----------------------------------------------------------------------
diff --git a/index.html b/index.html
index a8fb82b..f83d03e 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Apache HBase™ Home</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -421,7 +421,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-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/integration.html
----------------------------------------------------------------------
diff --git a/integration.html b/integration.html
index f8d0280..9aa09c3 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -301,7 +301,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/issue-tracking.html
----------------------------------------------------------------------
diff --git a/issue-tracking.html b/issue-tracking.html
index 1147539..bc74bc3 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -298,7 +298,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/license.html
----------------------------------------------------------------------
diff --git a/license.html b/license.html
index b1c7651..b442aef 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -501,7 +501,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/mail-lists.html
----------------------------------------------------------------------
diff --git a/mail-lists.html b/mail-lists.html
index 122f57a..dfeb846 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -351,7 +351,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/metrics.html
----------------------------------------------------------------------
diff --git a/metrics.html b/metrics.html
index 0a20795..f940182 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013;  
       Apache HBase (TM) Metrics
@@ -469,7 +469,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-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/old_news.html
----------------------------------------------------------------------
diff --git a/old_news.html b/old_news.html
index 18910b1..3eff97d 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; 
       Old Apache HBase (TM) News
@@ -450,7 +450,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-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/plugin-management.html
----------------------------------------------------------------------
diff --git a/plugin-management.html b/plugin-management.html
index 6902e80..d69226a 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -450,7 +450,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/plugins.html
----------------------------------------------------------------------
diff --git a/plugins.html b/plugins.html
index 3fd8e16..53f1f95 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -381,7 +381,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/poweredbyhbase.html
----------------------------------------------------------------------
diff --git a/poweredbyhbase.html b/poweredbyhbase.html
index 31eba53..e6f0c4f 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <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.4-HBase.min.css" />
@@ -779,7 +779,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-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/project-info.html
----------------------------------------------------------------------
diff --git a/project-info.html b/project-info.html
index 153e6b2..0bfad8d 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -345,7 +345,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/project-reports.html
----------------------------------------------------------------------
diff --git a/project-reports.html b/project-reports.html
index 2b85605..3378fc4 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Generated Reports</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -315,7 +315,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/project-summary.html
----------------------------------------------------------------------
diff --git a/project-summary.html b/project-summary.html
index fd72958..e2a1859 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Summary</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -341,7 +341,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/pseudo-distributed.html
----------------------------------------------------------------------
diff --git a/pseudo-distributed.html b/pseudo-distributed.html
index c5caf3c..b56a5d3 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013;  
 Running Apache HBase (TM) in pseudo-distributed mode
@@ -318,7 +318,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-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/replication.html
----------------------------------------------------------------------
diff --git a/replication.html b/replication.html
index 446c96a..45d173b 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; 
       Apache HBase (TM) Replication
@@ -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-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/resources.html
----------------------------------------------------------------------
diff --git a/resources.html b/resources.html
index b70f256..1e0fcb3 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <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.4-HBase.min.css" />
@@ -341,7 +341,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-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/source-repository.html
----------------------------------------------------------------------
diff --git a/source-repository.html b/source-repository.html
index 2eeb306..3816e44 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Source Code Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -309,7 +309,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/sponsors.html
----------------------------------------------------------------------
diff --git a/sponsors.html b/sponsors.html
index faea188..20a21e5 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Apache HBase™ Sponsors</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -343,7 +343,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-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/supportingprojects.html
----------------------------------------------------------------------
diff --git a/supportingprojects.html b/supportingprojects.html
index 0821c53..f6170cb 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Supporting Projects</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -530,7 +530,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-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/team-list.html
----------------------------------------------------------------------
diff --git a/team-list.html b/team-list.html
index cdcd426..7841e60 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="20181212" />
+    <meta name="Date-Revision-yyyymmdd" content="20181213" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Team</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.4-HBase.min.css" />
@@ -776,7 +776,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-12-12</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-12-13</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/c727a708/testdevapidocs/index-all.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/index-all.html b/testdevapidocs/index-all.html
index eeedc86..f4fe326 100644
--- a/testdevapidocs/index-all.html
+++ b/testdevapidocs/index-all.html
@@ -17963,6 +17963,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/master/snapshot/TestSnapshotManager.html#getNewManager-org.apache.hadoop.conf.Configuration-">getNewManager(Configuration)</a></span> - Method in class org.apache.hadoop.hbase.master.snapshot.<a href="org/apache/hadoop/hbase/master/snapshot/TestSnapshotManager.html" title="class in org.apache.hadoop.hbase.master.snapshot">TestSnapshotManager</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/master/snapshot/TestSnapshotManager.html#getNewManager-org.apache.hadoop.conf.Configuration-int-">getNewManager(Configuration, int)</a></span> - Method in class org.apache.hadoop.hbase.master.snapshot.<a href="org/apache/hadoop/hbase/master/snapshot/TestSnapshotManager.html" title="class in org.apache.hadoop.hbase.master.snapshot">TestSnapshotManager</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/mapreduce/IntegrationTestBulkLoad.LinkChain.html#getNext--">getNext()</a></span> - Method in class org.apache.hadoop.hbase.mapreduce.<a href="org/apache/hadoop/hbase/mapreduce/IntegrationTestBulkLoad.LinkChain.html" title="class in org.apache.hadoop.hbase.mapreduce">IntegrationTestBulkLoad.LinkChain</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/filter/TestFilterList.MockSeekHintFilter.html#getNextCellHint-org.apache.hadoop.hbase.Cell-">getNextCellHint(Cell)</a></span> - Method in class org.apache.hadoop.hbase.filter.<a href="org/apache/hadoop/hbase/filter/TestFilterList.MockSeekHintFilter.html" title="class in org.apache.hadoop.hbase.filter">TestFilterList.MockSeekHintFilter</a></dt>
@@ -26227,8 +26229,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/client/TestMetricsConnection.html#METRICS">METRICS</a></span> - Static variable in class org.apache.hadoop.hbase.client.<a href="org/apache/hadoop/hbase/client/TestMetricsConnection.html" title="class in org.apache.hadoop.hbase.client">TestMetricsConnection</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/master/snapshot/TestSnapshotManager.html#metrics">metrics</a></span> - Variable in class org.apache.hadoop.hbase.master.snapshot.<a href="org/apache/hadoop/hbase/master/snapshot/TestSnapshotManager.html" title="class in org.apache.hadoop.hbase.master.snapshot">TestSnapshotManager</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/replication/ReplicationSourceDummy.html#metrics">metrics</a></span> - Variable in class org.apache.hadoop.hbase.replication.<a href="org/apache/hadoop/hbase/replication/ReplicationSourceDummy.html" title="class in org.apache.hadoop.hbase.replication">ReplicationSourceDummy</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/wal/WALPerformanceEvaluation.html#metrics">metrics</a></span> - Variable in class org.apache.hadoop.hbase.wal.<a href="org/apache/hadoop/hbase/wal/WALPerformanceEvaluation.html" title="class in org.apache.hadoop.hbase.wal">WALPerformanceEvaluation</a></dt>
@@ -46716,6 +46716,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/client/TestAsyncSnapshotAdminApi.html#TestAsyncSnapshotAdminApi--">TestAsyncSnapshotAdminApi()</a></span> - Constructor for class org.apache.hadoop.hbase.client.<a href="org/apache/hadoop/hbase/client/TestAsyncSnapshotAdminApi.html" title="class in org.apache.hadoop.hbase.client">TestAsyncSnapshotAdminApi</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/master/cleaner/TestSnapshotFromMaster.html#testAsyncSnapshotWillNotBlockSnapshotHFileCleaner--">testAsyncSnapshotWillNotBlockSnapshotHFileCleaner()</a></span> - Method in class org.apache.hadoop.hbase.master.cleaner.<a href="org/apache/hadoop/hbase/master/cleaner/TestSnapshotFromMaster.html" title="class in org.apache.hadoop.hbase.master.cleaner">TestSnapshotFromMaster</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="org/apache/hadoop/hbase/client/TestAsyncTable.html" title="class in org.apache.hadoop.hbase.client"><span class="typeNameLink">TestAsyncTable</span></a> - Class in <a href="org/apache/hadoop/hbase/client/package-summary.html">org.apache.hadoop.hbase.client</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/client/TestAsyncTable.html#TestAsyncTable--">TestAsyncTable()</a></span> - Constructor for class org.apache.hadoop.hbase.client.<a href="org/apache/hadoop/hbase/client/TestAsyncTable.html" title="class in org.apache.hadoop.hbase.client">TestAsyncTable</a></dt>
@@ -48519,6 +48521,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/regionserver/compactions/TestCompactedHFilesDischarger.html#testCleanerWithParallelScannersAfterCompaction--">testCleanerWithParallelScannersAfterCompaction()</a></span> - Method in class org.apache.hadoop.hbase.regionserver.compactions.<a href="org/apache/hadoop/hbase/regionserver/compactions/TestCompactedHFilesDischarger.html" title="class in org.apache.hadoop.hbase.regionserver.compactions">TestCompactedHFilesDischarger</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/master/snapshot/TestSnapshotManager.html#testCleanFinishedHandler--">testCleanFinishedHandler()</a></span> - Method in class org.apache.hadoop.hbase.master.snapshot.<a href="org/apache/hadoop/hbase/master/snapshot/TestSnapshotManager.html" title="class in org.apache.hadoop.hbase.master.snapshot">TestSnapshotManager</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/backup/TestHFileArchiving.html#testCleaningRace--">testCleaningRace()</a></span> - Method in class org.apache.hadoop.hbase.backup.<a href="org/apache/hadoop/hbase/backup/TestHFileArchiving.html" title="class in org.apache.hadoop.hbase.backup">TestHFileArchiving</a></dt>
 <dd>
 <div class="block">Test HFileArchiver.resolveAndArchive() race condition HBASE-7643</div>