You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by tg...@apache.org on 2017/04/26 16:50:36 UTC

[1/2] beam git commit: This closes #2693

Repository: beam
Updated Branches:
  refs/heads/master 9023df893 -> f3cff3695


This closes #2693


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

Branch: refs/heads/master
Commit: f3cff3695ff86220a0277d2132b8ae0b87e284fe
Parents: 9023df8 451e074
Author: Thomas Groh <tg...@google.com>
Authored: Wed Apr 26 09:50:30 2017 -0700
Committer: Thomas Groh <tg...@google.com>
Committed: Wed Apr 26 09:50:30 2017 -0700

----------------------------------------------------------------------
 .../org/apache/beam/sdk/coders/AtomicCoder.java | 55 --------------------
 1 file changed, 55 deletions(-)
----------------------------------------------------------------------



[2/2] beam git commit: Remove AtomicCoder

Posted by tg...@apache.org.
Remove AtomicCoder


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

Branch: refs/heads/master
Commit: 451e074983fc17c576f83e30652997171a1fad93
Parents: 9023df8
Author: Thomas Groh <tg...@google.com>
Authored: Thu Apr 20 10:57:56 2017 -0700
Committer: Thomas Groh <tg...@google.com>
Committed: Wed Apr 26 09:50:30 2017 -0700

----------------------------------------------------------------------
 .../org/apache/beam/sdk/coders/AtomicCoder.java | 55 --------------------
 1 file changed, 55 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/beam/blob/451e0749/sdks/java/core/src/main/java/org/apache/beam/sdk/coders/AtomicCoder.java
----------------------------------------------------------------------
diff --git a/sdks/java/core/src/main/java/org/apache/beam/sdk/coders/AtomicCoder.java b/sdks/java/core/src/main/java/org/apache/beam/sdk/coders/AtomicCoder.java
deleted file mode 100644
index 816af87..0000000
--- a/sdks/java/core/src/main/java/org/apache/beam/sdk/coders/AtomicCoder.java
+++ /dev/null
@@ -1,55 +0,0 @@
-/*
- * 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 java.util.Collections;
-import java.util.List;
-
-/**
- * A {@link Coder} that has no component {@link Coder Coders} or other state.
- *
- * <p>Note that, unless the behavior is overridden, atomic coders are presumed to be deterministic
- * and all instances are considered equal.
- *
- * @param <T> the type of the values being transcoded
- */
-public abstract class AtomicCoder<T> extends StandardCoder<T> {
-  protected AtomicCoder() { }
-
-  @Override
-  public void verifyDeterministic() throws NonDeterministicException { }
-
-  @Override
-  public final List<Coder<?>> getCoderArguments() {
-    return null;
-  }
-
-  /**
-   * Returns a list of values contained in the provided example
-   * value, one per type parameter. If there are no type parameters,
-   * returns an empty list.
-   *
-   * <p>Because {@link AtomicCoder} has no components, always returns an empty list.
-   *
-   * @param exampleValue unused, but part of the latent interface expected by
-   * {@link CoderFactories#fromStaticMethods}
-   */
-  public static <T> List<Object> getInstanceComponents(T exampleValue) {
-    return Collections.emptyList();
-  }
-}