You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ta...@apache.org on 2015/07/02 00:01:16 UTC

activemq git commit: Fix test name to match its issue: AMQ-5822

Repository: activemq
Updated Branches:
  refs/heads/master 60ca85c92 -> 0c72e5d7d


Fix test name to match its issue: AMQ-5822

Project: http://git-wip-us.apache.org/repos/asf/activemq/repo
Commit: http://git-wip-us.apache.org/repos/asf/activemq/commit/0c72e5d7
Tree: http://git-wip-us.apache.org/repos/asf/activemq/tree/0c72e5d7
Diff: http://git-wip-us.apache.org/repos/asf/activemq/diff/0c72e5d7

Branch: refs/heads/master
Commit: 0c72e5d7dc4b36327c4074374c5c3623d328debc
Parents: 60ca85c
Author: Timothy Bish <ta...@gmail.com>
Authored: Wed Jul 1 18:00:43 2015 -0400
Committer: Timothy Bish <ta...@gmail.com>
Committed: Wed Jul 1 18:00:43 2015 -0400

----------------------------------------------------------------------
 .../org/apache/activemq/bugs/AMQ5822Test.java   | 83 ++++++++++++++++++++
 .../org/apache/activemq/bugs/AMQ6000Test.java   | 83 --------------------
 2 files changed, 83 insertions(+), 83 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq/blob/0c72e5d7/activemq-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ5822Test.java
----------------------------------------------------------------------
diff --git a/activemq-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ5822Test.java b/activemq-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ5822Test.java
new file mode 100644
index 0000000..417414c
--- /dev/null
+++ b/activemq-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ5822Test.java
@@ -0,0 +1,83 @@
+/**
+ * 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.activemq.bugs;
+
+import javax.jms.BytesMessage;
+import javax.jms.DeliveryMode;
+import javax.jms.MessageProducer;
+import javax.jms.Queue;
+import javax.jms.Session;
+
+import org.apache.activemq.ActiveMQConnection;
+import org.apache.activemq.ActiveMQConnectionFactory;
+import org.apache.activemq.broker.BrokerService;
+import org.junit.After;
+import org.junit.Before;
+import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+public class AMQ5822Test {
+
+    private static final Logger LOG = LoggerFactory.getLogger(AMQ5822Test.class);
+
+    private BrokerService brokerService;
+    private String connectionUri;
+
+    @Before
+    public void setUp() throws Exception {
+        brokerService = new BrokerService();
+        brokerService.setPersistent(false);
+        brokerService.setUseJmx(false);
+        brokerService.addConnector("nio://0.0.0.0:0?"
+            + "wireFormat.maxInactivityDurationInitalDelay=1000&wireFormat.maxInactivityDuration=300");
+        brokerService.start();
+
+        connectionUri = brokerService.getTransportConnectorByScheme("nio").getPublishableConnectString();
+    }
+
+    @After
+    public void tearDown() throws Exception {
+        brokerService.stop();
+        brokerService.waitUntilStopped();
+    }
+
+    @Test
+    public void testReadCounter() throws Exception {
+        LOG.info("Connecting to: {}", connectionUri);
+
+        byte[] payload = new byte[50 * 1024 * 1024];
+
+        ActiveMQConnectionFactory factory = new ActiveMQConnectionFactory(connectionUri + "?useInactivityMonitor=false");
+        final ActiveMQConnection connection = (ActiveMQConnection) factory.createConnection();
+        connection.start();
+
+        LOG.info("Connected to: {}", connection.getTransport());
+
+        Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+        Queue queue = session.createQueue("test");
+        MessageProducer producer = session.createProducer(queue);
+        BytesMessage message = session.createBytesMessage();
+
+        message.writeBytes(payload);
+
+        producer.setDeliveryMode(DeliveryMode.PERSISTENT);
+        producer.send(message);
+
+        connection.close();
+    }
+}

http://git-wip-us.apache.org/repos/asf/activemq/blob/0c72e5d7/activemq-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ6000Test.java
----------------------------------------------------------------------
diff --git a/activemq-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ6000Test.java b/activemq-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ6000Test.java
deleted file mode 100644
index 39c6fe8..0000000
--- a/activemq-unit-tests/src/test/java/org/apache/activemq/bugs/AMQ6000Test.java
+++ /dev/null
@@ -1,83 +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.activemq.bugs;
-
-import javax.jms.BytesMessage;
-import javax.jms.DeliveryMode;
-import javax.jms.MessageProducer;
-import javax.jms.Queue;
-import javax.jms.Session;
-
-import org.apache.activemq.ActiveMQConnection;
-import org.apache.activemq.ActiveMQConnectionFactory;
-import org.apache.activemq.broker.BrokerService;
-import org.junit.After;
-import org.junit.Before;
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-public class AMQ6000Test {
-
-    private static final Logger LOG = LoggerFactory.getLogger(AMQ6000Test.class);
-
-    private BrokerService brokerService;
-    private String connectionUri;
-
-    @Before
-    public void setUp() throws Exception {
-        brokerService = new BrokerService();
-        brokerService.setPersistent(false);
-        brokerService.setUseJmx(false);
-        brokerService.addConnector("nio://0.0.0.0:0?"
-            + "wireFormat.maxInactivityDurationInitalDelay=1000&wireFormat.maxInactivityDuration=300");
-        brokerService.start();
-
-        connectionUri = brokerService.getTransportConnectorByScheme("nio").getPublishableConnectString();
-    }
-
-    @After
-    public void tearDown() throws Exception {
-        brokerService.stop();
-        brokerService.waitUntilStopped();
-    }
-
-    @Test
-    public void testReadCounter() throws Exception {
-        LOG.info("Connecting to: {}", connectionUri);
-
-        byte[] payload = new byte[50 * 1024 * 1024];
-
-        ActiveMQConnectionFactory factory = new ActiveMQConnectionFactory(connectionUri + "?useInactivityMonitor=false");
-        final ActiveMQConnection connection = (ActiveMQConnection) factory.createConnection();
-        connection.start();
-
-        LOG.info("Connected to: {}", connection.getTransport());
-
-        Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-        Queue queue = session.createQueue("test");
-        MessageProducer producer = session.createProducer(queue);
-        BytesMessage message = session.createBytesMessage();
-
-        message.writeBytes(payload);
-
-        producer.setDeliveryMode(DeliveryMode.PERSISTENT);
-        producer.send(message);
-
-        connection.close();
-    }
-}