You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by da...@apache.org on 2014/02/05 12:57:07 UTC

[2/2] git commit: CAMEL-7167: onCompletion should be called on agg strategy on splitter/multicast etc, just like it does in aggregte eip.

CAMEL-7167: onCompletion should be called on agg strategy on splitter/multicast etc, just like it does in aggregte eip.


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

Branch: refs/heads/camel-2.12.x
Commit: eed81aa3693c5728fc8ead37f99021d005d58360
Parents: c580480
Author: Claus Ibsen <da...@apache.org>
Authored: Wed Feb 5 12:57:28 2014 +0100
Committer: Claus Ibsen <da...@apache.org>
Committed: Wed Feb 5 12:57:48 2014 +0100

----------------------------------------------------------------------
 .../camel/processor/MulticastProcessor.java     |  7 ++
 .../CustomListAggregationStrategySplitTest.java | 85 ++++++++++++++++++++
 2 files changed, 92 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/eed81aa3/camel-core/src/main/java/org/apache/camel/processor/MulticastProcessor.java
----------------------------------------------------------------------
diff --git a/camel-core/src/main/java/org/apache/camel/processor/MulticastProcessor.java b/camel-core/src/main/java/org/apache/camel/processor/MulticastProcessor.java
index be1772f..5e8d5c0 100644
--- a/camel-core/src/main/java/org/apache/camel/processor/MulticastProcessor.java
+++ b/camel-core/src/main/java/org/apache/camel/processor/MulticastProcessor.java
@@ -48,6 +48,7 @@ import org.apache.camel.Processor;
 import org.apache.camel.Producer;
 import org.apache.camel.Traceable;
 import org.apache.camel.processor.aggregate.AggregationStrategy;
+import org.apache.camel.processor.aggregate.CompletionAwareAggregationStrategy;
 import org.apache.camel.processor.aggregate.TimeoutAwareAggregationStrategy;
 import org.apache.camel.spi.RouteContext;
 import org.apache.camel.spi.TracedRouteNodes;
@@ -748,6 +749,12 @@ public class MulticastProcessor extends ServiceSupport implements AsyncProcessor
             IOHelper.close((Closeable) pairs, "pairs", LOG);
         }
 
+        AggregationStrategy strategy = getAggregationStrategy(subExchange);
+        // invoke the on completion callback
+        if (strategy instanceof CompletionAwareAggregationStrategy) {
+            ((CompletionAwareAggregationStrategy) strategy).onCompletion(subExchange);
+        }
+
         // cleanup any per exchange aggregation strategy
         removeAggregationStrategyFromExchange(original);
 

http://git-wip-us.apache.org/repos/asf/camel/blob/eed81aa3/camel-core/src/test/java/org/apache/camel/processor/aggregator/CustomListAggregationStrategySplitTest.java
----------------------------------------------------------------------
diff --git a/camel-core/src/test/java/org/apache/camel/processor/aggregator/CustomListAggregationStrategySplitTest.java b/camel-core/src/test/java/org/apache/camel/processor/aggregator/CustomListAggregationStrategySplitTest.java
new file mode 100644
index 0000000..5de6fd4
--- /dev/null
+++ b/camel-core/src/test/java/org/apache/camel/processor/aggregator/CustomListAggregationStrategySplitTest.java
@@ -0,0 +1,85 @@
+/**
+ * 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.camel.processor.aggregator;
+
+import java.util.ArrayList;
+import java.util.List;
+
+import org.apache.camel.ContextTestSupport;
+import org.apache.camel.Exchange;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.mock.MockEndpoint;
+import org.apache.camel.processor.aggregate.AbstractListAggregationStrategy;
+
+/**
+ *
+ */
+public class CustomListAggregationStrategySplitTest extends ContextTestSupport {
+
+    @SuppressWarnings("unchecked")
+    public void testCustomAggregationStrategy() throws Exception {
+        getMockEndpoint("mock:line").expectedBodiesReceived(100, 150, 130);
+
+        // the strategy will combine the data into a list of numbers
+        MockEndpoint result = getMockEndpoint("mock:result");
+        result.expectedMessageCount(1);
+        result.message(0).body().isInstanceOf(List.class);
+
+        List<String> body = new ArrayList<String>();
+        body.add("100");
+        body.add("150");
+        body.add("130");
+
+        template.sendBody("direct:start", body);
+
+        assertMockEndpointsSatisfied();
+
+        // the list will be stored as the message body by default
+        List<Integer> numbers = result.getExchanges().get(0).getIn().getBody(List.class);
+        assertNotNull(numbers);
+        assertEquals(Integer.valueOf("100"), numbers.get(0));
+        assertEquals(Integer.valueOf("150"), numbers.get(1));
+        assertEquals(Integer.valueOf("130"), numbers.get(2));
+    }
+
+    @Override
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new RouteBuilder() {
+            @Override
+            public void configure() throws Exception {
+                from("direct:start")
+                    .split(body(), new MyListOfNumbersStrategy())
+                        .to("mock:line")
+                    .end()
+                    .to("mock:result");
+            }
+        };
+    }
+
+    /**
+     * Our strategy just group a list of integers.
+     */
+    public final class MyListOfNumbersStrategy extends AbstractListAggregationStrategy<Integer> {
+
+        @Override
+        public Integer getValue(Exchange exchange) {
+            String s = exchange.getIn().getBody(String.class);
+            return Integer.valueOf(s);
+        }
+    }
+
+}