You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by kw...@apache.org on 2017/12/28 20:24:15 UTC

[4/4] qpid-broker-j git commit: QPID-6933: [System Tests] Remove QueueBindTest - this 0-8..0-91 test is covered by a specific 0-8..0-91 protocol tests and the general JMS 1.1 DurableSubscribtionTest

QPID-6933: [System Tests] Remove QueueBindTest - this 0-8..0-91 test is covered by a specific 0-8..0-91 protocol tests and the general JMS 1.1 DurableSubscribtionTest


Project: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/commit/40a7fdbe
Tree: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/tree/40a7fdbe
Diff: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/diff/40a7fdbe

Branch: refs/heads/master
Commit: 40a7fdbe45b505885189199739222e82dc295d72
Parents: 755dda5
Author: Keith Wall <kw...@apache.org>
Authored: Thu Dec 28 20:05:12 2017 +0000
Committer: Keith Wall <kw...@apache.org>
Committed: Thu Dec 28 20:05:12 2017 +0000

----------------------------------------------------------------------
 .../apache/qpid/server/queue/QueueBindTest.java | 131 -------------------
 test-profiles/CPPExcludes                       |   3 -
 test-profiles/Java010Excludes                   |   3 -
 test-profiles/Java10Excludes                    |   3 -
 4 files changed, 140 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/40a7fdbe/systests/src/test/java/org/apache/qpid/server/queue/QueueBindTest.java
