You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by js...@apache.org on 2007/06/27 19:19:39 UTC

svn commit: r551231 - in /activemq/camel/trunk/components/camel-jbi: ./ src/main/java/org/apache/camel/component/jbi/ src/test/java/org/apache/camel/component/jbi/ src/test/resources/ src/test/resources/org/ src/test/resources/org/apache/ src/test/reso...

Author: jstrachan
Date: Wed Jun 27 10:19:38 2007
New Revision: 551231

URL: http://svn.apache.org/viewvc?view=rev&rev=551231
Log:
added a deployer and integration test of auto-deploying a camel context inside a JBI SU and invoking it via the NMR

Added:
    activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelSpringDeployer.java   (with props)
    activemq/camel/trunk/components/camel-jbi/src/test/java/org/apache/camel/component/jbi/IntegrationTest.java   (with props)
    activemq/camel/trunk/components/camel-jbi/src/test/resources/
    activemq/camel/trunk/components/camel-jbi/src/test/resources/log4j.properties   (with props)
    activemq/camel/trunk/components/camel-jbi/src/test/resources/org/
    activemq/camel/trunk/components/camel-jbi/src/test/resources/org/apache/
    activemq/camel/trunk/components/camel-jbi/src/test/resources/org/apache/camel/
    activemq/camel/trunk/components/camel-jbi/src/test/resources/org/apache/camel/component/
    activemq/camel/trunk/components/camel-jbi/src/test/resources/org/apache/camel/component/jbi/
    activemq/camel/trunk/components/camel-jbi/src/test/resources/org/apache/camel/component/jbi/su1-src/
    activemq/camel/trunk/components/camel-jbi/src/test/resources/org/apache/camel/component/jbi/su1-src/camel-context.xml   (with props)
Modified:
    activemq/camel/trunk/components/camel-jbi/pom.xml
    activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelJbiComponent.java
    activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelJbiEndpoint.java

Modified: activemq/camel/trunk/components/camel-jbi/pom.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jbi/pom.xml?view=diff&rev=551231&r1=551230&r2=551231
==============================================================================
--- activemq/camel/trunk/components/camel-jbi/pom.xml (original)
+++ activemq/camel/trunk/components/camel-jbi/pom.xml Wed Jun 27 10:19:38 2007
@@ -29,48 +29,47 @@
   </parent>
 
   <artifactId>camel-jbi</artifactId>
+  <packaging>jbi-component</packaging>
   <name>Camel :: JBI</name>
   <description>Camel JBI support</description>
 
+  <properties>
+    <servicemix-version>3.2-incubating-SNAPSHOT</servicemix-version>
+  </properties>
   <dependencies>
 
     <dependency>
       <groupId>org.apache.camel</groupId>
-      <artifactId>camel-core</artifactId>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.camel</groupId>
-      <artifactId>camel-core</artifactId>
-      <type>test-jar</type>
-      <optional>true</optional>
-      <scope>test</scope>
+      <artifactId>camel-spring</artifactId>
     </dependency>
-
     <dependency>
       <groupId>org.apache.servicemix</groupId>
       <artifactId>servicemix-jbi</artifactId>
-      <version>3.2-incubating-SNAPSHOT</version>
+      <version>${servicemix-version}</version>
     </dependency>
-
     <dependency>
       <groupId>org.apache.servicemix</groupId>
       <artifactId>servicemix-core</artifactId>
-      <version>3.2-incubating-SNAPSHOT</version>
+      <version>${servicemix-version}</version>
     </dependency>
-
     <dependency>
       <groupId>org.apache.servicemix</groupId>
       <artifactId>servicemix-common</artifactId>
-      <version>3.2-incubating-SNAPSHOT</version>
+      <version>${servicemix-version}</version>
     </dependency>
-
     <dependency>
-      <groupId>commons-logging</groupId>
-      <artifactId>commons-logging-api</artifactId>
-      <optional>false</optional>
+      <groupId>org.apache.xbean</groupId>
+      <artifactId>xbean-server</artifactId>
+      <version>3.1-SNAPSHOT</version>
     </dependency>
 
-
+    <!-- testing -->
+    <dependency>
+      <groupId>org.apache.camel</groupId>
+      <artifactId>camel-core</artifactId>
+      <type>test-jar</type>
+      <scope>test</scope>
+    </dependency>
     <dependency>
       <groupId>junit</groupId>
       <artifactId>junit</artifactId>
@@ -80,6 +79,17 @@
 
   <build>
     <plugins>
