You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by or...@apache.org on 2018/03/15 18:07:57 UTC

[2/3] qpid-broker-j git commit: QPID-8123: [System Tests] Minor test related changes

QPID-8123: [System Tests] Minor test related changes


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/58e38f31
Tree: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/tree/58e38f31
Diff: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/diff/58e38f31

Branch: refs/heads/master
Commit: 58e38f31214795e8cffa596979327b04b83de771
Parents: 59f78b0
Author: Alex Rudyy <or...@apache.org>
Authored: Thu Mar 15 17:14:15 2018 +0000
Committer: Alex Rudyy <or...@apache.org>
Committed: Thu Mar 15 17:14:15 2018 +0000

----------------------------------------------------------------------
 .../berkeleydb/replication/GroupCreator.java    |  7 ++-
 .../berkeleydb/replication/MultiNodeTest.java   |  4 +-
 .../berkeleydb/replication/TwoNodeTest.java     |  2 +-
 .../apache/qpid/systests/ConnectionBuilder.java |  5 ++-
 test-profiles/test-provider-1-0.properties      | 39 -----------------
 test-profiles/test-provider.properties          | 45 --------------------
 6 files changed, 9 insertions(+), 93 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/58e38f31/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/GroupCreator.java
----------------------------------------------------------------------
diff --git a/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/GroupCreator.java b/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/GroupCreator.java
index 8215e88..7750a0d 100644
--- a/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/GroupCreator.java
+++ b/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/GroupCreator.java
@@ -70,7 +70,6 @@ public class GroupCreator
     private static final Logger LOGGER = LoggerFactory.getLogger(GroupCreator.class);
 
     private static final int FAILOVER_CYCLECOUNT = 40;
-    private static final int FAILOVER_RETRIES = 0;
     private static final int FAILOVER_CONNECTDELAY = 1000;
 
     private final QpidBrokerTestCase _testcase;
@@ -281,17 +280,17 @@ public class GroupCreator
 
     public ConnectionBuilder getConnectionBuilderForAllClusterNodes() throws Exception
     {
-        return getConnectionBuilderForAllClusterNodes(FAILOVER_CONNECTDELAY, FAILOVER_RETRIES, FAILOVER_CYCLECOUNT);
+        return getConnectionBuilderForAllClusterNodes(FAILOVER_CONNECTDELAY, FAILOVER_CYCLECOUNT);
     }
 
