Return-Path: Delivered-To: apmail-camel-commits-archive@www.apache.org Received: (qmail 31529 invoked from network); 25 Jul 2010 12:06:16 -0000 Received: from unknown (HELO mail.apache.org) (140.211.11.3) by 140.211.11.9 with SMTP; 25 Jul 2010 12:06:16 -0000 Received: (qmail 16997 invoked by uid 500); 25 Jul 2010 12:06:16 -0000 Delivered-To: apmail-camel-commits-archive@camel.apache.org Received: (qmail 16949 invoked by uid 500); 25 Jul 2010 12:06:15 -0000 Mailing-List: contact commits-help@camel.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@camel.apache.org Delivered-To: mailing list commits@camel.apache.org Received: (qmail 16942 invoked by uid 99); 25 Jul 2010 12:06:14 -0000 Received: from athena.apache.org (HELO athena.apache.org) (140.211.11.136) by apache.org (qpsmtpd/0.29) with ESMTP; Sun, 25 Jul 2010 12:06:14 +0000 X-ASF-Spam-Status: No, hits=-2000.0 required=10.0 tests=ALL_TRUSTED X-Spam-Check-By: apache.org Received: from [140.211.11.4] (HELO eris.apache.org) (140.211.11.4) by apache.org (qpsmtpd/0.29) with ESMTP; Sun, 25 Jul 2010 12:06:12 +0000 Received: by eris.apache.org (Postfix, from userid 65534) id D34072388903; Sun, 25 Jul 2010 12:05:19 +0000 (UTC) Content-Type: text/plain; charset="utf-8" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit Subject: svn commit: r979027 - in /camel/trunk/components/camel-jms: ./ src/main/java/org/apache/camel/component/jms/ src/test/java/org/apache/camel/component/jms/ Date: Sun, 25 Jul 2010 12:05:19 -0000 To: commits@camel.apache.org From: davsclaus@apache.org X-Mailer: svnmailer-1.0.8 Message-Id: <20100725120519.D34072388903@eris.apache.org> Author: davsclaus Date: Sun Jul 25 12:05:19 2010 New Revision: 979027 URL: http://svn.apache.org/viewvc?rev=979027&view=rev Log: CAMEL-2992: Removed support for JMS 1.0.2 api. Removed: camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsSimpleRequestReply102Test.java Modified: camel/trunk/components/camel-jms/pom.xml camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsComponent.java camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsConfiguration.java camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsEndpoint.java camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsProducer.java camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsComponentTest.java camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsEndpointConfigurationTest.java camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsRouteRequestReplyTest.java Modified: camel/trunk/components/camel-jms/pom.xml URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/pom.xml?rev=979027&r1=979026&r2=979027&view=diff ============================================================================== --- camel/trunk/components/camel-jms/pom.xml (original) +++ camel/trunk/components/camel-jms/pom.xml Sun Jul 25 12:05:19 2010 @@ -167,13 +167,6 @@ - - org.apache.maven.plugins maven-clean-plugin Modified: camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsComponent.java URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsComponent.java?rev=979027&r1=979026&r2=979027&view=diff ============================================================================== --- camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsComponent.java (original) +++ camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsComponent.java Sun Jul 25 12:05:19 2010 @@ -319,14 +319,6 @@ public class JmsComponent extends Defaul getConfiguration().setTransferException(transferException); } - /** - * @deprecated will be removed in Camel 2.2 - */ - @Deprecated - public void setUseVersion102(boolean useVersion102) { - getConfiguration().setUseVersion102(useVersion102); - } - public void setJmsOperations(JmsOperations jmsOperations) { getConfiguration().setJmsOperations(jmsOperations); } Modified: camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsConfiguration.java URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsConfiguration.java?rev=979027&r1=979026&r2=979027&view=diff ============================================================================== --- camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsConfiguration.java (original) +++ camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsConfiguration.java Sun Jul 25 12:05:19 2010 @@ -23,7 +23,6 @@ import javax.jms.JMSException; import javax.jms.Message; import javax.jms.MessageProducer; import javax.jms.Session; -import javax.jms.TopicPublisher; import org.apache.camel.RuntimeCamelException; import org.apache.camel.util.ObjectHelper; @@ -35,14 +34,11 @@ import org.springframework.jms.JmsExcept import org.springframework.jms.connection.JmsTransactionManager; import org.springframework.jms.core.JmsOperations; import org.springframework.jms.core.JmsTemplate; -import org.springframework.jms.core.JmsTemplate102; import org.springframework.jms.core.MessageCreator; import org.springframework.jms.core.SessionCallback; import org.springframework.jms.listener.AbstractMessageListenerContainer; import org.springframework.jms.listener.DefaultMessageListenerContainer; -import org.springframework.jms.listener.DefaultMessageListenerContainer102; import org.springframework.jms.listener.SimpleMessageListenerContainer; -import org.springframework.jms.listener.SimpleMessageListenerContainer102; import org.springframework.jms.support.JmsUtils; import org.springframework.jms.support.converter.MessageConverter; import org.springframework.jms.support.destination.DestinationResolver; @@ -61,14 +57,6 @@ public class JmsConfiguration implements public static final String TEMP_QUEUE_PREFIX = "temp:queue:"; public static final String TEMP_TOPIC_PREFIX = "temp:topic:"; - protected static final String TRANSACTED = "TRANSACTED"; - protected static final String CLIENT_ACKNOWLEDGE = "CLIENT_ACKNOWLEDGE"; - protected static final String AUTO_ACKNOWLEDGE = "AUTO_ACKNOWLEDGE"; - protected static final String DUPS_OK_ACKNOWLEDGE = "DUPS_OK_ACKNOWLEDGE"; - protected static final String REPLYTO_TEMP_DEST_AFFINITY_PER_COMPONENT = "component"; - protected static final String REPLYTO_TEMP_DEST_AFFINITY_PER_ENDPOINT = "endpoint"; - protected static final String REPLYTO_TEMP_DEST_AFFINITY_PER_PRODUCER = "producer"; - private static final transient Log LOG = LogFactory.getLog(JmsConfiguration.class); private JmsOperations jmsOperations; private DestinationResolver destinationResolver; @@ -98,7 +86,6 @@ public class JmsConfiguration implements private int idleTaskExecutionLimit = 1; private int maxConcurrentConsumers = 1; // JmsTemplate only - private boolean useVersion102; private Boolean explicitQosEnabled; private boolean deliveryPersistent = true; private boolean replyToDeliveryPersistent = true; @@ -116,7 +103,6 @@ public class JmsConfiguration implements private String transactionName; private int transactionTimeout = -1; private boolean preserveMessageQos; - private long requestMapPurgePollTimeMillis = 1000L; private boolean disableReplyTo; private boolean eagerLoadingOfProperties; // Always make a JMS message copy when it's passed to Producer @@ -274,139 +260,6 @@ public class JmsConfiguration implements } } - /** - * @deprecated will be removed in the future - */ - @Deprecated - public static class CamelJmsTemplate102 extends JmsTemplate102 { - private JmsConfiguration config; - - public CamelJmsTemplate102(JmsConfiguration config, ConnectionFactory connectionFactory, boolean pubSubDomain) { - super(connectionFactory, pubSubDomain); - this.config = config; - } - - public void send(final String destinationName, - final MessageCreator messageCreator, - final MessageSentCallback callback) throws JmsException { - execute(new SessionCallback() { - public Object doInJms(Session session) throws JMSException { - Destination destination = resolveDestinationName(session, destinationName); - return doSendToDestination(destination, messageCreator, callback, session); - } - }, false); - } - - public void send(final Destination destination, - final MessageCreator messageCreator, - final MessageSentCallback callback) throws JmsException { - execute(new SessionCallback() { - public Object doInJms(Session session) throws JMSException { - return doSendToDestination(destination, messageCreator, callback, session); - } - }, false); - } - - public void send(final String destinationName, - final MessageCreator messageCreator) throws JmsException { - execute(new SessionCallback() { - public Object doInJms(Session session) throws JMSException { - Destination destination = resolveDestinationName(session, destinationName); - return doSendToDestination(destination, messageCreator, null, session); - } - }, false); - } - - public void send(final Destination destination, - final MessageCreator messageCreator) throws JmsException { - execute(new SessionCallback() { - public Object doInJms(Session session) throws JMSException { - return doSendToDestination(destination, messageCreator, null, session); - } - }, false); - } - - private Object doSendToDestination(final Destination destination, - final MessageCreator messageCreator, - final MessageSentCallback callback, - final Session session) throws JMSException { - Assert.notNull(messageCreator, "MessageCreator must not be null"); - MessageProducer producer = createProducer(session, destination); - Message message = null; - try { - message = messageCreator.createMessage(session); - if (logger.isDebugEnabled()) { - logger.debug("Sending JMS message to: " + producer.getDestination() + " with message: " + message); - } - doSend(producer, message); - if (message != null && callback != null) { - callback.sent(message, destination); - } - // Check commit - avoid commit call within a JTA transaction. - if (session.getTransacted() && isSessionLocallyTransacted(session)) { - // Transacted session created by this template -> commit. - JmsUtils.commitIfNecessary(session); - } - } finally { - JmsUtils.closeMessageProducer(producer); - } - return null; - } - - /** - * Override so we can support preserving the Qos settings that have - * been set on the message. - */ - @Override - protected void doSend(MessageProducer producer, Message message) throws JMSException { - if (config.isPreserveMessageQos()) { - long ttl = message.getJMSExpiration(); - if (ttl != 0) { - ttl = ttl - System.currentTimeMillis(); - // Message had expired.. so set the ttl as small as possible - if (ttl <= 0) { - ttl = 1; - } - } - - int priority = message.getJMSPriority(); - if (priority <= 0) { - // use priority from endpoint if not provided on message - priority = this.getPriority(); - } - - // if a delivery mode was set as a JMS header then we have used a temporary - // property to store it - CamelJMSDeliveryMode. Otherwise we could not keep - // track whether it was set or not as getJMSDeliveryMode() will default return 1 regardless - // if it was set or not, so we can never tell if end user provided it in a header - int deliveryMode; - if (JmsMessageHelper.hasProperty(message, JmsConstants.JMS_DELIVERY_MODE)) { - deliveryMode = message.getIntProperty(JmsConstants.JMS_DELIVERY_MODE); - // remove the temporary property - JmsMessageHelper.removeJmsProperty(message, JmsConstants.JMS_DELIVERY_MODE); - } else { - deliveryMode = this.getDeliveryMode(); - } - - // need to log just before so the message is 100% correct when logged - if (logger.isDebugEnabled()) { - logger.debug("Sending JMS message to: " + producer.getDestination() + " with message: " + message); - } - if (isPubSubDomain()) { - ((TopicPublisher) producer).publish(message, deliveryMode, priority, ttl); - } else { - producer.send(message, deliveryMode, priority, ttl); - } - } else { - // need to log just before so the message is 100% correct when logged - if (logger.isDebugEnabled()) { - logger.debug("Sending JMS message to: " + producer.getDestination() + " with message: " + message); - } - super.doSend(producer, message); - } - } - } - /** * Creates a {@link JmsOperations} object used for request/response using a request timeout value @@ -441,16 +294,12 @@ public class JmsConfiguration implements * Creates a {@link JmsOperations} object used for one way messaging */ public JmsOperations createInOnlyTemplate(JmsEndpoint endpoint, boolean pubSubDomain, String destination) { - if (jmsOperations != null) { return jmsOperations; } ConnectionFactory factory = getTemplateConnectionFactory(); - - JmsTemplate template = useVersion102 - ? new CamelJmsTemplate102(this, factory, pubSubDomain) - : new CamelJmsTemplate(this, factory); + JmsTemplate template = new CamelJmsTemplate(this, factory); template.setPubSubDomain(pubSubDomain); if (destinationResolver != null) { @@ -561,22 +410,6 @@ public class JmsConfiguration implements this.templateConnectionFactory = templateConnectionFactory; } - /** - * @deprecated will be removed in the future - */ - @Deprecated - public boolean isUseVersion102() { - return useVersion102; - } - - /** - * @deprecated will be removed in the future - */ - @Deprecated - public void setUseVersion102(boolean useVersion102) { - this.useVersion102 = useVersion102; - } - public boolean isAutoStartup() { return autoStartup; } @@ -929,18 +762,6 @@ public class JmsConfiguration implements this.destinationResolver = destinationResolver; } - public long getRequestMapPurgePollTimeMillis() { - return requestMapPurgePollTimeMillis; - } - - /** - * Sets the frequency that the requestMap for InOut exchanges is purged for - * timed out message exchanges - */ - public void setRequestMapPurgePollTimeMillis(long requestMapPurgePollTimeMillis) { - this.requestMapPurgePollTimeMillis = requestMapPurgePollTimeMillis; - } - public JmsProviderMetadata getProviderMetadata() { return providerMetadata; } @@ -1112,14 +933,11 @@ public class JmsConfiguration implements } public AbstractMessageListenerContainer chooseMessageListenerContainerImplementation() { - // TODO we could allow a spring container to auto-inject these objects? switch (consumerType) { case Simple: - return isUseVersion102() - ? new SimpleMessageListenerContainer102() : new SimpleMessageListenerContainer(); + return new SimpleMessageListenerContainer(); case Default: - return isUseVersion102() - ? new DefaultMessageListenerContainer102() : new DefaultMessageListenerContainer(); + return new DefaultMessageListenerContainer(); default: throw new IllegalArgumentException("Unknown consumer type: " + consumerType); } @@ -1136,7 +954,7 @@ public class JmsConfiguration implements * created and destroyed per message). * * @param endpoint the endpoint - * @return the cacne level + * @return the cache level */ protected int defaultCacheLevel(JmsEndpoint endpoint) { // if we are on a new enough spring version we can assume CACHE_CONSUMER Modified: camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsEndpoint.java URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsEndpoint.java?rev=979027&r1=979026&r2=979027&view=diff ============================================================================== --- camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsEndpoint.java (original) +++ camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsEndpoint.java Sun Jul 25 12:05:19 2010 @@ -500,10 +500,6 @@ public class JmsEndpoint extends Default return getConfiguration().getReplyToDestinationSelectorName(); } - public long getRequestMapPurgePollTimeMillis() { - return getConfiguration().getRequestMapPurgePollTimeMillis(); - } - @ManagedAttribute public long getRequestTimeout() { return getConfiguration().getRequestTimeout(); @@ -621,14 +617,6 @@ public class JmsEndpoint extends Default return getConfiguration().isUseMessageIDAsCorrelationID(); } - /** - * @deprecated will be removed in Camel 2.2 - */ - @Deprecated - public boolean isUseVersion102() { - return getConfiguration().isUseVersion102(); - } - @ManagedAttribute public void setAcceptMessagesWhileStopping(boolean acceptMessagesWhileStopping) { getConfiguration().setAcceptMessagesWhileStopping(acceptMessagesWhileStopping); @@ -805,10 +793,6 @@ public class JmsEndpoint extends Default getConfiguration().setReplyToDestinationSelectorName(replyToDestinationSelectorName); } - public void setRequestMapPurgePollTimeMillis(long requestMapPurgePollTimeMillis) { - getConfiguration().setRequestMapPurgePollTimeMillis(requestMapPurgePollTimeMillis); - } - @ManagedAttribute public void setRequestTimeout(long requestTimeout) { getConfiguration().setRequestTimeout(requestTimeout); @@ -861,14 +845,6 @@ public class JmsEndpoint extends Default getConfiguration().setUseMessageIDAsCorrelationID(useMessageIDAsCorrelationID); } - /** - * @deprecated will be removed in Camel 2.2 - */ - @Deprecated - public void setUseVersion102(boolean useVersion102) { - getConfiguration().setUseVersion102(useVersion102); - } - public JmsMessageType getJmsMessageType() { return getConfiguration().getJmsMessageType(); } Modified: camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsProducer.java URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsProducer.java?rev=979027&r1=979026&r2=979027&view=diff ============================================================================== --- camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsProducer.java (original) +++ camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsProducer.java Sun Jul 25 12:05:19 2010 @@ -27,7 +27,6 @@ import org.apache.camel.Exchange; import org.apache.camel.FailedToCreateProducerException; import org.apache.camel.RuntimeExchangeException; import org.apache.camel.component.jms.JmsConfiguration.CamelJmsTemplate; -import org.apache.camel.component.jms.JmsConfiguration.CamelJmsTemplate102; import org.apache.camel.component.jms.reply.ReplyManager; import org.apache.camel.component.jms.reply.UseMessageIdAsCorrelationIdMessageSentCallback; import org.apache.camel.impl.DefaultAsyncProducer; @@ -257,17 +256,10 @@ public class JmsProducer extends Default protected void doSend(boolean inOut, String destinationName, Destination destination, MessageCreator messageCreator, MessageSentCallback callback) { - CamelJmsTemplate template = null; - CamelJmsTemplate102 template102 = null; - if (endpoint.isUseVersion102()) { - template102 = (JmsConfiguration.CamelJmsTemplate102) (inOut ? getInOutTemplate() : getInOnlyTemplate()); - } else { - template = (CamelJmsTemplate) (inOut ? getInOutTemplate() : getInOnlyTemplate()); - } + CamelJmsTemplate template = (CamelJmsTemplate) (inOut ? getInOutTemplate() : getInOnlyTemplate()); if (LOG.isTraceEnabled()) { - LOG.trace("Using " + (inOut ? "inOut" : "inOnly") + " jms template to send with API " - + (endpoint.isUseVersion102() ? "v1.0.2" : "v1.1")); + LOG.trace("Using " + (inOut ? "inOut" : "inOnly") + " jms template"); } // destination should be preferred @@ -275,28 +267,20 @@ public class JmsProducer extends Default if (inOut) { if (template != null) { template.send(destination, messageCreator, callback); - } else if (template102 != null) { - template102.send(destination, messageCreator, callback); } } else { if (template != null) { template.send(destination, messageCreator); - } else if (template102 != null) { - template102.send(destination, messageCreator); } } } else if (destinationName != null) { if (inOut) { if (template != null) { template.send(destinationName, messageCreator, callback); - } else if (template102 != null) { - template102.send(destinationName, messageCreator, callback); } } else { if (template != null) { template.send(destinationName, messageCreator); - } else if (template102 != null) { - template102.send(destinationName, messageCreator); } } } else { Modified: camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsComponentTest.java URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsComponentTest.java?rev=979027&r1=979026&r2=979027&view=diff ============================================================================== --- camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsComponentTest.java (original) +++ camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsComponentTest.java Sun Jul 25 12:05:19 2010 @@ -57,7 +57,6 @@ public class JmsComponentTest extends Ca assertEquals(3000, endpoint.getTimeToLive()); assertEquals(true, endpoint.isTransacted()); assertEquals(15000, endpoint.getTransactionTimeout()); - assertEquals(false, endpoint.isUseVersion102()); } protected CamelContext createCamelContext() throws Exception { @@ -85,7 +84,6 @@ public class JmsComponentTest extends Ca comp.setTimeToLive(3000); comp.setTransacted(true); comp.setTransactionTimeout(15000); - comp.setUseVersion102(false); camelContext.addComponent(componentName, comp); Modified: camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsEndpointConfigurationTest.java URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsEndpointConfigurationTest.java?rev=979027&r1=979026&r2=979027&view=diff ============================================================================== --- camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsEndpointConfigurationTest.java (original) +++ camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsEndpointConfigurationTest.java Sun Jul 25 12:05:19 2010 @@ -205,7 +205,6 @@ public class JmsEndpointConfigurationTes assertNotNull(endpoint.getRecoveryInterval()); assertNull(endpoint.getReplyTo()); assertNull(endpoint.getReplyToDestinationSelectorName()); - assertEquals(1000, endpoint.getRequestMapPurgePollTimeMillis()); assertEquals(20000, endpoint.getRequestTimeout()); assertNull(endpoint.getSelector()); assertEquals(-1, endpoint.getTimeToLive()); @@ -231,7 +230,6 @@ public class JmsEndpointConfigurationTes assertEquals(false, endpoint.isPubSubNoLocal()); assertEquals(true, endpoint.isReplyToDeliveryPersistent()); assertEquals(false, endpoint.isUseMessageIDAsCorrelationID()); - assertEquals(false, endpoint.isUseVersion102()); assertEquals(true, endpoint.isSingleton()); assertEquals(false, endpoint.isSubscriptionDurable()); assertEquals(false, endpoint.isTransacted()); @@ -341,9 +339,6 @@ public class JmsEndpointConfigurationTes endpoint.setReplyToDestinationSelectorName("me"); assertEquals("me", endpoint.getReplyToDestinationSelectorName()); - endpoint.setRequestMapPurgePollTimeMillis(2000); - assertEquals(2000, endpoint.getRequestMapPurgePollTimeMillis()); - endpoint.setRequestTimeout(3000); assertEquals(3000, endpoint.getRequestTimeout()); @@ -367,9 +362,6 @@ public class JmsEndpointConfigurationTes endpoint.setJmsMessageType(JmsMessageType.Text); assertEquals(JmsMessageType.Text, endpoint.getJmsMessageType()); - - endpoint.setUseVersion102(true); - assertEquals(true, endpoint.isUseVersion102()); } protected void assertCacheLevel(JmsEndpoint endpoint, int expected) throws Exception { Modified: camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsRouteRequestReplyTest.java URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsRouteRequestReplyTest.java?rev=979027&r1=979026&r2=979027&view=diff ============================================================================== --- camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsRouteRequestReplyTest.java (original) +++ camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/JmsRouteRequestReplyTest.java Sun Jul 25 12:05:19 2010 @@ -309,28 +309,27 @@ public class JmsRouteRequestReplyTest ex Thread.sleep(1000); } - public void xxxtestUseMessageIDAsCorrelationID() throws Exception { + public void testUseMessageIDAsCorrelationID() throws Exception { runRequestReplyThreaded(endpointUriA); } - public void xxxtestUseCorrelationID() throws Exception { + public void testUseCorrelationID() throws Exception { runRequestReplyThreaded(endpointUriA); } - public void xxxtestUseMessageIDAsCorrelationIDMultiNode() throws Exception { + public void testUseMessageIDAsCorrelationIDMultiNode() throws Exception { runRequestReplyThreaded(endpointUriA); } - public void xxxtestUseCorrelationIDMultiNode() throws Exception { + public void testUseCorrelationIDMultiNode() throws Exception { runRequestReplyThreaded(endpointUriA); } - // TODO: A bit tricky test public void testUseMessageIDAsCorrelationIDPersistReplyToMultiNode() throws Exception { runRequestReplyThreaded(endpointReplyToUriA); } - public void xxxtestUseCorrelationIDPersistReplyToMultiNode() throws Exception { + public void testUseCorrelationIDPersistReplyToMultiNode() throws Exception { runRequestReplyThreaded(endpointUriA); } @@ -342,7 +341,7 @@ public class JmsRouteRequestReplyTest ex // for a faster way to do this. Note however that in this case the message copy has to occur // between consumer -> producer as the selector value needs to be propagated to the ultimate // destination, which in turn will copy this value back into the reply message - public void xxxtestUseMessageIDAsCorrelationIDPersistMultiReplyToMultiNode() throws Exception { + public void testUseMessageIDAsCorrelationIDPersistMultiReplyToMultiNode() throws Exception { int oldMaxTasks = maxTasks; int oldMaxServerTasks = maxServerTasks; int oldMaxCalls = maxCalls; @@ -361,7 +360,7 @@ public class JmsRouteRequestReplyTest ex } // see (1) - public void xxxtestUseCorrelationIDPersistMultiReplyToMultiNode() throws Exception { + public void testUseCorrelationIDPersistMultiReplyToMultiNode() throws Exception { int oldMaxTasks = maxTasks; int oldMaxServerTasks = maxServerTasks; int oldMaxCalls = maxCalls; @@ -379,18 +378,17 @@ public class JmsRouteRequestReplyTest ex } } - public void xxxtestUseMessageIDAsCorrelationIDPersistMultiReplyToWithNamedSelectorMultiNode() throws Exception { + public void testUseMessageIDAsCorrelationIDPersistMultiReplyToWithNamedSelectorMultiNode() throws Exception { runRequestReplyThreaded(endpointUriA); } - public void xxxtestUseCorrelationIDPersistMultiReplyToWithNamedSelectorMultiNode() throws Exception { + public void testUseCorrelationIDPersistMultiReplyToWithNamedSelectorMultiNode() throws Exception { runRequestReplyThreaded(endpointUriA); } - public void xxxtestUseCorrelationIDTimeout() throws Exception { + public void testUseCorrelationIDTimeout() throws Exception { JmsComponent c = (JmsComponent)context.getComponent(componentName); c.getConfiguration().setRequestTimeout(1000); - c.getConfiguration().setRequestMapPurgePollTimeMillis(1000); Object reply = ""; try { @@ -402,10 +400,9 @@ public class JmsRouteRequestReplyTest ex assertEquals("", reply); } - public void xxxtestUseMessageIDAsCorrelationIDTimeout() throws Exception { + public void testUseMessageIDAsCorrelationIDTimeout() throws Exception { JmsComponent c = (JmsComponent)context.getComponent(componentName); c.getConfiguration().setRequestTimeout(1000); - c.getConfiguration().setRequestMapPurgePollTimeMillis(1000); Object reply = ""; try { @@ -417,11 +414,11 @@ public class JmsRouteRequestReplyTest ex assertEquals("", reply); } - public void xxxtestUseCorrelationIDMultiNodeDiffComponents() throws Exception { + public void testUseCorrelationIDMultiNodeDiffComponents() throws Exception { runRequestReplyThreaded(endpointUriA); } - public void xxxtestUseMessageIDAsCorrelationIDMultiNodeDiffComponents() throws Exception { + public void testUseMessageIDAsCorrelationIDMultiNodeDiffComponents() throws Exception { runRequestReplyThreaded(endpointUriA); }