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/11/20 06:03:14 UTC

svn commit: r719163 - in /activemq/camel/trunk/components/camel-jms/src: main/java/org/apache/camel/component/jms/ test/java/org/apache/camel/component/jms/tx/ test/resources/org/apache/camel/component/jms/issues/ test/resources/org/apache/camel/compon...

Author: ningjiang
Date: Wed Nov 19 21:03:14 2008
New Revision: 719163

URL: http://svn.apache.org/viewvc?rev=719163&view=rev
Log:
CAMEL-959 only inject the TransactionManager into the MessageListenerContainer when transacted and transactedInOut are true

Added:
    activemq/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/MyActiveMQConsumer.java   (with props)
    activemq/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/NonTransactedInOutForJmsWithTxnMgrTest.java   (with props)
    activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/activemq.xml   (with props)
    activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/nonTxInOutJmsTest.xml   (with props)
Modified:
    activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsComponent.java
    activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsConfiguration.java
    activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/issues/TransactionErrorHandlerRedeliveryDelayTest-context.xml
    activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/AbstractTransactionTest.xml
    activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/JMSTransactionalClientTest.xml
    activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/TransactionErrorHandlerBuilderAsSpringBeanTest.xml

Modified: activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsComponent.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsComponent.java?rev=719163&r1=719162&r2=719163&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsComponent.java (original)
+++ activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsComponent.java Wed Nov 19 21:03:14 2008
@@ -126,6 +126,7 @@
         JmsConfiguration template = new JmsConfiguration(connectionFactory);
         template.setTransactionManager(transactionManager);
         template.setTransacted(true);
+        template.setTransactedInOut(true);
         return jmsComponent(template);
     }
 
@@ -383,7 +384,7 @@
 
         // lets make sure we copy the configuration as each endpoint can
         // customize its own version
