You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ro...@apache.org on 2022/06/27 14:06:55 UTC

[activemq-artemis] 03/03: more fixups from chainges on main to 2ab0e85db48964fdb45b47b7c7da3ea504943c56, convert modules missed originally due to the test interdependencies

This is an automated email from the ASF dual-hosted git repository.

robbie pushed a commit to branch new-logging
in repository https://gitbox.apache.org/repos/asf/activemq-artemis.git

commit c658de2cbb11d6a371de1753c362ee29a6faf567
Author: Robbie Gemmell <ro...@apache.org>
AuthorDate: Mon Jun 27 14:13:47 2022 +0100

    more fixups from chainges on main to 2ab0e85db48964fdb45b47b7c7da3ea504943c56, convert modules missed originally due to the test interdependencies
---
 .../e2e/brokerConnection/ChainedMirrorTest.java    |  3 --
 .../DualMirrorFailoverWithContainerTest.java       |  5 +--
 .../e2e/brokerConnection/QpidDispatchPeerTest.java |  9 ++---
 .../e2e/brokerConnection/SplitMirrorTest.java      |  3 --
 .../bridgeTransfer/BridgeTransferingTest.java      | 11 +++---
 .../DualMirrorNoContainerTest.java                 |  3 --
 .../brokerConnection/PagedMirrorSmokeTest.java     |  3 --
 .../tests/smoke/dnsswitch/DNSSwitchTest.java       |  5 +--
 .../infinite/InfiniteRedeliverySmokeTest.java      |  9 ++---
 .../artemis/tests/smoke/jms/ManifestTest.java      |  2 --
 .../ReplicatedMultipleFailbackTest.java            | 27 +++++++-------
 .../tests/smoke/mmfactory/MMSFactoryTest.java      | 25 ++++++-------
 .../smoke/paging/FloodServerWithAsyncSendTest.java | 11 +++---
 .../quorum/PluggableQuorumSinglePairTest.java      | 41 +++++++++++-----------
 .../quorum/ZookeeperPluggableQuorumPeerTest.java   | 13 +++----
 .../ZookeeperPluggableQuorumSinglePairTest.java    |  7 ++--
 .../smoke/replicationflow/SoakPagingTest.java      | 17 ++++-----
 17 files changed, 96 insertions(+), 98 deletions(-)

diff --git a/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/ChainedMirrorTest.java b/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/ChainedMirrorTest.java
index db00673966..44f9332e76 100644
--- a/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/ChainedMirrorTest.java
+++ b/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/ChainedMirrorTest.java
@@ -26,7 +26,6 @@ import javax.jms.TextMessage;
 
 import org.apache.activemq.artemis.tests.e2e.common.ContainerService;
 import org.apache.activemq.artemis.tests.e2e.common.E2ETestBase;
-import org.jboss.logging.Logger;
 import org.junit.After;
 import org.junit.Assert;
 import org.junit.Before;
