You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ni...@apache.org on 2008/05/12 04:00:17 UTC

svn commit: r655401 - in /activemq/camel/trunk: camel-core/src/test/java/org/apache/camel/component/file/ components/camel-hamcrest/ components/camel-hamcrest/src/main/java/org/apache/camel/hamcrest/ components/camel-hamcrest/src/test/java/org/apache/c...

Author: ningjiang
Date: Sun May 11 19:00:16 2008
New Revision: 655401

URL: http://svn.apache.org/viewvc?rev=655401&view=rev
Log:
Apply the svn auto-props on the files

Modified:
    activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/MoveFilesToDirectoryWithNoopTest.java   (contents, props changed)
    activemq/camel/trunk/components/camel-hamcrest/pom.xml   (props changed)
    activemq/camel/trunk/components/camel-hamcrest/src/main/java/org/apache/camel/hamcrest/Assertions.java   (contents, props changed)
    activemq/camel/trunk/components/camel-hamcrest/src/test/java/org/apache/camel/hamcrest/AssertionsTest.java   (contents, props changed)
    activemq/camel/trunk/components/camel-mail/src/test/java/org/apache/camel/component/mail/MailAttachmentTest.java   (contents, props changed)
    activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/SMulticastType.scala   (contents, props changed)
    activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/ScalaProcessor.scala   (contents, props changed)
    activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ContentEnricherTest.scala   (contents, props changed)
    activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ExplicitMulticastTest.scala   (contents, props changed)
    activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponentException.java   (props changed)