-    public ConnectionBuilder getConnectionBuilderForAllClusterNodes(int connectDelay, int retries, final int cyclecount) throws Exception
+    public ConnectionBuilder getConnectionBuilderForAllClusterNodes(int connectDelay, final int cyclecount) throws Exception
     {
         final ConnectionBuilder connectionBuilder = _testcase.getConnectionBuilder();
         connectionBuilder.setFailoverReconnectDelay(connectDelay);
         connectionBuilder.setVirtualHost(_virtualHostName);
         connectionBuilder.setFailover(true);
 
-        final int reconnectAttempts = (retries == 0 ? 1 : retries) * (cyclecount == 0 ? 1 : cyclecount);
+        final int reconnectAttempts = cyclecount == 0 ? 1 : cyclecount;
         connectionBuilder.setFailoverReconnectAttempts(reconnectAttempts);
 
         final Iterator<Integer> iterator = _members.keySet().iterator();

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/58e38f31/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/MultiNodeTest.java
----------------------------------------------------------------------
diff --git a/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/MultiNodeTest.java b/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/MultiNodeTest.java
index 595d779..c964655 100644
--- a/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/MultiNodeTest.java
+++ b/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/MultiNodeTest.java
@@ -91,7 +91,7 @@ public class MultiNodeTest extends QpidBrokerTestCase
         _groupCreator.configureClusterNodes();
 
         _positiveFailoverBuilder = _groupCreator.getConnectionBuilderForAllClusterNodes();
-        _negativeFailoverBuilder = _groupCreator.getConnectionBuilderForAllClusterNodes(200, 0, 2);
+        _negativeFailoverBuilder = _groupCreator.getConnectionBuilderForAllClusterNodes(200, 2);
 
         _groupCreator.startCluster();
         _failoverListener = new FailoverAwaitingListener();
@@ -488,7 +488,7 @@ public class MultiNodeTest extends QpidBrokerTestCase
         ExecutorService executorService = Executors.newFixedThreadPool(connectionNumber + NUMBER_OF_NODES - 1);
         try
         {
-            final ConnectionBuilder builder = _groupCreator.getConnectionBuilderForAllClusterNodes(100, 0, 100);
+            final ConnectionBuilder builder = _groupCreator.getConnectionBuilderForAllClusterNodes(100, 100);
             final Connection consumerConnection = builder.build();
             Session s = consumerConnection.createSession(true, Session.SESSION_TRANSACTED);
             getJmsProvider().createQueue(s, getTestQueueName());

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/58e38f31/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/TwoNodeTest.java
----------------------------------------------------------------------
diff --git a/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/TwoNodeTest.java b/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/TwoNodeTest.java
index 385417f..3e0783d 100644
--- a/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/TwoNodeTest.java
+++ b/bdbstore/systests/src/test/java/org/apache/qpid/server/store/berkeleydb/replication/TwoNodeTest.java
@@ -67,7 +67,7 @@ public class TwoNodeTest extends QpidBrokerTestCase
         _groupCreator.configureClusterNodes();
         _groupCreator.setDesignatedPrimaryOnFirstBroker(designedPrimary);
         _positiveFailoverBuilder = _groupCreator.getConnectionBuilderForAllClusterNodes();
-        _negativeFailoverBuilder = _groupCreator.getConnectionBuilderForAllClusterNodes(200, 0, 2);
+        _negativeFailoverBuilder = _groupCreator.getConnectionBuilderForAllClusterNodes(200, 2);
         _groupCreator.startCluster();
     }
 

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/58e38f31/systests/qpid-systests-jms-core/src/main/java/org/apache/qpid/systests/ConnectionBuilder.java
----------------------------------------------------------------------
diff --git a/systests/qpid-systests-jms-core/src/main/java/org/apache/qpid/systests/ConnectionBuilder.java b/systests/qpid-systests-jms-core/src/main/java/org/apache/qpid/systests/ConnectionBuilder.java
index 34a7f62..2fa7b16 100644
--- a/systests/qpid-systests-jms-core/src/main/java/org/apache/qpid/systests/ConnectionBuilder.java
+++ b/systests/qpid-systests-jms-core/src/main/java/org/apache/qpid/systests/ConnectionBuilder.java
@@ -49,6 +49,8 @@ public interface ConnectionBuilder
     ConnectionBuilder setFailoverReconnectDelay(int connectDelay);
     ConnectionBuilder setTls(boolean enableTls);
     ConnectionBuilder setSyncPublish(boolean syncPublish);
+
+    @Deprecated
     ConnectionBuilder setOptions(Map<String, String> options);
     ConnectionBuilder setPopulateJMSXUserID(boolean populateJMSXUserID);
     ConnectionBuilder setMessageRedelivery(final boolean redelivery);
@@ -61,9 +63,8 @@ public interface ConnectionBuilder
     ConnectionBuilder setVerifyHostName(boolean verifyHostName);
     ConnectionBuilder setKeyAlias(String alias);
     ConnectionBuilder setSaslMechanisms(String... mechanism);
-
     ConnectionBuilder setCompress(boolean compress);
-    Connection build() throws NamingException, JMSException;
 
+    Connection build() throws NamingException, JMSException;
     ConnectionFactory buildConnectionFactory() throws NamingException;
 }

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/58e38f31/test-profiles/test-provider-1-0.properties
----------------------------------------------------------------------
diff --git a/test-profiles/test-provider-1-0.properties b/test-profiles/test-provider-1-0.properties
deleted file mode 100644
index cb72574..0000000
--- a/test-profiles/test-provider-1-0.properties
+++ /dev/null
@@ -1,39 +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.
-# 
-#
-
-# Copied from default.testprofile
-test.port=0
-test.port.ssl=0
-test.port.alt=0
-test.port.alt.ssl=0
-
-java.naming.factory.initial = org.apache.qpid.jms.jndi.JmsInitialContextFactory
-
-# The actual factory URIs are set in QpidBrokerTestCase 
-connectionfactory.default=amqp://localhost:5672
-connectionfactory.failover=amqp://localhost:5672
-
-
-queue.MyQueue = example.MyQueue
-queue.queue = example.queue
-
-topic.topic = amq.topic/topic
-topic.durableSubscriberTopic = durableSubscriberTopic

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/58e38f31/test-profiles/test-provider.properties
----------------------------------------------------------------------
diff --git a/test-profiles/test-provider.properties b/test-profiles/test-provider.properties
deleted file mode 100644
index 83f6ded..0000000
--- a/test-profiles/test-provider.properties
+++ /dev/null
@@ -1,45 +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.
-# 
-#
-
-# Copied from default.testprofile
-test.port=0
-test.port.ssl=0
-test.port.alt=0
-test.port.alt.ssl=0
-
-
-connectionfactory.default = amqp://username:password@clientid/test?brokerlist='tcp://localhost:${test.port}'
-connectionfactory.default.ssl = amqp://username:password@clientid/test?brokerlist='tcp://localhost:${test.port.ssl}?ssl='true''
-
-connectionfactory.failover = amqp://username:password@clientid/test?brokerlist='tcp://localhost:${test.port};tcp://localhost:${test.port.alt}'&sync_ack='true'&sync_publish='all'&failover='roundrobin?cyclecount='20''
-connectionfactory.failover.ssl = amqp://username:password@clientid/test?brokerlist='tcp://localhost:${test.port.ssl}?ssl='true';tcp://localhost:${test.port.alt.ssl}?ssl='true''&sync_ack='true'&sync_publish='all'&failover='roundrobin?cyclecount='20''
-
-connectionfactory.connection2 = amqp://username:password@clientid/test?brokerlist='tcp://localhost:${test.port.alt}'
-
-connectionfactory.management = amqp://username:password@clientid/$management?brokerlist='tcp://localhost:${test.port}'
-connectionfactory.management.ssl = amqp://username:password@clientid/$management?brokerlist='tcp://localhost:${test.port.ssl}?ssl='true''
-
-
-queue.MyQueue = example.MyQueue
-queue.queue = example.queue
-
-topic.topic = topic
-topic.durableSubscriberTopic = durableSubscriberTopic


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