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

[2/8] activemq-artemis git commit: Removing a non open wire test -- this test is only validating AMQP <-> MQTT converstion through ActiveMQ5. No value for OpenWire tests

Removing a non open wire test
-- this test is only validating AMQP <-> MQTT converstion through ActiveMQ5. No value for OpenWire tests


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

Branch: refs/heads/master
Commit: e7e1e0c6ebd30748743585fa1620b1fa1aa47ed9
Parents: 7b2c504
Author: Clebert Suconic <cl...@apache.org>
Authored: Thu Sep 10 15:52:56 2015 -0400
Committer: Clebert Suconic <cl...@apache.org>
Committed: Fri Sep 11 09:06:00 2015 -0400

----------------------------------------------------------------------
 .../activemq/conversions/AmqpAndMqttTest.java   | 119 -------------------
 1 file changed, 119 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/e7e1e0c6/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/conversions/AmqpAndMqttTest.java
----------------------------------------------------------------------
diff --git a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/conversions/AmqpAndMqttTest.java b/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/conversions/AmqpAndMqttTest.java
deleted file mode 100644
index d9b7add..0000000
--- a/tests/activemq5-unit-tests/src/test/java/org/apache/activemq/conversions/AmqpAndMqttTest.java
+++ /dev/null
@@ -1,119 +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.conversions;
-
-import org.apache.activemq.CombinationTestSupport;
-import org.apache.activemq.broker.BrokerService;
-import org.apache.activemq.broker.TransportConnector;
-import org.apache.qpid.amqp_1_0.jms.impl.ConnectionFactoryImpl;
-import org.apache.qpid.amqp_1_0.jms.impl.QueueImpl;
-import org.apache.qpid.amqp_1_0.jms.impl.TopicImpl;
-import org.fusesource.mqtt.client.BlockingConnection;
-import org.fusesource.mqtt.client.MQTT;
-import org.fusesource.mqtt.client.QoS;
-
-import javax.jms.*;
-import java.io.UnsupportedEncodingException;
-import java.util.Arrays;
-
-/**
- */
-public class AmqpAndMqttTest extends CombinationTestSupport {
-
-   protected BrokerService broker;
-   private TransportConnector amqpConnector;
-   private TransportConnector mqttConnector;
-
-   @Override
-   protected void setUp() throws Exception {
-      super.setUp();
-      broker = createBroker();
-      broker.start();
-      broker.waitUntilStarted();
-   }
-
-   @Override
-   protected void tearDown() throws Exception {
-      if (broker != null) {
-         broker.stop();
-         broker.waitUntilStopped();
-         broker = null;
-      }
-      super.tearDown();
-   }
-
-   protected BrokerService createBroker() throws Exception {
-      BrokerService broker = new BrokerService();
-      broker.setPersistent(false);
-      amqpConnector = broker.addConnector("amqp://0.0.0.0:0");
-      mqttConnector = broker.addConnector("mqtt://0.0.0.0:0");
-      return broker;
-   }
-
-   public void testFromMqttToAmqp() throws Exception {
-      Connection amqp = createAmqpConnection();
-      Session session = amqp.createSession(false, Session.AUTO_ACKNOWLEDGE);
-      MessageConsumer consumer = session.createConsumer(session.createTopic("topic://FOO"));
-
-      final BlockingConnection mqtt = createMQTTConnection().blockingConnection();
-      mqtt.connect();
-      byte[] payload = bytes("Hello World");
-      mqtt.publish("FOO", payload, QoS.AT_LEAST_ONCE, false);
-      mqtt.disconnect();
-
-      Message msg = consumer.receive(1000 * 5);
-      assertNotNull(msg);
-      assertTrue(msg instanceof BytesMessage);
-
-      BytesMessage bmsg = (BytesMessage) msg;
-      byte[] actual = new byte[(int) bmsg.getBodyLength()];
-      bmsg.readBytes(actual);
-      assertTrue(Arrays.equals(actual, payload));
-      amqp.close();
-   }
-
-   private byte[] bytes(String value) {
-      try {
-         return value.getBytes("UTF-8");
-      }
-      catch (UnsupportedEncodingException e) {
-         throw new RuntimeException(e);
-      }
-   }
-
-   protected MQTT createMQTTConnection() throws Exception {
-      MQTT mqtt = new MQTT();
-      mqtt.setConnectAttemptsMax(1);
-      mqtt.setReconnectAttemptsMax(0);
-      mqtt.setHost("localhost", mqttConnector.getConnectUri().getPort());
-      return mqtt;
-   }
-
-   public Connection createAmqpConnection() throws Exception {
-      final ConnectionFactoryImpl factory = new ConnectionFactoryImpl("localhost", amqpConnector.getConnectUri().getPort(), "admin", "password");
-      final Connection connection = factory.createConnection();
-      connection.setExceptionListener(new ExceptionListener() {
-         @Override
-         public void onException(JMSException exception) {
-            exception.printStackTrace();
-         }
-      });
-      connection.start();
-      return connection;
-   }
-
-}