You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@apex.apache.org by da...@apache.org on 2016/10/14 19:46:18 UTC

apex-malhar git commit: Renamed MergeWindowedOperator to WindowedMergedOperator.

Repository: apex-malhar
Updated Branches:
  refs/heads/master 7477502f3 -> 9eadce12c


Renamed MergeWindowedOperator to WindowedMergedOperator.


Project: http://git-wip-us.apache.org/repos/asf/apex-malhar/repo
Commit: http://git-wip-us.apache.org/repos/asf/apex-malhar/commit/9eadce12
Tree: http://git-wip-us.apache.org/repos/asf/apex-malhar/tree/9eadce12
Diff: http://git-wip-us.apache.org/repos/asf/apex-malhar/diff/9eadce12

Branch: refs/heads/master
Commit: 9eadce12c535f31aac0e46c87f7836af78e00a4a
Parents: 7477502
Author: Shunxin <lu...@hotmail.com>
Authored: Fri Oct 14 12:28:28 2016 -0700
Committer: Shunxin <lu...@hotmail.com>
Committed: Fri Oct 14 12:29:19 2016 -0700

----------------------------------------------------------------------
 .../lib/window/MergeWindowedOperator.java       | 40 --------------------
 .../lib/window/WindowedMergeOperator.java       | 40 ++++++++++++++++++++
 .../impl/KeyedWindowedMergeOperatorImpl.java    |  4 +-
 .../window/impl/WindowedMergeOperatorImpl.java  |  4 +-
 4 files changed, 44 insertions(+), 44 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/apex-malhar/blob/9eadce12/library/src/main/java/org/apache/apex/malhar/lib/window/MergeWindowedOperator.java
----------------------------------------------------------------------
diff --git a/library/src/main/java/org/apache/apex/malhar/lib/window/MergeWindowedOperator.java b/library/src/main/java/org/apache/apex/malhar/lib/window/MergeWindowedOperator.java
deleted file mode 100644
index 1561caa..0000000
--- a/library/src/main/java/org/apache/apex/malhar/lib/window/MergeWindowedOperator.java
+++ /dev/null
@@ -1,40 +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.apex.malhar.lib.window;
-
-/**
- * Interface for Merge Windowed Operator.
- */
-public interface MergeWindowedOperator<InputT1, InputT2>
-    extends WindowedOperator<InputT1>
-{
-  /**
-   * The method to accumulate the data tuple from the 2nd input stream
-   *
-   * @param tuple the data tuple
-   */
-  void accumulateTuple2(Tuple.WindowedTuple<InputT2> tuple);
-
-  /**
-   * The method to process the watermark tuple from the 2nd input stream
-   *
-   * @param watermark the watermark tuple
-   */
-  void processWatermark2(ControlTuple.Watermark watermark);
-}

http://git-wip-us.apache.org/repos/asf/apex-malhar/blob/9eadce12/library/src/main/java/org/apache/apex/malhar/lib/window/WindowedMergeOperator.java
----------------------------------------------------------------------
diff --git a/library/src/main/java/org/apache/apex/malhar/lib/window/WindowedMergeOperator.java b/library/src/main/java/org/apache/apex/malhar/lib/window/WindowedMergeOperator.java
new file mode 100644
index 0000000..4706302
--- /dev/null
+++ b/library/src/main/java/org/apache/apex/malhar/lib/window/WindowedMergeOperator.java
@@ -0,0 +1,40 @@
+/**
+ * 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.apex.malhar.lib.window;
+
+/**
+ * Interface for Merge Windowed Operator.
+ */
+public interface WindowedMergeOperator<InputT1, InputT2>
+    extends WindowedOperator<InputT1>
+{
+  /**
+   * The method to accumulate the data tuple from the 2nd input stream
+   *
+   * @param tuple the data tuple
+   */
+  void accumulateTuple2(Tuple.WindowedTuple<InputT2> tuple);
+
+  /**
+   * The method to process the watermark tuple from the 2nd input stream
+   *
+   * @param watermark the watermark tuple
+   */
+  void processWatermark2(ControlTuple.Watermark watermark);
+}