Modified: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/MoveFilesToDirectoryWithNoopTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/MoveFilesToDirectoryWithNoopTest.java?rev=655401&r1=655400&r2=655401&view=diff
==============================================================================
--- activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/MoveFilesToDirectoryWithNoopTest.java (original)
+++ activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/MoveFilesToDirectoryWithNoopTest.java Sun May 11 19:00:16 2008
@@ -17,7 +17,7 @@
 package org.apache.camel.component.file;
 
 /**
- * @version $Revision: 1.1 $
+ * @version $Revision$
  */
 public class MoveFilesToDirectoryWithNoopTest extends MoveFilesToDirectoryTest {
 

Propchange: activemq/camel/trunk/camel-core/src/test/java/org/apache/camel/component/file/MoveFilesToDirectoryWithNoopTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/components/camel-hamcrest/pom.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/components/camel-hamcrest/pom.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Modified: activemq/camel/trunk/components/camel-hamcrest/src/main/java/org/apache/camel/hamcrest/Assertions.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-hamcrest/src/main/java/org/apache/camel/hamcrest/Assertions.java?rev=655401&r1=655400&r2=655401&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-hamcrest/src/main/java/org/apache/camel/hamcrest/Assertions.java (original)
+++ activemq/camel/trunk/components/camel-hamcrest/src/main/java/org/apache/camel/hamcrest/Assertions.java Sun May 11 19:00:16 2008
@@ -23,7 +23,7 @@
 /**
  * A set of useful assertions you can use when testing
  * 
- * @version $Revision: 1.1 $
+ * @version $Revision$
  */
 public class Assertions {
 

Propchange: activemq/camel/trunk/components/camel-hamcrest/src/main/java/org/apache/camel/hamcrest/Assertions.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/components/camel-hamcrest/src/test/java/org/apache/camel/hamcrest/AssertionsTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-hamcrest/src/test/java/org/apache/camel/hamcrest/AssertionsTest.java?rev=655401&r1=655400&r2=655401&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-hamcrest/src/test/java/org/apache/camel/hamcrest/AssertionsTest.java (original)
+++ activemq/camel/trunk/components/camel-hamcrest/src/test/java/org/apache/camel/hamcrest/AssertionsTest.java Sun May 11 19:00:16 2008
@@ -22,7 +22,7 @@
 import org.apache.commons.logging.LogFactory;
 
 /**
- * @version $Revision: 1.1 $
+ * @version $Revision$
  */
 public class AssertionsTest extends TestCase {
     private static final transient Log LOG = LogFactory.getLog(AssertionsTest.class);

Propchange: activemq/camel/trunk/components/camel-hamcrest/src/test/java/org/apache/camel/hamcrest/AssertionsTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/components/camel-mail/src/test/java/org/apache/camel/component/mail/MailAttachmentTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-mail/src/test/java/org/apache/camel/component/mail/MailAttachmentTest.java?rev=655401&r1=655400&r2=655401&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-mail/src/test/java/org/apache/camel/component/mail/MailAttachmentTest.java (original)
+++ activemq/camel/trunk/components/camel-mail/src/test/java/org/apache/camel/component/mail/MailAttachmentTest.java Sun May 11 19:00:16 2008
@@ -1,88 +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.component.mail;
-
-import java.util.Map;
-
-import javax.activation.DataHandler;
-import javax.activation.FileDataSource;
-
-import org.apache.camel.ContextTestSupport;
-import org.apache.camel.Endpoint;
-import org.apache.camel.Exchange;
-import org.apache.camel.Message;
-import org.apache.camel.Producer;
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.mock.MockEndpoint;
-
-/**
- * Unit test for Camel attachments and Mail attachments.
- */
-public class MailAttachmentTest extends ContextTestSupport {
-
-    public void testSendAndRecieveMailWithAttachments() throws Exception {
-        // START SNIPPET: e1
-
-        // create an exchange with a normal body and attachment to be produced as email
-        Endpoint endpoint = context.getEndpoint("smtp://james@mymailserver.com?password=secret");
-
-        // create the exchange with the mail message that is multipart with a file and a Hello World text/plain message.
-        Exchange exchange = endpoint.createExchange();
-        Message in = exchange.getIn();
-        in.setBody("Hello World");
-        in.addAttachment("logo.jpeg", new DataHandler(new FileDataSource("src/test/data/logo.jpeg")));
-
-        // create a producer that can produce the exchange (= send the mail)
-        Producer producer = endpoint.createProducer();
-        // start the producer
-        producer.start();
-        // and let it go (processes the exchange by sending the email)
-        producer.process(exchange);
-
-        // END SNIPPET: e1
-
-        // need some time for the mail to arrive on the inbox (consumed and sent to the mock)
-        Thread.sleep(1000);
-
-        MockEndpoint mock = getMockEndpoint("mock:result");
-        mock.expectedMessageCount(1);
-        Exchange out = mock.assertExchangeReceived(0);
-        mock.assertIsSatisfied();
-
-        // plain text
-        assertEquals("Hello World", out.getIn().getBody(String.class));
-
-        // attachment
-        Map<String, DataHandler> attachments = out.getIn().getAttachments();
-        assertNotNull("Should have attachments", attachments);
-        assertEquals(1, attachments.size());
-
-        DataHandler handler = out.getIn().getAttachment("logo.jpeg");
-        assertNotNull("The logo should be there", handler);
-        assertEquals("image/jpeg; name=logo.jpeg", handler.getContentType());
-
-        producer.stop();
-    }
-
-    protected RouteBuilder createRouteBuilder() throws Exception {
-        return new RouteBuilder() {
-            public void configure() throws Exception {
-                from("pop3://james@mymailserver.com?password=secret&consumer.delay=1000").to("mock:result");
-            }
-        };
-    }
-}
+/**
+ * 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.component.mail;
+
+import java.util.Map;
+
+import javax.activation.DataHandler;
+import javax.activation.FileDataSource;
+
+import org.apache.camel.ContextTestSupport;
+import org.apache.camel.Endpoint;
+import org.apache.camel.Exchange;
+import org.apache.camel.Message;
+import org.apache.camel.Producer;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.mock.MockEndpoint;
+
+/**
+ * Unit test for Camel attachments and Mail attachments.
+ */
+public class MailAttachmentTest extends ContextTestSupport {
+
+    public void testSendAndRecieveMailWithAttachments() throws Exception {
+        // START SNIPPET: e1
+
+        // create an exchange with a normal body and attachment to be produced as email
+        Endpoint endpoint = context.getEndpoint("smtp://james@mymailserver.com?password=secret");
+
+        // create the exchange with the mail message that is multipart with a file and a Hello World text/plain message.
+        Exchange exchange = endpoint.createExchange();
+        Message in = exchange.getIn();
+        in.setBody("Hello World");
+        in.addAttachment("logo.jpeg", new DataHandler(new FileDataSource("src/test/data/logo.jpeg")));
+
+        // create a producer that can produce the exchange (= send the mail)
+        Producer producer = endpoint.createProducer();
+        // start the producer
+        producer.start();
+        // and let it go (processes the exchange by sending the email)
+        producer.process(exchange);
+
+        // END SNIPPET: e1
+
+        // need some time for the mail to arrive on the inbox (consumed and sent to the mock)
+        Thread.sleep(1000);
+
+        MockEndpoint mock = getMockEndpoint("mock:result");
+        mock.expectedMessageCount(1);
+        Exchange out = mock.assertExchangeReceived(0);
+        mock.assertIsSatisfied();
+
+        // plain text
+        assertEquals("Hello World", out.getIn().getBody(String.class));
+
+        // attachment
+        Map<String, DataHandler> attachments = out.getIn().getAttachments();
+        assertNotNull("Should have attachments", attachments);
+        assertEquals(1, attachments.size());
+
+        DataHandler handler = out.getIn().getAttachment("logo.jpeg");
+        assertNotNull("The logo should be there", handler);
+        assertEquals("image/jpeg; name=logo.jpeg", handler.getContentType());
+
+        producer.stop();
+    }
+
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new RouteBuilder() {
+            public void configure() throws Exception {
+                from("pop3://james@mymailserver.com?password=secret&consumer.delay=1000").to("mock:result");
+            }
+        };
+    }
+}

Propchange: activemq/camel/trunk/components/camel-mail/src/test/java/org/apache/camel/component/mail/MailAttachmentTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/components/camel-mail/src/test/java/org/apache/camel/component/mail/MailAttachmentTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/SMulticastType.scala
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/SMulticastType.scala?rev=655401&r1=655400&r2=655401&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/SMulticastType.scala (original)
+++ activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/SMulticastType.scala Sun May 11 19:00:16 2008
@@ -1,26 +1,26 @@
-/**
- * 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.scala.dsl;
-
-import org.apache.camel.model.MulticastType
-import org.apache.camel.scala.builder.RouteBuilder
-
-class SMulticastType(val target: MulticastType)(implicit val builder: RouteBuilder) extends ScalaDsl with Wrapper[MulticastType] {
-  
-  val unwrap = target
-  
-}
+/**
+ * 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.scala.dsl;
+
+import org.apache.camel.model.MulticastType
+import org.apache.camel.scala.builder.RouteBuilder
+
+class SMulticastType(val target: MulticastType)(implicit val builder: RouteBuilder) extends ScalaDsl with Wrapper[MulticastType] {
+  
+  val unwrap = target
+  
+}

Propchange: activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/SMulticastType.scala
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/SMulticastType.scala
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/ScalaProcessor.scala
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/ScalaProcessor.scala?rev=655401&r1=655400&r2=655401&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/ScalaProcessor.scala (original)
+++ activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/ScalaProcessor.scala Sun May 11 19:00:16 2008
@@ -1,26 +1,26 @@
-/**
- * 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.scala.dsl;
-
-/**
- * Scala implementation for an Apache Camel Processor
- */
-class ScalaProcessor(val function: Exchange => Any) extends Processor {
-  
-  def process(exchange: Exchange) = function(exchange)
-
-}
+/**
+ * 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.scala.dsl;
+
+/**
+ * Scala implementation for an Apache Camel Processor
+ */
+class ScalaProcessor(val function: Exchange => Any) extends Processor {
+  
+  def process(exchange: Exchange) = function(exchange)
+
+}

Propchange: activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/ScalaProcessor.scala
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/components/camel-scala/src/main/scala/org/apache/camel/scala/dsl/ScalaProcessor.scala
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ContentEnricherTest.scala
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ContentEnricherTest.scala?rev=655401&r1=655400&r2=655401&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ContentEnricherTest.scala (original)
+++ activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ContentEnricherTest.scala Sun May 11 19:00:16 2008
@@ -1,70 +1,70 @@
-/**
- * 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.scala.dsl;
- 
-import scala.builder.RouteBuilder
-
-class ContentEnricherTest extends ScalaTestSupport {
-  
-  def testContentEnricherBySimpleProcessor = {
-    "mock:a" expect { _.received ("James says hello", 
-                                  "Hadrian says hello",
-                                  "Willem says hello")}
-    "direct:a" ! ("James", "Hadrian", "Willem")
-    "mock:a" assert()
-  }
-  
-  def testContentEnricherByProcessorDef = {
-    "mock:b" expect { _.received ("hello from the UK", 
-                                  "hallo vanuit Belgie",
-                                  "bonjour de la douce France")}
-    "direct:b" ! ("hello", "hallo", "bonjour")
-    "mock:b" assert()
-  }
-  
-  def testContentEnricherWithVelocity = {
-    "mock:c" expect { _.received ("<hello>James</hello>", 
-                                  "<hello>Hadrian</hello>",
-                                  "<hello>Willem</hello>")}
-    "direct:c" ! ("James", "Hadrian", "Willem")
-    "mock:c" assert()
-  }
-
-  val builder = new RouteBuilder {
-    // START SNIPPET: simple
-    "direct:a" process(_.in += " says hello") to ("mock:a")
-    // END SNIPPET: simple
-    
-    // START SNIPPET: def
-    "direct:b" process(myProcessor) to ("mock:b")
-    
-    def myProcessor(exchange: Exchange) = {
-      exchange.in match {
-        case "hello" => exchange.in = "hello from the UK"
-        case "hallo" => exchange.in = "hallo vanuit Belgie"
-        case "bonjour" => exchange.in = "bonjour de la douce France"
-      }
-    }
-    // END SNIPPET: def
-    
-    // START SNIPPET: velocity
-    "direct:c" to ("velocity:org/apache/camel/scala/dsl/enricher.vm") to ("mock:c")   
-    // END SNIPPET: velocity
-
-  }
-
-}
+/**
+ * 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.scala.dsl;
+ 
+import scala.builder.RouteBuilder
+
+class ContentEnricherTest extends ScalaTestSupport {
+  
+  def testContentEnricherBySimpleProcessor = {
+    "mock:a" expect { _.received ("James says hello", 
+                                  "Hadrian says hello",
+                                  "Willem says hello")}
+    "direct:a" ! ("James", "Hadrian", "Willem")
+    "mock:a" assert()
+  }
+  
+  def testContentEnricherByProcessorDef = {
+    "mock:b" expect { _.received ("hello from the UK", 
+                                  "hallo vanuit Belgie",
+                                  "bonjour de la douce France")}
+    "direct:b" ! ("hello", "hallo", "bonjour")
+    "mock:b" assert()
+  }
+  
+  def testContentEnricherWithVelocity = {
+    "mock:c" expect { _.received ("<hello>James</hello>", 
+                                  "<hello>Hadrian</hello>",
+                                  "<hello>Willem</hello>")}
+    "direct:c" ! ("James", "Hadrian", "Willem")
+    "mock:c" assert()
+  }
+
+  val builder = new RouteBuilder {
+    // START SNIPPET: simple
+    "direct:a" process(_.in += " says hello") to ("mock:a")
+    // END SNIPPET: simple
+    
+    // START SNIPPET: def
+    "direct:b" process(myProcessor) to ("mock:b")
+    
+    def myProcessor(exchange: Exchange) = {
+      exchange.in match {
+        case "hello" => exchange.in = "hello from the UK"
+        case "hallo" => exchange.in = "hallo vanuit Belgie"
+        case "bonjour" => exchange.in = "bonjour de la douce France"
+      }
+    }
+    // END SNIPPET: def
+    
+    // START SNIPPET: velocity
+    "direct:c" to ("velocity:org/apache/camel/scala/dsl/enricher.vm") to ("mock:c")   
+    // END SNIPPET: velocity
+
+  }
+
+}

Propchange: activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ContentEnricherTest.scala
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ContentEnricherTest.scala
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ExplicitMulticastTest.scala
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ExplicitMulticastTest.scala?rev=655401&r1=655400&r2=655401&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ExplicitMulticastTest.scala (original)
+++ activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ExplicitMulticastTest.scala Sun May 11 19:00:16 2008
@@ -1,45 +1,45 @@
-/**
- * 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.scala.dsl;
- 
-import scala.builder.RouteBuilder
-
-class ExplicitMulticastTest extends ScalaTestSupport {
-
-  def testExplicitMulticast = {
-    "mock:a" expect { _.count = 3 }
-    "mock:b" expect { _.count = 3 }
-    "mock:c" expect { _.count = 3 }
-    "direct:a" ! ("<hello/>", "<hallo/>", "<bonjour/>")
-    "mock:a" assert()
-    "mock:b" assert()
-    "mock:c" assert()
-  }
-
-  val builder = new RouteBuilder {
-    // START SNIPPET: multicast
-    "direct:a" ==> {
-      multicast {
-        to ("mock:a")
-        to ("mock:b")
-        to ("mock:c")
-      }
-    }
-    // END SNIPPET: multicast
-  }
-
-}
+/**
+ * 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.scala.dsl;
+ 
+import scala.builder.RouteBuilder
+
+class ExplicitMulticastTest extends ScalaTestSupport {
+
+  def testExplicitMulticast = {
+    "mock:a" expect { _.count = 3 }
+    "mock:b" expect { _.count = 3 }
+    "mock:c" expect { _.count = 3 }
+    "direct:a" ! ("<hello/>", "<hallo/>", "<bonjour/>")
+    "mock:a" assert()
+    "mock:b" assert()
+    "mock:c" assert()
+  }
+
+  val builder = new RouteBuilder {
+    // START SNIPPET: multicast
+    "direct:a" ==> {
+      multicast {
+        to ("mock:a")
+        to ("mock:b")
+        to ("mock:c")
+      }
+    }
+    // END SNIPPET: multicast
+  }
+
+}

Propchange: activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ExplicitMulticastTest.scala
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/components/camel-scala/src/test/scala/org/apache/camel/scala/dsl/ExplicitMulticastTest.scala
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponentException.java
------------------------------------------------------------------------------
    svn:eol-style = native