You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by jb...@apache.org on 2016/11/23 17:43:16 UTC

[15/48] activemq-artemis git commit: CLI WORK

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bd4b7cec/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/DestinationCommandTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/DestinationCommandTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/DestinationCommandTest.java
deleted file mode 100644
index a9266ef..0000000
--- a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/DestinationCommandTest.java
+++ /dev/null
@@ -1,226 +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.artemis.tests.integration.cli;
-
-import java.io.ByteArrayOutputStream;
-import java.io.PrintStream;
-import java.util.Map;
-
-import org.apache.activemq.artemis.api.core.SimpleString;
-import org.apache.activemq.artemis.cli.commands.ActionContext;
-import org.apache.activemq.artemis.cli.commands.destination.CreateDestination;
-import org.apache.activemq.artemis.cli.commands.destination.DeleteDestination;
-import org.apache.activemq.artemis.cli.commands.destination.DestinationAction;
-import org.apache.activemq.artemis.core.filter.Filter;
-import org.apache.activemq.artemis.core.postoffice.Binding;
-import org.apache.activemq.artemis.tests.util.JMSTestBase;
-import org.junit.Before;
-import org.junit.Test;
-
-public class DestinationCommandTest extends JMSTestBase {
-
-   //the command
-   private ByteArrayOutputStream output;
-   private ByteArrayOutputStream error;
-
-   @Before
-   @Override
-   public void setUp() throws Exception {
-      super.setUp();
-      this.output = new ByteArrayOutputStream(1024);
-      this.error = new ByteArrayOutputStream(1024);
-   }
-
-   @Test
-   public void testCreateJmsQueue() throws Exception {
-      CreateDestination command = new CreateDestination();
-      command.setName("jmsQueue1");
-      command.setBindings("jmsQueue1Binding");
-      command.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
-      checkExecutionResult(command);
-   }
-
-   @Test
-   public void testDeleteJmsQueue() throws Exception {
-      CreateDestination command = new CreateDestination();
-      command.setName("jmsQueue1");
-      command.setBindings("jmsQueue1Binding");
-      command.execute(new ActionContext());
-
-      DeleteDestination delete = new DeleteDestination();
-      delete.setName("jmsQueue1");
-      delete.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
-      checkExecutionResult(delete);
-   }
-
-   @Test
-   public void testDeleteNonExistJmsQueue() throws Exception {
-      DeleteDestination delete = new DeleteDestination();
-      delete.setName("jmsQueue1NotExist");
-      delete.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
-      checkExecutionResult(delete);
-   }
-
-   @Test
-   public void testCreateJmsQueueWithFilter() throws Exception {
-      CreateDestination command = new CreateDestination();
-      command.setName("jmsQueue2");
-      command.setBindings("jmsQueue2Binding");
-      command.setFilter("color='red'");
-      command.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
-      checkExecutionResult(command);
-      assertTrue(checkBindingExists(command, "color='red'"));
-   }
-
-   @Test
-   public void testCreateJmsTopic() throws Exception {
-      CreateDestination command = new CreateDestination();
-      command.setDestType(DestinationAction.JMS_TOPIC);
-      command.setName("jmsTopic1");
-      command.setBindings("jmsTopic1Binding");
-      command.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
-      checkExecutionResult(command);
-   }
-
-   @Test
-   public void testDeleteJmsTopic() throws Exception {
-      CreateDestination command = new CreateDestination();
-      command.setDestType(DestinationAction.JMS_TOPIC);
-      command.setName("jmsTopic1");
-      command.setBindings("jmsTopic1Binding");
-      command.execute(new ActionContext());
-
-      DeleteDestination delete = new DeleteDestination();
-      delete.setDestType(DestinationAction.JMS_TOPIC);
-      delete.setName("jmsTopic1");
-      delete.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
-      checkExecutionResult(delete);
-   }
-
-   @Test
-   public void testDeleteJmsTopicNotExist() throws Exception {
-      DeleteDestination delete = new DeleteDestination();
-      delete.setDestType(DestinationAction.JMS_TOPIC);
-      delete.setName("jmsTopic1NotExist");
-      delete.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
-      checkExecutionResult(delete);
-   }
-
-   @Test
-   public void testCreateCoreQueue() throws Exception {
-      CreateDestination command = new CreateDestination();
-      command.setDestType(DestinationAction.CORE_QUEUE);
-      command.setName("coreQueue1");
-      command.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
-      checkExecutionResult(command);
-   }
-
-   @Test
-   public void testCreateCoreQueueWithFilter() throws Exception {
-      CreateDestination command = new CreateDestination();
-      command.setName("coreQueue2");
-      command.setDestType(DestinationAction.CORE_QUEUE);
-      command.setFilter("color='green'");
-      command.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
-      checkExecutionResult(command);
-   }
-
-   @Test
-   public void testDeleteCoreQueue() throws Exception {
-      CreateDestination command = new CreateDestination();
-      command.setName("coreQueue2");
-      command.setDestType(DestinationAction.CORE_QUEUE);
-      command.setFilter("color='green'");
-      command.execute(new ActionContext());
-
-      DeleteDestination delete = new DeleteDestination();
-      delete.setName("coreQueue2");
-      delete.setDestType(DestinationAction.CORE_QUEUE);
-      delete.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
-      checkExecutionResult(delete);
-   }
-
-   @Test
-   public void testDeleteCoreQueueNotExist() throws Exception {
-      DeleteDestination delete = new DeleteDestination();
-      delete.setName("coreQueue2NotExist");
-      delete.setDestType(DestinationAction.CORE_QUEUE);
-      delete.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
-      checkExecutionResult(delete);
-   }
-
-   private boolean isCreateCommand(DestinationAction command) {
-      return command instanceof CreateDestination;
-   }
-
-   private boolean isJms(DestinationAction command) {
-      String destType = command.getDestType();
-      return !DestinationAction.CORE_QUEUE.equals(destType);
-   }
-
-   private boolean isTopic(DestinationAction command) {
-      String destType = command.getDestType();
-      return DestinationAction.JMS_TOPIC.equals(destType);
-   }
-
-   private void checkExecutionResult(DestinationAction command) throws Exception {
-      if (isCreateCommand(command)) {
-         String fullMessage = output.toString();
-         System.out.println("output: " + fullMessage);
-         assertTrue(fullMessage, fullMessage.contains("successfully"));
-         assertTrue(checkBindingExists(command, null));
-      } else {
-         if (command.getName().equals("jmsQueue1") || command.getName().equals("coreQueue2") || command.getName().equals("jmsTopic1")) {
-            String fullMessage = output.toString();
-            System.out.println("output: " + fullMessage);
-            assertTrue(fullMessage, fullMessage.contains("successfully"));
-            assertFalse(checkBindingExists(command, null));
-         } else {
-            String errorMessage = error.toString();
-            System.out.println("error: " + errorMessage);
-            assertTrue(errorMessage, errorMessage.contains("Failed to"));
-            assertFalse(checkBindingExists(command, null));
-         }
-      }
-   }
-
-   private boolean checkBindingExists(DestinationAction command, String filter) {
-      String bindingKey = command.getName();
-      if (isJms(command)) {
-         if (isTopic(command)) {
-//            bindingKey = bindingKey;
-         } else {
-//            bindingKey = bindingKey;
-         }
-      }
-      Map<SimpleString, Binding> bindings = server.getPostOffice().getAllBindings();
-      System.out.println("bindings: " + bindings);
-      Binding binding = bindings.get(new SimpleString(bindingKey));
-      System.out.println("got binding: " + binding);
-      if (binding == null) {
-         System.out.println("No bindings for " + bindingKey);
-         return false;
-      }
-      if (filter != null) {
-         Filter bindingFilter = binding.getFilter();
-         assertNotNull(bindingFilter);
-         assertEquals(filter, bindingFilter.getFilterString().toString());
-      }
-      return true;
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bd4b7cec/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/DummyServerConsumer.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/DummyServerConsumer.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/DummyServerConsumer.java
new file mode 100644
index 0000000..d79b444
--- /dev/null
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/DummyServerConsumer.java
@@ -0,0 +1,204 @@
+/*
+ * 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.artemis.tests.integration.cli;
+
+import java.util.List;
+
+import org.apache.activemq.artemis.core.filter.Filter;
+import org.apache.activemq.artemis.core.server.HandleStatus;
+import org.apache.activemq.artemis.core.server.MessageReference;
+import org.apache.activemq.artemis.core.server.Queue;
+import org.apache.activemq.artemis.core.server.ServerConsumer;
+import org.apache.activemq.artemis.core.server.SlowConsumerDetectionListener;
+import org.apache.activemq.artemis.core.transaction.Transaction;
+
+public class DummyServerConsumer implements ServerConsumer {
+
+   @Override
+   public void setlowConsumerDetection(SlowConsumerDetectionListener listener) {
+
+   }
+
+   @Override
+   public SlowConsumerDetectionListener getSlowConsumerDetecion() {
+      return null;
+   }
+
+   @Override
+   public void fireSlowConsumer() {
+
+   }
+
+   @Override
+   public Object getProtocolData() {
+      return null;
+   }
+
+   @Override
+   public void setProtocolData(Object protocolData) {
+
+   }
+
+   @Override
+   public void setProtocolContext(Object protocolContext) {
+
+   }
+
+   @Override
+   public Object getProtocolContext() {
+      return null;
+   }
+
+   @Override
+   public long getID() {
+      return 0;
+   }
+
+   @Override
+   public Object getConnectionID() {
+      return null;
+   }
+
+   @Override
+   public void close(boolean failed) throws Exception {
+
+   }
+
+   @Override
+   public void removeItself() throws Exception {
+
+   }
+
+   @Override
+   public List<MessageReference> cancelRefs(boolean failed,
+                                            boolean lastConsumedAsDelivered,
+                                            Transaction tx) throws Exception {
+      return null;
+   }
+
+   @Override
+   public void setStarted(boolean started) {
+
+   }
+
+   @Override
+   public void receiveCredits(int credits) {
+
+   }
+
+   @Override
+   public Queue getQueue() {
+      return null;
+   }
+
+   @Override
+   public MessageReference removeReferenceByID(long messageID) throws Exception {
+      return null;
+   }
+
+   @Override
+   public void backToDelivering(MessageReference reference) {
+
+   }
+
+   @Override
+   public List<MessageReference> getDeliveringReferencesBasedOnProtocol(boolean remove,
+                                                                        Object protocolDataStart,
+                                                                        Object protocolDataEnd) {
+      return null;
+   }
+
+   @Override
+   public void acknowledge(Transaction tx, long messageID) throws Exception {
+
+   }
+
+   @Override
+   public void individualAcknowledge(Transaction tx, long messageID) throws Exception {
+
+   }
+
+   @Override
+   public void individualCancel(long messageID, boolean failed) throws Exception {
+
+   }
+
+   @Override
+   public void forceDelivery(long sequence) {
+
+   }
+
+   @Override
+   public void setTransferring(boolean transferring) {
+
+   }
+
+   @Override
+   public boolean isBrowseOnly() {
+      return false;
+   }
+
+   @Override
+   public long getCreationTime() {
+      return 0;
+   }
+
+   @Override
+   public String getSessionID() {
+      return null;
+   }
+
+   @Override
+   public void promptDelivery() {
+
+   }
+
+   @Override
+   public HandleStatus handle(MessageReference reference) throws Exception {
+      return null;
+   }
+
+   @Override
+   public void proceedDeliver(MessageReference reference) throws Exception {
+
+   }
+
+   @Override
+   public Filter getFilter() {
+      return null;
+   }
+
+   @Override
+   public List<MessageReference> getDeliveringMessages() {
+      return null;
+   }
+
+   @Override
+   public String debug() {
+      return null;
+   }
+
+   @Override
+   public String toManagementString() {
+      return null;
+   }
+
+   @Override
+   public void disconnect() {
+
+   }
+}

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bd4b7cec/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/QueueCommandTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/QueueCommandTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/QueueCommandTest.java
new file mode 100644
index 0000000..9d63439
--- /dev/null
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/cli/QueueCommandTest.java
@@ -0,0 +1,227 @@
+/*
+ * 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.artemis.tests.integration.cli;
+
+import java.io.ByteArrayOutputStream;
+import java.io.PrintStream;
+import java.util.UUID;
+
+import org.apache.activemq.artemis.api.core.SimpleString;
+import org.apache.activemq.artemis.cli.commands.ActionContext;
+import org.apache.activemq.artemis.cli.commands.queue.CreateQueue;
+import org.apache.activemq.artemis.cli.commands.queue.DeleteQueue;
+import org.apache.activemq.artemis.cli.commands.queue.QueueAction;
+import org.apache.activemq.artemis.core.server.Queue;
+import org.apache.activemq.artemis.core.server.impl.AddressInfo;
+import org.apache.activemq.artemis.tests.util.JMSTestBase;
+import org.junit.Before;
+import org.junit.Test;
+
+public class QueueCommandTest extends JMSTestBase {
+
+   //the command
+   private ByteArrayOutputStream output;
+   private ByteArrayOutputStream error;
+
+   @Before
+   @Override
+   public void setUp() throws Exception {
+      super.setUp();
+      this.output = new ByteArrayOutputStream(1024);
+      this.error = new ByteArrayOutputStream(1024);
+   }
+
+   @Test
+   public void testCreateCoreQueueShowsErrorWhenAddressDoesNotExists() throws Exception {
+      String queueName = "queue1";
+      CreateQueue command = new CreateQueue();
+      command.setName(queueName);
+      command.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
+      checkExecutionFailure(command, "AMQ119203: Address Does Not Exist:");;
+      assertFalse(server.queueQuery(new SimpleString(queueName)).isExists());
+   }
+
+   @Test
+   public void testCreateCoreQueueAutoCreateAddressDefaultAddress() throws Exception {
+      String queueName = UUID.randomUUID().toString();
+      CreateQueue command = new CreateQueue();
+      command.setName(queueName);
+      command.setAutoCreateAddress(true);
+      command.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
+      checkExecutionPassed(command);
+      assertNotNull(server.getAddressInfo(new SimpleString(queueName)));
+
+      Queue queue = server.locateQueue(new SimpleString(queueName));
+      assertEquals(-1, queue.getMaxConsumers());
+      assertEquals(false, queue.isDeleteOnNoConsumers());
+      assertTrue(server.queueQuery(new SimpleString(queueName)).isExists());
+   }
+
+   @Test
+   public void testCreateCoreQueueAddressExists() throws Exception {
+      String queueName = "queue";
+      String address= "address";
+
+      CreateQueue command = new CreateQueue();
+      command.setName(queueName);
+      command.setAutoCreateAddress(false);
+      command.setAddress(address);
+
+      server.createOrUpdateAddressInfo(new AddressInfo(new SimpleString(address)));
+
+      command.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
+      checkExecutionPassed(command);
+      assertNotNull(server.getAddressInfo(new SimpleString(address)));
+
+      Queue queue = server.locateQueue(new SimpleString(queueName));
+      assertEquals(-1, queue.getMaxConsumers());
+      assertEquals(false, queue.isDeleteOnNoConsumers());
+      assertTrue(server.queueQuery(new SimpleString(queueName)).isExists());
+   }
+
+   @Test
+   public void testCreateCoreQueueWithFilter() throws Exception {
+      String queueName = "queue2";
+      String filerString = "color='green'";
+
+      CreateQueue command = new CreateQueue();
+      command.setName(queueName);
+      command.setFilter("color='green'");
+      command.setAutoCreateAddress(true);
+      command.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
+
+      checkExecutionPassed(command);
+      Queue queue = server.locateQueue(new SimpleString(queueName));
+      assertNotNull(queue);
+      assertEquals(new SimpleString(filerString), queue.getFilter().getFilterString());
+   }
+
+   @Test
+   public void testCreateQueueAlreadyExists() throws Exception {
+      String queueName = "queue2";
+      String filerString = "color='green'";
+
+      CreateQueue command = new CreateQueue();
+      command.setName(queueName);
+      command.setFilter("color='green'");
+      command.setAutoCreateAddress(true);
+      command.execute(new ActionContext());
+      command.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
+      checkExecutionFailure(command, "AMQ119019: Queue already exists " + queueName);
+   }
+
+   @Test
+   public void testDeleteCoreQueue() throws Exception {
+      SimpleString queueName = new SimpleString("deleteQueue");
+
+      CreateQueue command = new CreateQueue();
+      command.setName(queueName.toString());
+      command.setFilter("color='green'");
+      command.setAutoCreateAddress(true);
+      command.execute(new ActionContext());
+
+      DeleteQueue delete = new DeleteQueue();
+      delete.setName(queueName.toString());
+      delete.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
+      checkExecutionPassed(delete);
+
+      assertFalse(server.queueQuery(queueName).isExists());
+   }
+
+   @Test
+   public void testDeleteQueueDoesNotExist() throws Exception {
+      SimpleString queueName = new SimpleString("deleteQueue");
+
+      DeleteQueue delete = new DeleteQueue();
+      delete.setName(queueName.toString());
+      delete.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
+      checkExecutionFailure(delete, "AMQ119017: Queue " + queueName + " does not exist");
+
+      assertFalse(server.queueQuery(queueName).isExists());
+   }
+
+   @Test
+   public void testDeleteQueueWithConsumersFails() throws Exception {
+      SimpleString queueName = new SimpleString("deleteQueue");
+
+      CreateQueue command = new CreateQueue();
+      command.setName(queueName.toString());
+      command.setFilter("color='green'");
+      command.setAutoCreateAddress(true);
+      command.execute(new ActionContext());
+
+      server.locateQueue(queueName).addConsumer(new DummyServerConsumer());
+
+      DeleteQueue delete = new DeleteQueue();
+      delete.setName(queueName.toString());
+      delete.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
+      checkExecutionFailure(delete, "AMQ119025: Cannot delete queue " + queueName + " on binding deleteQueue");
+   }
+
+   @Test
+   public void testDeleteQueueWithConsumersFailsAndRemoveConsumersTrue() throws Exception {
+      SimpleString queueName = new SimpleString("deleteQueue");
+
+      CreateQueue command = new CreateQueue();
+      command.setName(queueName.toString());
+      command.setFilter("color='green'");
+      command.setAutoCreateAddress(true);
+      command.execute(new ActionContext());
+
+      server.locateQueue(queueName).addConsumer(new DummyServerConsumer());
+
+      DeleteQueue delete = new DeleteQueue();
+      delete.setName(queueName.toString());
+      delete.setRemoveConsumers(true);
+      delete.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
+      checkExecutionPassed(command);
+   }
+
+   @Test
+   public void testAutoDeleteAddress() throws Exception {
+      SimpleString queueName = new SimpleString("deleteQueue");
+
+      CreateQueue command = new CreateQueue();
+      command.setName(queueName.toString());
+      command.setFilter("color='green'");
+      command.setAutoCreateAddress(true);
+      command.execute(new ActionContext());
+      assertNotNull(server.getAddressInfo(queueName));
+
+      server.locateQueue(queueName).addConsumer(new DummyServerConsumer());
+
+      DeleteQueue delete = new DeleteQueue();
+      delete.setName(queueName.toString());
+      delete.setRemoveConsumers(true);
+      delete.setAutoDeleteAddress(true);
+      delete.execute(new ActionContext(System.in, new PrintStream(output), new PrintStream(error)));
+      checkExecutionPassed(command);
+      assertNull(server.getAddressInfo(queueName));
+   }
+
+   private void checkExecutionPassed(QueueAction command) throws Exception {
+      String fullMessage = output.toString();
+      System.out.println("output: " + fullMessage);
+      assertTrue(fullMessage, fullMessage.contains("successfully"));
+   }
+
+   private void checkExecutionFailure(QueueAction command, String message) throws Exception {
+      String fullMessage = error.toString();
+      System.out.println("error: " + fullMessage);
+      assertTrue(fullMessage, fullMessage.contains(message));
+   }
+}

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bd4b7cec/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/management/ActiveMQServerControlUsingCoreTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/management/ActiveMQServerControlUsingCoreTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/management/ActiveMQServerControlUsingCoreTest.java
index ad36598..bac0784 100644
--- a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/management/ActiveMQServerControlUsingCoreTest.java
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/management/ActiveMQServerControlUsingCoreTest.java
@@ -122,6 +122,17 @@ public class ActiveMQServerControlUsingCoreTest extends ActiveMQServerControlTes
          }
 
          @Override
+         public void createQueue(@Parameter(name = "address", desc = "Address of the queue") String address,
+                                 @Parameter(name = "name", desc = "Name of the queue") String name,
+                                 @Parameter(name = "filter", desc = "Filter of the queue") String filter,
+                                 @Parameter(name = "durable", desc = "Is the queue durable?") boolean durable,
+                                 @Parameter(name = "maxConsumers", desc = "The maximum number of consumers allowed on this queue at any one time") int maxConsumers,
+                                 @Parameter(name = "deleteOnNoConsumers", desc = "Delete this queue when the last consumer disconnects") boolean deleteOnNoConsumers,
+                                 @Parameter(name = "autoCreateAddress", desc = "Create an address with default values should a matching address not be found") boolean autoCreateAddress) throws Exception {
+
+         }
+
+         @Override
          public void deployQueue(final String address,
                                  final String name,
                                  final String filter,

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bd4b7cec/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/mqtt/imported/MQTTTest.java
----------------------------------------------------------------------
diff --git a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/mqtt/imported/MQTTTest.java b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/mqtt/imported/MQTTTest.java
index 00d220b..3095cb5 100644
--- a/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/mqtt/imported/MQTTTest.java
+++ b/tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/mqtt/imported/MQTTTest.java
@@ -1628,7 +1628,7 @@ public class MQTTTest extends MQTTTestSupport {
          addressInfo.setDefaultMaxQueueConsumers(0);
          getServer().createOrUpdateAddressInfo(addressInfo);
 
-         getServer().createQueue(coreAddress, new SimpleString(clientId + "." + coreAddress), null, false, true, 0, false);
+         getServer().createQueue(coreAddress, new SimpleString(clientId + "." + coreAddress), null, false, true, 0, false, false);
 
          MQTT mqtt = createMQTTConnection();
          mqtt.setClientId(clientId);
@@ -1674,7 +1674,7 @@ public class MQTTTest extends MQTTTestSupport {
       try {
          String clientId = "testMqtt";
          SimpleString coreAddress = new SimpleString("foo.bar");
-         getServer().createQueue(coreAddress, new SimpleString(clientId + "." + coreAddress), null, false, true, -1, true);
+         getServer().createQueue(coreAddress, new SimpleString(clientId + "." + coreAddress), null, false, true, -1, true, false);
 
          Topic[] mqttSubscription = new Topic[]{new Topic("foo/bar", QoS.AT_LEAST_ONCE)};