View Javadoc

1   /*
2    * Licensed to the Apache Software Foundation (ASF) under one
3    * or more contributor license agreements.  See the NOTICE file
4    * distributed with this work for additional information
5    * regarding copyright ownership.  The ASF licenses this file
6    * to you under the Apache License, Version 2.0 (the
7    * "License"); you may not use this file except in compliance
8    * with the License.  You may obtain a copy of the License at
9    *
10   * http://www.apache.org/licenses/LICENSE-2.0
11   *
12   * Unless required by applicable law or agreed to in writing, software
13   * distributed under the License is distributed on an "AS IS" BASIS,
14   * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
15   * See the License for the specific language governing permissions and
16   * limitations under the License.
17   */
18  package org.apache.hadoop.hbase.ipc;
19  
20  import java.io.DataInput;
21  import java.io.IOException;
22  import java.io.InputStream;
23  import java.io.OutputStream;
24  import java.nio.BufferOverflowException;
25  import java.nio.ByteBuffer;
26  
27  import org.apache.commons.io.IOUtils;
28  import org.apache.commons.logging.Log;
29  import org.apache.commons.logging.LogFactory;
30  import org.apache.hadoop.hbase.classification.InterfaceAudience;
31  import org.apache.hadoop.conf.Configurable;
32  import org.apache.hadoop.conf.Configuration;
33  import org.apache.hadoop.hbase.CellScanner;
34  import org.apache.hadoop.hbase.DoNotRetryIOException;
35  import org.apache.hadoop.hbase.HBaseIOException;
36  import org.apache.hadoop.hbase.codec.Codec;
37  import org.apache.hadoop.hbase.io.BoundedByteBufferPool;
38  import org.apache.hadoop.hbase.io.ByteBufferInputStream;
39  import org.apache.hadoop.hbase.io.ByteBufferOutputStream;
40  import org.apache.hadoop.hbase.io.HeapSize;
41  import org.apache.hadoop.hbase.util.Bytes;
42  import org.apache.hadoop.hbase.util.ClassSize;
43  import org.apache.hadoop.io.compress.CodecPool;
44  import org.apache.hadoop.io.compress.CompressionCodec;
45  import org.apache.hadoop.io.compress.CompressionInputStream;
46  import org.apache.hadoop.io.compress.Compressor;
47  import org.apache.hadoop.io.compress.Decompressor;
48  
49  import com.google.common.base.Preconditions;
50  import com.google.protobuf.CodedOutputStream;
51  import com.google.protobuf.Message;
52  
53  /**
54   * Utility to help ipc'ing.
55   */
56  @InterfaceAudience.Private
57  public class IPCUtil {
58    public static final Log LOG = LogFactory.getLog(IPCUtil.class);
59    /**
60     * How much we think the decompressor will expand the original compressed content.
61     */
62    private final int cellBlockDecompressionMultiplier;
63    private final int cellBlockBuildingInitialBufferSize;
64    private final Configuration conf;
65  
66    public IPCUtil(final Configuration conf) {
67      super();
68      this.conf = conf;
69      this.cellBlockDecompressionMultiplier =
70          conf.getInt("hbase.ipc.cellblock.decompression.buffersize.multiplier", 3);
71  
72      // Guess that 16k is a good size for rpc buffer.  Could go bigger.  See the TODO below in
73      // #buildCellBlock.
74      this.cellBlockBuildingInitialBufferSize =
75        ClassSize.align(conf.getInt("hbase.ipc.cellblock.building.initial.buffersize", 16 * 1024));
76    }
77  
78    /**
79     * Thrown if a cellscanner but no codec to encode it with.
80     */
81    public static class CellScannerButNoCodecException extends HBaseIOException {};
82  
83    /**
84     * Puts CellScanner Cells into a cell block using passed in <code>codec</code> and/or
85     * <code>compressor</code>.
86     * @param codec
87     * @param compressor
88     * @param cellScanner
89     * @return Null or byte buffer filled with a cellblock filled with passed-in Cells encoded using
90     * passed in <code>codec</code> and/or <code>compressor</code>; the returned buffer has been
91     * flipped and is ready for reading.  Use limit to find total size.
92     * @throws IOException
93     */
94    @SuppressWarnings("resource")
95    public ByteBuffer buildCellBlock(final Codec codec, final CompressionCodec compressor,
96      final CellScanner cellScanner)
97    throws IOException {
98      return buildCellBlock(codec, compressor, cellScanner, null);
99    }
100 
101   /**
102    * Puts CellScanner Cells into a cell block using passed in <code>codec</code> and/or
103    * <code>compressor</code>.
104    * @param codec
105    * @param compressor
106    * @param cellScanner
107    * @param pool Pool of ByteBuffers to make use of. Can be null and then we'll allocate
108    * our own ByteBuffer.
109    * @return Null or byte buffer filled with a cellblock filled with passed-in Cells encoded using
110    * passed in <code>codec</code> and/or <code>compressor</code>; the returned buffer has been
111    * flipped and is ready for reading.  Use limit to find total size. If <code>pool</code> was not
112    * null, then this returned ByteBuffer came from there and should be returned to the pool when
113    * done.
114    * @throws IOException
115    */
116   @SuppressWarnings("resource")
117   public ByteBuffer buildCellBlock(final Codec codec, final CompressionCodec compressor,
118     final CellScanner cellScanner, final BoundedByteBufferPool pool)
119   throws IOException {
120     if (cellScanner == null) return null;
121     if (codec == null) throw new CellScannerButNoCodecException();
122     int bufferSize = this.cellBlockBuildingInitialBufferSize;
123     ByteBufferOutputStream baos = null;
124     if (pool != null) {
125       ByteBuffer bb = pool.getBuffer();
126       bufferSize = bb.capacity();
127       baos = new ByteBufferOutputStream(bb);
128     } else {
129       // Then we need to make our own to return.
130       if (cellScanner instanceof HeapSize) {
131         long longSize = ((HeapSize)cellScanner).heapSize();
132         // Just make sure we don't have a size bigger than an int.
133         if (longSize > Integer.MAX_VALUE) {
134           throw new IOException("Size " + longSize + " > " + Integer.MAX_VALUE);
135         }
136         bufferSize = ClassSize.align((int)longSize);
137       }
138       baos = new ByteBufferOutputStream(bufferSize);
139     }
140     OutputStream os = baos;
141     Compressor poolCompressor = null;
142     try {
143       if (compressor != null) {
144         if (compressor instanceof Configurable) ((Configurable)compressor).setConf(this.conf);
145         poolCompressor = CodecPool.getCompressor(compressor);
146         os = compressor.createOutputStream(os, poolCompressor);
147       }
148       Codec.Encoder encoder = codec.getEncoder(os);
149       int count = 0;
150       while (cellScanner.advance()) {
151         encoder.write(cellScanner.current());
152         count++;
153       }
154       encoder.flush();
155       // If no cells, don't mess around.  Just return null (could be a bunch of existence checking
156       // gets or something -- stuff that does not return a cell).
157       if (count == 0) return null;
158     } catch (BufferOverflowException e) {
159       throw new DoNotRetryIOException(e);
160     } finally {
161       os.close();
162       if (poolCompressor != null) CodecPool.returnCompressor(poolCompressor);
163     }
164     if (LOG.isTraceEnabled()) {
165       if (bufferSize < baos.size()) {
166         LOG.trace("Buffer grew from initial bufferSize=" + bufferSize + " to " + baos.size() +
167           "; up hbase.ipc.cellblock.building.initial.buffersize?");
168       }
169     }
170     return baos.getByteBuffer();
171   }
172 
173   /**
174    * @param codec
175    * @param cellBlock
176    * @return CellScanner to work against the content of <code>cellBlock</code>
177    * @throws IOException
178    */
179   public CellScanner createCellScanner(final Codec codec, final CompressionCodec compressor,
180       final byte [] cellBlock)
181   throws IOException {
182     return createCellScanner(codec, compressor, ByteBuffer.wrap(cellBlock));
183   }
184 
185   /**
186    * @param codec
187    * @param cellBlock ByteBuffer containing the cells written by the Codec. The buffer should be
188    * position()'ed at the start of the cell block and limit()'ed at the end.
189    * @return CellScanner to work against the content of <code>cellBlock</code>
190    * @throws IOException
191    */
192   public CellScanner createCellScanner(final Codec codec, final CompressionCodec compressor,
193       final ByteBuffer cellBlock)
194   throws IOException {
195     // If compressed, decompress it first before passing it on else we will leak compression
196     // resources if the stream is not closed properly after we let it out.
197     InputStream is = null;
198     if (compressor != null) {
199       // GZIPCodec fails w/ NPE if no configuration.
200       if (compressor instanceof Configurable) ((Configurable)compressor).setConf(this.conf);
201       Decompressor poolDecompressor = CodecPool.getDecompressor(compressor);
202       CompressionInputStream cis =
203         compressor.createInputStream(new ByteBufferInputStream(cellBlock), poolDecompressor);
204       ByteBufferOutputStream bbos = null;
205       try {
206         // TODO: This is ugly.  The buffer will be resized on us if we guess wrong.
207         // TODO: Reuse buffers.
208         bbos = new ByteBufferOutputStream(cellBlock.remaining() *
209           this.cellBlockDecompressionMultiplier);
210         IOUtils.copy(cis, bbos);
211         bbos.close();
212         ByteBuffer bb = bbos.getByteBuffer();
213         is = new ByteBufferInputStream(bb);
214       } finally {
215         if (is != null) is.close();
216         if (bbos != null) bbos.close();
217 
218         CodecPool.returnDecompressor(poolDecompressor);
219       }
220     } else {
221       is = new ByteBufferInputStream(cellBlock);
222     }
223     return codec.getDecoder(is);
224   }
225 
226   /**
227    * @param m Message to serialize delimited; i.e. w/ a vint of its size preceeding its
228    * serialization.
229    * @return The passed in Message serialized with delimiter.  Return null if <code>m</code> is null
230    * @throws IOException
231    */
232   public static ByteBuffer getDelimitedMessageAsByteBuffer(final Message m) throws IOException {
233     if (m == null) return null;
234     int serializedSize = m.getSerializedSize();
235     int vintSize = CodedOutputStream.computeRawVarint32Size(serializedSize);
236     byte [] buffer = new byte[serializedSize + vintSize];
237     // Passing in a byte array saves COS creating a buffer which it does when using streams.
238     CodedOutputStream cos = CodedOutputStream.newInstance(buffer);
239     // This will write out the vint preamble and the message serialized.
240     cos.writeMessageNoTag(m);
241     cos.flush();
242     cos.checkNoSpaceLeft();
243     return ByteBuffer.wrap(buffer);
244   }
245 
246   /**
247    * Write out header, param, and cell block if there is one.
248    * @param dos
249    * @param header
250    * @param param
251    * @param cellBlock
252    * @return Total number of bytes written.
253    * @throws IOException
254    */
255   public static int write(final OutputStream dos, final Message header, final Message param,
256       final ByteBuffer cellBlock)
257   throws IOException {
258     // Must calculate total size and write that first so other side can read it all in in one
259     // swoop.  This is dictated by how the server is currently written.  Server needs to change
260     // if we are to be able to write without the length prefixing.
261     int totalSize = IPCUtil.getTotalSizeWhenWrittenDelimited(header, param);
262     if (cellBlock != null) totalSize += cellBlock.remaining();
263     return write(dos, header, param, cellBlock, totalSize);
264   }
265 
266   private static int write(final OutputStream dos, final Message header, final Message param,
267     final ByteBuffer cellBlock, final int totalSize)
268   throws IOException {
269     // I confirmed toBytes does same as DataOutputStream#writeInt.
270     dos.write(Bytes.toBytes(totalSize));
271     // This allocates a buffer that is the size of the message internally.
272     header.writeDelimitedTo(dos);
273     if (param != null) param.writeDelimitedTo(dos);
274     if (cellBlock != null) dos.write(cellBlock.array(), 0, cellBlock.remaining());
275     dos.flush();
276     return totalSize;
277   }
278 
279   /**
280    * Read in chunks of 8K (HBASE-7239)
281    * @param in
282    * @param dest
283    * @param offset
284    * @param len
285    * @throws IOException
286    */
287   public static void readChunked(final DataInput in, byte[] dest, int offset, int len)
288       throws IOException {
289     int maxRead = 8192;
290 
291     for (; offset < len; offset += maxRead) {
292       in.readFully(dest, offset, Math.min(len - offset, maxRead));
293     }
294   }
295 
296   /**
297    * @return Size on the wire when the two messages are written with writeDelimitedTo
298    */
299   public static int getTotalSizeWhenWrittenDelimited(Message ... messages) {
300     int totalSize = 0;
301     for (Message m: messages) {
302       if (m == null) continue;
303       totalSize += m.getSerializedSize();
304       totalSize += CodedOutputStream.computeRawVarint32Size(m.getSerializedSize());
305     }
306     Preconditions.checkArgument(totalSize < Integer.MAX_VALUE);
307     return totalSize;
308   }
309 }