+      <plugin>
+        <groupId>org.apache.servicemix.tooling</groupId>
+        <artifactId>jbi-maven-plugin</artifactId>
+        <version>${servicemix-version}</version>
+        <extensions>true</extensions>
+        <configuration>
+          <type>service-engine</type>
+          <component>org.apache.camel.component.jbi.CamelJbiComponent</component>
+        </configuration>
+      </plugin>
+
       <plugin>
         <artifactId>maven-surefire-plugin</artifactId>
         <configuration>

Modified: activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelJbiComponent.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelJbiComponent.java?view=diff&rev=551231&r1=551230&r2=551231
==============================================================================
--- activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelJbiComponent.java (original)
+++ activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelJbiComponent.java Wed Jun 27 10:19:38 2007
@@ -15,13 +15,15 @@
 import org.apache.camel.CamelContext;
 import org.apache.camel.Component;
 import org.apache.camel.Endpoint;
-import org.apache.camel.Processor;
 import org.apache.camel.Exchange;
 import org.apache.camel.FailedToCreateProducerException;
+import org.apache.camel.Processor;
+import org.apache.servicemix.common.BaseServiceUnitManager;
 import org.apache.servicemix.common.DefaultComponent;
+import org.apache.servicemix.common.Deployer;
+import org.apache.servicemix.jbi.resolver.URIResolver;
 import org.apache.servicemix.jbi.util.IntrospectionSupport;
 import org.apache.servicemix.jbi.util.URISupport;
-import org.apache.servicemix.jbi.resolver.URIResolver;
 
 import javax.jbi.servicedesc.ServiceEndpoint;
 import javax.xml.namespace.QName;
@@ -43,6 +45,14 @@
     private CamelContext camelContext;
     private ScheduledExecutorService executorService;
 
+    /* (non-Javadoc)
+     * @see org.servicemix.common.BaseComponent#createServiceUnitManager()
+     */
+    public BaseServiceUnitManager createServiceUnitManager() {
+        Deployer[] deployers = new Deployer[]{new CamelSpringDeployer(this)};
+        return new BaseServiceUnitManager(this, deployers);
+    }
+
     /**
      * @return List of endpoints
      * @see org.apache.servicemix.common.DefaultComponent#getConfiguredEndpoints()
@@ -67,7 +77,6 @@
         return new Class[]{CamelJbiEndpoint.class};
     }
 
-
     /**
      * @return the binding
      */
@@ -101,13 +110,7 @@
         Map map = URISupport.parseQuery(uri.getQuery());
         String camelUri = uri.getSchemeSpecificPart();
         Endpoint camelEndpoint = getCamelContext().getEndpoint(camelUri);
-        Processor processor = null;
-        try {
-            processor = camelEndpoint.createProducer();
-        }
-        catch (Exception e) {
-            throw new FailedToCreateProducerException(camelEndpoint, e);
-        }
+        Processor processor = createCamelProcessor(camelEndpoint);
         CamelJbiEndpoint endpoint = new CamelJbiEndpoint(getServiceUnit(), camelEndpoint, getBinding(), processor);
 
         IntrospectionSupport.setProperties(endpoint, map);
@@ -147,7 +150,15 @@
     /**
      * Returns a JBI endpoint created for the given Camel endpoint
      */