-        JmsConfiguration newConfiguration = getConfiguration().copy();
+        JmsConfiguration newConfiguration = getConfiguration().copy();        
         JmsEndpoint endpoint;
         if (pubSubDomain) {
             if (tempDestination) {

Modified: activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsConfiguration.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsConfiguration.java?rev=719163&r1=719162&r2=719163&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsConfiguration.java (original)
+++ activemq/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsConfiguration.java Wed Nov 19 21:03:14 2008
@@ -33,6 +33,7 @@
 import org.apache.commons.logging.LogFactory;
 import org.springframework.core.task.TaskExecutor;
 import org.springframework.jms.JmsException;
+import org.springframework.jms.connection.JmsResourceHolder;
 import org.springframework.jms.core.JmsOperations;
 import org.springframework.jms.core.JmsTemplate;
 import org.springframework.jms.core.JmsTemplate102;
@@ -47,6 +48,7 @@
 import org.springframework.jms.support.converter.MessageConverter;
 import org.springframework.jms.support.destination.DestinationResolver;
 import org.springframework.transaction.PlatformTransactionManager;
+import org.springframework.transaction.support.TransactionSynchronizationManager;
 import org.springframework.util.Assert;
 
 import static org.apache.camel.util.ObjectHelper.removeStartingCharacters;
@@ -850,8 +852,8 @@
 
         container.setAcceptMessagesWhileStopping(acceptMessagesWhileStopping);
         container.setExposeListenerSession(exposeListenerSession);
-        container.setSessionTransacted(transacted);
-        if (transacted) {
+        container.setSessionTransacted(transacted && transactedInOut);
+        if (transacted && transactedInOut) {
             container.setSessionAcknowledgeMode(Session.SESSION_TRANSACTED);
         } else {
             if (acknowledgementMode >= 0) {
@@ -900,9 +902,9 @@
                 listenerContainer.setTaskExecutor(taskExecutor);
             }
             PlatformTransactionManager tm = getTransactionManager();
-            if (tm != null) {
+            if (tm != null && (transacted && transactedInOut)) {
                 listenerContainer.setTransactionManager(tm);
-            } else if (transacted) {
+            } else if (transacted && transactedInOut) {
                 throw new IllegalArgumentException("Property transacted is enabled but a transactionManager was not injected!");
             }
             if (transactionName != null) {

Added: activemq/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/MyActiveMQConsumer.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/MyActiveMQConsumer.java?rev=719163&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/MyActiveMQConsumer.java (added)
+++ activemq/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/MyActiveMQConsumer.java Wed Nov 19 21:03:14 2008
@@ -0,0 +1,89 @@
+/**
+ * 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.jms.tx;
+
+import javax.jms.Connection;
+import javax.jms.Destination;
+import javax.jms.JMSException;
+import javax.jms.MessageConsumer;
+import javax.jms.MessageProducer;
+import javax.jms.Session;
+import javax.jms.TextMessage;
+
+
+import org.apache.activemq.ActiveMQConnectionFactory;
+import org.apache.activemq.command.ActiveMQDestination;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
+public class MyActiveMQConsumer implements Runnable {
+    public static final String ACTIVEMQ_BROKER_URI = "failover:tcp://localhost:61616";
+    public static final String REQUEST_QUEUE = "request";
+    private static final transient Log LOG = LogFactory.getLog(MyActiveMQConsumer.class);
+    
+    private Connection connection;
+    
+    public MyActiveMQConsumer() throws JMSException {
+        ActiveMQConnectionFactory factory = new ActiveMQConnectionFactory(ACTIVEMQ_BROKER_URI);
+        connection = factory.createConnection();
+    }
+    
+    public void close() {
+        try {
+            connection.close();
+        } catch (JMSException e) {
+            LOG.info("Get the exception " + e + ", when close the JMS connection.");
+            
+        }
+    }
+
+    public void run() {
+        try {
+            Destination requestDestination = ActiveMQDestination
+                .createDestination(REQUEST_QUEUE, ActiveMQDestination.QUEUE_TYPE);
+
+            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+            MessageConsumer consumer = session.createConsumer(requestDestination);
+            connection.start();
+
+            int i = 0;
+
+            while (true) {
+                TextMessage msg = (TextMessage)consumer.receive(1000 * 100);
+                if (msg == null) {
+                    LOG.debug("Response timed out.");
+                } else {
+                    Destination replyDestination = msg.getJMSReplyTo();
+                    String correlationId = msg.getJMSCorrelationID();
+                    LOG.debug("replyDestination: " + replyDestination);
+                    MessageProducer sender = session.createProducer(replyDestination);
+                    LOG.debug("Request No. " + (++i));
+                    LOG.debug("msg: " + msg);
+                    TextMessage response = session.createTextMessage();
+                    response.setText("I was here: " + msg.getText());
+                    response.setJMSCorrelationID(correlationId);
+                    LOG.debug("reponse: " + response);
+                    sender.send(response);
+                }
+            }
+        } catch (JMSException exception) {
+            LOG.info("Get the exception [" + exception + "], stop receive message");
+        }
+        
+    }
+
+}

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

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

Added: activemq/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/NonTransactedInOutForJmsWithTxnMgrTest.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/NonTransactedInOutForJmsWithTxnMgrTest.java?rev=719163&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/NonTransactedInOutForJmsWithTxnMgrTest.java (added)
+++ activemq/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/NonTransactedInOutForJmsWithTxnMgrTest.java Wed Nov 19 21:03:14 2008
@@ -0,0 +1,75 @@
+/**
+ * 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.jms.tx;
+
+import org.apache.camel.CamelContext;
+import org.apache.camel.ContextTestSupport;
+import org.apache.camel.Exchange;
+import org.apache.camel.ExchangePattern;
+import org.apache.camel.Processor;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.spring.SpringCamelContext;
+import org.apache.camel.spring.SpringRouteBuilder;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.springframework.context.support.ClassPathXmlApplicationContext;
+
+public class NonTransactedInOutForJmsWithTxnMgrTest extends ContextTestSupport {
+    private static final transient Log LOG = LogFactory.getLog(NonTransactedInOutForJmsWithTxnMgrTest.class);
+    private MyActiveMQConsumer consumer;
+    
+    public void testJmsNonTransactedInOutWithTxnMgr() throws Exception {
+        for (int i = 0; i < 10; i++) {
+            String tmpStr = "<?xml version=\"1.0\" encoding=\"UTF-8\"?><aft>" + i + "</aft>";
+            Object reply = template.requestBody("activemq:mainStage", tmpStr);
+            assertTrue("Received a reply", reply.equals("I was here: " + tmpStr));
+            LOG.info("received reply: " + reply);
+        }
+    }
+
+    protected ClassPathXmlApplicationContext createApplicationContext() {
+        return new ClassPathXmlApplicationContext("org/apache/camel/component/jms/tx/nonTxInOutJmsTest.xml");
+    }
+
+    @Override
+    protected CamelContext createCamelContext() throws Exception {
+        return SpringCamelContext.springCamelContext(createApplicationContext());
+    }
+
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new SpringRouteBuilder() {
+            public void configure() throws Exception {
+                from("activemq:queue:mainStage?replyTo=queue:mainStage.reply").to("activemq:queue:request?replyTo=queue:request.reply");
+            }
+        };
+    }
+
+    protected void setUp() throws Exception {
+        super.setUp();
+        // start the jms consumer here
+        consumer = new MyActiveMQConsumer();
+        Thread thread = new Thread(consumer);
+        thread.start();
+    }
+    @Override
+    protected void tearDown() throws Exception {
+        log.debug("tearDown test: " + getName());
+        Thread.sleep(2000);
+        consumer.close();
+        super.tearDown();
+    }
+}

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

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

Modified: activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/issues/TransactionErrorHandlerRedeliveryDelayTest-context.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/issues/TransactionErrorHandlerRedeliveryDelayTest-context.xml?rev=719163&r1=719162&r2=719163&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/issues/TransactionErrorHandlerRedeliveryDelayTest-context.xml (original)
+++ activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/issues/TransactionErrorHandlerRedeliveryDelayTest-context.xml Wed Nov 19 21:03:14 2008
@@ -61,6 +61,7 @@
         <property name="connectionFactory" ref="jmsConnectionFactory"/>
         <property name="transactionManager" ref="jmsTransactionManager"/>
         <property name="transacted" value="true"/>
+        <property name="transactedInOut" value="true"/>
         <property name="concurrentConsumers" value="1"/>
     </bean>
 

Modified: activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/AbstractTransactionTest.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/AbstractTransactionTest.xml?rev=719163&r1=719162&r2=719163&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/AbstractTransactionTest.xml (original)
+++ activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/AbstractTransactionTest.xml Wed Nov 19 21:03:14 2008
@@ -41,6 +41,7 @@
         <property name="connectionFactory" ref="jmsConnectionFactory"/>
         <property name="transactionManager" ref="jmsTransactionManager"/>
         <property name="transacted" value="true"/>
+        <property name="transactedInOut" value="true"/>
         <property name="concurrentConsumers" value="1"/>
     </bean>
 
@@ -48,6 +49,7 @@
         <property name="connectionFactory" ref="jmsConnectionFactory-1"/>
         <property name="transactionManager" ref="jmsTransactionManager-1"/>
         <property name="transacted" value="true"/>
+        <property name="transactedInOut" value="true"/>
         <property name="concurrentConsumers" value="1"/>
     </bean>
 

Modified: activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/JMSTransactionalClientTest.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/JMSTransactionalClientTest.xml?rev=719163&r1=719162&r2=719163&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/JMSTransactionalClientTest.xml (original)
+++ activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/JMSTransactionalClientTest.xml Wed Nov 19 21:03:14 2008
@@ -55,6 +55,7 @@
         <property name="connectionFactory" ref="jmsConnectionFactory"/>
         <property name="transactionManager" ref="jmsTransactionManager"/>
         <property name="transacted" value="true"/>
+        <property name="transactedInOut" value="true"/>
         <property name="concurrentConsumers" value="1"/>
     </bean>
 

Modified: activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/TransactionErrorHandlerBuilderAsSpringBeanTest.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/TransactionErrorHandlerBuilderAsSpringBeanTest.xml?rev=719163&r1=719162&r2=719163&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/TransactionErrorHandlerBuilderAsSpringBeanTest.xml (original)
+++ activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/TransactionErrorHandlerBuilderAsSpringBeanTest.xml Wed Nov 19 21:03:14 2008
@@ -92,6 +92,7 @@
         <property name="connectionFactory" ref="jmsConnectionFactory"/>
         <property name="transactionManager" ref="jmsTransactionManager"/>
         <property name="transacted" value="true"/>
+        <property name="transactedInOut" value="true"/>
         <property name="concurrentConsumers" value="1"/>
     </bean>
 

Added: activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/activemq.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/activemq.xml?rev=719163&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/activemq.xml (added)
+++ activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/activemq.xml Wed Nov 19 21:03:14 2008
@@ -0,0 +1,33 @@
+<!--
+    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: example -->
+<beans
+  xmlns="http://www.springframework.org/schema/beans"
+  xmlns:broker="http://activemq.apache.org/schema/core"
+  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.5.xsd
+  http://activemq.apache.org/schema/core http://activemq.apache.org/schema/core/activemq-core-5.1.0.xsd">
+
+   <broker:broker id="broker" useJmx="false" persistent="false" dataDirectory="target/activemq">
+    <broker:transportConnectors>
+       <broker:transportConnector name="openwire" uri="tcp://localhost:61616"/>
+    </broker:transportConnectors>
+  </broker:broker>
+
+
+</beans>
+<!-- END SNIPPET: example -->

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

Propchange: activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/activemq.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/activemq.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Added: activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/nonTxInOutJmsTest.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/nonTxInOutJmsTest.xml?rev=719163&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/nonTxInOutJmsTest.xml (added)
+++ activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/nonTxInOutJmsTest.xml Wed Nov 19 21:03:14 2008
@@ -0,0 +1,28 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<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">
+
+    <import resource="classpath:org/apache/camel/component/jms/tx/activemq.xml" />
+    
+    <bean id="activemq" class="org.apache.camel.component.jms.JmsComponent">
+        <property name="configuration" ref="jmsConfig"/>
+    </bean>
+    
+    <bean id="jmsConfig" class="org.apache.camel.component.jms.JmsConfiguration">
+        <property name="connectionFactory" ref="jmsConnectionFactory"/>
+        <property name="transactionManager" ref="jmsTransactionManager"/>
+        <property name="transacted" value="true"/>
+        <property name="transactedInOut" value="false" />
+    </bean>
+    
+    <bean id="jmsConnectionFactory" class="org.apache.activemq.ActiveMQConnectionFactory">
+        <property name="brokerURL" value="tcp://localhost:61616"/>
+    </bean>
+
+    <bean id="jmsTransactionManager" class="org.springframework.jms.connection.JmsTransactionManager">
+        <property name="connectionFactory" ref="jmsConnectionFactory"/>
+    </bean>
+</beans>

Propchange: activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/nonTxInOutJmsTest.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/nonTxInOutJmsTest.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: activemq/camel/trunk/components/camel-jms/src/test/resources/org/apache/camel/component/jms/tx/nonTxInOutJmsTest.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml