You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by da...@apache.org on 2016/06/20 22:16:27 UTC

[34/50] [abbrv] incubator-beam git commit: Added BigDecimal coder and tests.

Added BigDecimal coder and tests.


Project: http://git-wip-us.apache.org/repos/asf/incubator-beam/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-beam/commit/6460df19
Tree: http://git-wip-us.apache.org/repos/asf/incubator-beam/tree/6460df19
Diff: http://git-wip-us.apache.org/repos/asf/incubator-beam/diff/6460df19

Branch: refs/heads/python-sdk
Commit: 6460df195240dac4d488fcf111642e8706008690
Parents: 4f7a2ab
Author: Jesse Anderson <je...@smokinghand.com>
Authored: Mon May 9 10:05:15 2016 -0700
Committer: Davor Bonaci <da...@google.com>
Committed: Mon Jun 20 15:14:30 2016 -0700

----------------------------------------------------------------------
 .../apache/beam/sdk/coders/BigDecimalCoder.java | 112 +++++++++++++++++++
 .../beam/sdk/coders/BigDecimalCoderTest.java    | 105 +++++++++++++++++
 2 files changed, 217 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/6460df19/sdks/java/core/src/main/java/org/apache/beam/sdk/coders/BigDecimalCoder.java
----------------------------------------------------------------------
diff --git a/sdks/java/core/src/main/java/org/apache/beam/sdk/coders/BigDecimalCoder.java b/sdks/java/core/src/main/java/org/apache/beam/sdk/coders/BigDecimalCoder.java
new file mode 100644
index 0000000..3b723b9
--- /dev/null
+++ b/sdks/java/core/src/main/java/org/apache/beam/sdk/coders/BigDecimalCoder.java
@@ -0,0 +1,112 @@
+/*
+ * 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.beam.sdk.coders;
+
+import com.fasterxml.jackson.annotation.JsonCreator;
+
+import java.io.DataInputStream;
+import java.io.DataOutputStream;
+import java.io.IOException;
+import java.io.InputStream;
+import java.io.OutputStream;
+import java.math.BigDecimal;
+import java.math.BigInteger;
+
+/**
+ * A {@link BigDecimalCoder} encodes {@link BigDecimal} in an integer and
+ * a byte array. The integer represents the scale and the byte array
+ * represents a {@link BigInteger}. The integer is in 4 bytes, big-endian.
+ */
+public class BigDecimalCoder extends AtomicCoder<BigDecimal> {
+
+  @JsonCreator
+  public static BigDecimalCoder of() {
+    return INSTANCE;
+  }
+
+  /////////////////////////////////////////////////////////////////////////////
+
+  private static final BigDecimalCoder INSTANCE = new BigDecimalCoder();
+
+  private BigDecimalCoder() {}
+
+  @Override
+  public void encode(BigDecimal value, OutputStream outStream, Context context)
+      throws IOException, CoderException {
+    if (value == null) {
+      throw new CoderException("cannot encode a null BigDecimal");
+    }
+
+    byte[] bigIntBytes = value.unscaledValue().toByteArray();
+
+    DataOutputStream dataOutputStream = new DataOutputStream(outStream);
+    dataOutputStream.writeInt(value.scale());
+    dataOutputStream.writeInt(bigIntBytes.length);
+    dataOutputStream.write(bigIntBytes);
+  }
+
+  @Override
+  public BigDecimal decode(InputStream inStream, Context context)
+      throws IOException, CoderException {
+    DataInputStream dataInputStream = new DataInputStream(inStream);
+    int scale = dataInputStream.readInt();
+    int bigIntBytesSize = dataInputStream.readInt();
+
+    byte[] bigIntBytes = new byte[bigIntBytesSize];
+    dataInputStream.readFully(bigIntBytes);
+
+    BigInteger bigInteger = new BigInteger(bigIntBytes);
+    BigDecimal bigDecimal = new BigDecimal(bigInteger, scale);
+
+    return bigDecimal;
+  }
+
+  /**
+   * {@inheritDoc}
+   *
+   * @return {@code true}. This coder is injective.
+   */
+  @Override
+  public boolean consistentWithEquals() {
+    return true;
+  }
+
+  /**
+   * {@inheritDoc}
+   *
+   * @return {@code true}, because {@link #getEncodedElementByteSize} runs in constant time.
+   */
+  @Override
+  public boolean isRegisterByteSizeObserverCheap(BigDecimal value, Context context) {
+    return true;
+  }
+
+  /**
+   * {@inheritDoc}
+   *
+   * @return {@code 8} plus the size of the {@link BigInteger} bytes.
+   */
+  @Override
+  protected long getEncodedElementByteSize(BigDecimal value, Context context)
+      throws Exception {
+    if (value == null) {
+      throw new CoderException("cannot encode a null BigDecimal");
+    }
+    return 8 + value.unscaledValue().toByteArray().length;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/6460df19/sdks/java/core/src/test/java/org/apache/beam/sdk/coders/BigDecimalCoderTest.java
----------------------------------------------------------------------
diff --git a/sdks/java/core/src/test/java/org/apache/beam/sdk/coders/BigDecimalCoderTest.java b/sdks/java/core/src/test/java/org/apache/beam/sdk/coders/BigDecimalCoderTest.java
new file mode 100644
index 0000000..5911535
--- /dev/null
+++ b/sdks/java/core/src/test/java/org/apache/beam/sdk/coders/BigDecimalCoderTest.java
@@ -0,0 +1,105 @@
+/*
+ * 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.beam.sdk.coders;
+
+import org.apache.beam.sdk.testing.CoderProperties;
+import org.apache.beam.sdk.util.CoderUtils;
+
+import org.junit.Rule;
+import org.junit.Test;
+import org.junit.rules.ExpectedException;
+import org.junit.runner.RunWith;
+import org.junit.runners.JUnit4;
+
+import java.math.BigDecimal;
+import java.util.Arrays;
+import java.util.List;
+
+/**
+ * Test case for {@link BigDecimalCoder}.
+ */
+@RunWith(JUnit4.class)
+public class BigDecimalCoderTest {
+
+  private static final Coder<BigDecimal> TEST_CODER = BigDecimalCoder.of();
+
+  private static final List<BigDecimal> TEST_VALUES = Arrays.asList(
+      new BigDecimal(Double.MIN_VALUE),
+      new BigDecimal(-11),
+      new BigDecimal(-3),
+      new BigDecimal(-1),
+      new BigDecimal(0),
+      new BigDecimal(1),
+      new BigDecimal(5),
+      new BigDecimal(13),
+      new BigDecimal(29),
+      new BigDecimal(Double.MAX_VALUE));
+
+  @Test
+  public void testDecodeEncodeEqual() throws Exception {
+    for (BigDecimal value : TEST_VALUES) {
+      CoderProperties.coderDecodeEncodeEqual(TEST_CODER, value);
+    }
+  }
+
+  // This should never change. The definition of big endian encoding is fixed.
+  private static final String EXPECTED_ENCODING_ID = "";
+
+  @Test
+  public void testEncodingId() throws Exception {
+    CoderProperties.coderHasEncodingId(TEST_CODER, EXPECTED_ENCODING_ID);
+  }
+
+  /**
+   * Generated data to check that the wire format has not changed. To regenerate, see
+   * {@link org.apache.beam.sdk.coders.PrintBase64Encodings}.
+   */
+  private static final List<String> TEST_ENCODINGS = Arrays.asList(
+      "AAAEMgAAATg12KOw51bHBNnjNkPn-wPiaWQ_AsohTe-mXyOGWcybUGt9TKi2FHqY2OH-gV0_GWqRbjNAGsSskI7K3" +
+          "xf9JmTjf1ySZXuvF9S9PsgV3kT-sgypaRw_i1MK_orzcJVg_s3cEGTjTY1_Xor3JM9UBVKiQy3Vpulf7aN9LM" +
+          "kiQEfO28mXQibyUtXL4yoLIwujoo8ArC9SayfbH5HmUxX9G0e506_cefoYIGByfq3M8GLp1_METj97ViU38je" +
+          "xsXkggqxXrMG8PO6pCYNB8P_jcf9i5OagpPafem18giZ8-v3fWJPN63vkbuOtaHb9u9yGQfrN25aLpNW9ooU9" +
+          "eYbL-1ewSBwENptcIT5SMhkulcVY6e9LyAqamGWdvnbevpwW84rTQpkeJePOkIt6G1_slfkQn6VBw7Jz3Vk",
+      "AAAAAAAAAAH1",
+      "AAAAAAAAAAH9",
+      "AAAAAAAAAAH_",
+      "AAAAAAAAAAEA",
+      "AAAAAAAAAAEB",
+      "AAAAAAAAAAEF",
+      "AAAAAAAAAAEN",
+      "AAAAAAAAAAEd",
+      "AAAAAAAAAIEA________-AAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAA" +
+          "AAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAA" +
+          "AAAAAAAAA");
+
+  @Test
+  public void testWireFormatEncode() throws Exception {
+    CoderProperties.coderEncodesBase64(TEST_CODER, TEST_VALUES, TEST_ENCODINGS);
+  }
+
+  @Rule
+  public ExpectedException thrown = ExpectedException.none();
+
+  @Test
+  public void encodeNullThrowsCoderException() throws Exception {
+    thrown.expect(CoderException.class);
+    thrown.expectMessage("cannot encode a null BigDecimal");
+
+    CoderUtils.encodeToBase64(TEST_CODER, null);
+  }
+}