You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ro...@apache.org on 2014/10/20 13:09:48 UTC

[1/4] git commit: fix typo that got c&p across everything

Repository: qpid-jms
Updated Branches:
  refs/heads/master 375b05503 -> ace7dc392


fix typo that got c&p across everything


Project: http://git-wip-us.apache.org/repos/asf/qpid-jms/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-jms/commit/f2cd19e4
Tree: http://git-wip-us.apache.org/repos/asf/qpid-jms/tree/f2cd19e4
Diff: http://git-wip-us.apache.org/repos/asf/qpid-jms/diff/f2cd19e4

Branch: refs/heads/master
Commit: f2cd19e49793bd5a63f09eb5ff8ec0c8c64baea3
Parents: 375b055
Author: Robert Gemmell <ro...@apache.org>
Authored: Mon Oct 20 09:47:36 2014 +0100
Committer: Robert Gemmell <ro...@apache.org>
Committed: Mon Oct 20 09:51:22 2014 +0100

----------------------------------------------------------------------
 .../org/apache/qpid/jms/provider/amqp/AmqpConnection.java |  4 ++--
 .../org/apache/qpid/jms/provider/amqp/AmqpProvider.java   | 10 +++++-----
 .../jms/provider/amqp/message/AmqpJmsMessageFacade.java   |  4 ++--
 .../qpid/jms/integration/MessageIntegrationTest.java      |  4 ++--
 4 files changed, 11 insertions(+), 11 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/f2cd19e4/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnection.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnection.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnection.java
index 052a893..0ef8835 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnection.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnection.java
@@ -287,8 +287,8 @@ public class AmqpConnection extends AmqpAbstractResource<JmsConnectionInfo, Conn
      * @return true if the provider has been configured to use byte values for
      * destination type annotations.
      */
