You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by gi...@apache.org on 2017/07/20 22:07:24 UTC

[11/19] hbase-site git commit: Published site at 82d554e3783372cc6b05489452c815b57c06f6cd.

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/devapidocs/src-html/org/apache/hadoop/hbase/util/ByteBufferArray.html
----------------------------------------------------------------------
diff --git a/devapidocs/src-html/org/apache/hadoop/hbase/util/ByteBufferArray.html b/devapidocs/src-html/org/apache/hadoop/hbase/util/ByteBufferArray.html
index 7a442f0..103cd9e 100644
--- a/devapidocs/src-html/org/apache/hadoop/hbase/util/ByteBufferArray.html
+++ b/devapidocs/src-html/org/apache/hadoop/hbase/util/ByteBufferArray.html
@@ -52,278 +52,285 @@
 <span class="sourceLineNo">044</span> * reading/writing data from this large buffer with a position and offset<a name="line.44"></a>
 <span class="sourceLineNo">045</span> */<a name="line.45"></a>
 <span class="sourceLineNo">046</span>@InterfaceAudience.Private<a name="line.46"></a>
-<span class="sourceLineNo">047</span>public final class ByteBufferArray {<a name="line.47"></a>
+<span class="sourceLineNo">047</span>public class ByteBufferArray {<a name="line.47"></a>
 <span class="sourceLineNo">048</span>  private static final Log LOG = LogFactory.getLog(ByteBufferArray.class);<a name="line.48"></a>
 <span class="sourceLineNo">049</span><a name="line.49"></a>
 <span class="sourceLineNo">050</span>  public static final int DEFAULT_BUFFER_SIZE = 4 * 1024 * 1024;<a name="line.50"></a>
 <span class="sourceLineNo">051</span>  @VisibleForTesting<a name="line.51"></a>
 <span class="sourceLineNo">052</span>  ByteBuffer buffers[];<a name="line.52"></a>
 <span class="sourceLineNo">053</span>  private int bufferSize;<a name="line.53"></a>
-<span class="sourceLineNo">054</span>  private int bufferCount;<a name="line.54"></a>
-<span class="sourceLineNo">055</span><a name="line.55"></a>
-<span class="sourceLineNo">056</span>  /**<a name="line.56"></a>
-<span class="sourceLineNo">057</span>   * We allocate a number of byte buffers as the capacity. In order not to out<a name="line.57"></a>
-<span class="sourceLineNo">058</span>   * of the array bounds for the last byte(see {@link ByteBufferArray#multiple}),<a name="line.58"></a>
-<span class="sourceLineNo">059</span>   * we will allocate one additional buffer with capacity 0;<a name="line.59"></a>
-<span class="sourceLineNo">060</span>   * @param capacity total size of the byte buffer array<a name="line.60"></a>
-<span class="sourceLineNo">061</span>   * @param directByteBuffer true if we allocate direct buffer<a name="line.61"></a>
-<span class="sourceLineNo">062</span>   * @param allocator the ByteBufferAllocator that will create the buffers<a name="line.62"></a>
-<span class="sourceLineNo">063</span>   * @throws IOException throws IOException if there is an exception thrown by the allocator<a name="line.63"></a>
-<span class="sourceLineNo">064</span>   */<a name="line.64"></a>
-<span class="sourceLineNo">065</span>  public ByteBufferArray(long capacity, boolean directByteBuffer, ByteBufferAllocator allocator)<a name="line.65"></a>
-<span class="sourceLineNo">066</span>      throws IOException {<a name="line.66"></a>
-<span class="sourceLineNo">067</span>    this.bufferSize = DEFAULT_BUFFER_SIZE;<a name="line.67"></a>
-<span class="sourceLineNo">068</span>    if (this.bufferSize &gt; (capacity / 16))<a name="line.68"></a>
-<span class="sourceLineNo">069</span>      this.bufferSize = (int) roundUp(capacity / 16, 32768);<a name="line.69"></a>
-<span class="sourceLineNo">070</span>    this.bufferCount = (int) (roundUp(capacity, bufferSize) / bufferSize);<a name="line.70"></a>
-<span class="sourceLineNo">071</span>    LOG.info("Allocating buffers total=" + StringUtils.byteDesc(capacity)<a name="line.71"></a>
-<span class="sourceLineNo">072</span>        + ", sizePerBuffer=" + StringUtils.byteDesc(bufferSize) + ", count="<a name="line.72"></a>
-<span class="sourceLineNo">073</span>        + bufferCount + ", direct=" + directByteBuffer);<a name="line.73"></a>
-<span class="sourceLineNo">074</span>    buffers = new ByteBuffer[bufferCount + 1];<a name="line.74"></a>
-<span class="sourceLineNo">075</span>    createBuffers(directByteBuffer, allocator);<a name="line.75"></a>
-<span class="sourceLineNo">076</span>  }<a name="line.76"></a>
-<span class="sourceLineNo">077</span><a name="line.77"></a>
-<span class="sourceLineNo">078</span>  private void createBuffers(boolean directByteBuffer, ByteBufferAllocator allocator)<a name="line.78"></a>
-<span class="sourceLineNo">079</span>      throws IOException {<a name="line.79"></a>
-<span class="sourceLineNo">080</span>    int threadCount = Runtime.getRuntime().availableProcessors();<a name="line.80"></a>
-<span class="sourceLineNo">081</span>    ExecutorService service = new ThreadPoolExecutor(threadCount, threadCount, 0L,<a name="line.81"></a>
-<span class="sourceLineNo">082</span>        TimeUnit.MILLISECONDS, new LinkedBlockingQueue&lt;Runnable&gt;());<a name="line.82"></a>
-<span class="sourceLineNo">083</span>    int perThreadCount = Math.round((float) (bufferCount) / threadCount);<a name="line.83"></a>
-<span class="sourceLineNo">084</span>    int lastThreadCount = bufferCount - (perThreadCount * (threadCount - 1));<a name="line.84"></a>
-<span class="sourceLineNo">085</span>    Future&lt;ByteBuffer[]&gt;[] futures = new Future[threadCount];<a name="line.85"></a>
-<span class="sourceLineNo">086</span>    try {<a name="line.86"></a>
-<span class="sourceLineNo">087</span>      for (int i = 0; i &lt; threadCount; i++) {<a name="line.87"></a>
-<span class="sourceLineNo">088</span>        // Last thread will have to deal with a different number of buffers<a name="line.88"></a>
-<span class="sourceLineNo">089</span>        int buffersToCreate = (i == threadCount - 1) ? lastThreadCount : perThreadCount;<a name="line.89"></a>
-<span class="sourceLineNo">090</span>        futures[i] = service.submit(<a name="line.90"></a>
-<span class="sourceLineNo">091</span>          new BufferCreatorCallable(bufferSize, directByteBuffer, buffersToCreate, allocator));<a name="line.91"></a>
-<span class="sourceLineNo">092</span>      }<a name="line.92"></a>
-<span class="sourceLineNo">093</span>      int bufferIndex = 0;<a name="line.93"></a>
-<span class="sourceLineNo">094</span>      for (Future&lt;ByteBuffer[]&gt; future : futures) {<a name="line.94"></a>
-<span class="sourceLineNo">095</span>        try {<a name="line.95"></a>
-<span class="sourceLineNo">096</span>          ByteBuffer[] buffers = future.get();<a name="line.96"></a>
-<span class="sourceLineNo">097</span>          for (ByteBuffer buffer : buffers) {<a name="line.97"></a>
-<span class="sourceLineNo">098</span>            this.buffers[bufferIndex++] = buffer;<a name="line.98"></a>
-<span class="sourceLineNo">099</span>          }<a name="line.99"></a>
-<span class="sourceLineNo">100</span>        } catch (InterruptedException | ExecutionException e) {<a name="line.100"></a>
-<span class="sourceLineNo">101</span>          LOG.error("Buffer creation interrupted", e);<a name="line.101"></a>
-<span class="sourceLineNo">102</span>          throw new IOException(e);<a name="line.102"></a>
-<span class="sourceLineNo">103</span>        }<a name="line.103"></a>
-<span class="sourceLineNo">104</span>      }<a name="line.104"></a>
-<span class="sourceLineNo">105</span>    } finally {<a name="line.105"></a>
-<span class="sourceLineNo">106</span>      service.shutdownNow();<a name="line.106"></a>
-<span class="sourceLineNo">107</span>    }<a name="line.107"></a>
-<span class="sourceLineNo">108</span>    // always create on heap empty dummy buffer at last<a name="line.108"></a>
-<span class="sourceLineNo">109</span>    this.buffers[bufferCount] = ByteBuffer.allocate(0);<a name="line.109"></a>
-<span class="sourceLineNo">110</span>  }<a name="line.110"></a>
-<span class="sourceLineNo">111</span><a name="line.111"></a>
-<span class="sourceLineNo">112</span>  /**<a name="line.112"></a>
-<span class="sourceLineNo">113</span>   * A callable that creates buffers of the specified length either onheap/offheap using the<a name="line.113"></a>
-<span class="sourceLineNo">114</span>   * {@link ByteBufferAllocator}<a name="line.114"></a>
-<span class="sourceLineNo">115</span>   */<a name="line.115"></a>
-<span class="sourceLineNo">116</span>  private static class BufferCreatorCallable implements Callable&lt;ByteBuffer[]&gt; {<a name="line.116"></a>
-<span class="sourceLineNo">117</span>    private final int bufferCapacity;<a name="line.117"></a>
-<span class="sourceLineNo">118</span>    private final boolean directByteBuffer;<a name="line.118"></a>
-<span class="sourceLineNo">119</span>    private final int bufferCount;<a name="line.119"></a>
-<span class="sourceLineNo">120</span>    private final ByteBufferAllocator allocator;<a name="line.120"></a>
-<span class="sourceLineNo">121</span><a name="line.121"></a>
-<span class="sourceLineNo">122</span>    BufferCreatorCallable(int bufferCapacity, boolean directByteBuffer, int bufferCount,<a name="line.122"></a>
-<span class="sourceLineNo">123</span>        ByteBufferAllocator allocator) {<a name="line.123"></a>
-<span class="sourceLineNo">124</span>      this.bufferCapacity = bufferCapacity;<a name="line.124"></a>
-<span class="sourceLineNo">125</span>      this.directByteBuffer = directByteBuffer;<a name="line.125"></a>
-<span class="sourceLineNo">126</span>      this.bufferCount = bufferCount;<a name="line.126"></a>
-<span class="sourceLineNo">127</span>      this.allocator = allocator;<a name="line.127"></a>
-<span class="sourceLineNo">128</span>    }<a name="line.128"></a>
-<span class="sourceLineNo">129</span><a name="line.129"></a>
-<span class="sourceLineNo">130</span>    @Override<a name="line.130"></a>
-<span class="sourceLineNo">131</span>    public ByteBuffer[] call() throws Exception {<a name="line.131"></a>
-<span class="sourceLineNo">132</span>      ByteBuffer[] buffers = new ByteBuffer[this.bufferCount];<a name="line.132"></a>
-<span class="sourceLineNo">133</span>      for (int i = 0; i &lt; this.bufferCount; i++) {<a name="line.133"></a>
-<span class="sourceLineNo">134</span>        buffers[i] = allocator.allocate(this.bufferCapacity, this.directByteBuffer);<a name="line.134"></a>
-<span class="sourceLineNo">135</span>      }<a name="line.135"></a>
-<span class="sourceLineNo">136</span>      return buffers;<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>  private long roundUp(long n, long to) {<a name="line.140"></a>
-<span class="sourceLineNo">141</span>    return ((n + to - 1) / to) * to;<a name="line.141"></a>
-<span class="sourceLineNo">142</span>  }<a name="line.142"></a>
-<span class="sourceLineNo">143</span><a name="line.143"></a>
-<span class="sourceLineNo">144</span>  /**<a name="line.144"></a>
-<span class="sourceLineNo">145</span>   * Transfers bytes from this buffer array into the given destination array<a name="line.145"></a>
-<span class="sourceLineNo">146</span>   * @param start start position in the ByteBufferArray<a name="line.146"></a>
-<span class="sourceLineNo">147</span>   * @param len The maximum number of bytes to be written to the given array<a name="line.147"></a>
-<span class="sourceLineNo">148</span>   * @param dstArray The array into which bytes are to be written<a name="line.148"></a>
-<span class="sourceLineNo">149</span>   * @return number of bytes read<a name="line.149"></a>
-<span class="sourceLineNo">150</span>   */<a name="line.150"></a>
-<span class="sourceLineNo">151</span>  public int getMultiple(long start, int len, byte[] dstArray) {<a name="line.151"></a>
-<span class="sourceLineNo">152</span>    return getMultiple(start, len, dstArray, 0);<a name="line.152"></a>
-<span class="sourceLineNo">153</span>  }<a name="line.153"></a>
-<span class="sourceLineNo">154</span><a name="line.154"></a>
-<span class="sourceLineNo">155</span>  /**<a name="line.155"></a>
-<span class="sourceLineNo">156</span>   * Transfers bytes from this buffer array into the given destination array<a name="line.156"></a>
-<span class="sourceLineNo">157</span>   * @param start start offset of this buffer array<a name="line.157"></a>
-<span class="sourceLineNo">158</span>   * @param len The maximum number of bytes to be written to the given array<a name="line.158"></a>
-<span class="sourceLineNo">159</span>   * @param dstArray The array into which bytes are to be written<a name="line.159"></a>
-<span class="sourceLineNo">160</span>   * @param dstOffset The offset within the given array of the first byte to be<a name="line.160"></a>
-<span class="sourceLineNo">161</span>   *          written<a name="line.161"></a>
-<span class="sourceLineNo">162</span>   * @return number of bytes read<a name="line.162"></a>
-<span class="sourceLineNo">163</span>   */<a name="line.163"></a>
-<span class="sourceLineNo">164</span>  public int getMultiple(long start, int len, byte[] dstArray, int dstOffset) {<a name="line.164"></a>
-<span class="sourceLineNo">165</span>    multiple(start, len, dstArray, dstOffset, GET_MULTIPLE_VISTOR);<a name="line.165"></a>
-<span class="sourceLineNo">166</span>    return len;<a name="line.166"></a>
-<span class="sourceLineNo">167</span>  }<a name="line.167"></a>
-<span class="sourceLineNo">168</span><a name="line.168"></a>
-<span class="sourceLineNo">169</span>  private final static Visitor GET_MULTIPLE_VISTOR = new Visitor() {<a name="line.169"></a>
-<span class="sourceLineNo">170</span>    @Override<a name="line.170"></a>
-<span class="sourceLineNo">171</span>    public void visit(ByteBuffer bb, int pos, byte[] array, int arrayIdx, int len) {<a name="line.171"></a>
-<span class="sourceLineNo">172</span>      ByteBufferUtils.copyFromBufferToArray(array, bb, pos, arrayIdx, len);<a name="line.172"></a>
-<span class="sourceLineNo">173</span>    }<a name="line.173"></a>
-<span class="sourceLineNo">174</span>  };<a name="line.174"></a>
+<span class="sourceLineNo">054</span>  @VisibleForTesting<a name="line.54"></a>
+<span class="sourceLineNo">055</span>  int bufferCount;<a name="line.55"></a>
+<span class="sourceLineNo">056</span><a name="line.56"></a>
+<span class="sourceLineNo">057</span>  /**<a name="line.57"></a>
+<span class="sourceLineNo">058</span>   * We allocate a number of byte buffers as the capacity. In order not to out<a name="line.58"></a>
+<span class="sourceLineNo">059</span>   * of the array bounds for the last byte(see {@link ByteBufferArray#multiple}),<a name="line.59"></a>
+<span class="sourceLineNo">060</span>   * we will allocate one additional buffer with capacity 0;<a name="line.60"></a>
+<span class="sourceLineNo">061</span>   * @param capacity total size of the byte buffer array<a name="line.61"></a>
+<span class="sourceLineNo">062</span>   * @param directByteBuffer true if we allocate direct buffer<a name="line.62"></a>
+<span class="sourceLineNo">063</span>   * @param allocator the ByteBufferAllocator that will create the buffers<a name="line.63"></a>
+<span class="sourceLineNo">064</span>   * @throws IOException throws IOException if there is an exception thrown by the allocator<a name="line.64"></a>
+<span class="sourceLineNo">065</span>   */<a name="line.65"></a>
+<span class="sourceLineNo">066</span>  public ByteBufferArray(long capacity, boolean directByteBuffer, ByteBufferAllocator allocator)<a name="line.66"></a>
+<span class="sourceLineNo">067</span>      throws IOException {<a name="line.67"></a>
+<span class="sourceLineNo">068</span>    this.bufferSize = DEFAULT_BUFFER_SIZE;<a name="line.68"></a>
+<span class="sourceLineNo">069</span>    if (this.bufferSize &gt; (capacity / 16))<a name="line.69"></a>
+<span class="sourceLineNo">070</span>      this.bufferSize = (int) roundUp(capacity / 16, 32768);<a name="line.70"></a>
+<span class="sourceLineNo">071</span>    this.bufferCount = (int) (roundUp(capacity, bufferSize) / bufferSize);<a name="line.71"></a>
+<span class="sourceLineNo">072</span>    LOG.info("Allocating buffers total=" + StringUtils.byteDesc(capacity)<a name="line.72"></a>
+<span class="sourceLineNo">073</span>        + ", sizePerBuffer=" + StringUtils.byteDesc(bufferSize) + ", count="<a name="line.73"></a>
+<span class="sourceLineNo">074</span>        + bufferCount + ", direct=" + directByteBuffer);<a name="line.74"></a>
+<span class="sourceLineNo">075</span>    buffers = new ByteBuffer[bufferCount + 1];<a name="line.75"></a>
+<span class="sourceLineNo">076</span>    createBuffers(directByteBuffer, allocator);<a name="line.76"></a>
+<span class="sourceLineNo">077</span>  }<a name="line.77"></a>
+<span class="sourceLineNo">078</span><a name="line.78"></a>
+<span class="sourceLineNo">079</span>  @VisibleForTesting<a name="line.79"></a>
+<span class="sourceLineNo">080</span>  void createBuffers(boolean directByteBuffer, ByteBufferAllocator allocator)<a name="line.80"></a>
+<span class="sourceLineNo">081</span>      throws IOException {<a name="line.81"></a>
+<span class="sourceLineNo">082</span>    int threadCount = getThreadCount();<a name="line.82"></a>
+<span class="sourceLineNo">083</span>    ExecutorService service = new ThreadPoolExecutor(threadCount, threadCount, 0L,<a name="line.83"></a>
+<span class="sourceLineNo">084</span>        TimeUnit.MILLISECONDS, new LinkedBlockingQueue&lt;Runnable&gt;());<a name="line.84"></a>
+<span class="sourceLineNo">085</span>    int perThreadCount = (int)Math.floor((double) (bufferCount) / threadCount);<a name="line.85"></a>
+<span class="sourceLineNo">086</span>    int lastThreadCount = bufferCount - (perThreadCount * (threadCount - 1));<a name="line.86"></a>
+<span class="sourceLineNo">087</span>    Future&lt;ByteBuffer[]&gt;[] futures = new Future[threadCount];<a name="line.87"></a>
+<span class="sourceLineNo">088</span>    try {<a name="line.88"></a>
+<span class="sourceLineNo">089</span>      for (int i = 0; i &lt; threadCount; i++) {<a name="line.89"></a>
+<span class="sourceLineNo">090</span>        // Last thread will have to deal with a different number of buffers<a name="line.90"></a>
+<span class="sourceLineNo">091</span>        int buffersToCreate = (i == threadCount - 1) ? lastThreadCount : perThreadCount;<a name="line.91"></a>
+<span class="sourceLineNo">092</span>        futures[i] = service.submit(<a name="line.92"></a>
+<span class="sourceLineNo">093</span>          new BufferCreatorCallable(bufferSize, directByteBuffer, buffersToCreate, allocator));<a name="line.93"></a>
+<span class="sourceLineNo">094</span>      }<a name="line.94"></a>
+<span class="sourceLineNo">095</span>      int bufferIndex = 0;<a name="line.95"></a>
+<span class="sourceLineNo">096</span>      for (Future&lt;ByteBuffer[]&gt; future : futures) {<a name="line.96"></a>
+<span class="sourceLineNo">097</span>        try {<a name="line.97"></a>
+<span class="sourceLineNo">098</span>          ByteBuffer[] buffers = future.get();<a name="line.98"></a>
+<span class="sourceLineNo">099</span>          for (ByteBuffer buffer : buffers) {<a name="line.99"></a>
+<span class="sourceLineNo">100</span>            this.buffers[bufferIndex++] = buffer;<a name="line.100"></a>
+<span class="sourceLineNo">101</span>          }<a name="line.101"></a>
+<span class="sourceLineNo">102</span>        } catch (InterruptedException | ExecutionException e) {<a name="line.102"></a>
+<span class="sourceLineNo">103</span>          LOG.error("Buffer creation interrupted", e);<a name="line.103"></a>
+<span class="sourceLineNo">104</span>          throw new IOException(e);<a name="line.104"></a>
+<span class="sourceLineNo">105</span>        }<a name="line.105"></a>
+<span class="sourceLineNo">106</span>      }<a name="line.106"></a>
+<span class="sourceLineNo">107</span>    } finally {<a name="line.107"></a>
+<span class="sourceLineNo">108</span>      service.shutdownNow();<a name="line.108"></a>
+<span class="sourceLineNo">109</span>    }<a name="line.109"></a>
+<span class="sourceLineNo">110</span>    // always create on heap empty dummy buffer at last<a name="line.110"></a>
+<span class="sourceLineNo">111</span>    this.buffers[bufferCount] = ByteBuffer.allocate(0);<a name="line.111"></a>
+<span class="sourceLineNo">112</span>  }<a name="line.112"></a>
+<span class="sourceLineNo">113</span><a name="line.113"></a>
+<span class="sourceLineNo">114</span>  @VisibleForTesting<a name="line.114"></a>
+<span class="sourceLineNo">115</span>  int getThreadCount() {<a name="line.115"></a>
+<span class="sourceLineNo">116</span>    return Runtime.getRuntime().availableProcessors();<a name="line.116"></a>
+<span class="sourceLineNo">117</span>  }<a name="line.117"></a>
+<span class="sourceLineNo">118</span><a name="line.118"></a>
+<span class="sourceLineNo">119</span>  /**<a name="line.119"></a>
+<span class="sourceLineNo">120</span>   * A callable that creates buffers of the specified length either onheap/offheap using the<a name="line.120"></a>
+<span class="sourceLineNo">121</span>   * {@link ByteBufferAllocator}<a name="line.121"></a>
+<span class="sourceLineNo">122</span>   */<a name="line.122"></a>
+<span class="sourceLineNo">123</span>  private static class BufferCreatorCallable implements Callable&lt;ByteBuffer[]&gt; {<a name="line.123"></a>
+<span class="sourceLineNo">124</span>    private final int bufferCapacity;<a name="line.124"></a>
+<span class="sourceLineNo">125</span>    private final boolean directByteBuffer;<a name="line.125"></a>
+<span class="sourceLineNo">126</span>    private final int bufferCount;<a name="line.126"></a>
+<span class="sourceLineNo">127</span>    private final ByteBufferAllocator allocator;<a name="line.127"></a>
+<span class="sourceLineNo">128</span><a name="line.128"></a>
+<span class="sourceLineNo">129</span>    BufferCreatorCallable(int bufferCapacity, boolean directByteBuffer, int bufferCount,<a name="line.129"></a>
+<span class="sourceLineNo">130</span>        ByteBufferAllocator allocator) {<a name="line.130"></a>
+<span class="sourceLineNo">131</span>      this.bufferCapacity = bufferCapacity;<a name="line.131"></a>
+<span class="sourceLineNo">132</span>      this.directByteBuffer = directByteBuffer;<a name="line.132"></a>
+<span class="sourceLineNo">133</span>      this.bufferCount = bufferCount;<a name="line.133"></a>
+<span class="sourceLineNo">134</span>      this.allocator = allocator;<a name="line.134"></a>
+<span class="sourceLineNo">135</span>    }<a name="line.135"></a>
+<span class="sourceLineNo">136</span><a name="line.136"></a>
+<span class="sourceLineNo">137</span>    @Override<a name="line.137"></a>
+<span class="sourceLineNo">138</span>    public ByteBuffer[] call() throws Exception {<a name="line.138"></a>
+<span class="sourceLineNo">139</span>      ByteBuffer[] buffers = new ByteBuffer[this.bufferCount];<a name="line.139"></a>
+<span class="sourceLineNo">140</span>      for (int i = 0; i &lt; this.bufferCount; i++) {<a name="line.140"></a>
+<span class="sourceLineNo">141</span>        buffers[i] = allocator.allocate(this.bufferCapacity, this.directByteBuffer);<a name="line.141"></a>
+<span class="sourceLineNo">142</span>      }<a name="line.142"></a>
+<span class="sourceLineNo">143</span>      return buffers;<a name="line.143"></a>
+<span class="sourceLineNo">144</span>    }<a name="line.144"></a>
+<span class="sourceLineNo">145</span>  }<a name="line.145"></a>
+<span class="sourceLineNo">146</span><a name="line.146"></a>
+<span class="sourceLineNo">147</span>  private long roundUp(long n, long to) {<a name="line.147"></a>
+<span class="sourceLineNo">148</span>    return ((n + to - 1) / to) * to;<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>   * Transfers bytes from this buffer array into the given destination array<a name="line.152"></a>
+<span class="sourceLineNo">153</span>   * @param start start position in the ByteBufferArray<a name="line.153"></a>
+<span class="sourceLineNo">154</span>   * @param len The maximum number of bytes to be written to the given array<a name="line.154"></a>
+<span class="sourceLineNo">155</span>   * @param dstArray The array into which bytes are to be written<a name="line.155"></a>
+<span class="sourceLineNo">156</span>   * @return number of bytes read<a name="line.156"></a>
+<span class="sourceLineNo">157</span>   */<a name="line.157"></a>
+<span class="sourceLineNo">158</span>  public int getMultiple(long start, int len, byte[] dstArray) {<a name="line.158"></a>
+<span class="sourceLineNo">159</span>    return getMultiple(start, len, dstArray, 0);<a name="line.159"></a>
+<span class="sourceLineNo">160</span>  }<a name="line.160"></a>
+<span class="sourceLineNo">161</span><a name="line.161"></a>
+<span class="sourceLineNo">162</span>  /**<a name="line.162"></a>
+<span class="sourceLineNo">163</span>   * Transfers bytes from this buffer array into the given destination array<a name="line.163"></a>
+<span class="sourceLineNo">164</span>   * @param start start offset of this buffer array<a name="line.164"></a>
+<span class="sourceLineNo">165</span>   * @param len The maximum number of bytes to be written to the given array<a name="line.165"></a>
+<span class="sourceLineNo">166</span>   * @param dstArray The array into which bytes are to be written<a name="line.166"></a>
+<span class="sourceLineNo">167</span>   * @param dstOffset The offset within the given array of the first byte to be<a name="line.167"></a>
+<span class="sourceLineNo">168</span>   *          written<a name="line.168"></a>
+<span class="sourceLineNo">169</span>   * @return number of bytes read<a name="line.169"></a>
+<span class="sourceLineNo">170</span>   */<a name="line.170"></a>
+<span class="sourceLineNo">171</span>  public int getMultiple(long start, int len, byte[] dstArray, int dstOffset) {<a name="line.171"></a>
+<span class="sourceLineNo">172</span>    multiple(start, len, dstArray, dstOffset, GET_MULTIPLE_VISTOR);<a name="line.172"></a>
+<span class="sourceLineNo">173</span>    return len;<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>   * Transfers bytes from the given source array into this buffer array<a name="line.177"></a>
-<span class="sourceLineNo">178</span>   * @param start start offset of this buffer array<a name="line.178"></a>
-<span class="sourceLineNo">179</span>   * @param len The maximum number of bytes to be read from the given array<a name="line.179"></a>
-<span class="sourceLineNo">180</span>   * @param srcArray The array from which bytes are to be read<a name="line.180"></a>
-<span class="sourceLineNo">181</span>   */<a name="line.181"></a>
-<span class="sourceLineNo">182</span>  public void putMultiple(long start, int len, byte[] srcArray) {<a name="line.182"></a>
-<span class="sourceLineNo">183</span>    putMultiple(start, len, srcArray, 0);<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>   * Transfers bytes from the given source array into this buffer array<a name="line.187"></a>
-<span class="sourceLineNo">188</span>   * @param start start offset of this buffer array<a name="line.188"></a>
-<span class="sourceLineNo">189</span>   * @param len The maximum number of bytes to be read from the given array<a name="line.189"></a>
-<span class="sourceLineNo">190</span>   * @param srcArray The array from which bytes are to be read<a name="line.190"></a>
-<span class="sourceLineNo">191</span>   * @param srcOffset The offset within the given array of the first byte to be<a name="line.191"></a>
-<span class="sourceLineNo">192</span>   *          read<a name="line.192"></a>
-<span class="sourceLineNo">193</span>   */<a name="line.193"></a>
-<span class="sourceLineNo">194</span>  public void putMultiple(long start, int len, byte[] srcArray, int srcOffset) {<a name="line.194"></a>
-<span class="sourceLineNo">195</span>    multiple(start, len, srcArray, srcOffset, PUT_MULTIPLE_VISITOR);<a name="line.195"></a>
-<span class="sourceLineNo">196</span>  }<a name="line.196"></a>
-<span class="sourceLineNo">197</span><a name="line.197"></a>
-<span class="sourceLineNo">198</span>  private final static Visitor PUT_MULTIPLE_VISITOR = new Visitor() {<a name="line.198"></a>
-<span class="sourceLineNo">199</span>    @Override<a name="line.199"></a>
-<span class="sourceLineNo">200</span>    public void visit(ByteBuffer bb, int pos, byte[] array, int arrayIdx, int len) {<a name="line.200"></a>
-<span class="sourceLineNo">201</span>      ByteBufferUtils.copyFromArrayToBuffer(bb, pos, array, arrayIdx, len);<a name="line.201"></a>
-<span class="sourceLineNo">202</span>    }<a name="line.202"></a>
-<span class="sourceLineNo">203</span>  };<a name="line.203"></a>
+<span class="sourceLineNo">176</span>  private final static Visitor GET_MULTIPLE_VISTOR = new Visitor() {<a name="line.176"></a>
+<span class="sourceLineNo">177</span>    @Override<a name="line.177"></a>
+<span class="sourceLineNo">178</span>    public void visit(ByteBuffer bb, int pos, byte[] array, int arrayIdx, int len) {<a name="line.178"></a>
+<span class="sourceLineNo">179</span>      ByteBufferUtils.copyFromBufferToArray(array, bb, pos, arrayIdx, len);<a name="line.179"></a>
+<span class="sourceLineNo">180</span>    }<a name="line.180"></a>
+<span class="sourceLineNo">181</span>  };<a name="line.181"></a>
+<span class="sourceLineNo">182</span><a name="line.182"></a>
+<span class="sourceLineNo">183</span>  /**<a name="line.183"></a>
+<span class="sourceLineNo">184</span>   * Transfers bytes from the given source array into this buffer array<a name="line.184"></a>
+<span class="sourceLineNo">185</span>   * @param start start offset of this buffer array<a name="line.185"></a>
+<span class="sourceLineNo">186</span>   * @param len The maximum number of bytes to be read from the given array<a name="line.186"></a>
+<span class="sourceLineNo">187</span>   * @param srcArray The array from which bytes are to be read<a name="line.187"></a>
+<span class="sourceLineNo">188</span>   */<a name="line.188"></a>
+<span class="sourceLineNo">189</span>  public void putMultiple(long start, int len, byte[] srcArray) {<a name="line.189"></a>
+<span class="sourceLineNo">190</span>    putMultiple(start, len, srcArray, 0);<a name="line.190"></a>
+<span class="sourceLineNo">191</span>  }<a name="line.191"></a>
+<span class="sourceLineNo">192</span><a name="line.192"></a>
+<span class="sourceLineNo">193</span>  /**<a name="line.193"></a>
+<span class="sourceLineNo">194</span>   * Transfers bytes from the given source array into this buffer array<a name="line.194"></a>
+<span class="sourceLineNo">195</span>   * @param start start offset of this buffer array<a name="line.195"></a>
+<span class="sourceLineNo">196</span>   * @param len The maximum number of bytes to be read from the given array<a name="line.196"></a>
+<span class="sourceLineNo">197</span>   * @param srcArray The array from which bytes are to be read<a name="line.197"></a>
+<span class="sourceLineNo">198</span>   * @param srcOffset The offset within the given array of the first byte to be<a name="line.198"></a>
+<span class="sourceLineNo">199</span>   *          read<a name="line.199"></a>
+<span class="sourceLineNo">200</span>   */<a name="line.200"></a>
+<span class="sourceLineNo">201</span>  public void putMultiple(long start, int len, byte[] srcArray, int srcOffset) {<a name="line.201"></a>
+<span class="sourceLineNo">202</span>    multiple(start, len, srcArray, srcOffset, PUT_MULTIPLE_VISITOR);<a name="line.202"></a>
+<span class="sourceLineNo">203</span>  }<a name="line.203"></a>
 <span class="sourceLineNo">204</span><a name="line.204"></a>
-<span class="sourceLineNo">205</span>  private interface Visitor {<a name="line.205"></a>
-<span class="sourceLineNo">206</span>    /**<a name="line.206"></a>
-<span class="sourceLineNo">207</span>     * Visit the given byte buffer, if it is a read action, we will transfer the<a name="line.207"></a>
-<span class="sourceLineNo">208</span>     * bytes from the buffer to the destination array, else if it is a write<a name="line.208"></a>
-<span class="sourceLineNo">209</span>     * action, we will transfer the bytes from the source array to the buffer<a name="line.209"></a>
-<span class="sourceLineNo">210</span>     * @param bb byte buffer<a name="line.210"></a>
-<span class="sourceLineNo">211</span>     * @param pos Start position in ByteBuffer<a name="line.211"></a>
-<span class="sourceLineNo">212</span>     * @param array a source or destination byte array<a name="line.212"></a>
-<span class="sourceLineNo">213</span>     * @param arrayOffset offset of the byte array<a name="line.213"></a>
-<span class="sourceLineNo">214</span>     * @param len read/write length<a name="line.214"></a>
-<span class="sourceLineNo">215</span>     */<a name="line.215"></a>
-<span class="sourceLineNo">216</span>    void visit(ByteBuffer bb, int pos, byte[] array, int arrayOffset, int len);<a name="line.216"></a>
-<span class="sourceLineNo">217</span>  }<a name="line.217"></a>
-<span class="sourceLineNo">218</span><a name="line.218"></a>
-<span class="sourceLineNo">219</span>  /**<a name="line.219"></a>
-<span class="sourceLineNo">220</span>   * Access(read or write) this buffer array with a position and length as the<a name="line.220"></a>
-<span class="sourceLineNo">221</span>   * given array. Here we will only lock one buffer even if it may be need visit<a name="line.221"></a>
-<span class="sourceLineNo">222</span>   * several buffers. The consistency is guaranteed by the caller.<a name="line.222"></a>
-<span class="sourceLineNo">223</span>   * @param start start offset of this buffer array<a name="line.223"></a>
-<span class="sourceLineNo">224</span>   * @param len The maximum number of bytes to be accessed<a name="line.224"></a>
-<span class="sourceLineNo">225</span>   * @param array The array from/to which bytes are to be read/written<a name="line.225"></a>
-<span class="sourceLineNo">226</span>   * @param arrayOffset The offset within the given array of the first byte to<a name="line.226"></a>
-<span class="sourceLineNo">227</span>   *          be read or written<a name="line.227"></a>
-<span class="sourceLineNo">228</span>   * @param visitor implement of how to visit the byte buffer<a name="line.228"></a>
-<span class="sourceLineNo">229</span>   */<a name="line.229"></a>
-<span class="sourceLineNo">230</span>  void multiple(long start, int len, byte[] array, int arrayOffset, Visitor visitor) {<a name="line.230"></a>
-<span class="sourceLineNo">231</span>    assert len &gt;= 0;<a name="line.231"></a>
-<span class="sourceLineNo">232</span>    long end = start + len;<a name="line.232"></a>
-<span class="sourceLineNo">233</span>    int startBuffer = (int) (start / bufferSize), startOffset = (int) (start % bufferSize);<a name="line.233"></a>
-<span class="sourceLineNo">234</span>    int endBuffer = (int) (end / bufferSize), endOffset = (int) (end % bufferSize);<a name="line.234"></a>
-<span class="sourceLineNo">235</span>    assert array.length &gt;= len + arrayOffset;<a name="line.235"></a>
-<span class="sourceLineNo">236</span>    assert startBuffer &gt;= 0 &amp;&amp; startBuffer &lt; bufferCount;<a name="line.236"></a>
-<span class="sourceLineNo">237</span>    assert endBuffer &gt;= 0 &amp;&amp; endBuffer &lt; bufferCount<a name="line.237"></a>
-<span class="sourceLineNo">238</span>        || (endBuffer == bufferCount &amp;&amp; endOffset == 0);<a name="line.238"></a>
-<span class="sourceLineNo">239</span>    if (startBuffer &gt;= buffers.length || startBuffer &lt; 0) {<a name="line.239"></a>
-<span class="sourceLineNo">240</span>      String msg = "Failed multiple, start=" + start + ",startBuffer="<a name="line.240"></a>
-<span class="sourceLineNo">241</span>          + startBuffer + ",bufferSize=" + bufferSize;<a name="line.241"></a>
-<span class="sourceLineNo">242</span>      LOG.error(msg);<a name="line.242"></a>
-<span class="sourceLineNo">243</span>      throw new RuntimeException(msg);<a name="line.243"></a>
-<span class="sourceLineNo">244</span>    }<a name="line.244"></a>
-<span class="sourceLineNo">245</span>    int srcIndex = 0, cnt = -1;<a name="line.245"></a>
-<span class="sourceLineNo">246</span>    for (int i = startBuffer; i &lt;= endBuffer; ++i) {<a name="line.246"></a>
-<span class="sourceLineNo">247</span>      ByteBuffer bb = buffers[i].duplicate();<a name="line.247"></a>
-<span class="sourceLineNo">248</span>      int pos = 0;<a name="line.248"></a>
-<span class="sourceLineNo">249</span>      if (i == startBuffer) {<a name="line.249"></a>
-<span class="sourceLineNo">250</span>        cnt = bufferSize - startOffset;<a name="line.250"></a>
-<span class="sourceLineNo">251</span>        if (cnt &gt; len) cnt = len;<a name="line.251"></a>
-<span class="sourceLineNo">252</span>        pos = startOffset;<a name="line.252"></a>
-<span class="sourceLineNo">253</span>      } else if (i == endBuffer) {<a name="line.253"></a>
-<span class="sourceLineNo">254</span>        cnt = endOffset;<a name="line.254"></a>
-<span class="sourceLineNo">255</span>      } else {<a name="line.255"></a>
-<span class="sourceLineNo">256</span>        cnt = bufferSize;<a name="line.256"></a>
-<span class="sourceLineNo">257</span>      }<a name="line.257"></a>
-<span class="sourceLineNo">258</span>      visitor.visit(bb, pos, array, srcIndex + arrayOffset, cnt);<a name="line.258"></a>
-<span class="sourceLineNo">259</span>      srcIndex += cnt;<a name="line.259"></a>
-<span class="sourceLineNo">260</span>    }<a name="line.260"></a>
-<span class="sourceLineNo">261</span>    assert srcIndex == len;<a name="line.261"></a>
-<span class="sourceLineNo">262</span>  }<a name="line.262"></a>
-<span class="sourceLineNo">263</span><a name="line.263"></a>
-<span class="sourceLineNo">264</span>  /**<a name="line.264"></a>
-<span class="sourceLineNo">265</span>   * Creates a ByteBuff from a given array of ByteBuffers from the given offset to the<a name="line.265"></a>
-<span class="sourceLineNo">266</span>   * length specified. For eg, if there are 4 buffers forming an array each with length 10 and<a name="line.266"></a>
-<span class="sourceLineNo">267</span>   * if we call asSubBuffer(5, 10) then we will create an MBB consisting of two BBs<a name="line.267"></a>
-<span class="sourceLineNo">268</span>   * and the first one be a BB from 'position' 5 to a 'length' 5 and the 2nd BB will be from<a name="line.268"></a>
-<span class="sourceLineNo">269</span>   * 'position' 0 to 'length' 5.<a name="line.269"></a>
-<span class="sourceLineNo">270</span>   * @param offset<a name="line.270"></a>
-<span class="sourceLineNo">271</span>   * @param len<a name="line.271"></a>
-<span class="sourceLineNo">272</span>   * @return a ByteBuff formed from the underlying ByteBuffers<a name="line.272"></a>
-<span class="sourceLineNo">273</span>   */<a name="line.273"></a>
-<span class="sourceLineNo">274</span>  public ByteBuff asSubByteBuff(long offset, int len) {<a name="line.274"></a>
-<span class="sourceLineNo">275</span>    assert len &gt;= 0;<a name="line.275"></a>
-<span class="sourceLineNo">276</span>    long end = offset + len;<a name="line.276"></a>
-<span class="sourceLineNo">277</span>    int startBuffer = (int) (offset / bufferSize), startBufferOffset = (int) (offset % bufferSize);<a name="line.277"></a>
-<span class="sourceLineNo">278</span>    int endBuffer = (int) (end / bufferSize), endBufferOffset = (int) (end % bufferSize);<a name="line.278"></a>
-<span class="sourceLineNo">279</span>    // Last buffer in the array is a dummy one with 0 capacity. Avoid sending back that<a name="line.279"></a>
-<span class="sourceLineNo">280</span>    if (endBuffer == this.bufferCount) {<a name="line.280"></a>
-<span class="sourceLineNo">281</span>      endBuffer--;<a name="line.281"></a>
-<span class="sourceLineNo">282</span>      endBufferOffset = bufferSize;<a name="line.282"></a>
-<span class="sourceLineNo">283</span>    }<a name="line.283"></a>
-<span class="sourceLineNo">284</span>    assert startBuffer &gt;= 0 &amp;&amp; startBuffer &lt; bufferCount;<a name="line.284"></a>
-<span class="sourceLineNo">285</span>    assert endBuffer &gt;= 0 &amp;&amp; endBuffer &lt; bufferCount<a name="line.285"></a>
-<span class="sourceLineNo">286</span>        || (endBuffer == bufferCount &amp;&amp; endBufferOffset == 0);<a name="line.286"></a>
-<span class="sourceLineNo">287</span>    if (startBuffer &gt;= buffers.length || startBuffer &lt; 0) {<a name="line.287"></a>
-<span class="sourceLineNo">288</span>      String msg = "Failed subArray, start=" + offset + ",startBuffer=" + startBuffer<a name="line.288"></a>
-<span class="sourceLineNo">289</span>          + ",bufferSize=" + bufferSize;<a name="line.289"></a>
-<span class="sourceLineNo">290</span>      LOG.error(msg);<a name="line.290"></a>
-<span class="sourceLineNo">291</span>      throw new RuntimeException(msg);<a name="line.291"></a>
-<span class="sourceLineNo">292</span>    }<a name="line.292"></a>
-<span class="sourceLineNo">293</span>    int srcIndex = 0, cnt = -1;<a name="line.293"></a>
-<span class="sourceLineNo">294</span>    ByteBuffer[] mbb = new ByteBuffer[endBuffer - startBuffer + 1];<a name="line.294"></a>
-<span class="sourceLineNo">295</span>    for (int i = startBuffer, j = 0; i &lt;= endBuffer; ++i, j++) {<a name="line.295"></a>
-<span class="sourceLineNo">296</span>      ByteBuffer bb = buffers[i].duplicate();<a name="line.296"></a>
-<span class="sourceLineNo">297</span>      if (i == startBuffer) {<a name="line.297"></a>
-<span class="sourceLineNo">298</span>        cnt = bufferSize - startBufferOffset;<a name="line.298"></a>
-<span class="sourceLineNo">299</span>        if (cnt &gt; len) cnt = len;<a name="line.299"></a>
-<span class="sourceLineNo">300</span>        bb.limit(startBufferOffset + cnt).position(startBufferOffset);<a name="line.300"></a>
-<span class="sourceLineNo">301</span>      } else if (i == endBuffer) {<a name="line.301"></a>
-<span class="sourceLineNo">302</span>        cnt = endBufferOffset;<a name="line.302"></a>
-<span class="sourceLineNo">303</span>        bb.position(0).limit(cnt);<a name="line.303"></a>
-<span class="sourceLineNo">304</span>      } else {<a name="line.304"></a>
-<span class="sourceLineNo">305</span>        cnt = bufferSize;<a name="line.305"></a>
-<span class="sourceLineNo">306</span>        bb.position(0).limit(cnt);<a name="line.306"></a>
-<span class="sourceLineNo">307</span>      }<a name="line.307"></a>
-<span class="sourceLineNo">308</span>      mbb[j] = bb.slice();<a name="line.308"></a>
-<span class="sourceLineNo">309</span>      srcIndex += cnt;<a name="line.309"></a>
-<span class="sourceLineNo">310</span>    }<a name="line.310"></a>
-<span class="sourceLineNo">311</span>    assert srcIndex == len;<a name="line.311"></a>
-<span class="sourceLineNo">312</span>    if (mbb.length &gt; 1) {<a name="line.312"></a>
-<span class="sourceLineNo">313</span>      return new MultiByteBuff(mbb);<a name="line.313"></a>
-<span class="sourceLineNo">314</span>    } else {<a name="line.314"></a>
-<span class="sourceLineNo">315</span>      return new SingleByteBuff(mbb[0]);<a name="line.315"></a>
-<span class="sourceLineNo">316</span>    }<a name="line.316"></a>
-<span class="sourceLineNo">317</span>  }<a name="line.317"></a>
-<span class="sourceLineNo">318</span>}<a name="line.318"></a>
+<span class="sourceLineNo">205</span>  private final static Visitor PUT_MULTIPLE_VISITOR = new Visitor() {<a name="line.205"></a>
+<span class="sourceLineNo">206</span>    @Override<a name="line.206"></a>
+<span class="sourceLineNo">207</span>    public void visit(ByteBuffer bb, int pos, byte[] array, int arrayIdx, int len) {<a name="line.207"></a>
+<span class="sourceLineNo">208</span>      ByteBufferUtils.copyFromArrayToBuffer(bb, pos, array, arrayIdx, len);<a name="line.208"></a>
+<span class="sourceLineNo">209</span>    }<a name="line.209"></a>
+<span class="sourceLineNo">210</span>  };<a name="line.210"></a>
+<span class="sourceLineNo">211</span><a name="line.211"></a>
+<span class="sourceLineNo">212</span>  private interface Visitor {<a name="line.212"></a>
+<span class="sourceLineNo">213</span>    /**<a name="line.213"></a>
+<span class="sourceLineNo">214</span>     * Visit the given byte buffer, if it is a read action, we will transfer the<a name="line.214"></a>
+<span class="sourceLineNo">215</span>     * bytes from the buffer to the destination array, else if it is a write<a name="line.215"></a>
+<span class="sourceLineNo">216</span>     * action, we will transfer the bytes from the source array to the buffer<a name="line.216"></a>
+<span class="sourceLineNo">217</span>     * @param bb byte buffer<a name="line.217"></a>
+<span class="sourceLineNo">218</span>     * @param pos Start position in ByteBuffer<a name="line.218"></a>
+<span class="sourceLineNo">219</span>     * @param array a source or destination byte array<a name="line.219"></a>
+<span class="sourceLineNo">220</span>     * @param arrayOffset offset of the byte array<a name="line.220"></a>
+<span class="sourceLineNo">221</span>     * @param len read/write length<a name="line.221"></a>
+<span class="sourceLineNo">222</span>     */<a name="line.222"></a>
+<span class="sourceLineNo">223</span>    void visit(ByteBuffer bb, int pos, byte[] array, int arrayOffset, int len);<a name="line.223"></a>
+<span class="sourceLineNo">224</span>  }<a name="line.224"></a>
+<span class="sourceLineNo">225</span><a name="line.225"></a>
+<span class="sourceLineNo">226</span>  /**<a name="line.226"></a>
+<span class="sourceLineNo">227</span>   * Access(read or write) this buffer array with a position and length as the<a name="line.227"></a>
+<span class="sourceLineNo">228</span>   * given array. Here we will only lock one buffer even if it may be need visit<a name="line.228"></a>
+<span class="sourceLineNo">229</span>   * several buffers. The consistency is guaranteed by the caller.<a name="line.229"></a>
+<span class="sourceLineNo">230</span>   * @param start start offset of this buffer array<a name="line.230"></a>
+<span class="sourceLineNo">231</span>   * @param len The maximum number of bytes to be accessed<a name="line.231"></a>
+<span class="sourceLineNo">232</span>   * @param array The array from/to which bytes are to be read/written<a name="line.232"></a>
+<span class="sourceLineNo">233</span>   * @param arrayOffset The offset within the given array of the first byte to<a name="line.233"></a>
+<span class="sourceLineNo">234</span>   *          be read or written<a name="line.234"></a>
+<span class="sourceLineNo">235</span>   * @param visitor implement of how to visit the byte buffer<a name="line.235"></a>
+<span class="sourceLineNo">236</span>   */<a name="line.236"></a>
+<span class="sourceLineNo">237</span>  void multiple(long start, int len, byte[] array, int arrayOffset, Visitor visitor) {<a name="line.237"></a>
+<span class="sourceLineNo">238</span>    assert len &gt;= 0;<a name="line.238"></a>
+<span class="sourceLineNo">239</span>    long end = start + len;<a name="line.239"></a>
+<span class="sourceLineNo">240</span>    int startBuffer = (int) (start / bufferSize), startOffset = (int) (start % bufferSize);<a name="line.240"></a>
+<span class="sourceLineNo">241</span>    int endBuffer = (int) (end / bufferSize), endOffset = (int) (end % bufferSize);<a name="line.241"></a>
+<span class="sourceLineNo">242</span>    assert array.length &gt;= len + arrayOffset;<a name="line.242"></a>
+<span class="sourceLineNo">243</span>    assert startBuffer &gt;= 0 &amp;&amp; startBuffer &lt; bufferCount;<a name="line.243"></a>
+<span class="sourceLineNo">244</span>    assert endBuffer &gt;= 0 &amp;&amp; endBuffer &lt; bufferCount<a name="line.244"></a>
+<span class="sourceLineNo">245</span>        || (endBuffer == bufferCount &amp;&amp; endOffset == 0);<a name="line.245"></a>
+<span class="sourceLineNo">246</span>    if (startBuffer &gt;= buffers.length || startBuffer &lt; 0) {<a name="line.246"></a>
+<span class="sourceLineNo">247</span>      String msg = "Failed multiple, start=" + start + ",startBuffer="<a name="line.247"></a>
+<span class="sourceLineNo">248</span>          + startBuffer + ",bufferSize=" + bufferSize;<a name="line.248"></a>
+<span class="sourceLineNo">249</span>      LOG.error(msg);<a name="line.249"></a>
+<span class="sourceLineNo">250</span>      throw new RuntimeException(msg);<a name="line.250"></a>
+<span class="sourceLineNo">251</span>    }<a name="line.251"></a>
+<span class="sourceLineNo">252</span>    int srcIndex = 0, cnt = -1;<a name="line.252"></a>
+<span class="sourceLineNo">253</span>    for (int i = startBuffer; i &lt;= endBuffer; ++i) {<a name="line.253"></a>
+<span class="sourceLineNo">254</span>      ByteBuffer bb = buffers[i].duplicate();<a name="line.254"></a>
+<span class="sourceLineNo">255</span>      int pos = 0;<a name="line.255"></a>
+<span class="sourceLineNo">256</span>      if (i == startBuffer) {<a name="line.256"></a>
+<span class="sourceLineNo">257</span>        cnt = bufferSize - startOffset;<a name="line.257"></a>
+<span class="sourceLineNo">258</span>        if (cnt &gt; len) cnt = len;<a name="line.258"></a>
+<span class="sourceLineNo">259</span>        pos = startOffset;<a name="line.259"></a>
+<span class="sourceLineNo">260</span>      } else if (i == endBuffer) {<a name="line.260"></a>
+<span class="sourceLineNo">261</span>        cnt = endOffset;<a name="line.261"></a>
+<span class="sourceLineNo">262</span>      } else {<a name="line.262"></a>
+<span class="sourceLineNo">263</span>        cnt = bufferSize;<a name="line.263"></a>
+<span class="sourceLineNo">264</span>      }<a name="line.264"></a>
+<span class="sourceLineNo">265</span>      visitor.visit(bb, pos, array, srcIndex + arrayOffset, cnt);<a name="line.265"></a>
+<span class="sourceLineNo">266</span>      srcIndex += cnt;<a name="line.266"></a>
+<span class="sourceLineNo">267</span>    }<a name="line.267"></a>
+<span class="sourceLineNo">268</span>    assert srcIndex == len;<a name="line.268"></a>
+<span class="sourceLineNo">269</span>  }<a name="line.269"></a>
+<span class="sourceLineNo">270</span><a name="line.270"></a>
+<span class="sourceLineNo">271</span>  /**<a name="line.271"></a>
+<span class="sourceLineNo">272</span>   * Creates a ByteBuff from a given array of ByteBuffers from the given offset to the<a name="line.272"></a>
+<span class="sourceLineNo">273</span>   * length specified. For eg, if there are 4 buffers forming an array each with length 10 and<a name="line.273"></a>
+<span class="sourceLineNo">274</span>   * if we call asSubBuffer(5, 10) then we will create an MBB consisting of two BBs<a name="line.274"></a>
+<span class="sourceLineNo">275</span>   * and the first one be a BB from 'position' 5 to a 'length' 5 and the 2nd BB will be from<a name="line.275"></a>
+<span class="sourceLineNo">276</span>   * 'position' 0 to 'length' 5.<a name="line.276"></a>
+<span class="sourceLineNo">277</span>   * @param offset<a name="line.277"></a>
+<span class="sourceLineNo">278</span>   * @param len<a name="line.278"></a>
+<span class="sourceLineNo">279</span>   * @return a ByteBuff formed from the underlying ByteBuffers<a name="line.279"></a>
+<span class="sourceLineNo">280</span>   */<a name="line.280"></a>
+<span class="sourceLineNo">281</span>  public ByteBuff asSubByteBuff(long offset, int len) {<a name="line.281"></a>
+<span class="sourceLineNo">282</span>    assert len &gt;= 0;<a name="line.282"></a>
+<span class="sourceLineNo">283</span>    long end = offset + len;<a name="line.283"></a>
+<span class="sourceLineNo">284</span>    int startBuffer = (int) (offset / bufferSize), startBufferOffset = (int) (offset % bufferSize);<a name="line.284"></a>
+<span class="sourceLineNo">285</span>    int endBuffer = (int) (end / bufferSize), endBufferOffset = (int) (end % bufferSize);<a name="line.285"></a>
+<span class="sourceLineNo">286</span>    // Last buffer in the array is a dummy one with 0 capacity. Avoid sending back that<a name="line.286"></a>
+<span class="sourceLineNo">287</span>    if (endBuffer == this.bufferCount) {<a name="line.287"></a>
+<span class="sourceLineNo">288</span>      endBuffer--;<a name="line.288"></a>
+<span class="sourceLineNo">289</span>      endBufferOffset = bufferSize;<a name="line.289"></a>
+<span class="sourceLineNo">290</span>    }<a name="line.290"></a>
+<span class="sourceLineNo">291</span>    assert startBuffer &gt;= 0 &amp;&amp; startBuffer &lt; bufferCount;<a name="line.291"></a>
+<span class="sourceLineNo">292</span>    assert endBuffer &gt;= 0 &amp;&amp; endBuffer &lt; bufferCount<a name="line.292"></a>
+<span class="sourceLineNo">293</span>        || (endBuffer == bufferCount &amp;&amp; endBufferOffset == 0);<a name="line.293"></a>
+<span class="sourceLineNo">294</span>    if (startBuffer &gt;= buffers.length || startBuffer &lt; 0) {<a name="line.294"></a>
+<span class="sourceLineNo">295</span>      String msg = "Failed subArray, start=" + offset + ",startBuffer=" + startBuffer<a name="line.295"></a>
+<span class="sourceLineNo">296</span>          + ",bufferSize=" + bufferSize;<a name="line.296"></a>
+<span class="sourceLineNo">297</span>      LOG.error(msg);<a name="line.297"></a>
+<span class="sourceLineNo">298</span>      throw new RuntimeException(msg);<a name="line.298"></a>
+<span class="sourceLineNo">299</span>    }<a name="line.299"></a>
+<span class="sourceLineNo">300</span>    int srcIndex = 0, cnt = -1;<a name="line.300"></a>
+<span class="sourceLineNo">301</span>    ByteBuffer[] mbb = new ByteBuffer[endBuffer - startBuffer + 1];<a name="line.301"></a>
+<span class="sourceLineNo">302</span>    for (int i = startBuffer, j = 0; i &lt;= endBuffer; ++i, j++) {<a name="line.302"></a>
+<span class="sourceLineNo">303</span>      ByteBuffer bb = buffers[i].duplicate();<a name="line.303"></a>
+<span class="sourceLineNo">304</span>      if (i == startBuffer) {<a name="line.304"></a>
+<span class="sourceLineNo">305</span>        cnt = bufferSize - startBufferOffset;<a name="line.305"></a>
+<span class="sourceLineNo">306</span>        if (cnt &gt; len) cnt = len;<a name="line.306"></a>
+<span class="sourceLineNo">307</span>        bb.limit(startBufferOffset + cnt).position(startBufferOffset);<a name="line.307"></a>
+<span class="sourceLineNo">308</span>      } else if (i == endBuffer) {<a name="line.308"></a>
+<span class="sourceLineNo">309</span>        cnt = endBufferOffset;<a name="line.309"></a>
+<span class="sourceLineNo">310</span>        bb.position(0).limit(cnt);<a name="line.310"></a>
+<span class="sourceLineNo">311</span>      } else {<a name="line.311"></a>
+<span class="sourceLineNo">312</span>        cnt = bufferSize;<a name="line.312"></a>
+<span class="sourceLineNo">313</span>        bb.position(0).limit(cnt);<a name="line.313"></a>
+<span class="sourceLineNo">314</span>      }<a name="line.314"></a>
+<span class="sourceLineNo">315</span>      mbb[j] = bb.slice();<a name="line.315"></a>
+<span class="sourceLineNo">316</span>      srcIndex += cnt;<a name="line.316"></a>
+<span class="sourceLineNo">317</span>    }<a name="line.317"></a>
+<span class="sourceLineNo">318</span>    assert srcIndex == len;<a name="line.318"></a>
+<span class="sourceLineNo">319</span>    if (mbb.length &gt; 1) {<a name="line.319"></a>
+<span class="sourceLineNo">320</span>      return new MultiByteBuff(mbb);<a name="line.320"></a>
+<span class="sourceLineNo">321</span>    } else {<a name="line.321"></a>
+<span class="sourceLineNo">322</span>      return new SingleByteBuff(mbb[0]);<a name="line.322"></a>
+<span class="sourceLineNo">323</span>    }<a name="line.323"></a>
+<span class="sourceLineNo">324</span>  }<a name="line.324"></a>
+<span class="sourceLineNo">325</span>}<a name="line.325"></a>
 
 
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/export_control.html
----------------------------------------------------------------------
diff --git a/export_control.html b/export_control.html
index 1c40eee..46d84d9 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="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; 
       Export Control
@@ -336,7 +336,7 @@ for more details.</p>
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-07-19</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-07-20</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/checkstyle.html b/hbase-annotations/checkstyle.html
index 29e4578..1098aa9 100644
--- a/hbase-annotations/checkstyle.html
+++ b/hbase-annotations/checkstyle.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependencies.html b/hbase-annotations/dependencies.html
index e8d549c..d1f0f16 100644
--- a/hbase-annotations/dependencies.html
+++ b/hbase-annotations/dependencies.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-convergence.html b/hbase-annotations/dependency-convergence.html
index c99c2a1..f240f42 100644
--- a/hbase-annotations/dependency-convergence.html
+++ b/hbase-annotations/dependency-convergence.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-info.html b/hbase-annotations/dependency-info.html
index 8bb7790..732c030 100644
--- a/hbase-annotations/dependency-info.html
+++ b/hbase-annotations/dependency-info.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-management.html b/hbase-annotations/dependency-management.html
index 73f18d1..3daefb0 100644
--- a/hbase-annotations/dependency-management.html
+++ b/hbase-annotations/dependency-management.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/index.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/index.html b/hbase-annotations/index.html
index e983385..2ad5924 100644
--- a/hbase-annotations/index.html
+++ b/hbase-annotations/index.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/integration.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/integration.html b/hbase-annotations/integration.html
index 84d471f..02069f7 100644
--- a/hbase-annotations/integration.html
+++ b/hbase-annotations/integration.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/issue-tracking.html b/hbase-annotations/issue-tracking.html
index f87a619..666d6ec 100644
--- a/hbase-annotations/issue-tracking.html
+++ b/hbase-annotations/issue-tracking.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/license.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/license.html b/hbase-annotations/license.html
index 05451e8..c0f30c0 100644
--- a/hbase-annotations/license.html
+++ b/hbase-annotations/license.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/mail-lists.html b/hbase-annotations/mail-lists.html
index 97b1f43..f3438b7 100644
--- a/hbase-annotations/mail-lists.html
+++ b/hbase-annotations/mail-lists.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugin-management.html b/hbase-annotations/plugin-management.html
index 6f26ede..925f956 100644
--- a/hbase-annotations/plugin-management.html
+++ b/hbase-annotations/plugin-management.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugins.html b/hbase-annotations/plugins.html
index 28e9b54..631a2c4 100644
--- a/hbase-annotations/plugins.html
+++ b/hbase-annotations/plugins.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-info.html b/hbase-annotations/project-info.html
index f5f598d..b1032ef 100644
--- a/hbase-annotations/project-info.html
+++ b/hbase-annotations/project-info.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/project-reports.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-reports.html b/hbase-annotations/project-reports.html
index c0b28e2..82ea101 100644
--- a/hbase-annotations/project-reports.html
+++ b/hbase-annotations/project-reports.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-summary.html b/hbase-annotations/project-summary.html
index 4bf6d5e..3dfdcc3 100644
--- a/hbase-annotations/project-summary.html
+++ b/hbase-annotations/project-summary.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/source-repository.html b/hbase-annotations/source-repository.html
index a8d3310..5d337e3 100644
--- a/hbase-annotations/source-repository.html
+++ b/hbase-annotations/source-repository.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-annotations/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/team-list.html b/hbase-annotations/team-list.html
index 5bab3d7..2e7e1ce 100644
--- a/hbase-annotations/team-list.html
+++ b/hbase-annotations/team-list.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Annotations">Apache HBase - Annotations</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-archetypes/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-archetypes/dependencies.html b/hbase-archetypes/dependencies.html
index fa17f24..604c9bf 100644
--- a/hbase-archetypes/dependencies.html
+++ b/hbase-archetypes/dependencies.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Archetypes">Apache HBase - Archetypes</a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9e6e3360/hbase-archetypes/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-archetypes/dependency-convergence.html b/hbase-archetypes/dependency-convergence.html
index 1deb068..a0935f6 100644
--- a/hbase-archetypes/dependency-convergence.html
+++ b/hbase-archetypes/dependency-convergence.html
@@ -1,5 +1,5 @@
 <!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-19 -->
+<!-- Generated by Apache Maven Doxia Site Renderer 1.6 at 2017-07-20 -->
 <html xmlns="http://www.w3.org/1999/xhtml" xml:lang="en" lang="en">
   <head>
     <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
@@ -10,7 +10,7 @@
       @import url("./css/site.css");
     </style>
     <link rel="stylesheet" href="./css/print.css" type="text/css" media="print" />
-    <meta name="Date-Revision-yyyymmdd" content="20170719" />
+    <meta name="Date-Revision-yyyymmdd" content="20170720" />
     <meta http-equiv="Content-Language" content="en" />
         
         </head>
@@ -27,7 +27,7 @@
             
                     
                 <div class="xleft">
-        <span id="publishDate">Last Published: 2017-07-19</span>
+        <span id="publishDate">Last Published: 2017-07-20</span>
                   &nbsp;| <span id="projectVersion">Version: 3.0.0-SNAPSHOT</span>
                       </div>
             <div class="xright">                    <a href="./" title="Apache HBase - Archetypes">Apache HBase - Archetypes</a>