You are viewing a plain text version of this content. The canonical link for it is here.
Posted to common-commits@hadoop.apache.org by cn...@apache.org on 2013/07/26 23:51:20 UTC

svn commit: r1507484 - /hadoop/common/branches/branch-1-win/src/test/org/apache/hadoop/io/compress/TestBlockDecompressorStream.java

Author: cnauroth
Date: Fri Jul 26 21:51:20 2013
New Revision: 1507484

URL: http://svn.apache.org/r1507484
Log:
HADOOP-9665. Commit TestBlockDecompressorStream, new file missed in prior commit.

Added:
    hadoop/common/branches/branch-1-win/src/test/org/apache/hadoop/io/compress/TestBlockDecompressorStream.java

Added: hadoop/common/branches/branch-1-win/src/test/org/apache/hadoop/io/compress/TestBlockDecompressorStream.java
URL: http://svn.apache.org/viewvc/hadoop/common/branches/branch-1-win/src/test/org/apache/hadoop/io/compress/TestBlockDecompressorStream.java?rev=1507484&view=auto
==============================================================================
--- hadoop/common/branches/branch-1-win/src/test/org/apache/hadoop/io/compress/TestBlockDecompressorStream.java (added)
+++ hadoop/common/branches/branch-1-win/src/test/org/apache/hadoop/io/compress/TestBlockDecompressorStream.java Fri Jul 26 21:51:20 2013
@@ -0,0 +1,253 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.hadoop.io.compress;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.fail;
+
+import java.io.ByteArrayInputStream;
+import java.io.ByteArrayOutputStream;
+import java.io.IOException;
+import java.nio.ByteBuffer;
+
+import org.apache.hadoop.conf.Configuration;
+import org.junit.Test;
+
+public class TestBlockDecompressorStream {
+  
+  private byte[] buf;
+  private ByteArrayInputStream bytesIn;
+  private ByteArrayOutputStream bytesOut;
+
+  @Test
+  public void testRead1() throws IOException {
+    testRead(0);
+  }
+
+  @Test
+  public void testRead2() throws IOException {
+    // Test eof after getting non-zero block size info
+    testRead(4);
+  }
+
+  private void testRead(int bufLen) throws IOException {
+    // compress empty stream
+    bytesOut = new ByteArrayOutputStream();
+    if (bufLen > 0) {
+      bytesOut.write(ByteBuffer.allocate(bufLen).putInt(1024).array(), 0,
+          bufLen);
+    }
+    BlockCompressorStream blockCompressorStream = 
+      new BlockCompressorStream(bytesOut, 
+          new FakeCompressor(), 1024, 0);
+    // close without any write
+    blockCompressorStream.close();
+    
+    // check compressed output 
+    buf = bytesOut.toByteArray();
+    assertEquals("empty file compressed output size is not " + (bufLen + 4),
+        bufLen + 4, buf.length);
+    
+    // use compressed output as input for decompression
+    bytesIn = new ByteArrayInputStream(buf);
+    
+    // get decompression stream
+    BlockDecompressorStream blockDecompressorStream = 
+      new BlockDecompressorStream(bytesIn, new FakeDecompressor(), 1024);
+    try {
+      assertEquals("return value is not -1", 
+          -1 , blockDecompressorStream.read());
+    } catch (IOException e) {
+      fail("unexpected IOException : " + e);
+    } finally {
+      blockDecompressorStream.close();
+    }
+  }
+}
+
+/**
+ * A fake compressor
+ * Its input and output is the same.
+ */
+class FakeCompressor implements Compressor{
+
+  private boolean finish;
+  private boolean finished;
+  int nread;
+  int nwrite;
+  
+  byte [] userBuf;
+  int userBufOff;
+  int userBufLen;
+  
+  @Override
+  public int compress(byte[] b, int off, int len) throws IOException {
+    int n = Math.min(len, userBufLen);
+    if (userBuf != null && b != null)
+      System.arraycopy(userBuf, userBufOff, b, off, n);
+    userBufOff += n;
+    userBufLen -= n;
+    nwrite += n;
+    
+    if (finish && userBufLen <= 0)
+      finished = true;   
+        
+    return n;
+  }
+
+  @Override
+  public void end() {
+    // nop
+  }
+
+  @Override
+  public void finish() {
+    finish = true;
+  }
+
+  @Override
+  public boolean finished() {
+    return finished;
+  }
+
+  @Override
+  public long getBytesRead() {
+    return nread;
+  }
+
+  @Override
+  public long getBytesWritten() {
+    return nwrite;
+  }
+
+  @Override
+  public boolean needsInput() {
+    return userBufLen <= 0;
+  }
+
+  @Override
+  public void reset() {
+    finish = false;
+    finished = false;
+    nread = 0;
+    nwrite = 0;
+    userBuf = null;
+    userBufOff = 0;
+    userBufLen = 0;
+  }
+
+  @Override
+  public void setDictionary(byte[] b, int off, int len) {
+    // nop
+  }
+
+  @Override
+  public void setInput(byte[] b, int off, int len) {
+    nread += len;
+    userBuf = b;
+    userBufOff = off;
+    userBufLen = len;
+  }
+
+  @Override
+  public void reinit(Configuration conf) {
+    // nop
+  }
+  
+}
+
+/**
+ * A fake decompressor, just like FakeCompressor
+ * Its input and output is the same.
+ */
+class FakeDecompressor implements Decompressor {
+  
+  private boolean finish;
+  private boolean finished;
+  int nread;
+  int nwrite;
+  
+  byte [] userBuf;
+  int userBufOff;
+  int userBufLen;
+
+  @Override
+  public int decompress(byte[] b, int off, int len) throws IOException {
+    int n = Math.min(len, userBufLen);
+    if (userBuf != null && b != null)
+      System.arraycopy(userBuf, userBufOff, b, off, n);
+    userBufOff += n;
+    userBufLen -= n;
+    nwrite += n;
+    
+    if (finish && userBufLen <= 0)
+      finished = true;
+    
+    return n;
+  }
+
+  @Override
+  public void end() {
+    // nop
+  }
+
+  @Override
+  public boolean finished() {
+    return finished;
+  }
+
+  @Override
+  public boolean needsDictionary() {
+    return false;
+  }
+
+  @Override
+  public boolean needsInput() {
+    return userBufLen <= 0;
+  }
+
+  @Override
+  public void reset() {
+    finish = false;
+    finished = false;
+    nread = 0;
+    nwrite = 0;
+    userBuf = null;
+    userBufOff = 0;
+    userBufLen = 0;
+  }
+
+  @Override
+  public void setDictionary(byte[] b, int off, int len) {
+    // nop
+  }
+
+  @Override
+  public void setInput(byte[] b, int off, int len) {
+    nread += len;
+    userBuf = b;
+    userBufOff = off;
+    userBufLen = len;
+  }
+
+  @Override
+  public int getRemaining() {
+    return 0;
+  }
+  
+}
\ No newline at end of file