-    public boolean isUseByteDestintionTypeAnnotation() {
-        return provider.isUseByteDestintionTypeAnnotation();
+    public boolean isUseByteDestinationTypeAnnotation() {
+        return provider.isUseByteDestinationTypeAnnotation();
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/f2cd19e4/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpProvider.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpProvider.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpProvider.java
index a36a308..6573d26 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpProvider.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpProvider.java
@@ -88,7 +88,7 @@ public class AmqpProvider extends AbstractProvider implements TransportListener
     private boolean traceBytes;
     private boolean presettleConsumers;
     private boolean presettleProducers;
-    private boolean useByteDestintionTypeAnnotation = false;//TODO: enable
+    private boolean useByteDestinationTypeAnnotation = false; //TODO: enable
     private long connectTimeout = JmsConnectionInfo.DEFAULT_CONNECT_TIMEOUT;
     private long closeTimeout = JmsConnectionInfo.DEFAULT_CLOSE_TIMEOUT;
     private long requestTimeout = JmsConnectionInfo.DEFAULT_REQUEST_TIMEOUT;
@@ -824,12 +824,12 @@ public class AmqpProvider extends AbstractProvider implements TransportListener
         this.presettleProducers = presettle;
     }
 
-    public void setUseByteDestintionTypeAnnotation(boolean useByteDestintionTypeAnnotation) {
-        this.useByteDestintionTypeAnnotation = useByteDestintionTypeAnnotation;
+    public void setUseByteDestinationTypeAnnotation(boolean useByteDestinationTypeAnnotation) {
+        this.useByteDestinationTypeAnnotation = useByteDestinationTypeAnnotation;
     }
 
-    public boolean isUseByteDestintionTypeAnnotation() {
-        return useByteDestintionTypeAnnotation;
+    public boolean isUseByteDestinationTypeAnnotation() {
+        return useByteDestinationTypeAnnotation;
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/f2cd19e4/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessageFacade.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessageFacade.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessageFacade.java
index b65a1da..5a75ede 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessageFacade.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessageFacade.java
@@ -655,7 +655,7 @@ public class AmqpJmsMessageFacade implements JmsMessageFacade {
     public void setDestination(JmsDestination destination) {
         this.destination = destination;
         lazyCreateMessageAnnotations();
-        AmqpDestinationHelper.INSTANCE.setToAddressFromDestination(this, destination, connection.isUseByteDestintionTypeAnnotation());
+        AmqpDestinationHelper.INSTANCE.setToAddressFromDestination(this, destination, connection.isUseByteDestinationTypeAnnotation());
     }
 
     @Override
@@ -676,7 +676,7 @@ public class AmqpJmsMessageFacade implements JmsMessageFacade {
     public void setReplyTo(JmsDestination replyTo) {
         this.replyTo = replyTo;
         lazyCreateMessageAnnotations();
-        AmqpDestinationHelper.INSTANCE.setReplyToAddressFromDestination(this, replyTo, connection.isUseByteDestintionTypeAnnotation());
+        AmqpDestinationHelper.INSTANCE.setReplyToAddressFromDestination(this, replyTo, connection.isUseByteDestinationTypeAnnotation());
     }
 
     @Override

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/f2cd19e4/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
index 45c257a..b70f8d6 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
@@ -364,7 +364,7 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     public void testSentMessageContainsToTypeAnnotationStringIfConfigured() throws Exception {
         try (TestAmqpPeer testPeer = new TestAmqpPeer(IntegrationTestFixture.PORT);) {
             // Enable the old string destination type annotation values
-            Connection connection = testFixture.establishConnecton(testPeer, "?provider.useByteDestintionTypeAnnotation=false");
+            Connection connection = testFixture.establishConnecton(testPeer, "?provider.useByteDestinationTypeAnnotation=false");
 
             testPeer.expectBegin(true);
             testPeer.expectSenderAttach();
@@ -404,7 +404,7 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     public void testSentMessageContainsReplyToTypeAnnotationStringIfConfigured() throws Exception {
         try (TestAmqpPeer testPeer = new TestAmqpPeer(IntegrationTestFixture.PORT);) {
             // Enable the old string destination type annotation values
-            Connection connection = testFixture.establishConnecton(testPeer, "?provider.useByteDestintionTypeAnnotation=false");
+            Connection connection = testFixture.establishConnecton(testPeer, "?provider.useByteDestinationTypeAnnotation=false");
 
             testPeer.expectBegin(true);
             testPeer.expectSenderAttach();


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@qpid.apache.org
For additional commands, e-mail: commits-help@qpid.apache.org


[2/4] git commit: remove unused import

Posted by ro...@apache.org.
remove unused import


Project: http://git-wip-us.apache.org/repos/asf/qpid-jms/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-jms/commit/473e8814
Tree: http://git-wip-us.apache.org/repos/asf/qpid-jms/tree/473e8814
Diff: http://git-wip-us.apache.org/repos/asf/qpid-jms/diff/473e8814

Branch: refs/heads/master
Commit: 473e88148b91e28cbf960b5493bfecdaa07039cb
Parents: f2cd19e
Author: Robert Gemmell <ro...@apache.org>
Authored: Mon Oct 20 10:33:21 2014 +0100
Committer: Robert Gemmell <ro...@apache.org>
Committed: Mon Oct 20 10:33:21 2014 +0100

----------------------------------------------------------------------
 .../org/apache/qpid/jms/transactions/JmsTransactedConsumerTest.java | 1 -
 1 file changed, 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/473e8814/qpid-jms-interop-tests/qpid-jms-activemq-tests/src/test/java/org/apache/qpid/jms/transactions/JmsTransactedConsumerTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-interop-tests/qpid-jms-activemq-tests/src/test/java/org/apache/qpid/jms/transactions/JmsTransactedConsumerTest.java b/qpid-jms-interop-tests/qpid-jms-activemq-tests/src/test/java/org/apache/qpid/jms/transactions/JmsTransactedConsumerTest.java
index fdc3c3a..49121ad 100644
--- a/qpid-jms-interop-tests/qpid-jms-activemq-tests/src/test/java/org/apache/qpid/jms/transactions/JmsTransactedConsumerTest.java
+++ b/qpid-jms-interop-tests/qpid-jms-activemq-tests/src/test/java/org/apache/qpid/jms/transactions/JmsTransactedConsumerTest.java
@@ -28,7 +28,6 @@ import javax.jms.TextMessage;
 
 import org.apache.activemq.broker.jmx.QueueViewMBean;
 import org.apache.qpid.jms.support.AmqpTestSupport;
-import org.junit.Ignore;
 import org.junit.Test;
 
 /**


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@qpid.apache.org
For additional commands, e-mail: commits-help@qpid.apache.org


[4/4] git commit: enable sending byte value for destination type annotations

Posted by ro...@apache.org.
enable sending byte value for destination type annotations


Project: http://git-wip-us.apache.org/repos/asf/qpid-jms/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-jms/commit/ace7dc39
Tree: http://git-wip-us.apache.org/repos/asf/qpid-jms/tree/ace7dc39
Diff: http://git-wip-us.apache.org/repos/asf/qpid-jms/diff/ace7dc39

Branch: refs/heads/master
Commit: ace7dc392fdf978c0efa0c1918b3c0033e9f66b7
Parents: 03d3ff3
Author: Robert Gemmell <ro...@apache.org>
Authored: Mon Oct 20 11:27:27 2014 +0100
Committer: Robert Gemmell <ro...@apache.org>
Committed: Mon Oct 20 11:27:49 2014 +0100

----------------------------------------------------------------------
 .../qpid/jms/provider/amqp/AmqpConnection.java  |  5 ++++
 .../provider/amqp/AmqpConnectionProperties.java |  3 +++
 .../qpid/jms/provider/amqp/AmqpProvider.java    |  2 +-
 .../amqp/message/AmqpMessageSupport.java        | 25 --------------------
 .../jms/integration/MessageIntegrationTest.java |  6 ++---
 5 files changed, 11 insertions(+), 30 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/ace7dc39/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnection.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnection.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnection.java
index 0ef8835..448556a 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnection.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnection.java
@@ -30,6 +30,7 @@ import org.apache.qpid.jms.meta.JmsSessionInfo;
 import org.apache.qpid.jms.provider.AsyncResult;
 import org.apache.qpid.jms.provider.amqp.message.AmqpJmsMessageFactory;
 import org.apache.qpid.jms.util.IOExceptionSupport;
+import org.apache.qpid.proton.amqp.Symbol;
 import org.apache.qpid.proton.engine.Connection;
 import org.apache.qpid.proton.engine.EndpointState;
 import org.apache.qpid.proton.engine.Sasl;
@@ -63,6 +64,10 @@ public class AmqpConnection extends AmqpAbstractResource<JmsConnectionInfo, Conn
     public AmqpConnection(AmqpProvider provider, Connection protonConnection, Sasl sasl, JmsConnectionInfo info) {
         super(info, protonConnection);
 
+        Map<Symbol, Object> properties = new HashMap<>();
+        properties.put(AmqpConnectionProperties.JMS_MAPPING_VERSION_KEY, AmqpConnectionProperties.JMS_MAPPING_VERSION_VALUE);
+        protonConnection.setProperties(properties);
+
         this.provider = provider;
         this.remoteURI = provider.getRemoteURI();
         this.amqpMessageFactory = new AmqpJmsMessageFactory(this);

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/ace7dc39/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnectionProperties.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnectionProperties.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnectionProperties.java
index add4d72..9708bda 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnectionProperties.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConnectionProperties.java
@@ -27,6 +27,9 @@ import org.apache.qpid.proton.amqp.Symbol;
  */
 public class AmqpConnectionProperties {
 
+    public static final Symbol JMS_MAPPING_VERSION_KEY = Symbol.valueOf("x-opt-jms-mapping-version");
+    public static final short JMS_MAPPING_VERSION_VALUE = 0;
+
     private static final Symbol ANONYMOUS_RELAY = Symbol.valueOf("x-opt-anonymous-relay");
 
     private String anonymousRelayName;

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/ace7dc39/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpProvider.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpProvider.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpProvider.java
index 6573d26..4766bf0 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpProvider.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpProvider.java
@@ -88,7 +88,7 @@ public class AmqpProvider extends AbstractProvider implements TransportListener
     private boolean traceBytes;
     private boolean presettleConsumers;
     private boolean presettleProducers;
-    private boolean useByteDestinationTypeAnnotation = false; //TODO: enable
+    private boolean useByteDestinationTypeAnnotation = true;
     private long connectTimeout = JmsConnectionInfo.DEFAULT_CONNECT_TIMEOUT;
     private long closeTimeout = JmsConnectionInfo.DEFAULT_CLOSE_TIMEOUT;
     private long requestTimeout = JmsConnectionInfo.DEFAULT_REQUEST_TIMEOUT;

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/ace7dc39/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpMessageSupport.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpMessageSupport.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpMessageSupport.java
index 2d9c6f7..92f4617 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpMessageSupport.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpMessageSupport.java
@@ -44,31 +44,6 @@ public final class AmqpMessageSupport {
     public static final String AMQP_REPLY_TO_ANNOTATION = "x-opt-reply-type";
 
     /**
-     * Attribute used to mark a destination as temporary.
-     */
-    public static final String TEMPORARY_ATTRIBUTE = "temporary";
-
-    /**
-     * Attribute used to mark a destination as being a Queue type.
-     */
-    public static final String QUEUE_ATTRIBUTES = "queue";
-
-    /**
-     * Attribute used to mark a destination as being a Topic type.
-     */
-    public static final String TOPIC_ATTRIBUTES = "topic";
-
-    /**
-     * Convenience value used to mark a destination as a Temporary Queue.
-     */
-    public static final String TEMP_QUEUE_ATTRIBUTES = TEMPORARY_ATTRIBUTE + "," + QUEUE_ATTRIBUTES;
-
-    /**
-     * Convenience value used to mark a destination as a Temporary Topic.
-     */
-    public static final String TEMP_TOPIC_ATTRIBUTES = TEMPORARY_ATTRIBUTE + "," + TOPIC_ATTRIBUTES;
-
-    /**
      * Attribute used to mark the Application defined correlation Id that has been
      * set for the message.
      */

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/ace7dc39/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
index b70f8d6..d8220d8 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
@@ -276,7 +276,6 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that the {@link AmqpMessageSupport#AMQP_TO_ANNOTATION} is set as a byte on
      * a sent message to indicate its 'to' address represents a Topic JMSDestination.
      */
-    @Ignore //TODO: enable when toggling default
     @Test(timeout = 5000)
     public void testSentMessageContainsToTypeAnnotationByte() throws Exception {
         try (TestAmqpPeer testPeer = new TestAmqpPeer(IntegrationTestFixture.PORT);) {
@@ -314,7 +313,6 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that the {@link AmqpMessageSupport#AMQP_REPLY_TO_ANNOTATION} is set as a byte on
      * a sent message to indicate its 'reply-to' address represents a Topic JMSDestination.
      */
-    @Ignore //TODO: enable when toggling default
     @Test(timeout = 5000)
     public void testSentMessageContainsReplyToTypeAnnotationByte() throws Exception {
         try (TestAmqpPeer testPeer = new TestAmqpPeer(IntegrationTestFixture.PORT);) {
@@ -456,7 +454,7 @@ public class MessageIntegrationTest extends QpidJmsTestCase
             Queue queue = session.createQueue("myQueue");
 
             MessageAnnotationsDescribedType msgAnnotations = new MessageAnnotationsDescribedType();
-            msgAnnotations.setSymbolKeyedAnnotation(AmqpMessageSupport.AMQP_TO_ANNOTATION, AmqpMessageSupport.TOPIC_ATTRIBUTES);
+            msgAnnotations.setSymbolKeyedAnnotation(AmqpMessageSupport.AMQP_TO_ANNOTATION, AmqpDestinationHelper.TOPIC_ATTRIBUTES_STRING);
 
             PropertiesDescribedType props = new PropertiesDescribedType();
             String myTopicAddress = "myTopicAddress";
@@ -498,7 +496,7 @@ public class MessageIntegrationTest extends QpidJmsTestCase
             Queue queue = session.createQueue("myQueue");
 
             MessageAnnotationsDescribedType msgAnnotations = new MessageAnnotationsDescribedType();
-            msgAnnotations.setSymbolKeyedAnnotation(AmqpMessageSupport.AMQP_REPLY_TO_ANNOTATION, AmqpMessageSupport.TOPIC_ATTRIBUTES);
+            msgAnnotations.setSymbolKeyedAnnotation(AmqpMessageSupport.AMQP_REPLY_TO_ANNOTATION, AmqpDestinationHelper.TOPIC_ATTRIBUTES_STRING);
 
             PropertiesDescribedType props = new PropertiesDescribedType();
             String myTopicAddress = "myTopicAddress";


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@qpid.apache.org
For additional commands, e-mail: commits-help@qpid.apache.org


[3/4] git commit: streamline test, other elements have their own specific tests

Posted by ro...@apache.org.
streamline test, other elements have their own specific tests


Project: http://git-wip-us.apache.org/repos/asf/qpid-jms/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-jms/commit/03d3ff37
Tree: http://git-wip-us.apache.org/repos/asf/qpid-jms/tree/03d3ff37
Diff: http://git-wip-us.apache.org/repos/asf/qpid-jms/diff/03d3ff37

Branch: refs/heads/master
Commit: 03d3ff37bfe9271ea0de1d97dff29b8c362b4390
Parents: 473e881
Author: Robert Gemmell <ro...@apache.org>
Authored: Mon Oct 20 11:15:36 2014 +0100
Committer: Robert Gemmell <ro...@apache.org>
Committed: Mon Oct 20 11:15:36 2014 +0100

----------------------------------------------------------------------
 .../jms/integration/SenderIntegrationTest.java     | 17 ++++++-----------
 1 file changed, 6 insertions(+), 11 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/03d3ff37/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/SenderIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/SenderIntegrationTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/SenderIntegrationTest.java
index 108b36c..dd3318e 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/SenderIntegrationTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/SenderIntegrationTest.java
@@ -137,11 +137,10 @@ public class SenderIntegrationTest extends QpidJmsTestCase {
     }
 
     /**
-     * Test that when a message is sent the JMSDestination header is set to the Destination used by the
-     * producer, and the emitted AMQP message has the relevant value set in the 'to' field of properties,
-     * with associated message annotation value to indicate the Destination type.
+     * Test that when a message is sent the JMSDestination header is set to
+     * the Destination used by the producer.
      */
-    @Test(timeout = 10000)
+    @Test(timeout = 5000)
     public void testSendingMessageSetsJMSDestination() throws Exception {
         try (TestAmqpPeer testPeer = new TestAmqpPeer(IntegrationTestFixture.PORT);) {
             Connection connection = testFixture.establishConnecton(testPeer);
@@ -154,13 +153,9 @@ public class SenderIntegrationTest extends QpidJmsTestCase {
             MessageProducer producer = session.createProducer(queue);
 
             String text = "myMessage";
-            MessageHeaderSectionMatcher headersMatcher = new MessageHeaderSectionMatcher(true)
-                    .withDurable(equalTo(true));
-            MessageAnnotationsSectionMatcher msgAnnotationsMatcher = new MessageAnnotationsSectionMatcher(true)
-                    .withEntry(Symbol.valueOf(AmqpMessageSupport.AMQP_TO_ANNOTATION),
-                            equalTo(AmqpMessageSupport.QUEUE_ATTRIBUTES));
-            MessagePropertiesSectionMatcher propsMatcher = new MessagePropertiesSectionMatcher(true)
-                    .withTo(equalTo(queueName));
+            MessageHeaderSectionMatcher headersMatcher = new MessageHeaderSectionMatcher(true);
+            MessageAnnotationsSectionMatcher msgAnnotationsMatcher = new MessageAnnotationsSectionMatcher(true);
+            MessagePropertiesSectionMatcher propsMatcher = new MessagePropertiesSectionMatcher(true);
             TransferPayloadCompositeMatcher messageMatcher = new TransferPayloadCompositeMatcher();
             messageMatcher.setHeadersMatcher(headersMatcher);
             messageMatcher.setMessageAnnotationsMatcher(msgAnnotationsMatcher);


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@qpid.apache.org
For additional commands, e-mail: commits-help@qpid.apache.org