----------------------------------------------------------------------
diff --git a/systests/src/test/java/org/apache/qpid/server/queue/QueueBindTest.java b/systests/src/test/java/org/apache/qpid/server/queue/QueueBindTest.java
deleted file mode 100644
index c85e65f..0000000
--- a/systests/src/test/java/org/apache/qpid/server/queue/QueueBindTest.java
+++ /dev/null
@@ -1,131 +0,0 @@
-/*
- *
- * 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.qpid.server.queue;
-
-import java.util.Collections;
-import java.util.HashMap;
-import java.util.Map;
-
-import javax.jms.Connection;
-import javax.jms.JMSException;
-import javax.jms.Message;
-import javax.jms.MessageConsumer;
-import javax.jms.Session;
-
-import org.apache.qpid.QpidException;
-import org.apache.qpid.client.AMQDestination;
-import org.apache.qpid.client.AMQQueue;
-import org.apache.qpid.client.AMQSession;
-import org.apache.qpid.common.AMQPFilterTypes;
-import org.apache.qpid.test.utils.QpidBrokerTestCase;
-import org.apache.qpid.url.AMQBindingURL;
-
-public class QueueBindTest extends QpidBrokerTestCase
-{
-    private Connection _connection;
-    private AMQSession<?, ?> _session;
-
-    @Override
-    protected void setUp() throws Exception
-    {
-        super.setUp();
-
-        _connection = getConnection();
-        _session = (AMQSession<?, ?>) _connection.createSession(true, Session.SESSION_TRANSACTED);
-    }
-
-    public void testQueueCannotBeReboundOnNonTopicExchange() throws Exception
-    {
-        runTestForNonTopicExhange(new AMQQueue(new AMQBindingURL("direct://amq.direct//" + getTestQueueName())));
-        runTestForNonTopicExhange(new AMQQueue(new AMQBindingURL("fanout://amq.fanout//" + getTestQueueName()) + "?routingkey='"
-                + getTestQueueName() + "'"));
-    }
-
-    public void testQueueCanBeReboundOnTopicExchange() throws Exception
-    {
-        AMQQueue destination = new AMQQueue(new AMQBindingURL("topic://amq.topic//" + getTestQueueName() + "?routingkey='"
-                + getTestQueueName() + "'"));
-        setTestClientSystemProperty("qpid.default_mandatory", "false");
-        runTestForTopicExchange(destination);
-
-    }
-
-    private void runTestForTopicExchange(AMQDestination destination) throws QpidException, JMSException, Exception
-    {
-        // binding queue with empty arguments
-        _session.declareAndBind(destination,Collections.<String, Object>emptyMap());
-
-        // try to re-bind queue with a selector
-        Map<String, Object> bindArguments = new HashMap<String, Object>();
-        bindArguments.put(AMQPFilterTypes.JMS_SELECTOR.getValue(), INDEX + "=0");
-        _session.bindQueue(destination.getAMQQueueName(), destination.getRoutingKey(),
-                           bindArguments, destination.getExchangeName(), destination);
-
-        _connection.start();
-
-        // repeat send/receive twice to make sure that selector is working
-        for (int i = 0; i < 2; i++)
-        {
-            int numberOfMesssages = 2;
-            sendMessage(_session, destination, numberOfMesssages);
-
-            MessageConsumer consumer = _session.createConsumer(destination);
-            Message m = consumer.receive(1000);
-            assertNotNull("Message not received", m);
-            assertEquals("Unexpected index", 0, m.getIntProperty(INDEX));
-            _session.commit();
-
-            m = consumer.receive(1000);
-            assertNull("Message received", m);
-
-            consumer.close();
-        }
-    }
-
-    private void runTestForNonTopicExhange(AMQQueue destination) throws QpidException, Exception, JMSException
-    {
-        // binding queue with empty arguments
-        _session.declareAndBind(destination,
-                                Collections.<String, Object>emptyMap());
-
-        // try to re-bind queue with a selector
-        Map<String, Object> bindArguments = new HashMap<String, Object>();
-        bindArguments.put(AMQPFilterTypes.JMS_SELECTOR.getValue(), INDEX + "=0");
-        _session.bindQueue(destination.getAMQQueueName(), destination.getRoutingKey(),
-                           bindArguments, destination.getExchangeName(), destination);
-
-        // send and receive to prove that selector is not used
-        int numberOfMesssages = 2;
-        sendMessage(_session, destination, numberOfMesssages);
-
-        MessageConsumer consumer = _session.createConsumer(destination);
-        _connection.start();
-
-        for (int i = 0; i < numberOfMesssages; i++)
-        {
-            Message m = consumer.receive(1000l);
-            assertNotNull("Message [" + i + "] not received with exchange " + destination.getExchangeName(), m);
-            assertEquals("Unexpected index", i, m.getIntProperty(INDEX));
-            _session.commit();
-        }
-        consumer.close();
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/40a7fdbe/test-profiles/CPPExcludes
----------------------------------------------------------------------
diff --git a/test-profiles/CPPExcludes b/test-profiles/CPPExcludes
index 1b42582..6b10a13 100755
--- a/test-profiles/CPPExcludes
+++ b/test-profiles/CPPExcludes
@@ -151,9 +151,6 @@ org.apache.qpid.client.ssl.SSLTest#testCreateSSLandTCPonSamePort
 org.apache.qpid.client.HeartbeatTest#testUnidirectionalHeartbeating
 org.apache.qpid.client.HeartbeatTest#testHeartbeatsEnabledBrokerSide
 
-// Exclude Qpid Broker-J specific behavior allowing queue re-bind to topic exchanges on 0.8/0-10 paths
-org.apache.qpid.server.queue.QueueBindTest#testQueueCanBeReboundOnTopicExchange
-
 // Tests queue message durability settings which are a Qpid Broker-J specific feature
 org.apache.qpid.server.queue.QueueMessageDurabilityTest#*
 

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/40a7fdbe/test-profiles/Java010Excludes
----------------------------------------------------------------------
diff --git a/test-profiles/Java010Excludes b/test-profiles/Java010Excludes
index 1d6d98e..0911088 100755
--- a/test-profiles/Java010Excludes
+++ b/test-profiles/Java010Excludes
@@ -50,9 +50,6 @@ org.apache.qpid.client.failover.AddressBasedFailoverBehaviourTest#testFailoverHa
 org.apache.qpid.client.failover.AddressBasedFailoverBehaviourTest#testFailoverHandlerTimeoutReconnected
 org.apache.qpid.client.failover.AddressBasedFailoverBehaviourTest#testFlowControlFlagResetOnFailover
 
-// JMS 0-10 client does not support re-binding the queue to the same exchange
-org.apache.qpid.server.queue.QueueBindTest#testQueueCanBeReboundOnTopicExchange
-
 org.apache.qpid.test.unit.client.AMQSessionTest#testQueueDepthForQueueThatDoesNotExistLegacyBehaviour_08_091
 
 // QPID-6722: Race client side means that session close can end in exception when failover is in progress.

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/40a7fdbe/test-profiles/Java10Excludes
----------------------------------------------------------------------
diff --git a/test-profiles/Java10Excludes b/test-profiles/Java10Excludes
index fe30ede..00eb4c8 100644
--- a/test-profiles/Java10Excludes
+++ b/test-profiles/Java10Excludes
@@ -75,9 +75,6 @@ org.apache.qpid.client.failover.MultipleBrokersFailoverTest#*
 org.apache.qpid.test.client.failover.FailoverTest#*
 
 
-// Tests explicit binding using the mechanisms of the 0-x client/protocol
-org.apache.qpid.server.queue.QueueBindTest#*
-
 // Tests the issue of connection exceptions being generated for unroutable messages in the 0-x client
 org.apache.qpid.test.unit.client.connection.ExceptionListenerTest#testExceptionListenerConnectionStopDeadlock
 


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