http://git-wip-us.apache.org/repos/asf/apex-malhar/blob/9eadce12/library/src/main/java/org/apache/apex/malhar/lib/window/impl/KeyedWindowedMergeOperatorImpl.java
----------------------------------------------------------------------
diff --git a/library/src/main/java/org/apache/apex/malhar/lib/window/impl/KeyedWindowedMergeOperatorImpl.java b/library/src/main/java/org/apache/apex/malhar/lib/window/impl/KeyedWindowedMergeOperatorImpl.java
index 3714d6d..eeb4777 100644
--- a/library/src/main/java/org/apache/apex/malhar/lib/window/impl/KeyedWindowedMergeOperatorImpl.java
+++ b/library/src/main/java/org/apache/apex/malhar/lib/window/impl/KeyedWindowedMergeOperatorImpl.java
@@ -19,8 +19,8 @@
 package org.apache.apex.malhar.lib.window.impl;
 
 import org.apache.apex.malhar.lib.window.ControlTuple;
-import org.apache.apex.malhar.lib.window.MergeWindowedOperator;
 import org.apache.apex.malhar.lib.window.Tuple;
+import org.apache.apex.malhar.lib.window.WindowedMergeOperator;
 
 import com.google.common.base.Function;
 
@@ -41,7 +41,7 @@ import com.datatorrent.lib.util.KeyValPair;
  */
 public class KeyedWindowedMergeOperatorImpl<KeyT, InputT1, InputT2, AccumT, OutputT>
     extends KeyedWindowedOperatorImpl<KeyT, InputT1, AccumT, OutputT>
-    implements MergeWindowedOperator<KeyValPair<KeyT, InputT1>, KeyValPair<KeyT, InputT2>>
+    implements WindowedMergeOperator<KeyValPair<KeyT, InputT1>, KeyValPair<KeyT, InputT2>>
 {
   private Function<KeyValPair<KeyT, InputT2>, Long> timestampExtractor2;
 

http://git-wip-us.apache.org/repos/asf/apex-malhar/blob/9eadce12/library/src/main/java/org/apache/apex/malhar/lib/window/impl/WindowedMergeOperatorImpl.java
----------------------------------------------------------------------
diff --git a/library/src/main/java/org/apache/apex/malhar/lib/window/impl/WindowedMergeOperatorImpl.java b/library/src/main/java/org/apache/apex/malhar/lib/window/impl/WindowedMergeOperatorImpl.java
index 0f8a762..79475e3 100644
--- a/library/src/main/java/org/apache/apex/malhar/lib/window/impl/WindowedMergeOperatorImpl.java
+++ b/library/src/main/java/org/apache/apex/malhar/lib/window/impl/WindowedMergeOperatorImpl.java
@@ -19,8 +19,8 @@
 package org.apache.apex.malhar.lib.window.impl;
 
 import org.apache.apex.malhar.lib.window.ControlTuple;
-import org.apache.apex.malhar.lib.window.MergeWindowedOperator;
 import org.apache.apex.malhar.lib.window.Tuple;
+import org.apache.apex.malhar.lib.window.WindowedMergeOperator;
 
 import com.google.common.base.Function;
 
@@ -38,7 +38,7 @@ import com.datatorrent.api.annotation.InputPortFieldAnnotation;
  * @param <OutputT> The type of output tuple.
  */
 public class WindowedMergeOperatorImpl<InputT1, InputT2, AccumT, OutputT>
-    extends WindowedOperatorImpl<InputT1, AccumT, OutputT> implements MergeWindowedOperator<InputT1, InputT2>
+    extends WindowedOperatorImpl<InputT1, AccumT, OutputT> implements WindowedMergeOperator<InputT1, InputT2>
 {
   private Function<InputT2, Long> timestampExtractor2;