You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by gi...@apache.org on 2018/01/15 15:31:32 UTC

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

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/devapidocs/src-html/org/apache/hadoop/hbase/zookeeper/ZNodePaths.html
----------------------------------------------------------------------
diff --git a/devapidocs/src-html/org/apache/hadoop/hbase/zookeeper/ZNodePaths.html b/devapidocs/src-html/org/apache/hadoop/hbase/zookeeper/ZNodePaths.html
index 6309308..5625aa2 100644
--- a/devapidocs/src-html/org/apache/hadoop/hbase/zookeeper/ZNodePaths.html
+++ b/devapidocs/src-html/org/apache/hadoop/hbase/zookeeper/ZNodePaths.html
@@ -34,177 +34,188 @@
 <span class="sourceLineNo">026</span><a name="line.26"></a>
 <span class="sourceLineNo">027</span>import java.util.Optional;<a name="line.27"></a>
 <span class="sourceLineNo">028</span>import java.util.stream.IntStream;<a name="line.28"></a>
-<span class="sourceLineNo">029</span><a name="line.29"></a>
-<span class="sourceLineNo">030</span>import org.apache.hadoop.conf.Configuration;<a name="line.30"></a>
-<span class="sourceLineNo">031</span>import org.apache.hadoop.hbase.client.RegionInfo;<a name="line.31"></a>
-<span class="sourceLineNo">032</span>import org.apache.yetus.audience.InterfaceAudience;<a name="line.32"></a>
-<span class="sourceLineNo">033</span><a name="line.33"></a>
-<span class="sourceLineNo">034</span>import org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap;<a name="line.34"></a>
-<span class="sourceLineNo">035</span><a name="line.35"></a>
-<span class="sourceLineNo">036</span>/**<a name="line.36"></a>
-<span class="sourceLineNo">037</span> * Class that hold all the paths of znode for HBase.<a name="line.37"></a>
-<span class="sourceLineNo">038</span> */<a name="line.38"></a>
-<span class="sourceLineNo">039</span>@InterfaceAudience.Private<a name="line.39"></a>
-<span class="sourceLineNo">040</span>public class ZNodePaths {<a name="line.40"></a>
-<span class="sourceLineNo">041</span>  // TODO: Replace this with ZooKeeper constant when ZOOKEEPER-277 is resolved.<a name="line.41"></a>
-<span class="sourceLineNo">042</span>  public static final char ZNODE_PATH_SEPARATOR = '/';<a name="line.42"></a>
-<span class="sourceLineNo">043</span><a name="line.43"></a>
-<span class="sourceLineNo">044</span>  public final static String META_ZNODE_PREFIX = "meta-region-server";<a name="line.44"></a>
-<span class="sourceLineNo">045</span><a name="line.45"></a>
-<span class="sourceLineNo">046</span>  // base znode for this cluster<a name="line.46"></a>
-<span class="sourceLineNo">047</span>  public final String baseZNode;<a name="line.47"></a>
-<span class="sourceLineNo">048</span>  // the prefix of meta znode, does not include baseZNode.<a name="line.48"></a>
-<span class="sourceLineNo">049</span>  public final String metaZNodePrefix;<a name="line.49"></a>
-<span class="sourceLineNo">050</span>  // znodes containing the locations of the servers hosting the meta replicas<a name="line.50"></a>
-<span class="sourceLineNo">051</span>  public final ImmutableMap&lt;Integer, String&gt; metaReplicaZNodes;<a name="line.51"></a>
-<span class="sourceLineNo">052</span>  // znode containing ephemeral nodes of the regionservers<a name="line.52"></a>
-<span class="sourceLineNo">053</span>  public final String rsZNode;<a name="line.53"></a>
-<span class="sourceLineNo">054</span>  // znode containing ephemeral nodes of the draining regionservers<a name="line.54"></a>
-<span class="sourceLineNo">055</span>  public final String drainingZNode;<a name="line.55"></a>
-<span class="sourceLineNo">056</span>  // znode of currently active master<a name="line.56"></a>
-<span class="sourceLineNo">057</span>  public final String masterAddressZNode;<a name="line.57"></a>
-<span class="sourceLineNo">058</span>  // znode of this master in backup master directory, if not the active master<a name="line.58"></a>
-<span class="sourceLineNo">059</span>  public final String backupMasterAddressesZNode;<a name="line.59"></a>
-<span class="sourceLineNo">060</span>  // znode containing the current cluster state<a name="line.60"></a>
-<span class="sourceLineNo">061</span>  public final String clusterStateZNode;<a name="line.61"></a>
-<span class="sourceLineNo">062</span>  // znode used for table disabling/enabling<a name="line.62"></a>
-<span class="sourceLineNo">063</span>  @Deprecated<a name="line.63"></a>
-<span class="sourceLineNo">064</span>  public final String tableZNode;<a name="line.64"></a>
-<span class="sourceLineNo">065</span>  // znode containing the unique cluster ID<a name="line.65"></a>
-<span class="sourceLineNo">066</span>  public final String clusterIdZNode;<a name="line.66"></a>
-<span class="sourceLineNo">067</span>  // znode used for log splitting work assignment<a name="line.67"></a>
-<span class="sourceLineNo">068</span>  public final String splitLogZNode;<a name="line.68"></a>
-<span class="sourceLineNo">069</span>  // znode containing the state of the load balancer<a name="line.69"></a>
-<span class="sourceLineNo">070</span>  public final String balancerZNode;<a name="line.70"></a>
-<span class="sourceLineNo">071</span>  // znode containing the state of region normalizer<a name="line.71"></a>
-<span class="sourceLineNo">072</span>  public final String regionNormalizerZNode;<a name="line.72"></a>
-<span class="sourceLineNo">073</span>  // znode containing the state of all switches, currently there are split and merge child node.<a name="line.73"></a>
-<span class="sourceLineNo">074</span>  public final String switchZNode;<a name="line.74"></a>
-<span class="sourceLineNo">075</span>  // znode containing the lock for the tables<a name="line.75"></a>
-<span class="sourceLineNo">076</span>  public final String tableLockZNode;<a name="line.76"></a>
-<span class="sourceLineNo">077</span>  // znode containing namespace descriptors<a name="line.77"></a>
-<span class="sourceLineNo">078</span>  public final String namespaceZNode;<a name="line.78"></a>
-<span class="sourceLineNo">079</span>  // znode of indicating master maintenance mode<a name="line.79"></a>
-<span class="sourceLineNo">080</span>  public final String masterMaintZNode;<a name="line.80"></a>
-<span class="sourceLineNo">081</span><a name="line.81"></a>
-<span class="sourceLineNo">082</span>  // znode containing all replication state.<a name="line.82"></a>
-<span class="sourceLineNo">083</span>  public final String replicationZNode;<a name="line.83"></a>
-<span class="sourceLineNo">084</span>  // znode containing a list of all remote slave (i.e. peer) clusters.<a name="line.84"></a>
-<span class="sourceLineNo">085</span>  public final String peersZNode;<a name="line.85"></a>
-<span class="sourceLineNo">086</span>  // znode containing all replication queues<a name="line.86"></a>
-<span class="sourceLineNo">087</span>  public final String queuesZNode;<a name="line.87"></a>
-<span class="sourceLineNo">088</span>  // znode containing queues of hfile references to be replicated<a name="line.88"></a>
-<span class="sourceLineNo">089</span>  public final String hfileRefsZNode;<a name="line.89"></a>
-<span class="sourceLineNo">090</span><a name="line.90"></a>
-<span class="sourceLineNo">091</span>  public ZNodePaths(Configuration conf) {<a name="line.91"></a>
-<span class="sourceLineNo">092</span>    baseZNode = conf.get(ZOOKEEPER_ZNODE_PARENT, DEFAULT_ZOOKEEPER_ZNODE_PARENT);<a name="line.92"></a>
-<span class="sourceLineNo">093</span>    ImmutableMap.Builder&lt;Integer, String&gt; builder = ImmutableMap.builder();<a name="line.93"></a>
-<span class="sourceLineNo">094</span>    metaZNodePrefix = conf.get("zookeeper.znode.metaserver", META_ZNODE_PREFIX);<a name="line.94"></a>
-<span class="sourceLineNo">095</span>    String defaultMetaReplicaZNode = ZNodePaths.joinZNode(baseZNode, metaZNodePrefix);<a name="line.95"></a>
-<span class="sourceLineNo">096</span>    builder.put(DEFAULT_REPLICA_ID, defaultMetaReplicaZNode);<a name="line.96"></a>
-<span class="sourceLineNo">097</span>    int numMetaReplicas = conf.getInt(META_REPLICAS_NUM, DEFAULT_META_REPLICA_NUM);<a name="line.97"></a>
-<span class="sourceLineNo">098</span>    IntStream.range(1, numMetaReplicas)<a name="line.98"></a>
-<span class="sourceLineNo">099</span>        .forEachOrdered(i -&gt; builder.put(i, defaultMetaReplicaZNode + "-" + i));<a name="line.99"></a>
-<span class="sourceLineNo">100</span>    metaReplicaZNodes = builder.build();<a name="line.100"></a>
-<span class="sourceLineNo">101</span>    rsZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.rs", "rs"));<a name="line.101"></a>
-<span class="sourceLineNo">102</span>    drainingZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.draining.rs", "draining"));<a name="line.102"></a>
-<span class="sourceLineNo">103</span>    masterAddressZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.master", "master"));<a name="line.103"></a>
-<span class="sourceLineNo">104</span>    backupMasterAddressesZNode =<a name="line.104"></a>
-<span class="sourceLineNo">105</span>        joinZNode(baseZNode, conf.get("zookeeper.znode.backup.masters", "backup-masters"));<a name="line.105"></a>
-<span class="sourceLineNo">106</span>    clusterStateZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.state", "running"));<a name="line.106"></a>
-<span class="sourceLineNo">107</span>    tableZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.tableEnableDisable", "table"));<a name="line.107"></a>
-<span class="sourceLineNo">108</span>    clusterIdZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.clusterId", "hbaseid"));<a name="line.108"></a>
-<span class="sourceLineNo">109</span>    splitLogZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.splitlog", SPLIT_LOGDIR_NAME));<a name="line.109"></a>
-<span class="sourceLineNo">110</span>    balancerZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.balancer", "balancer"));<a name="line.110"></a>
-<span class="sourceLineNo">111</span>    regionNormalizerZNode =<a name="line.111"></a>
-<span class="sourceLineNo">112</span>        joinZNode(baseZNode, conf.get("zookeeper.znode.regionNormalizer", "normalizer"));<a name="line.112"></a>
-<span class="sourceLineNo">113</span>    switchZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.switch", "switch"));<a name="line.113"></a>
-<span class="sourceLineNo">114</span>    tableLockZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.tableLock", "table-lock"));<a name="line.114"></a>
-<span class="sourceLineNo">115</span>    namespaceZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.namespace", "namespace"));<a name="line.115"></a>
-<span class="sourceLineNo">116</span>    masterMaintZNode =<a name="line.116"></a>
-<span class="sourceLineNo">117</span>        joinZNode(baseZNode, conf.get("zookeeper.znode.masterMaintenance", "master-maintenance"));<a name="line.117"></a>
-<span class="sourceLineNo">118</span>    replicationZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.replication", "replication"));<a name="line.118"></a>
-<span class="sourceLineNo">119</span>    peersZNode =<a name="line.119"></a>
-<span class="sourceLineNo">120</span>        joinZNode(replicationZNode, conf.get("zookeeper.znode.replication.peers", "peers"));<a name="line.120"></a>
-<span class="sourceLineNo">121</span>    queuesZNode = joinZNode(replicationZNode, conf.get("zookeeper.znode.replication.rs", "rs"));<a name="line.121"></a>
-<span class="sourceLineNo">122</span>    hfileRefsZNode = joinZNode(replicationZNode,<a name="line.122"></a>
-<span class="sourceLineNo">123</span>      conf.get("zookeeper.znode.replication.hfile.refs", "hfile-refs"));<a name="line.123"></a>
-<span class="sourceLineNo">124</span>  }<a name="line.124"></a>
-<span class="sourceLineNo">125</span><a name="line.125"></a>
-<span class="sourceLineNo">126</span>  @Override<a name="line.126"></a>
-<span class="sourceLineNo">127</span>  public String toString() {<a name="line.127"></a>
-<span class="sourceLineNo">128</span>    return "ZNodePaths [baseZNode=" + baseZNode + ", metaReplicaZNodes=" + metaReplicaZNodes<a name="line.128"></a>
-<span class="sourceLineNo">129</span>        + ", rsZNode=" + rsZNode + ", drainingZNode=" + drainingZNode + ", masterAddressZNode="<a name="line.129"></a>
-<span class="sourceLineNo">130</span>        + masterAddressZNode + ", backupMasterAddressesZNode=" + backupMasterAddressesZNode<a name="line.130"></a>
-<span class="sourceLineNo">131</span>        + ", clusterStateZNode=" + clusterStateZNode + ", tableZNode=" + tableZNode<a name="line.131"></a>
-<span class="sourceLineNo">132</span>        + ", clusterIdZNode=" + clusterIdZNode + ", splitLogZNode=" + splitLogZNode<a name="line.132"></a>
-<span class="sourceLineNo">133</span>        + ", balancerZNode=" + balancerZNode + ", regionNormalizerZNode=" + regionNormalizerZNode<a name="line.133"></a>
-<span class="sourceLineNo">134</span>        + ", switchZNode=" + switchZNode + ", tableLockZNode=" + tableLockZNode<a name="line.134"></a>
-<span class="sourceLineNo">135</span>        + ", namespaceZNode=" + namespaceZNode + ", masterMaintZNode=" + masterMaintZNode<a name="line.135"></a>
-<span class="sourceLineNo">136</span>        + ", replicationZNode=" + replicationZNode + ", peersZNode=" + peersZNode<a name="line.136"></a>
-<span class="sourceLineNo">137</span>        + ", queuesZNode=" + queuesZNode + ", hfileRefsZNode=" + hfileRefsZNode + "]";<a name="line.137"></a>
-<span class="sourceLineNo">138</span>  }<a name="line.138"></a>
-<span class="sourceLineNo">139</span><a name="line.139"></a>
-<span class="sourceLineNo">140</span>  /**<a name="line.140"></a>
-<span class="sourceLineNo">141</span>   * Is the znode of any meta replica<a name="line.141"></a>
-<span class="sourceLineNo">142</span>   * @param node<a name="line.142"></a>
-<span class="sourceLineNo">143</span>   * @return true or false<a name="line.143"></a>
-<span class="sourceLineNo">144</span>   */<a name="line.144"></a>
-<span class="sourceLineNo">145</span>  public boolean isAnyMetaReplicaZNode(String node) {<a name="line.145"></a>
-<span class="sourceLineNo">146</span>    if (metaReplicaZNodes.containsValue(node)) {<a name="line.146"></a>
-<span class="sourceLineNo">147</span>      return true;<a name="line.147"></a>
-<span class="sourceLineNo">148</span>    }<a name="line.148"></a>
-<span class="sourceLineNo">149</span>    return false;<a name="line.149"></a>
-<span class="sourceLineNo">150</span>  }<a name="line.150"></a>
-<span class="sourceLineNo">151</span><a name="line.151"></a>
-<span class="sourceLineNo">152</span>  /**<a name="line.152"></a>
-<span class="sourceLineNo">153</span>   * Get the znode string corresponding to a replicaId<a name="line.153"></a>
-<span class="sourceLineNo">154</span>   * @param replicaId<a name="line.154"></a>
-<span class="sourceLineNo">155</span>   * @return znode<a name="line.155"></a>
-<span class="sourceLineNo">156</span>   */<a name="line.156"></a>
-<span class="sourceLineNo">157</span>  public String getZNodeForReplica(int replicaId) {<a name="line.157"></a>
-<span class="sourceLineNo">158</span>    // return a newly created path but don't update the cache of paths<a name="line.158"></a>
-<span class="sourceLineNo">159</span>    // This is mostly needed for tests that attempt to create meta replicas<a name="line.159"></a>
-<span class="sourceLineNo">160</span>    // from outside the master<a name="line.160"></a>
-<span class="sourceLineNo">161</span>    return Optional.ofNullable(metaReplicaZNodes.get(replicaId))<a name="line.161"></a>
-<span class="sourceLineNo">162</span>        .orElseGet(() -&gt; metaReplicaZNodes.get(DEFAULT_REPLICA_ID) + "-" + replicaId);<a name="line.162"></a>
-<span class="sourceLineNo">163</span>  }<a name="line.163"></a>
-<span class="sourceLineNo">164</span><a name="line.164"></a>
-<span class="sourceLineNo">165</span>  /**<a name="line.165"></a>
-<span class="sourceLineNo">166</span>   * Parse the meta replicaId from the passed znode<a name="line.166"></a>
-<span class="sourceLineNo">167</span>   * @param znode<a name="line.167"></a>
-<span class="sourceLineNo">168</span>   * @return replicaId<a name="line.168"></a>
-<span class="sourceLineNo">169</span>   */<a name="line.169"></a>
-<span class="sourceLineNo">170</span>  public int getMetaReplicaIdFromZnode(String znode) {<a name="line.170"></a>
-<span class="sourceLineNo">171</span>    if (znode.equals(metaZNodePrefix)) {<a name="line.171"></a>
-<span class="sourceLineNo">172</span>      return RegionInfo.DEFAULT_REPLICA_ID;<a name="line.172"></a>
-<span class="sourceLineNo">173</span>    }<a name="line.173"></a>
-<span class="sourceLineNo">174</span>    return Integer.parseInt(znode.substring(metaZNodePrefix.length() + 1));<a name="line.174"></a>
-<span class="sourceLineNo">175</span>  }<a name="line.175"></a>
-<span class="sourceLineNo">176</span><a name="line.176"></a>
-<span class="sourceLineNo">177</span>  /**<a name="line.177"></a>
-<span class="sourceLineNo">178</span>   * Is it the default meta replica's znode<a name="line.178"></a>
-<span class="sourceLineNo">179</span>   * @param znode<a name="line.179"></a>
-<span class="sourceLineNo">180</span>   * @return true or false<a name="line.180"></a>
-<span class="sourceLineNo">181</span>   */<a name="line.181"></a>
-<span class="sourceLineNo">182</span>  public boolean isDefaultMetaReplicaZnode(String znode) {<a name="line.182"></a>
-<span class="sourceLineNo">183</span>    return metaReplicaZNodes.get(DEFAULT_REPLICA_ID).equals(znode);<a name="line.183"></a>
-<span class="sourceLineNo">184</span>  }<a name="line.184"></a>
-<span class="sourceLineNo">185</span><a name="line.185"></a>
-<span class="sourceLineNo">186</span>  /**<a name="line.186"></a>
-<span class="sourceLineNo">187</span>   * Join the prefix znode name with the suffix znode name to generate a proper<a name="line.187"></a>
-<span class="sourceLineNo">188</span>   * full znode name.<a name="line.188"></a>
-<span class="sourceLineNo">189</span>   *<a name="line.189"></a>
-<span class="sourceLineNo">190</span>   * Assumes prefix does not end with slash and suffix does not begin with it.<a name="line.190"></a>
-<span class="sourceLineNo">191</span>   *<a name="line.191"></a>
-<span class="sourceLineNo">192</span>   * @param prefix beginning of znode name<a name="line.192"></a>
-<span class="sourceLineNo">193</span>   * @param suffix ending of znode name<a name="line.193"></a>
-<span class="sourceLineNo">194</span>   * @return result of properly joining prefix with suffix<a name="line.194"></a>
-<span class="sourceLineNo">195</span>   */<a name="line.195"></a>
-<span class="sourceLineNo">196</span>  public static String joinZNode(String prefix, String suffix) {<a name="line.196"></a>
-<span class="sourceLineNo">197</span>    return prefix + ZNodePaths.ZNODE_PATH_SEPARATOR + suffix;<a name="line.197"></a>
-<span class="sourceLineNo">198</span>  }<a name="line.198"></a>
-<span class="sourceLineNo">199</span>}<a name="line.199"></a>
+<span class="sourceLineNo">029</span>import org.apache.hadoop.conf.Configuration;<a name="line.29"></a>
+<span class="sourceLineNo">030</span>import org.apache.hadoop.hbase.client.RegionInfo;<a name="line.30"></a>
+<span class="sourceLineNo">031</span>import org.apache.yetus.audience.InterfaceAudience;<a name="line.31"></a>
+<span class="sourceLineNo">032</span><a name="line.32"></a>
+<span class="sourceLineNo">033</span>import org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap;<a name="line.33"></a>
+<span class="sourceLineNo">034</span><a name="line.34"></a>
+<span class="sourceLineNo">035</span>/**<a name="line.35"></a>
+<span class="sourceLineNo">036</span> * Class that hold all the paths of znode for HBase.<a name="line.36"></a>
+<span class="sourceLineNo">037</span> */<a name="line.37"></a>
+<span class="sourceLineNo">038</span>@InterfaceAudience.Private<a name="line.38"></a>
+<span class="sourceLineNo">039</span>public class ZNodePaths {<a name="line.39"></a>
+<span class="sourceLineNo">040</span>  // TODO: Replace this with ZooKeeper constant when ZOOKEEPER-277 is resolved.<a name="line.40"></a>
+<span class="sourceLineNo">041</span>  public static final char ZNODE_PATH_SEPARATOR = '/';<a name="line.41"></a>
+<span class="sourceLineNo">042</span><a name="line.42"></a>
+<span class="sourceLineNo">043</span>  public final static String META_ZNODE_PREFIX = "meta-region-server";<a name="line.43"></a>
+<span class="sourceLineNo">044</span><a name="line.44"></a>
+<span class="sourceLineNo">045</span>  // base znode for this cluster<a name="line.45"></a>
+<span class="sourceLineNo">046</span>  public final String baseZNode;<a name="line.46"></a>
+<span class="sourceLineNo">047</span>  // the prefix of meta znode, does not include baseZNode.<a name="line.47"></a>
+<span class="sourceLineNo">048</span>  public final String metaZNodePrefix;<a name="line.48"></a>
+<span class="sourceLineNo">049</span>  // znodes containing the locations of the servers hosting the meta replicas<a name="line.49"></a>
+<span class="sourceLineNo">050</span>  public final ImmutableMap&lt;Integer, String&gt; metaReplicaZNodes;<a name="line.50"></a>
+<span class="sourceLineNo">051</span>  // znode containing ephemeral nodes of the regionservers<a name="line.51"></a>
+<span class="sourceLineNo">052</span>  public final String rsZNode;<a name="line.52"></a>
+<span class="sourceLineNo">053</span>  // znode containing ephemeral nodes of the draining regionservers<a name="line.53"></a>
+<span class="sourceLineNo">054</span>  public final String drainingZNode;<a name="line.54"></a>
+<span class="sourceLineNo">055</span>  // znode of currently active master<a name="line.55"></a>
+<span class="sourceLineNo">056</span>  public final String masterAddressZNode;<a name="line.56"></a>
+<span class="sourceLineNo">057</span>  // znode of this master in backup master directory, if not the active master<a name="line.57"></a>
+<span class="sourceLineNo">058</span>  public final String backupMasterAddressesZNode;<a name="line.58"></a>
+<span class="sourceLineNo">059</span>  // znode containing the current cluster state<a name="line.59"></a>
+<span class="sourceLineNo">060</span>  public final String clusterStateZNode;<a name="line.60"></a>
+<span class="sourceLineNo">061</span>  // znode used for table disabling/enabling<a name="line.61"></a>
+<span class="sourceLineNo">062</span>  @Deprecated<a name="line.62"></a>
+<span class="sourceLineNo">063</span>  public final String tableZNode;<a name="line.63"></a>
+<span class="sourceLineNo">064</span>  // znode containing the unique cluster ID<a name="line.64"></a>
+<span class="sourceLineNo">065</span>  public final String clusterIdZNode;<a name="line.65"></a>
+<span class="sourceLineNo">066</span>  // znode used for log splitting work assignment<a name="line.66"></a>
+<span class="sourceLineNo">067</span>  public final String splitLogZNode;<a name="line.67"></a>
+<span class="sourceLineNo">068</span>  // znode containing the state of the load balancer<a name="line.68"></a>
+<span class="sourceLineNo">069</span>  public final String balancerZNode;<a name="line.69"></a>
+<span class="sourceLineNo">070</span>  // znode containing the state of region normalizer<a name="line.70"></a>
+<span class="sourceLineNo">071</span>  public final String regionNormalizerZNode;<a name="line.71"></a>
+<span class="sourceLineNo">072</span>  // znode containing the state of all switches, currently there are split and merge child node.<a name="line.72"></a>
+<span class="sourceLineNo">073</span>  public final String switchZNode;<a name="line.73"></a>
+<span class="sourceLineNo">074</span>  // znode containing the lock for the tables<a name="line.74"></a>
+<span class="sourceLineNo">075</span>  public final String tableLockZNode;<a name="line.75"></a>
+<span class="sourceLineNo">076</span>  // znode containing namespace descriptors<a name="line.76"></a>
+<span class="sourceLineNo">077</span>  public final String namespaceZNode;<a name="line.77"></a>
+<span class="sourceLineNo">078</span>  // znode of indicating master maintenance mode<a name="line.78"></a>
+<span class="sourceLineNo">079</span>  public final String masterMaintZNode;<a name="line.79"></a>
+<span class="sourceLineNo">080</span><a name="line.80"></a>
+<span class="sourceLineNo">081</span>  // znode containing all replication state.<a name="line.81"></a>
+<span class="sourceLineNo">082</span>  public final String replicationZNode;<a name="line.82"></a>
+<span class="sourceLineNo">083</span>  // znode containing a list of all remote slave (i.e. peer) clusters.<a name="line.83"></a>
+<span class="sourceLineNo">084</span>  public final String peersZNode;<a name="line.84"></a>
+<span class="sourceLineNo">085</span>  // znode containing all replication queues<a name="line.85"></a>
+<span class="sourceLineNo">086</span>  public final String queuesZNode;<a name="line.86"></a>
+<span class="sourceLineNo">087</span>  // znode containing queues of hfile references to be replicated<a name="line.87"></a>
+<span class="sourceLineNo">088</span>  public final String hfileRefsZNode;<a name="line.88"></a>
+<span class="sourceLineNo">089</span><a name="line.89"></a>
+<span class="sourceLineNo">090</span>  public ZNodePaths(Configuration conf) {<a name="line.90"></a>
+<span class="sourceLineNo">091</span>    baseZNode = conf.get(ZOOKEEPER_ZNODE_PARENT, DEFAULT_ZOOKEEPER_ZNODE_PARENT);<a name="line.91"></a>
+<span class="sourceLineNo">092</span>    ImmutableMap.Builder&lt;Integer, String&gt; builder = ImmutableMap.builder();<a name="line.92"></a>
+<span class="sourceLineNo">093</span>    metaZNodePrefix = conf.get("zookeeper.znode.metaserver", META_ZNODE_PREFIX);<a name="line.93"></a>
+<span class="sourceLineNo">094</span>    String defaultMetaReplicaZNode = ZNodePaths.joinZNode(baseZNode, metaZNodePrefix);<a name="line.94"></a>
+<span class="sourceLineNo">095</span>    builder.put(DEFAULT_REPLICA_ID, defaultMetaReplicaZNode);<a name="line.95"></a>
+<span class="sourceLineNo">096</span>    int numMetaReplicas = conf.getInt(META_REPLICAS_NUM, DEFAULT_META_REPLICA_NUM);<a name="line.96"></a>
+<span class="sourceLineNo">097</span>    IntStream.range(1, numMetaReplicas)<a name="line.97"></a>
+<span class="sourceLineNo">098</span>        .forEachOrdered(i -&gt; builder.put(i, defaultMetaReplicaZNode + "-" + i));<a name="line.98"></a>
+<span class="sourceLineNo">099</span>    metaReplicaZNodes = builder.build();<a name="line.99"></a>
+<span class="sourceLineNo">100</span>    rsZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.rs", "rs"));<a name="line.100"></a>
+<span class="sourceLineNo">101</span>    drainingZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.draining.rs", "draining"));<a name="line.101"></a>
+<span class="sourceLineNo">102</span>    masterAddressZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.master", "master"));<a name="line.102"></a>
+<span class="sourceLineNo">103</span>    backupMasterAddressesZNode =<a name="line.103"></a>
+<span class="sourceLineNo">104</span>        joinZNode(baseZNode, conf.get("zookeeper.znode.backup.masters", "backup-masters"));<a name="line.104"></a>
+<span class="sourceLineNo">105</span>    clusterStateZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.state", "running"));<a name="line.105"></a>
+<span class="sourceLineNo">106</span>    tableZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.tableEnableDisable", "table"));<a name="line.106"></a>
+<span class="sourceLineNo">107</span>    clusterIdZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.clusterId", "hbaseid"));<a name="line.107"></a>
+<span class="sourceLineNo">108</span>    splitLogZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.splitlog", SPLIT_LOGDIR_NAME));<a name="line.108"></a>
+<span class="sourceLineNo">109</span>    balancerZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.balancer", "balancer"));<a name="line.109"></a>
+<span class="sourceLineNo">110</span>    regionNormalizerZNode =<a name="line.110"></a>
+<span class="sourceLineNo">111</span>        joinZNode(baseZNode, conf.get("zookeeper.znode.regionNormalizer", "normalizer"));<a name="line.111"></a>
+<span class="sourceLineNo">112</span>    switchZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.switch", "switch"));<a name="line.112"></a>
+<span class="sourceLineNo">113</span>    tableLockZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.tableLock", "table-lock"));<a name="line.113"></a>
+<span class="sourceLineNo">114</span>    namespaceZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.namespace", "namespace"));<a name="line.114"></a>
+<span class="sourceLineNo">115</span>    masterMaintZNode =<a name="line.115"></a>
+<span class="sourceLineNo">116</span>        joinZNode(baseZNode, conf.get("zookeeper.znode.masterMaintenance", "master-maintenance"));<a name="line.116"></a>
+<span class="sourceLineNo">117</span>    replicationZNode = joinZNode(baseZNode, conf.get("zookeeper.znode.replication", "replication"));<a name="line.117"></a>
+<span class="sourceLineNo">118</span>    peersZNode =<a name="line.118"></a>
+<span class="sourceLineNo">119</span>        joinZNode(replicationZNode, conf.get("zookeeper.znode.replication.peers", "peers"));<a name="line.119"></a>
+<span class="sourceLineNo">120</span>    queuesZNode = joinZNode(replicationZNode, conf.get("zookeeper.znode.replication.rs", "rs"));<a name="line.120"></a>
+<span class="sourceLineNo">121</span>    hfileRefsZNode = joinZNode(replicationZNode,<a name="line.121"></a>
+<span class="sourceLineNo">122</span>      conf.get("zookeeper.znode.replication.hfile.refs", "hfile-refs"));<a name="line.122"></a>
+<span class="sourceLineNo">123</span>  }<a name="line.123"></a>
+<span class="sourceLineNo">124</span><a name="line.124"></a>
+<span class="sourceLineNo">125</span>  @Override<a name="line.125"></a>
+<span class="sourceLineNo">126</span>  public String toString() {<a name="line.126"></a>
+<span class="sourceLineNo">127</span>    return "ZNodePaths [baseZNode=" + baseZNode + ", metaReplicaZNodes=" + metaReplicaZNodes<a name="line.127"></a>
+<span class="sourceLineNo">128</span>        + ", rsZNode=" + rsZNode + ", drainingZNode=" + drainingZNode + ", masterAddressZNode="<a name="line.128"></a>
+<span class="sourceLineNo">129</span>        + masterAddressZNode + ", backupMasterAddressesZNode=" + backupMasterAddressesZNode<a name="line.129"></a>
+<span class="sourceLineNo">130</span>        + ", clusterStateZNode=" + clusterStateZNode + ", tableZNode=" + tableZNode<a name="line.130"></a>
+<span class="sourceLineNo">131</span>        + ", clusterIdZNode=" + clusterIdZNode + ", splitLogZNode=" + splitLogZNode<a name="line.131"></a>
+<span class="sourceLineNo">132</span>        + ", balancerZNode=" + balancerZNode + ", regionNormalizerZNode=" + regionNormalizerZNode<a name="line.132"></a>
+<span class="sourceLineNo">133</span>        + ", switchZNode=" + switchZNode + ", tableLockZNode=" + tableLockZNode<a name="line.133"></a>
+<span class="sourceLineNo">134</span>        + ", namespaceZNode=" + namespaceZNode + ", masterMaintZNode=" + masterMaintZNode<a name="line.134"></a>
+<span class="sourceLineNo">135</span>        + ", replicationZNode=" + replicationZNode + ", peersZNode=" + peersZNode<a name="line.135"></a>
+<span class="sourceLineNo">136</span>        + ", queuesZNode=" + queuesZNode + ", hfileRefsZNode=" + hfileRefsZNode + "]";<a name="line.136"></a>
+<span class="sourceLineNo">137</span>  }<a name="line.137"></a>
+<span class="sourceLineNo">138</span><a name="line.138"></a>
+<span class="sourceLineNo">139</span>  /**<a name="line.139"></a>
+<span class="sourceLineNo">140</span>   * Is the znode of any meta replica<a name="line.140"></a>
+<span class="sourceLineNo">141</span>   * @param node<a name="line.141"></a>
+<span class="sourceLineNo">142</span>   * @return true or false<a name="line.142"></a>
+<span class="sourceLineNo">143</span>   */<a name="line.143"></a>
+<span class="sourceLineNo">144</span>  public boolean isAnyMetaReplicaZNode(String node) {<a name="line.144"></a>
+<span class="sourceLineNo">145</span>    if (metaReplicaZNodes.containsValue(node)) {<a name="line.145"></a>
+<span class="sourceLineNo">146</span>      return true;<a name="line.146"></a>
+<span class="sourceLineNo">147</span>    }<a name="line.147"></a>
+<span class="sourceLineNo">148</span>    return false;<a name="line.148"></a>
+<span class="sourceLineNo">149</span>  }<a name="line.149"></a>
+<span class="sourceLineNo">150</span><a name="line.150"></a>
+<span class="sourceLineNo">151</span>  /**<a name="line.151"></a>
+<span class="sourceLineNo">152</span>   * Get the znode string corresponding to a replicaId<a name="line.152"></a>
+<span class="sourceLineNo">153</span>   * @param replicaId<a name="line.153"></a>
+<span class="sourceLineNo">154</span>   * @return znode<a name="line.154"></a>
+<span class="sourceLineNo">155</span>   */<a name="line.155"></a>
+<span class="sourceLineNo">156</span>  public String getZNodeForReplica(int replicaId) {<a name="line.156"></a>
+<span class="sourceLineNo">157</span>    // return a newly created path but don't update the cache of paths<a name="line.157"></a>
+<span class="sourceLineNo">158</span>    // This is mostly needed for tests that attempt to create meta replicas<a name="line.158"></a>
+<span class="sourceLineNo">159</span>    // from outside the master<a name="line.159"></a>
+<span class="sourceLineNo">160</span>    return Optional.ofNullable(metaReplicaZNodes.get(replicaId))<a name="line.160"></a>
+<span class="sourceLineNo">161</span>        .orElseGet(() -&gt; metaReplicaZNodes.get(DEFAULT_REPLICA_ID) + "-" + replicaId);<a name="line.161"></a>
+<span class="sourceLineNo">162</span>  }<a name="line.162"></a>
+<span class="sourceLineNo">163</span><a name="line.163"></a>
+<span class="sourceLineNo">164</span>  /**<a name="line.164"></a>
+<span class="sourceLineNo">165</span>   * Parse the meta replicaId from the passed znode<a name="line.165"></a>
+<span class="sourceLineNo">166</span>   * @param znode<a name="line.166"></a>
+<span class="sourceLineNo">167</span>   * @return replicaId<a name="line.167"></a>
+<span class="sourceLineNo">168</span>   */<a name="line.168"></a>
+<span class="sourceLineNo">169</span>  public int getMetaReplicaIdFromZnode(String znode) {<a name="line.169"></a>
+<span class="sourceLineNo">170</span>    if (znode.equals(metaZNodePrefix)) {<a name="line.170"></a>
+<span class="sourceLineNo">171</span>      return RegionInfo.DEFAULT_REPLICA_ID;<a name="line.171"></a>
+<span class="sourceLineNo">172</span>    }<a name="line.172"></a>
+<span class="sourceLineNo">173</span>    return Integer.parseInt(znode.substring(metaZNodePrefix.length() + 1));<a name="line.173"></a>
+<span class="sourceLineNo">174</span>  }<a name="line.174"></a>
+<span class="sourceLineNo">175</span><a name="line.175"></a>
+<span class="sourceLineNo">176</span>  /**<a name="line.176"></a>
+<span class="sourceLineNo">177</span>   * Is it the default meta replica's znode<a name="line.177"></a>
+<span class="sourceLineNo">178</span>   * @param znode<a name="line.178"></a>
+<span class="sourceLineNo">179</span>   * @return true or false<a name="line.179"></a>
+<span class="sourceLineNo">180</span>   */<a name="line.180"></a>
+<span class="sourceLineNo">181</span>  public boolean isDefaultMetaReplicaZnode(String znode) {<a name="line.181"></a>
+<span class="sourceLineNo">182</span>    return metaReplicaZNodes.get(DEFAULT_REPLICA_ID).equals(znode);<a name="line.182"></a>
+<span class="sourceLineNo">183</span>  }<a name="line.183"></a>
+<span class="sourceLineNo">184</span><a name="line.184"></a>
+<span class="sourceLineNo">185</span>  /**<a name="line.185"></a>
+<span class="sourceLineNo">186</span>   * Returns whether the znode is supposed to be readable by the client and DOES NOT contain<a name="line.186"></a>
+<span class="sourceLineNo">187</span>   * sensitive information (world readable).<a name="line.187"></a>
+<span class="sourceLineNo">188</span>   */<a name="line.188"></a>
+<span class="sourceLineNo">189</span>  public boolean isClientReadable(String node) {<a name="line.189"></a>
+<span class="sourceLineNo">190</span>    // Developer notice: These znodes are world readable. DO NOT add more znodes here UNLESS<a name="line.190"></a>
+<span class="sourceLineNo">191</span>    // all clients need to access this data to work. Using zk for sharing data to clients (other<a name="line.191"></a>
+<span class="sourceLineNo">192</span>    // than service lookup case is not a recommended design pattern.<a name="line.192"></a>
+<span class="sourceLineNo">193</span>    return node.equals(baseZNode) || isAnyMetaReplicaZNode(node) ||<a name="line.193"></a>
+<span class="sourceLineNo">194</span>      node.equals(masterAddressZNode) || node.equals(clusterIdZNode) || node.equals(rsZNode) ||<a name="line.194"></a>
+<span class="sourceLineNo">195</span>      // /hbase/table and /hbase/table/foo is allowed, /hbase/table-lock is not<a name="line.195"></a>
+<span class="sourceLineNo">196</span>      node.equals(tableZNode) || node.startsWith(tableZNode + "/");<a name="line.196"></a>
+<span class="sourceLineNo">197</span>  }<a name="line.197"></a>
+<span class="sourceLineNo">198</span><a name="line.198"></a>
+<span class="sourceLineNo">199</span>  /**<a name="line.199"></a>
+<span class="sourceLineNo">200</span>   * Join the prefix znode name with the suffix znode name to generate a proper full znode name.<a name="line.200"></a>
+<span class="sourceLineNo">201</span>   * &lt;p&gt;<a name="line.201"></a>
+<span class="sourceLineNo">202</span>   * Assumes prefix does not end with slash and suffix does not begin with it.<a name="line.202"></a>
+<span class="sourceLineNo">203</span>   * @param prefix beginning of znode name<a name="line.203"></a>
+<span class="sourceLineNo">204</span>   * @param suffix ending of znode name<a name="line.204"></a>
+<span class="sourceLineNo">205</span>   * @return result of properly joining prefix with suffix<a name="line.205"></a>
+<span class="sourceLineNo">206</span>   */<a name="line.206"></a>
+<span class="sourceLineNo">207</span>  public static String joinZNode(String prefix, String suffix) {<a name="line.207"></a>
+<span class="sourceLineNo">208</span>    return prefix + ZNodePaths.ZNODE_PATH_SEPARATOR + suffix;<a name="line.208"></a>
+<span class="sourceLineNo">209</span>  }<a name="line.209"></a>
+<span class="sourceLineNo">210</span>}<a name="line.210"></a>
 
 
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/export_control.html
----------------------------------------------------------------------
diff --git a/export_control.html b/export_control.html
index a40b5c7..7dbbcc9 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="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; 
       Export Control