@@ -34,8 +33,6 @@ import org.junit.Test;
 
 public class ChainedMirrorTest extends E2ETestBase {
 
-   private static final Logger logger = Logger.getLogger(ChainedMirrorTest.class);
-
    Object network;
 
    public Object serverMainA;
diff --git a/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/DualMirrorFailoverWithContainerTest.java b/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/DualMirrorFailoverWithContainerTest.java
index debb60a2a2..8d8202a610 100644
--- a/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/DualMirrorFailoverWithContainerTest.java
+++ b/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/DualMirrorFailoverWithContainerTest.java
@@ -27,15 +27,16 @@ import javax.jms.TextMessage;
 
 import org.apache.activemq.artemis.tests.e2e.common.ContainerService;
 import org.apache.activemq.artemis.tests.e2e.common.E2ETestBase;
-import org.jboss.logging.Logger;
 import org.junit.After;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class DualMirrorFailoverWithContainerTest extends E2ETestBase {
 
-   private static final Logger logger = Logger.getLogger(DualMirrorFailoverWithContainerTest.class);
+   private static final Logger logger = LoggerFactory.getLogger(DualMirrorFailoverWithContainerTest.class);
 
    Object network;
 
diff --git a/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/QpidDispatchPeerTest.java b/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/QpidDispatchPeerTest.java
index 0598e55f89..057adf91a5 100644
--- a/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/QpidDispatchPeerTest.java
+++ b/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/QpidDispatchPeerTest.java
@@ -27,12 +27,13 @@ import javax.jms.Session;
 
 import org.apache.activemq.artemis.tests.e2e.common.E2ETestBase;
 import org.apache.activemq.artemis.tests.e2e.common.ContainerService;
-import org.jboss.logging.Logger;
 import org.junit.AfterClass;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.BeforeClass;
 import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 /**
  * You need to build the Artemis Centos image before this test is executed.
@@ -40,7 +41,7 @@ import org.junit.Test;
  */
 public class QpidDispatchPeerTest extends E2ETestBase {
 
-   private static final Logger logger = Logger.getLogger(QpidDispatchPeerTest.class);
+   private static final Logger logger = LoggerFactory.getLogger(QpidDispatchPeerTest.class);
 
    static Object network;
    static Object qpidServer;
@@ -109,7 +110,7 @@ public class QpidDispatchPeerTest extends E2ETestBase {
             producer.setDeliveryMode(DeliveryMode.PERSISTENT);
 
             for (int i = 0; i < numberOfMessages; i++) {
-               logger.debug("Sending " + i);
+               logger.debug("Sending {}", i);
                producer.send(session.createTextMessage("hello " + i));
             }
             connection.close();
@@ -152,7 +153,7 @@ public class QpidDispatchPeerTest extends E2ETestBase {
          producer.setDeliveryMode(DeliveryMode.PERSISTENT);
 
          for (int i = 0; i < numberOfMessages; i++) {
-            logger.debug("Sending " + i);
+            logger.debug("Sending {}", i);
             producer.send(session.createTextMessage("hello " + i));
          }
          connection.close();
diff --git a/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/SplitMirrorTest.java b/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/SplitMirrorTest.java
index 9cea6d285f..5702f0ffd6 100644
--- a/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/SplitMirrorTest.java
+++ b/tests/e2e-tests/src/test/java/org/apache/activemq/artemis/tests/e2e/brokerConnection/SplitMirrorTest.java
@@ -27,7 +27,6 @@ import javax.jms.TextMessage;
 
 import org.apache.activemq.artemis.tests.e2e.common.ContainerService;
 import org.apache.activemq.artemis.tests.e2e.common.E2ETestBase;
-import org.jboss.logging.Logger;
 import org.junit.After;
 import org.junit.Assert;
 import org.junit.Before;
@@ -35,8 +34,6 @@ import org.junit.Test;
 
 public class SplitMirrorTest extends E2ETestBase {
 
-   private static final Logger logger = Logger.getLogger(SplitMirrorTest.class);
-
    Object network;
 
    public Object serverMainA;
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/bridgeTransfer/BridgeTransferingTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/bridgeTransfer/BridgeTransferingTest.java
index fd12e170cc..5cd7e6cef5 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/bridgeTransfer/BridgeTransferingTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/bridgeTransfer/BridgeTransferingTest.java
@@ -31,20 +31,21 @@ import org.apache.activemq.artemis.jms.client.ActiveMQConnectionFactory;
 import org.apache.activemq.artemis.tests.smoke.common.SmokeTestBase;
 import org.apache.activemq.artemis.tests.util.CFUtil;
 import org.apache.activemq.artemis.utils.Wait;
-import org.jboss.logging.Logger;
 import org.junit.After;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 @RunWith(Parameterized.class)
 public class BridgeTransferingTest extends SmokeTestBase {
 
    public static final String SERVER_NAME_0 = "bridgeTransfer/serverA";
    public static final String SERVER_NAME_1 = "bridgeTransfer/serverB";
-   private static final Logger logger = Logger.getLogger(BridgeTransferingTest.class);
+   private static final Logger logger = LoggerFactory.getLogger(BridgeTransferingTest.class);
    private static final String JMX_SERVER_HOSTNAME = "localhost";
    private static final int JMX_SERVER_PORT = 11099;
 
@@ -117,13 +118,13 @@ public class BridgeTransferingTest extends SmokeTestBase {
             producer.send(session.createTextMessage(body + " " + i));
 
             if (++txElement == commitInterval) {
-               logger.debug("Sent " + (i + 1) + " messages");
+               logger.debug("Sent {} messages", (i + 1));
                txElement = 0;
                session.commit();
             }
 
             if (++killElement == killServerInterval) {
-               logger.debug("Killing server at " + (i + 1));
+               logger.debug("Killing server at {}", (i + 1));
                killElement = 0;
                if (killBothServers) {
                   serverProcess.destroyForcibly();
@@ -158,7 +159,7 @@ public class BridgeTransferingTest extends SmokeTestBase {
 
          for (int i = 0; i < numberOfMessages; i++) {
             if (i % 100 == 0) {
-               logger.debug("consuming " + i);
+               logger.debug("consuming {}", i);
             }
             TextMessage message = (TextMessage) consumer.receive(5000);
             Assert.assertNotNull(message);
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/brokerConnection/DualMirrorNoContainerTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/brokerConnection/DualMirrorNoContainerTest.java
index 3b7e3d8822..b842a080eb 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/brokerConnection/DualMirrorNoContainerTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/brokerConnection/DualMirrorNoContainerTest.java
@@ -35,7 +35,6 @@ import org.apache.activemq.artemis.cli.commands.tools.PrintData;
 import org.apache.activemq.artemis.tests.smoke.common.SmokeTestBase;
 import org.apache.activemq.artemis.tests.util.CFUtil;
 import org.apache.activemq.artemis.util.ServerUtil;
-import org.jboss.logging.Logger;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
@@ -45,8 +44,6 @@ public class DualMirrorNoContainerTest extends SmokeTestBase {
    // Change this to true to generate a print-data in certain cases on this test
    private static final boolean PRINT_DATA = false;
 
-   private static final Logger logger = Logger.getLogger(DualMirrorNoContainerTest.class);
-
    public static final String SERVER_NAME_A = "brokerConnect/mirrorSecurityA";
    public static final String SERVER_NAME_B = "brokerConnect/mirrorSecurityB";
 
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/brokerConnection/PagedMirrorSmokeTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/brokerConnection/PagedMirrorSmokeTest.java
index 3d88fbc2b0..f371ec90e2 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/brokerConnection/PagedMirrorSmokeTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/brokerConnection/PagedMirrorSmokeTest.java
@@ -33,7 +33,6 @@ import org.apache.activemq.artemis.tests.smoke.common.SmokeTestBase;
 import org.apache.activemq.artemis.tests.util.CFUtil;
 import org.apache.activemq.artemis.utils.Wait;
 import org.apache.activemq.artemis.util.ServerUtil;
-import org.jboss.logging.Logger;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
@@ -43,8 +42,6 @@ public class PagedMirrorSmokeTest extends SmokeTestBase {
    // Change this to true to generate a print-data in certain cases on this test
    private static final boolean PRINT_DATA = false;
 
-   private static final Logger logger = Logger.getLogger(PagedMirrorSmokeTest.class);
-
    public static final String SERVER_NAME_A = "brokerConnect/pagedA";
    public static final String SERVER_NAME_B = "brokerConnect/pagedB";
 
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/dnsswitch/DNSSwitchTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/dnsswitch/DNSSwitchTest.java
index 9eb2624a68..30b62a1fd4 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/dnsswitch/DNSSwitchTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/dnsswitch/DNSSwitchTest.java
@@ -52,7 +52,6 @@ import org.apache.activemq.artemis.utils.SpawnedVMSupport;
 import org.apache.activemq.artemis.utils.Wait;
 import org.apache.activemq.artemis.utils.network.NetUtil;
 import org.apache.activemq.artemis.utils.network.NetUtilResource;
-import org.jboss.logging.Logger;
 import org.junit.AfterClass;
 import org.junit.Assert;
 import org.junit.Assume;
@@ -60,6 +59,8 @@ import org.junit.Before;
 import org.junit.BeforeClass;
 import org.junit.Rule;
 import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 /**
  * Validating connection retry scenarios where the DNS had changes
@@ -70,7 +71,7 @@ public class DNSSwitchTest extends SmokeTestBase {
    private static final String JMX_SERVER_HOSTNAME = "localhost";
    private static final int JMX_SERVER_PORT_0 = 10099;
    private static final int JMX_SERVER_PORT_1 = 10199;
-   private static final Logger logger = Logger.getLogger(DNSSwitchTest.class);
+   private static final Logger logger = LoggerFactory.getLogger(DNSSwitchTest.class);
    private static final String SERVER_NAME_0 = "dnsswitch";
    private static final String SERVER_NAME_1 = "dnsswitch2";
    private static final String SERVER_STANDARD = "standard";
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/infinite/InfiniteRedeliverySmokeTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/infinite/InfiniteRedeliverySmokeTest.java
index 637cd695bf..1608bf561b 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/infinite/InfiniteRedeliverySmokeTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/infinite/InfiniteRedeliverySmokeTest.java
@@ -33,14 +33,15 @@ import org.apache.activemq.artemis.core.io.nio.NIOSequentialFileFactory;
 import org.apache.activemq.artemis.jms.client.ActiveMQConnectionFactory;
 import org.apache.activemq.artemis.tests.smoke.common.SmokeTestBase;
 import org.apache.activemq.artemis.utils.Wait;
-import org.jboss.logging.Logger;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class InfiniteRedeliverySmokeTest extends SmokeTestBase {
 
-   private static final Logger logger = Logger.getLogger(InfiniteRedeliverySmokeTest.class);
+   private static final Logger logger = LoggerFactory.getLogger(InfiniteRedeliverySmokeTest.class);
 
    public static final String SERVER_NAME_0 = "infinite-redelivery";
 
@@ -77,7 +78,7 @@ public class InfiniteRedeliverySmokeTest extends SmokeTestBase {
       SequentialFileFactory fileFactory = new NIOSequentialFileFactory(journalLocation, 1);
 
       for (int i = 0; i < 500; i++) {
-         if (i % 10 == 0) logger.debug("Redelivery " + i);
+         if (i % 10 == 0) logger.debug("Redelivery {}", i);
          for (int j = 0; j < 5000; j++) {
             Assert.assertNotNull(consumer.receive(5000));
          }
@@ -124,7 +125,7 @@ public class InfiniteRedeliverySmokeTest extends SmokeTestBase {
       connection.start();
       MessageConsumer consumer = session.createConsumer(queue);
       for (int i = 0; i < 500; i++) {
-         if (i % 10 == 0) logger.debug("Rollback send " + i);
+         if (i % 10 == 0) logger.debug("Rollback send {}", i);
          for (int j = 0; j < 5000; j++) {
             producer.send(message);
          }
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/jms/ManifestTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/jms/ManifestTest.java
index b63af7ba57..79aabb6e79 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/jms/ManifestTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/jms/ManifestTest.java
@@ -31,13 +31,11 @@ import org.apache.activemq.artemis.core.server.ActiveMQServers;
 import org.apache.activemq.artemis.core.version.Version;
 import org.apache.activemq.artemis.jms.client.ActiveMQConnectionMetaData;
 import org.apache.activemq.artemis.tests.smoke.common.SmokeTestBase;
-import org.jboss.logging.Logger;
 import org.junit.Assert;
 import org.junit.Test;
 
 public class ManifestTest extends SmokeTestBase {
 
-   private static final Logger log = Logger.getLogger(ManifestTest.class);
    private static List<String> jarFiles = new ArrayList<>(Arrays.asList(
            "artemis-jms-client-", "artemis-jms-server-"));
 
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/jmxmultiplefailback/ReplicatedMultipleFailbackTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/jmxmultiplefailback/ReplicatedMultipleFailbackTest.java
index 7bfe660f87..6b3ee8be2b 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/jmxmultiplefailback/ReplicatedMultipleFailbackTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/jmxmultiplefailback/ReplicatedMultipleFailbackTest.java
@@ -44,14 +44,15 @@ import org.apache.activemq.artemis.api.core.management.ObjectNameBuilder;
 import org.apache.activemq.artemis.tests.smoke.common.SmokeTestBase;
 import org.apache.activemq.artemis.utils.JsonLoader;
 import org.apache.activemq.artemis.utils.Wait;
-import org.jboss.logging.Logger;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class ReplicatedMultipleFailbackTest extends SmokeTestBase {
 
-   private static final Logger LOGGER = Logger.getLogger(ReplicatedMultipleFailbackTest.class);
+   private static final Logger LOGGER = LoggerFactory.getLogger(ReplicatedMultipleFailbackTest.class);
 
    @FunctionalInterface
    interface ThrowableFunction<T, R> {
@@ -102,7 +103,7 @@ public class ReplicatedMultipleFailbackTest extends SmokeTestBase {
             final String backup = nodePair.getString("backup", null);
             networkTopology.put(nodeID, new Pair<>(live, backup));
          } catch (Exception e) {
-            LOGGER.warnf(e, "Error on %s", nodePair);
+            LOGGER.warn("Error on {}", nodePair, e);
          }
       }
       return networkTopology;
@@ -221,7 +222,7 @@ public class ReplicatedMultipleFailbackTest extends SmokeTestBase {
 
    @Test
    public void testMultipleFailback() throws Exception {
-      LOGGER.infof("TEST BOOTSTRAPPING START: STARTING brokers %s", Arrays.toString(Broker.values()));
+      LOGGER.info("TEST BOOTSTRAPPING START: STARTING brokers {}", Arrays.toString(Broker.values()));
       final int failbackRetries = 10;
       final int timeout = (int) TimeUnit.SECONDS.toMillis(30);
       Process master1 = Broker.master1.startServer(this, timeout);
@@ -238,7 +239,7 @@ public class ReplicatedMultipleFailbackTest extends SmokeTestBase {
       final String nodeIDlive3 = Broker.master3.getNodeID().get();
 
       for (Broker broker : Broker.values()) {
-         LOGGER.infof("CHECKING NETWORK TOPOLOGY FOR %s", broker);
+         LOGGER.info("CHECKING NETWORK TOPOLOGY FOR {}", broker);
          Wait.assertTrue(() -> validateNetworkTopology(broker.listNetworkTopology().orElse(""),
                                                        containsExactNodeIds(nodeIDlive1, nodeIDlive2, nodeIDlive3)
                                                           .and(withLive(nodeIDlive1, Objects::nonNull))
@@ -253,18 +254,18 @@ public class ReplicatedMultipleFailbackTest extends SmokeTestBase {
       Assert.assertNotNull(urlMaster1);
       Assert.assertNotEquals(urlMaster1, urlSlave1);
 
-      LOGGER.infof("Node ID live 1 is %s", nodeIDlive1);
-      LOGGER.infof("Node ID live 2 is %s", nodeIDlive2);
-      LOGGER.infof("Node ID live 3 is %s", nodeIDlive3);
+      LOGGER.info("Node ID live 1 is {}", nodeIDlive1);
+      LOGGER.info("Node ID live 2 is {}", nodeIDlive2);
+      LOGGER.info("Node ID live 3 is {}", nodeIDlive3);
 
-      LOGGER.infof("%s has url: %s", Broker.master1, urlMaster1);
-      LOGGER.infof("%s has url: %s", Broker.slave1, urlSlave1);
+      LOGGER.info("{} has url: {}", Broker.master1, urlMaster1);
+      LOGGER.info("{} has url: {}", Broker.slave1, urlSlave1);
 
       LOGGER.info("BOOTSTRAPPING ENDED: READ nodeIds and master1/slave1 urls");
 
       for (int i = 0; i < failbackRetries; i++) {
-         LOGGER.infof("START TEST %d", i + 1);
-         LOGGER.infof("KILLING master1");
+         LOGGER.info("START TEST {}", i + 1);
+         LOGGER.info("KILLING master1");
          killServer(master1);
          // wait until slave1 became live
          Wait.assertTrue(() -> !Broker.slave1.isBackup().orElse(true), timeout);
@@ -286,7 +287,7 @@ public class ReplicatedMultipleFailbackTest extends SmokeTestBase {
          Wait.assertTrue(() -> !Broker.master1.isBackup().orElse(true), timeout);
          LOGGER.info("master1 is LIVE");
          for (Broker broker : Broker.values()) {
-            LOGGER.infof("CHECKING NETWORK TOPOLOGY FOR %s", broker);
+            LOGGER.info("CHECKING NETWORK TOPOLOGY FOR {}", broker);
             Wait.assertTrue(() -> validateNetworkTopology(broker.listNetworkTopology().orElse(""),
                                                           containsExactNodeIds(nodeIDlive1, nodeIDlive2, nodeIDlive3)
                                                              .and(withLive(nodeIDlive1, urlMaster1::equals))
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/mmfactory/MMSFactoryTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/mmfactory/MMSFactoryTest.java
index 620ef65bb5..0164982975 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/mmfactory/MMSFactoryTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/mmfactory/MMSFactoryTest.java
@@ -48,16 +48,17 @@ import org.apache.activemq.artemis.tests.util.CFUtil;
 import org.apache.activemq.artemis.utils.RandomUtil;
 import org.apache.activemq.artemis.utils.SpawnedVMSupport;
 import org.apache.activemq.artemis.utils.Wait;
-import org.jboss.logging.Logger;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 @RunWith(Parameterized.class)
 public class MMSFactoryTest extends SmokeTestBase {
 
-   private static final Logger logger = Logger.getLogger(MMSFactoryTest.class);
+   private static final Logger logger = LoggerFactory.getLogger(MMSFactoryTest.class);
 
    public static final String SERVER_NAME_0 = "mmfactory";
    private static final String JMX_SERVER_HOSTNAME = "localhost";
@@ -128,7 +129,7 @@ public class MMSFactoryTest extends SmokeTestBase {
    public void testMMSorting() throws Exception {
       for (int i = 0; i < restarts; i++) {
          logger.debug("*******************************************************************************************************************************");
-         logger.debug("Starting " + clientRuns);
+         logger.debug("Starting {}", clientRuns);
          logger.debug("*******************************************************************************************************************************");
          testMMSorting(clientRuns * i, clientRuns * (i + 1));
 
@@ -214,7 +215,7 @@ public class MMSFactoryTest extends SmokeTestBase {
                      consumers[1].destroyForcibly();
                      consumers[1] = startConsumerProcess(theprotocol, timeForConsumers[1], "MMFactory::MMConsumer", 100, 1);
                      logger.debug("...Reconnected");
-                     logger.debug("retry=" + retryNumber + ",sent=" + i + ", acked on this batch = " + (queueControl.getMessagesAcknowledged() - (retryNumber.get() * BATCH_SIZE * 2)) + ", total acked = " + queueControl.getMessagesAcknowledged());
+                     logger.debug("retry={},sent={}, acked on this batch = {}, total acked = {}", retryNumber, i, (queueControl.getMessagesAcknowledged() - (retryNumber.get() * BATCH_SIZE * 2)), queueControl.getMessagesAcknowledged());
                   }
                   TextMessage message = session.createTextMessage("This is blue " + largeString);
                   message.setStringProperty("color", "blue");
@@ -227,7 +228,7 @@ public class MMSFactoryTest extends SmokeTestBase {
                   mmsFactory.send(message);
 
                   if (i % 10 == 0) {
-                     logger.debug("Sending " + i + " run = " + run);
+                     logger.debug("Sending {} run = {}" , i, run);
                   }
 
                   if (i == 0) {
@@ -248,7 +249,7 @@ public class MMSFactoryTest extends SmokeTestBase {
                   if ((queueControl.getMessagesAcknowledged() + queueControl.getMessagesKilled() + queueControl.getMessagesExpired()) - (retryNumber.get() * BATCH_SIZE * 2) > (BATCH_SIZE * 2 - 500)) {
                      return true;
                   } else {
-                     logger.debug("Received " + queueControl.getMessagesAcknowledged());
+                     logger.debug("Received {}", queueControl.getMessagesAcknowledged());
                      return false;
                   }
                }, 45_000, 1_000);
@@ -265,7 +266,7 @@ public class MMSFactoryTest extends SmokeTestBase {
                for (int i = 0; i < consumers.length; i++) {
                   File file = new File(getConsumerLog(i));
                   if (!file.delete()) {
-                     logger.debug("not possible to remove " + file);
+                     logger.debug("not possible to remove {}", file);
                   }
                }
                for (int r = 0; r < consumers.length; r++) {
@@ -285,13 +286,13 @@ public class MMSFactoryTest extends SmokeTestBase {
             for (int i = 0; i < consumers.length; i++) {
                File file = new File(getConsumerLog(i));
                if (!file.delete()) {
-                  logger.warn("not possible to remove " + file);
+                  logger.warn("not possible to remove {}", file);
                }
             }
 
             File file = new File(getConsumerLog(1000)); //the DLQ processing ID used
             if (!file.delete()) {
-               logger.warn("not possible to remove " + file);
+               logger.warn("not possible to remove {}", file);
             }
          }
       }
@@ -302,10 +303,10 @@ public class MMSFactoryTest extends SmokeTestBase {
       Wait.waitFor(() -> {
 
          if (lastTime.get() == queueControl.getMessagesAcknowledged()) {
-            logger.debug("Waiting some change on " + queueControl.getMessagesAcknowledged() + " with messages Added = " + queueControl.getMessagesAdded() + " and killed = " + queueControl.getMessagesKilled());
+            logger.debug("Waiting some change on {} with messages Added = {} and killed = {}", queueControl.getMessagesAcknowledged(), queueControl.getMessagesAdded(), queueControl.getMessagesKilled());
             return false;
          } else {
-            logger.debug("Condition met! with " + queueControl.getMessagesAcknowledged() + " with messages Added = " + queueControl.getMessagesAdded() + " and killed = " + queueControl.getMessagesKilled());
+            logger.debug("Condition met! with {} with messages Added = {} and killed = {}", queueControl.getMessagesAcknowledged(), queueControl.getMessagesAdded(), queueControl.getMessagesKilled());
             lastTime.set((int)queueControl.getMessagesAcknowledged());
             return true;
          }
@@ -346,7 +347,7 @@ public class MMSFactoryTest extends SmokeTestBase {
             String color = message.getStringProperty("color");
             int messageSequence = message.getIntProperty("i");
             if (queuename.equals("DLQ")) {
-               logger.debug("Processing DLQ on color=" + color + ", sequence=" + messageSequence);
+               logger.debug("Processing DLQ on color={}, sequence={}", color, messageSequence);
             } else if (slowTime > 0) {
                Thread.sleep(slowTime);
             }
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/paging/FloodServerWithAsyncSendTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/paging/FloodServerWithAsyncSendTest.java
index 62323de158..2cada960cf 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/paging/FloodServerWithAsyncSendTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/paging/FloodServerWithAsyncSendTest.java
@@ -32,14 +32,15 @@ import java.util.concurrent.atomic.AtomicInteger;
 import org.apache.activemq.artemis.tests.smoke.common.SmokeTestBase;
 import org.apache.activemq.artemis.tests.util.CFUtil;
 import org.apache.activemq.artemis.utils.RandomUtil;
-import org.jboss.logging.Logger;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class FloodServerWithAsyncSendTest extends SmokeTestBase {
 
-   private static final Logger logger = Logger.getLogger(FloodServerWithAsyncSendTest.class);
+   private static final Logger logger = LoggerFactory.getLogger(FloodServerWithAsyncSendTest.class);
    public static final String SERVER_NAME_0 = "paging";
 
    volatile boolean running = true;
@@ -131,7 +132,7 @@ public class FloodServerWithAsyncSendTest extends SmokeTestBase {
                break;
             }
             if (rec % 10 == 0) {
-               logger.info(queueName + " receive " + rec);
+               logger.info("{} receive {}", queueName, rec);
             }
          }
 
@@ -167,7 +168,7 @@ public class FloodServerWithAsyncSendTest extends SmokeTestBase {
                break;
             }
             if (rec % 10 == 0) {
-               logger.info(queueName + " receive " + rec);
+               logger.info("{} receive {}", queueName, rec);
             }
          }
 
@@ -202,7 +203,7 @@ public class FloodServerWithAsyncSendTest extends SmokeTestBase {
 
          while (running) {
             if (++produced % 10 == 0) {
-               logger.info(queueName + " produced " + produced + " messages");
+               logger.info("{} produced {} messages", queueName ,produced);
             }
             producer.send(session.createTextMessage(randomString));
          }
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/PluggableQuorumSinglePairTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/PluggableQuorumSinglePairTest.java
index 864462c3e4..c3795edc33 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/PluggableQuorumSinglePairTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/PluggableQuorumSinglePairTest.java
@@ -31,13 +31,14 @@ import org.apache.activemq.artemis.tests.smoke.common.SmokeTestBase;
 import org.apache.activemq.artemis.tests.util.Jmx;
 import org.apache.activemq.artemis.util.ServerUtil;
 import org.apache.activemq.artemis.utils.Wait;
-import org.jboss.logging.Logger;
 import org.junit.After;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 import static org.apache.activemq.artemis.tests.util.Jmx.backupOf;
 import static org.apache.activemq.artemis.tests.util.Jmx.containsExactNodeIds;
@@ -52,7 +53,7 @@ import static org.apache.activemq.artemis.tests.util.Jmx.withNodes;
 @RunWith(Parameterized.class)
 public abstract class PluggableQuorumSinglePairTest extends SmokeTestBase {
 
-   private static final Logger LOGGER = Logger.getLogger(PluggableQuorumSinglePairTest.class);
+   private static final Logger LOGGER = LoggerFactory.getLogger(PluggableQuorumSinglePairTest.class);
 
    static final String JMX_SERVER_HOSTNAME = "localhost";
    static final int JMX_PORT_PRIMARY = 10099;
@@ -188,7 +189,7 @@ public abstract class PluggableQuorumSinglePairTest extends SmokeTestBase {
       Wait.assertTrue(() -> backup.isBackup().orElse(false), timeout);
       final String nodeID = primary.getNodeID().get();
       Assert.assertNotNull(nodeID);
-      LOGGER.infof("NodeID: %s", nodeID);
+      LOGGER.info("NodeID: {}", nodeID);
       for (BrokerControl broker : brokers) {
          Wait.assertTrue(() -> validateNetworkTopology(broker.listNetworkTopology().orElse(""),
                                                            containsExactNodeIds(nodeID)
@@ -197,16 +198,16 @@ public abstract class PluggableQuorumSinglePairTest extends SmokeTestBase {
                                                           .and(withMembers(1))
                                                           .and(withNodes(2))), timeout);
       }
-      LOGGER.infof("primary topology is: %s", primary.listNetworkTopology().get());
-      LOGGER.infof("backup topology is: %s", backup.listNetworkTopology().get());
+      LOGGER.info("primary topology is: {}", primary.listNetworkTopology().get());
+      LOGGER.info("backup topology is: {}", backup.listNetworkTopology().get());
       Assert.assertTrue(backup.isReplicaSync().get());
-      LOGGER.infof("backup is synchronized with live");
+      LOGGER.info("backup is synchronized with live");
       final String urlBackup = backupOf(nodeID, decodeNetworkTopologyJson(backup.listNetworkTopology().get()));
       Assert.assertNotNull(urlBackup);
-      LOGGER.infof("backup: %s", urlBackup);
+      LOGGER.info("backup: {}", urlBackup);
       final String urlPrimary = liveOf(nodeID, decodeNetworkTopologyJson(primary.listNetworkTopology().get()));
       Assert.assertNotNull(urlPrimary);
-      LOGGER.infof("primary: %s", urlPrimary);
+      LOGGER.info("primary: {}", urlPrimary);
       Assert.assertNotEquals(urlPrimary, urlBackup);
 
       // primary REPLICATED, backup matches (has replicated) activation sequence
@@ -223,7 +224,7 @@ public abstract class PluggableQuorumSinglePairTest extends SmokeTestBase {
                                                        .and(withBackup(nodeID, Objects::isNull))
                                                        .and(withMembers(1))
                                                        .and(withNodes(1))), timeout);
-      LOGGER.infof("backup topology is: %s", backup.listNetworkTopology().get());
+      LOGGER.info("backup topology is: {}", backup.listNetworkTopology().get());
       Assert.assertEquals(nodeID, backup.getNodeID().get());
 
       // backup UN REPLICATED (new version)
@@ -245,17 +246,17 @@ public abstract class PluggableQuorumSinglePairTest extends SmokeTestBase {
                                                           .and(withMembers(1))
                                                           .and(withNodes(2))), timeout);
       }
-      LOGGER.infof("primary topology is: %s", primary.listNetworkTopology().get());
-      LOGGER.infof("backup topology is: %s", backup.listNetworkTopology().get());
+      LOGGER.info("primary topology is: {}", primary.listNetworkTopology().get());
+      LOGGER.info("backup topology is: {}", backup.listNetworkTopology().get());
       Assert.assertTrue(backup.isReplicaSync().get());
-      LOGGER.infof("backup is synchronized with live");
+      LOGGER.info("backup is synchronized with live");
       Assert.assertEquals(nodeID, primary.getNodeID().get());
 
       // primary ran un replicated for a short while after failback, before backup was in sync
       Assert.assertEquals(3L, primary.getActivationSequence().get().longValue());
       Assert.assertEquals(3L, backup.getActivationSequence().get().longValue());
 
-      LOGGER.infof("Done, killing both");
+      LOGGER.info("Done, killing both");
       ServerUtil.killServer(primaryInstance);
       ServerUtil.killServer(backupInstance);
    }
@@ -335,7 +336,7 @@ public abstract class PluggableQuorumSinglePairTest extends SmokeTestBase {
       Wait.assertTrue(() -> backup.isBackup().orElse(false), timeout);
       final String nodeID = primary.getNodeID().get();
       Assert.assertNotNull(nodeID);
-      LOGGER.infof("NodeID: %s", nodeID);
+      LOGGER.info("NodeID: {}", nodeID);
       for (BrokerControl broker : brokers) {
          Wait.assertTrue(() -> validateNetworkTopology(broker.listNetworkTopology().orElse(""),
                                                        containsExactNodeIds(nodeID)
@@ -344,16 +345,16 @@ public abstract class PluggableQuorumSinglePairTest extends SmokeTestBase {
                                                           .and(withMembers(1))
                                                           .and(withNodes(2))), timeout);
       }
-      LOGGER.infof("primary topology is: %s", primary.listNetworkTopology().get());
-      LOGGER.infof("backup topology is: %s", backup.listNetworkTopology().get());
+      LOGGER.info("primary topology is: {}", primary.listNetworkTopology().get());
+      LOGGER.info("backup topology is: {}", backup.listNetworkTopology().get());
       Assert.assertTrue(backup.isReplicaSync().get());
-      LOGGER.infof("backup is synchronized with live");
+      LOGGER.info("backup is synchronized with live");
       final String urlBackup = backupOf(nodeID, decodeNetworkTopologyJson(backup.listNetworkTopology().get()));
       Assert.assertNotNull(urlBackup);
-      LOGGER.infof("backup: %s", urlBackup);
+      LOGGER.info("backup: {}", urlBackup);
       final String urlPrimary = liveOf(nodeID, decodeNetworkTopologyJson(primary.listNetworkTopology().get()));
       Assert.assertNotNull(urlPrimary);
-      LOGGER.infof("primary: %s", urlPrimary);
+      LOGGER.info("primary: {}", urlPrimary);
       Assert.assertNotEquals(urlPrimary, urlBackup);
 
 
@@ -371,7 +372,7 @@ public abstract class PluggableQuorumSinglePairTest extends SmokeTestBase {
                                                        .and(withBackup(nodeID, Objects::isNull))
                                                        .and(withMembers(1))
                                                        .and(withNodes(1))), timeout);
-      LOGGER.infof("backup topology is: %s", backup.listNetworkTopology().get());
+      LOGGER.info("backup topology is: {}", backup.listNetworkTopology().get());
       Assert.assertEquals(nodeID, backup.getNodeID().get());
 
 
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/ZookeeperPluggableQuorumPeerTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/ZookeeperPluggableQuorumPeerTest.java
index d6f2c50ca7..6252ef5497 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/ZookeeperPluggableQuorumPeerTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/ZookeeperPluggableQuorumPeerTest.java
@@ -24,9 +24,10 @@ import java.util.concurrent.TimeUnit;
 
 import org.apache.activemq.artemis.util.ServerUtil;
 import org.apache.activemq.artemis.utils.Wait;
-import org.jboss.logging.Logger;
 import org.junit.Assert;
 import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 import static org.apache.activemq.artemis.tests.util.Jmx.containsExactNodeIds;
 import static org.apache.activemq.artemis.tests.util.Jmx.decodeNetworkTopologyJson;
@@ -39,7 +40,7 @@ import static org.apache.activemq.artemis.tests.util.Jmx.withNodes;
 
 public class ZookeeperPluggableQuorumPeerTest extends ZookeeperPluggableQuorumSinglePairTest {
 
-   private static final Logger LOGGER = Logger.getLogger(ZookeeperPluggableQuorumPeerTest.class);
+   private static final Logger LOGGER = LoggerFactory.getLogger(ZookeeperPluggableQuorumPeerTest.class);
 
    public ZookeeperPluggableQuorumPeerTest() {
       super();
@@ -71,7 +72,7 @@ public class ZookeeperPluggableQuorumPeerTest extends ZookeeperPluggableQuorumSi
       Wait.waitFor(() -> primary.listNetworkTopology().isPresent(), timeout);
       final String urlPeerA = liveOf(coordinationId, decodeNetworkTopologyJson(primary.listNetworkTopology().get()));
       Assert.assertNotNull(urlPeerA);
-      LOGGER.infof("peer a acceptor: %s", urlPeerA);
+      LOGGER.info("peer a acceptor: {}", urlPeerA);
       LOGGER.info("killing peer a");
       ServerUtil.killServer(live, forceKill);
       LOGGER.info("starting peer b");
@@ -109,7 +110,7 @@ public class ZookeeperPluggableQuorumPeerTest extends ZookeeperPluggableQuorumSi
 
       final String nodeID = backup.getNodeID().get();
       Assert.assertNotNull(nodeID);
-      LOGGER.infof("NodeID: %s", nodeID);
+      LOGGER.info("NodeID: {}", nodeID);
 
       LOGGER.info("starting peer a primary");
       primary.startServer(this, 0);
@@ -126,8 +127,8 @@ public class ZookeeperPluggableQuorumPeerTest extends ZookeeperPluggableQuorumSi
                                                           .and(withNodes(2))), timeout);
       }
 
-      LOGGER.infof("primary topology is: %s", primary.listNetworkTopology().get());
-      LOGGER.infof("backup topology is: %s", backup.listNetworkTopology().get());
+      LOGGER.info("primary topology is: {}", primary.listNetworkTopology().get());
+      LOGGER.info("backup topology is: {}", backup.listNetworkTopology().get());
       Assert.assertTrue(backup.isReplicaSync().get());
       Assert.assertTrue(primary.isReplicaSync().get());
 
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/ZookeeperPluggableQuorumSinglePairTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/ZookeeperPluggableQuorumSinglePairTest.java
index 5d0de04424..25ded27384 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/ZookeeperPluggableQuorumSinglePairTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/quorum/ZookeeperPluggableQuorumSinglePairTest.java
@@ -24,14 +24,15 @@ import org.apache.activemq.artemis.utils.ThreadLeakCheckRule;
 import org.apache.curator.test.InstanceSpec;
 import org.apache.curator.test.TestingCluster;
 import org.apache.curator.test.TestingZooKeeperServer;
-import org.jboss.logging.Logger;
 import org.junit.After;
 import org.junit.Assert;
 import org.junit.Before;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class ZookeeperPluggableQuorumSinglePairTest extends PluggableQuorumSinglePairTest {
 
-   private static final Logger LOGGER = Logger.getLogger(ZookeeperPluggableQuorumSinglePairTest.class);
+   private static final Logger LOGGER = LoggerFactory.getLogger(ZookeeperPluggableQuorumSinglePairTest.class);
    private static final int BASE_SERVER_PORT = 6666;
    // Beware: the server tick must be small enough that to let the session to be correctly expired
    private static final int SERVER_TICK_MS = 100;
@@ -52,7 +53,7 @@ public class ZookeeperPluggableQuorumSinglePairTest extends PluggableQuorumSingl
       testingServer = new TestingCluster(clusterSpecs);
       testingServer.start();
       Assert.assertEquals("127.0.0.1:6666,127.0.0.1:6667,127.0.0.1:6668", testingServer.getConnectString());
-      LOGGER.infof("Cluster of %d nodes on: %s", 3, testingServer.getConnectString());
+      LOGGER.info("Cluster of {} nodes on: {}", 3, testingServer.getConnectString());
    }
 
    @Override
diff --git a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/replicationflow/SoakPagingTest.java b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/replicationflow/SoakPagingTest.java
index f37fb374a9..fcd4013f9d 100644
--- a/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/replicationflow/SoakPagingTest.java
+++ b/tests/smoke-tests/src/test/java/org/apache/activemq/artemis/tests/smoke/replicationflow/SoakPagingTest.java
@@ -58,17 +58,18 @@ import org.apache.qpid.jms.JmsConnectionFactory;
 import org.fusesource.mqtt.client.BlockingConnection;
 import org.fusesource.mqtt.client.MQTT;
 import org.fusesource.mqtt.client.QoS;
-import org.jboss.logging.Logger;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 @RunWith(Parameterized.class)
 public class SoakPagingTest extends SmokeTestBase {
 
-   private static final Logger log = Logger.getLogger(SoakPagingTest.class);
+   private static final Logger log = LoggerFactory.getLogger(SoakPagingTest.class);
 
    public static final int LAG_CONSUMER_TIME = 1000;
    public static final int TIME_RUNNING = 4000;
@@ -196,7 +197,7 @@ public class SoakPagingTest extends SmokeTestBase {
          Thread.sleep(time);
 
          int exitStatus = consumed.get() > 0 ? 1 : 0;
-         log.debug("Exiting with the status: " + exitStatus);
+         log.debug("Exiting with the status: {}", exitStatus);
          System.exit(exitStatus);
       } catch (Throwable t) {
          System.err.println("Exiting with the status 0. Reason: " + t);
@@ -253,7 +254,7 @@ public class SoakPagingTest extends SmokeTestBase {
          latch.countDown();
 
          connection.start();
-         log.debug("Producer" + index + " started");
+         log.debug("Producer{} started", index);
 
          final Session session;
 
@@ -287,7 +288,7 @@ public class SoakPagingTest extends SmokeTestBase {
             produced.incrementAndGet();
             i++;
             if (i % 100 == 0) {
-               log.debug("Producer" + index + " published " + i + " messages");
+               log.debug("Producer{} published {} messages", index, i);
                if (transaction) {
                   session.commit();
                }
@@ -332,17 +333,17 @@ public class SoakPagingTest extends SmokeTestBase {
 
          latch.countDown();
          connection.start();
-         log.debug("Consumer" + index + " started");
+         log.debug("Consumer{} started", index);
 
          int i = 0;
          while (true) {
             Message m = messageConsumer.receive(1000);
             consumed.incrementAndGet();
             if (m == null)
-               log.debug("Consumer" + index + "received null");
+               log.debug("Consumer{} received null", index);
             i++;
             if (i % 100 == 0) {
-               log.debug("Consumer" + index + "received " + i + " messages");
+               log.debug("Consumer{} received {} messages", index, i);
                if (transaction) {
                   session.commit();
                }