You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by bv...@apache.org on 2014/01/18 13:57:56 UTC

git commit: CAMEL-7142: Renamed the test class to fit better with the fix.

Updated Branches:
  refs/heads/master f96f669c2 -> 0d47ae108


CAMEL-7142: Renamed the test class to fit better with the fix.

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

Branch: refs/heads/master
Commit: 0d47ae108ee9f75d1f5fb309b9d4c9c383174bc5
Parents: f96f669
Author: Babak Vahdat <bv...@apache.org>
Authored: Sat Jan 18 13:57:50 2014 +0100
Committer: Babak Vahdat <bv...@apache.org>
Committed: Sat Jan 18 13:57:50 2014 +0100

----------------------------------------------------------------------
 ...UnmarshalTwoCsvDataFormatConcurrentTest.java | 88 ++++++++++++++++++++
 .../csv/CsvUnmarshalTwoCsvDataFormatTest.java   | 88 --------------------
 2 files changed, 88 insertions(+), 88 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/0d47ae10/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvUnmarshalTwoCsvDataFormatConcurrentTest.java
----------------------------------------------------------------------
diff --git a/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvUnmarshalTwoCsvDataFormatConcurrentTest.java b/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvUnmarshalTwoCsvDataFormatConcurrentTest.java
new file mode 100644
index 0000000..c721fd3
--- /dev/null
+++ b/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvUnmarshalTwoCsvDataFormatConcurrentTest.java
@@ -0,0 +1,88 @@
+/**
+ * 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.dataformat.csv;
+
+import java.util.List;
+
+import org.apache.camel.EndpointInject;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.mock.MockEndpoint;
+import org.apache.camel.test.junit4.CamelTestSupport;
+import org.junit.Test;
+
+/**
+ * @version 
+ */
+public class CsvUnmarshalTwoCsvDataFormatConcurrentTest extends CamelTestSupport {
+
+    @EndpointInject(uri = "mock:result")
+    private MockEndpoint result;
+
+    @EndpointInject(uri = "mock:result2")
+    private MockEndpoint result2;
+
+    @Test
+    public void testCsvUnMarshal() throws Exception {
+        result.expectedMessageCount(1);
+        result2.expectedMessageCount(1);
+        sendAndVerify("|", result);
+
+        resetMocks();
+
+        result.expectedMessageCount(1);
+        result2.expectedMessageCount(1);
+        sendAndVerify(";", result2);
+    }
+
+    private void sendAndVerify(String delimiter, MockEndpoint mock) throws InterruptedException {
+        template.sendBody("direct:start", "123" + delimiter + "Camel in Action" + delimiter + "1\n124" + delimiter + "ActiveMQ in Action" + delimiter + "2");
+        assertMockEndpointsSatisfied();
+
+        @SuppressWarnings("unchecked")
+        List<List<String>> body = mock.getReceivedExchanges().get(0).getIn().getBody(List.class);
+        assertEquals(2, body.size());
+        assertEquals("123", body.get(0).get(0));
+        assertEquals("Camel in Action", body.get(0).get(1));
+        assertEquals("1", body.get(0).get(2));
+        assertEquals("124", body.get(1).get(0));
+        assertEquals("ActiveMQ in Action", body.get(1).get(1));
+        assertEquals("2", body.get(1).get(2));
+    }
+
+    @Override
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new RouteBuilder() {
+            @Override
+            public void configure() throws Exception {
+                CsvDataFormat csv = new CsvDataFormat();
+                csv.setDelimiter("|");
+                CsvDataFormat csv2 = new CsvDataFormat();
+                csv2.setDelimiter(";");
+
+                from("direct:start").multicast().parallelProcessing().to("direct:csv", "direct:csv2");
+
+                from("direct:csv")
+                        .unmarshal(csv)
+                        .to("mock:result");
+
+                from("direct:csv2")
+                        .unmarshal(csv2)
+                        .to("mock:result2");
+            }
+        };
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/camel/blob/0d47ae10/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvUnmarshalTwoCsvDataFormatTest.java
----------------------------------------------------------------------
diff --git a/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvUnmarshalTwoCsvDataFormatTest.java b/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvUnmarshalTwoCsvDataFormatTest.java
deleted file mode 100644
index ef318be..0000000
--- a/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvUnmarshalTwoCsvDataFormatTest.java
+++ /dev/null
@@ -1,88 +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.camel.dataformat.csv;
-
-import java.util.List;
-
-import org.apache.camel.EndpointInject;
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.test.junit4.CamelTestSupport;
-import org.junit.Test;
-
-/**
- * @version 
- */
-public class CsvUnmarshalTwoCsvDataFormatTest extends CamelTestSupport {
-
-    @EndpointInject(uri = "mock:result")
-    private MockEndpoint result;
-
-    @EndpointInject(uri = "mock:result2")
-    private MockEndpoint result2;
-
-    @Test
-    public void testCsvUnMarshal() throws Exception {
-        result.expectedMessageCount(1);
-        result2.expectedMessageCount(1);
-        sendAndVerify("|", result);
-
-        resetMocks();
-
-        result.expectedMessageCount(1);
-        result2.expectedMessageCount(1);
-        sendAndVerify(";", result2);
-    }
-
-    private void sendAndVerify(String delimiter, MockEndpoint mock) throws InterruptedException {
-        template.sendBody("direct:start", "123" + delimiter + "Camel in Action" + delimiter + "1\n124" + delimiter + "ActiveMQ in Action" + delimiter + "2");
-        assertMockEndpointsSatisfied();
-
-        @SuppressWarnings("unchecked")
-        List<List<String>> body = mock.getReceivedExchanges().get(0).getIn().getBody(List.class);
-        assertEquals(2, body.size());
-        assertEquals("123", body.get(0).get(0));
-        assertEquals("Camel in Action", body.get(0).get(1));
-        assertEquals("1", body.get(0).get(2));
-        assertEquals("124", body.get(1).get(0));
-        assertEquals("ActiveMQ in Action", body.get(1).get(1));
-        assertEquals("2", body.get(1).get(2));
-    }
-
-    @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
-        return new RouteBuilder() {
-            @Override
-            public void configure() throws Exception {
-                CsvDataFormat csv = new CsvDataFormat();
-                csv.setDelimiter("|");
-                CsvDataFormat csv2 = new CsvDataFormat();
-                csv2.setDelimiter(";");
-
-                from("direct:start").multicast().parallelProcessing().to("direct:csv", "direct:csv2");
-
-                from("direct:csv")
-                        .unmarshal(csv)
-                        .to("mock:result");
-
-                from("direct:csv2")
-                        .unmarshal(csv2)
-                        .to("mock:result2");
-            }
-        };
-    }
-}
\ No newline at end of file