-    public CamelJbiEndpoint activateJbiEndpoint(JbiEndpoint camelEndpoint, Processor processor) throws Exception {
+    public CamelJbiEndpoint activateJbiEndpoint(Endpoint camelEndpoint, Processor processor) throws Exception {
+        CamelJbiEndpoint jbiEndpoint = createJbiEndpointFromCamel(camelEndpoint, processor);
+
+        // the following method will activate the new dynamic JBI endpoint
+        addEndpoint(jbiEndpoint);
+        return jbiEndpoint;
+    }
+
+    protected CamelJbiEndpoint createJbiEndpointFromCamel(Endpoint camelEndpoint, Processor processor) {
         CamelJbiEndpoint jbiEndpoint;
         String endpointUri = camelEndpoint.getEndpointUri();
         if (endpointUri.startsWith("endpoint:")) {
@@ -167,9 +178,25 @@
         else {
             jbiEndpoint = new CamelJbiEndpoint(getServiceUnit(), camelEndpoint, getBinding(), processor);
         }
-
-        // the following method will activate the new dynamic JBI endpoint
-        addEndpoint(jbiEndpoint);
         return jbiEndpoint;
+    }
+
+    /**
+     * Returns a JBI endpoint created for the given Camel endpoint
+     */
+    public CamelJbiEndpoint createJbiEndpointFromCamel(Endpoint camelEndpoint) {
+        Processor processor = createCamelProcessor(camelEndpoint);
+        return createJbiEndpointFromCamel(camelEndpoint, processor);
+    }
+
+    protected Processor createCamelProcessor(Endpoint camelEndpoint) {
+        Processor processor = null;
+        try {
+            processor = camelEndpoint.createProducer();
+        }
+        catch (Exception e) {
+            throw new FailedToCreateProducerException(camelEndpoint, e);
+        }
+        return processor;
     }
 }

Modified: activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelJbiEndpoint.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelJbiEndpoint.java?view=diff&rev=551231&r1=551230&r2=551231
==============================================================================
--- activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelJbiEndpoint.java (original)
+++ activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelJbiEndpoint.java Wed Jun 27 10:19:38 2007
@@ -14,7 +14,7 @@
 
 import org.apache.camel.Endpoint;
 import org.apache.camel.Processor;
-import org.apache.camel.Exchange;
+import org.apache.camel.FailedToCreateProducerException;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.apache.servicemix.common.ServiceUnit;
@@ -30,21 +30,22 @@
  * @version $Revision: 426415 $
  */
 public class CamelJbiEndpoint extends ProviderEndpoint {
+    public static final QName SERVICE_NAME = new QName("http://camel.apache.org/service", "CamelEndpointComponent");
+
     private static final transient Log log = LogFactory.getLog(CamelJbiEndpoint.class);
-    private static final QName SERVICE_NAME = new QName("http://camel.apache.org/service", "CamelEndpointComponent");
     private Endpoint camelEndpoint;
     private JbiBinding binding;
-    private Processor processor;
+    private Processor camelProcessor;
 
-    public CamelJbiEndpoint(ServiceUnit serviceUnit, QName service, String endpoint, Endpoint camelEndpoint, JbiBinding binding, Processor processor) {
+    public CamelJbiEndpoint(ServiceUnit serviceUnit, QName service, String endpoint, Endpoint camelEndpoint, JbiBinding binding, Processor camelProcessor) {
         super(serviceUnit, service, endpoint);
-        this.processor = processor;
+        this.camelProcessor = camelProcessor;
         this.camelEndpoint = camelEndpoint;
         this.binding = binding;
     }
 
-    public CamelJbiEndpoint(ServiceUnit serviceUnit, Endpoint camelEndpoint, JbiBinding binding, Processor processor) {
-        this(serviceUnit, SERVICE_NAME, camelEndpoint.getEndpointUri(), camelEndpoint, binding, processor);
+    public CamelJbiEndpoint(ServiceUnit serviceUnit, Endpoint camelEndpoint, JbiBinding binding, Processor camelProcesso) {
+        this(serviceUnit, SERVICE_NAME, camelEndpoint.getEndpointUri(), camelEndpoint, binding, camelProcesso);
     }
 
     protected void processInOnly(MessageExchange exchange, NormalizedMessage in) throws Exception {
@@ -52,7 +53,7 @@
             log.debug("Received exchange: " + exchange);
         }
         JbiExchange camelExchange = new JbiExchange(camelEndpoint.getContext(), binding, exchange);
-        processor.process(camelExchange);
+        camelProcessor.process(camelExchange);
     }
 
     protected void processInOut(MessageExchange exchange, NormalizedMessage in, NormalizedMessage out) throws Exception {

Added: activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelSpringDeployer.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelSpringDeployer.java?view=auto&rev=551231
==============================================================================
--- activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelSpringDeployer.java (added)
+++ activemq/camel/trunk/components/camel-jbi/src/main/java/org/apache/camel/component/jbi/CamelSpringDeployer.java Wed Jun 27 10:19:38 2007
@@ -0,0 +1,72 @@
+/**
+ *
+ * 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.jbi;
+
+import org.apache.servicemix.common.xbean.AbstractXBeanDeployer;
+import org.apache.xbean.kernel.Kernel;
+import org.apache.xbean.server.spring.loader.PureSpringLoader;
+import org.apache.xbean.server.spring.loader.SpringLoader;
+import org.apache.camel.spring.SpringCamelContext;
+import org.apache.camel.Endpoint;
+import org.springframework.context.ApplicationContext;
+
+import java.util.List;
+import java.util.ArrayList;
+import java.util.Collection;
+
+/**
+ * A deployer of the spring XML file
+ *
+ * @version $Revision: 1.1 $
+ */
+public class CamelSpringDeployer extends AbstractXBeanDeployer {
+    private PureSpringLoader springLoader = new PureSpringLoader();
+    private final CamelJbiComponent component;
+
+    public CamelSpringDeployer(CamelJbiComponent component) {
+        super(component);
+        this.component = component;
+    }
+
+    protected String getXBeanFile() {
+        return "camel-context";
+    }
+
+    protected List getServices(Kernel kernel) {
+        try {
+            List services = new ArrayList();
+
+            ApplicationContext applicationContext = springLoader.getApplicationContext();
+            SpringCamelContext camelContext = SpringCamelContext.springCamelContext(applicationContext);
+
+            // now lets iterate through all the endpoints
+            Collection<Endpoint> endpoints = camelContext.getSingletonEndpoints();
+            for (Endpoint endpoint : endpoints) {
+                services.add(component.createJbiEndpointFromCamel(endpoint));
+            }
+            return services;
+        } catch (Exception e) {
+            throw new RuntimeException(e);
+        }
+    }
+
+    @Override
+    protected SpringLoader createSpringLoader() {
+        return springLoader;
+    }
+}
\ No newline at end of file

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

Added: activemq/camel/trunk/components/camel-jbi/src/test/java/org/apache/camel/component/jbi/IntegrationTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jbi/src/test/java/org/apache/camel/component/jbi/IntegrationTest.java?view=auto&rev=551231
==============================================================================
--- activemq/camel/trunk/components/camel-jbi/src/test/java/org/apache/camel/component/jbi/IntegrationTest.java (added)
+++ activemq/camel/trunk/components/camel-jbi/src/test/java/org/apache/camel/component/jbi/IntegrationTest.java Wed Jun 27 10:19:38 2007
@@ -0,0 +1,132 @@
+/**
+ *
+ * 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.jbi;
+
+import junit.framework.TestCase;
+import org.apache.servicemix.jbi.container.JBIContainer;
+import org.apache.servicemix.client.ServiceMixClient;
+import org.apache.servicemix.client.DefaultServiceMixClient;
+
+import javax.jbi.messaging.InOut;
+import javax.jbi.messaging.MessagingException;
+import javax.jbi.servicedesc.ServiceEndpoint;
+import javax.xml.namespace.QName;
+import java.io.File;
+import java.net.URL;
+import java.net.URI;
+
+/**
+ * @version $Revision: 1.1 $
+ */
+public class IntegrationTest extends TestCase {
+    protected JBIContainer container = new JBIContainer();
+
+    private File tempRootDir;
+
+    /*
+     * @see TestCase#setUp()
+     */
+    protected void setUp() throws Exception {
+        super.setUp();
+        container.setCreateMBeanServer(false);
+        container.setMonitorInstallationDirectory(false);
+        tempRootDir = File.createTempFile("servicemix", "rootDir");
+        tempRootDir.delete();
+        File tempTemp = new File(tempRootDir.getAbsolutePath() + "/temp");
+        if (!tempTemp.mkdirs()) {
+            fail("Unable to create temporary working root directory [" + tempTemp.getAbsolutePath() + "]");
+        }
+        System.out.println("Using temporary root directory [" + tempRootDir.getAbsolutePath() + "]");
+
+        container.setRootDir(tempRootDir.getAbsolutePath());
+        container.setMonitorInstallationDirectory(false);
+        container.setUseMBeanServer(false);
+        container.setCreateMBeanServer(false);
+        container.setFlowName("st");
+        container.init();
+        container.start();
+    }
+
+    public void testComponentInstallation() throws Exception {
+        CamelJbiComponent component = new CamelJbiComponent();
+        container.activateComponent(component, "#ServiceMixComponent#");
+        URL url = getClass().getResource("su1-src/camel-context.xml");
+        File path = new File(new URI(url.toString()));
+        path = path.getParentFile();
+        ServiceMixClient client = new DefaultServiceMixClient(container);
+
+        for (int i = 0; i < 2; i++) {
+            // Deploy and start su
+            component.getServiceUnitManager().deploy("su1", path.getAbsolutePath());
+            component.getServiceUnitManager().init("su1", path.getAbsolutePath());
+            component.getServiceUnitManager().start("su1");
+
+            // Send message
+            InOut inout = client.createInOutExchange();
+            ServiceEndpoint endpoint = client.getContext().getEndpoint(CamelJbiEndpoint.SERVICE_NAME, "queue:a");
+
+            //QName serviceQName = new QName("http://servicemix.apache.org/demo/", "chained");
+            //QName serviceQName = new QName("queue:a", "endpoint");
+            //inout.setService(serviceQName);
+            inout.setEndpoint(endpoint);
+            client.send(inout);
+
+            // Stop and undeploy
+            component.getServiceUnitManager().stop("su1");
+            component.getServiceUnitManager().shutDown("su1");
+            component.getServiceUnitManager().undeploy("su1", path.getAbsolutePath());
+
+            // Send message
+            inout = client.createInOutExchange();
+            //inout.setService(serviceQName);
+            inout.setEndpoint(endpoint);
+            try {
+                client.send(inout);
+            } catch (MessagingException e) {
+                // Ok, the lw component is undeployed
+            }
+
+        }
+    }
+
+    /*
+     * @see TestCase#tearDown()
+     */
+
+    protected void tearDown() throws Exception {
+        super.tearDown();
+        container.stop();
+        container.shutDown();
+        deleteDir(tempRootDir);
+    }
+
+    public static boolean deleteDir(File dir) {
+        System.out.println("Deleting directory : " + dir.getAbsolutePath());
+        if (dir.isDirectory()) {
+            String[] children = dir.list();
+            for (int i = 0; i < children.length; i++) {
+                boolean success = deleteDir(new File(dir, children[i]));
+                if (!success) {
+                    return false;
+                }
+            }
+        }
+        // The directory is now empty so delete it
+        return dir.delete();
+    }
+}

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

Added: activemq/camel/trunk/components/camel-jbi/src/test/resources/log4j.properties
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jbi/src/test/resources/log4j.properties?view=auto&rev=551231
==============================================================================
--- activemq/camel/trunk/components/camel-jbi/src/test/resources/log4j.properties (added)
+++ activemq/camel/trunk/components/camel-jbi/src/test/resources/log4j.properties Wed Jun 27 10:19:38 2007
@@ -0,0 +1,42 @@
+#
+# 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.
+#
+#
+
+#
+# The logging properties used during tests..
+#
+log4j.rootLogger=INFO, stdout
+
+log4j.logger.org.springframework=INFO
+log4j.logger.org.apache.activemq=INFO
+log4j.logger.org.apache.activemq.spring=WARN
+
+#log4j.logger.org.apache.servicemix=DEBUG
+
+# CONSOLE appender
+log4j.appender.stdout=org.apache.log4j.ConsoleAppender
+log4j.appender.stdout.layout=org.apache.log4j.PatternLayout
+log4j.appender.stdout.layout.ConversionPattern=%d [%-15.15t] %-5p %-30.30c{1} - %m%n
+
+# File appender
+log4j.appender.out=org.apache.log4j.FileAppender
+log4j.appender.out.layout=org.apache.log4j.PatternLayout
+log4j.appender.out.layout.ConversionPattern=%d [%-15.15t] %-5p %-30.30c{1} - %m%n
+log4j.appender.out.file=target/servicemix-test.log
+log4j.appender.out.append=true

Propchange: activemq/camel/trunk/components/camel-jbi/src/test/resources/log4j.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Added: activemq/camel/trunk/components/camel-jbi/src/test/resources/org/apache/camel/component/jbi/su1-src/camel-context.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jbi/src/test/resources/org/apache/camel/component/jbi/su1-src/camel-context.xml?view=auto&rev=551231
==============================================================================
--- activemq/camel/trunk/components/camel-jbi/src/test/resources/org/apache/camel/component/jbi/su1-src/camel-context.xml (added)
+++ activemq/camel/trunk/components/camel-jbi/src/test/resources/org/apache/camel/component/jbi/su1-src/camel-context.xml Wed Jun 27 10:19:38 2007
@@ -0,0 +1,39 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    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.
+
+-->
+<!-- START SNIPPET: camel -->
+<beans xmlns="http://www.springframework.org/schema/beans"
+       xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+       xsi:schemaLocation="
+       http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans-2.0.xsd
+       http://activemq.apache.org/camel/schema/spring http://activemq.apache.org/camel/schema/spring/camel-spring.xsd
+    ">
+
+  <!--
+     from("queue:a").to("queue:b");
+  -->
+  <camelContext id="camel" xmlns="http://activemq.apache.org/camel/schema/spring">
+    <route>
+      <from uri="queue:a"/>
+      <to uri="queue:b"/>
+    </route>
+  </camelContext>
+
+</beans>
+<!-- END SNIPPET: camel -->

Propchange: activemq/camel/trunk/components/camel-jbi/src/test/resources/org/apache/camel/component/jbi/su1-src/camel-context.xml
------------------------------------------------------------------------------
    svn:eol-style = native