@@ -336,7 +336,7 @@ for more details.</p>
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-annotations/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/checkstyle.html b/hbase-annotations/checkstyle.html
index b967c7d..9eb4f57 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="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Checkstyle Results</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -150,7 +150,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-annotations/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependencies.html b/hbase-annotations/dependencies.html
index bac5550..3818b0d 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="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -272,7 +272,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-annotations/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-convergence.html b/hbase-annotations/dependency-convergence.html
index 4e4c5c2..2f8e3d2 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="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

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

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-annotations/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-management.html b/hbase-annotations/dependency-management.html
index 8db4744..bef1438 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="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -810,7 +810,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

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

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

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

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-annotations/license.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/license.html b/hbase-annotations/license.html
index f9e965f..49d1e43 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="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -326,7 +326,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-annotations/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/mail-lists.html b/hbase-annotations/mail-lists.html
index 07092b3..419f3ca 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="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -176,7 +176,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

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

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-annotations/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugins.html b/hbase-annotations/plugins.html
index 4efddb7..55548fd 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="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -222,7 +222,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

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

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

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

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

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

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

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-convergence.html b/hbase-build-configuration/dependency-convergence.html
index 12db3e4..ce62fa0 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="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

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

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-management.html b/hbase-build-configuration/dependency-management.html
index 90c6661..35d20ed 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="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -810,7 +810,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/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 578b2dc..3f1b298 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="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -330,7 +330,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/dependency-convergence.html b/hbase-build-configuration/hbase-archetypes/dependency-convergence.html
index 5bd8343..75997a0 100644
--- a/hbase-build-configuration/hbase-archetypes/dependency-convergence.html
+++ b/hbase-build-configuration/hbase-archetypes/dependency-convergence.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/dependency-info.html b/hbase-build-configuration/hbase-archetypes/dependency-info.html
index bc3830c..2a71237 100644
--- a/hbase-build-configuration/hbase-archetypes/dependency-info.html
+++ b/hbase-build-configuration/hbase-archetypes/dependency-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -148,7 +148,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/dependency-management.html b/hbase-build-configuration/hbase-archetypes/dependency-management.html
index abf7976..ff2fca6 100644
--- a/hbase-build-configuration/hbase-archetypes/dependency-management.html
+++ b/hbase-build-configuration/hbase-archetypes/dependency-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -810,7 +810,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependencies.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependencies.html
index c142827..4f666a9 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependencies.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependencies.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -330,7 +330,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-convergence.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-convergence.html
index d893037..7130c69 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-convergence.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-convergence.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -912,7 +912,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-info.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-info.html
index 20b9c40..111488a 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-info.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -148,7 +148,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-management.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-management.html
index 2a88fb1..6d8490b 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-management.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -810,7 +810,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/index.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/index.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/index.html
index 55b86c9..a7f076e 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/index.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/index.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; About</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -119,7 +119,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/integration.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/integration.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/integration.html
index 95c058c..74fc34a 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/integration.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/integration.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -126,7 +126,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/issue-tracking.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/issue-tracking.html
index 5783f4b..5a2b5aa 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/issue-tracking.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/issue-tracking.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -123,7 +123,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/license.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/license.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/license.html
index 0481e28..73187a8 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/license.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/license.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -326,7 +326,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/mail-lists.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/mail-lists.html
index eb72321..1e1cdbb 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/mail-lists.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/mail-lists.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -176,7 +176,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugin-management.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugin-management.html
index bbac73e..fe88cc1 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugin-management.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugin-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -271,7 +271,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/e80e3339/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugins.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugins.html
index 2d88aef..eec893f 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugins.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugins.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20180114" />
+    <meta name="Date-Revision-yyyymmdd" content="20180115" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -218,7 +218,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-01-14</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-01-15</li>
             </p>
                 </div>