You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by an...@apache.org on 2016/05/03 11:55:28 UTC

[3/6] activemq-artemis git commit: Individualizing logger.traces on org.apache.activemq.artemis.core.server (artemis-server project)

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationEndpoint.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationEndpoint.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationEndpoint.java
index c5b9851..18c68d7 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationEndpoint.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationEndpoint.java
@@ -89,7 +89,7 @@ import org.jboss.logging.Logger;
 public final class ReplicationEndpoint implements ChannelHandler, ActiveMQComponent {
 
    private static final Logger logger = Logger.getLogger(ReplicationEndpoint.class);
-   private static final boolean isTrace = logger.isTraceEnabled();
+
 
    private final IOCriticalErrorListener criticalErrorListener;
    private final ActiveMQServerImpl server;
@@ -155,7 +155,7 @@ public final class ReplicationEndpoint implements ChannelHandler, ActiveMQCompon
 
    @Override
    public void handlePacket(final Packet packet) {
-      if (isTrace) {
+      if (logger.isTraceEnabled()) {
          logger.trace("handlePacket::handling " + packet);
       }
       PacketImpl response = new ReplicationResponseMessage();
@@ -163,7 +163,7 @@ public final class ReplicationEndpoint implements ChannelHandler, ActiveMQCompon
 
       try {
          if (!started) {
-            if (isTrace) {
+            if (logger.isTraceEnabled()) {
                logger.trace("handlePacket::ignoring " + packet);
             }
 
@@ -350,7 +350,7 @@ public final class ReplicationEndpoint implements ChannelHandler, ActiveMQCompon
    }
 
    private void finishSynchronization(String liveID) throws Exception {
-      if (isTrace) {
+      if (logger.isTraceEnabled()) {
          logger.trace("finishSynchronization::" + liveID);
       }
       for (JournalContent jc : EnumSet.allOf(JournalContent.class)) {
@@ -445,7 +445,7 @@ public final class ReplicationEndpoint implements ChannelHandler, ActiveMQCompon
     */
    private ReplicationResponseMessageV2 handleStartReplicationSynchronization(final ReplicationStartSyncMessage packet) throws Exception {
 
-      if (isTrace) {
+      if (logger.isTraceEnabled()) {
          logger.trace("handleStartReplicationSynchronization:: nodeID = " + packet);
       }
       ReplicationResponseMessageV2 replicationResponseMessage = new ReplicationResponseMessageV2();
@@ -494,7 +494,7 @@ public final class ReplicationEndpoint implements ChannelHandler, ActiveMQCompon
    }
 
    private void handleLargeMessageEnd(final ReplicationLargeMessageEndMessage packet) {
-      if (isTrace) {
+      if (logger.isTraceEnabled()) {
          logger.trace("handleLargeMessageEnd on " + packet.getMessageId());
       }
       final ReplicatedLargeMessage message = lookupLargeMessage(packet.getMessageId(), true, false);
@@ -503,7 +503,7 @@ public final class ReplicationEndpoint implements ChannelHandler, ActiveMQCompon
             @Override
             public void run() {
                try {
-                  if (isTrace) {
+                  if (logger.isTraceEnabled()) {
                      logger.trace("Deleting LargeMessage " + packet.getMessageId() + " on the executor @ handleLargeMessageEnd");
                   }
                   message.deleteFile();
@@ -558,7 +558,7 @@ public final class ReplicationEndpoint implements ChannelHandler, ActiveMQCompon
    private void handleLargeMessageBegin(final ReplicationLargeMessageBeginMessage packet) {
       final long id = packet.getMessageId();
       createLargeMessage(id, false);
-      if (isTrace) {
+      if (logger.isTraceEnabled()) {
          logger.trace("Receiving Large Message Begin " + id + " on backup");
       }
    }
@@ -636,13 +636,13 @@ public final class ReplicationEndpoint implements ChannelHandler, ActiveMQCompon
    private void handleAppendAddRecord(final ReplicationAddMessage packet) throws Exception {
       Journal journalToUse = getJournal(packet.getJournalID());
       if (packet.getRecord() == ADD_OPERATION_TYPE.UPDATE) {
-         if (isTrace) {
+         if (logger.isTraceEnabled()) {
             logger.trace("Endpoint appendUpdate id = " + packet.getId());
          }
          journalToUse.appendUpdateRecord(packet.getId(), packet.getJournalRecordType(), packet.getRecordData(), noSync);
       }
       else {
-         if (isTrace) {
+         if (logger.isTraceEnabled()) {
             logger.trace("Endpoint append id = " + packet.getId());
          }
          journalToUse.appendAddRecord(packet.getId(), packet.getJournalRecordType(), packet.getRecordData(), noSync);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationManager.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationManager.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationManager.java
index 4081dd9..1abd9c6 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationManager.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/replication/ReplicationManager.java
@@ -83,8 +83,7 @@ import org.jboss.logging.Logger;
 public final class ReplicationManager implements ActiveMQComponent, ReadyListener {
 
 
-   Logger logger = Logger.getLogger(ReplicationManager.class);
-   final boolean isTrace = logger.isTraceEnabled();
+   private static final Logger logger = Logger.getLogger(ReplicationManager.class);
 
    public enum ADD_OPERATION_TYPE {
       UPDATE {
@@ -584,7 +583,7 @@ public final class ReplicationManager implements ActiveMQComponent, ReadyListene
    public void sendSynchronizationDone(String nodeID, long initialReplicationSyncTimeout) {
       if (enabled) {
 
-         if (isTrace) {
+         if (logger.isTraceEnabled()) {
             logger.trace("sendSynchronizationDone ::" + nodeID + ", " + initialReplicationSyncTimeout);
          }
 
@@ -596,7 +595,7 @@ public final class ReplicationManager implements ActiveMQComponent, ReadyListene
             }
          }
          catch (InterruptedException e) {
-            ActiveMQServerLogger.LOGGER.debug(e);
+            logger.debug(e);
          }
          inSync = false;
       }
@@ -627,9 +626,9 @@ public final class ReplicationManager implements ActiveMQComponent, ReadyListene
     * @return
     */
    public OperationContext sendLiveIsStopping(final LiveStopping finalMessage) {
-      ActiveMQServerLogger.LOGGER.debug("LIVE IS STOPPING?!? message=" + finalMessage + " enabled=" + enabled);
+      logger.debug("LIVE IS STOPPING?!? message=" + finalMessage + " enabled=" + enabled);
       if (enabled) {
-         ActiveMQServerLogger.LOGGER.debug("LIVE IS STOPPING?!? message=" + finalMessage + " " + enabled);
+         logger.debug("LIVE IS STOPPING?!? message=" + finalMessage + " " + enabled);
          return sendReplicatePacket(new ReplicationLiveIsStoppingMessage(finalMessage));
       }
       return null;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/security/impl/SecurityStoreImpl.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/security/impl/SecurityStoreImpl.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/security/impl/SecurityStoreImpl.java
index 2807b47..dcda59f 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/security/impl/SecurityStoreImpl.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/security/impl/SecurityStoreImpl.java
@@ -29,7 +29,6 @@ import org.apache.activemq.artemis.core.security.Role;
 import org.apache.activemq.artemis.core.security.SecurityAuth;
 import org.apache.activemq.artemis.core.security.SecurityStore;
 import org.apache.activemq.artemis.core.server.ActiveMQMessageBundle;
-import org.apache.activemq.artemis.core.server.ActiveMQServerLogger;
 import org.apache.activemq.artemis.core.server.management.Notification;
 import org.apache.activemq.artemis.core.server.management.NotificationService;
 import org.apache.activemq.artemis.core.settings.HierarchicalRepository;
@@ -38,18 +37,14 @@ import org.apache.activemq.artemis.spi.core.security.ActiveMQSecurityManager;
 import org.apache.activemq.artemis.spi.core.security.ActiveMQSecurityManager2;
 import org.apache.activemq.artemis.utils.ConcurrentHashSet;
 import org.apache.activemq.artemis.utils.TypedProperties;
+import org.jboss.logging.Logger;
 
 /**
  * The ActiveMQ Artemis SecurityStore implementation
  */
 public class SecurityStoreImpl implements SecurityStore, HierarchicalRepositoryChangeListener {
-   // Constants -----------------------------------------------------
 
-   // Static --------------------------------------------------------
-
-   // Attributes ----------------------------------------------------
-
-   private final boolean trace = ActiveMQServerLogger.LOGGER.isTraceEnabled();
+   private static final Logger logger = Logger.getLogger(SecurityStoreImpl.class);
 
    private final HierarchicalRepository<Set<Role>> securityRepository;
 
@@ -108,8 +103,8 @@ public class SecurityStoreImpl implements SecurityStore, HierarchicalRepositoryC
       if (securityEnabled) {
 
          if (managementClusterUser.equals(user)) {
-            if (trace) {
-               ActiveMQServerLogger.LOGGER.trace("Authenticating cluster admin user");
+            if (logger.isTraceEnabled()) {
+               logger.trace("Authenticating cluster admin user");
             }
 
             /*
@@ -152,8 +147,8 @@ public class SecurityStoreImpl implements SecurityStore, HierarchicalRepositoryC
                      final CheckType checkType,
                      final SecurityAuth session) throws Exception {
       if (securityEnabled) {
-         if (trace) {
-            ActiveMQServerLogger.LOGGER.trace("checking access permissions to " + address);
+         if (logger.isTraceEnabled()) {
+            logger.trace("checking access permissions to " + address);
          }
 
          String user = session.getUsername();

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/MemoryManager.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/MemoryManager.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/MemoryManager.java
index 9b96c9f..74e527e 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/MemoryManager.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/MemoryManager.java
@@ -17,6 +17,7 @@
 package org.apache.activemq.artemis.core.server;
 
 import org.apache.activemq.artemis.utils.SizeFormatterUtil;
+import org.jboss.logging.Logger;
 
 /**
  * A memory usage watcher.
@@ -26,6 +27,8 @@ import org.apache.activemq.artemis.utils.SizeFormatterUtil;
  */
 public class MemoryManager implements ActiveMQComponent {
 
+   private static final Logger logger = Logger.getLogger(MemoryManager.class);
+
    private final Runtime runtime;
 
    private final long measureInterval;
@@ -57,7 +60,7 @@ public class MemoryManager implements ActiveMQComponent {
 
    @Override
    public synchronized void start() {
-      ActiveMQServerLogger.LOGGER.debug("Starting MemoryManager with MEASURE_INTERVAL: " + measureInterval +
+      logger.debug("Starting MemoryManager with MEASURE_INTERVAL: " + measureInterval +
                                            " FREE_MEMORY_PERCENT: " +
                                            memoryWarningThreshold);
 
@@ -127,8 +130,8 @@ public class MemoryManager implements ActiveMQComponent {
             info.append(String.format("total memory:     %s%n", SizeFormatterUtil.sizeof(totalMemory)));
             info.append(String.format("available memory: %.2f%%%n", availableMemoryPercent));
 
-            if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-               ActiveMQServerLogger.LOGGER.debug(info);
+            if (logger.isDebugEnabled()) {
+               logger.debug(info);
             }
 
             if (availableMemoryPercent <= memoryWarningThreshold) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/BackupManager.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/BackupManager.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/BackupManager.java
index ed7f641..d8e077c 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/BackupManager.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/BackupManager.java
@@ -37,12 +37,15 @@ import org.apache.activemq.artemis.core.server.ActiveMQServer;
 import org.apache.activemq.artemis.core.server.ActiveMQServerLogger;
 import org.apache.activemq.artemis.core.server.NodeManager;
 import org.apache.activemq.artemis.utils.ExecutorFactory;
+import org.jboss.logging.Logger;
 
 /*
 * takes care of updating the cluster with a backups transport configuration which is based on each cluster connection.
 * */
 public class BackupManager implements ActiveMQComponent {
 
+   private static final Logger logger = Logger.getLogger(BackupManager.class);
+
    private ActiveMQServer server;
    private Executor executor;
    private ScheduledExecutorService scheduledExecutor;
@@ -236,8 +239,8 @@ public class BackupManager implements ActiveMQComponent {
                         ActiveMQServerLogger.LOGGER.error("Error announcing backup: backupServerLocator is null. " + this);
                      return;
                   }
-                  if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-                     ActiveMQServerLogger.LOGGER.debug(BackupConnector.this + ":: announcing " + connector + " to " + backupServerLocator);
+                  if (logger.isDebugEnabled()) {
+                     logger.debug(BackupConnector.this + ":: announcing " + connector + " to " + backupServerLocator);
                   }
                   announcingBackup = true;
                   //connect to the cluster
@@ -337,8 +340,8 @@ public class BackupManager implements ActiveMQComponent {
       @Override
       public ServerLocatorInternal createServerLocator(Topology topology) {
          if (tcConfigs != null && tcConfigs.length > 0) {
-            if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-               ActiveMQServerLogger.LOGGER.debug(BackupManager.this + "Creating a serverLocator for " + Arrays.toString(tcConfigs));
+            if (logger.isDebugEnabled()) {
+               logger.debug(BackupManager.this + "Creating a serverLocator for " + Arrays.toString(tcConfigs));
             }
             ServerLocatorImpl locator = new ServerLocatorImpl(topology, true, tcConfigs);
             locator.setClusterConnection(true);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterController.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterController.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterController.java
index 175ca99..f8579be 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterController.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterController.java
@@ -29,8 +29,8 @@ import org.apache.activemq.artemis.api.core.Interceptor;
 import org.apache.activemq.artemis.api.core.Pair;
 import org.apache.activemq.artemis.api.core.SimpleString;
 import org.apache.activemq.artemis.api.core.TransportConfiguration;
-import org.apache.activemq.artemis.api.core.client.ClusterTopologyListener;
 import org.apache.activemq.artemis.api.core.client.ActiveMQClient;
+import org.apache.activemq.artemis.api.core.client.ClusterTopologyListener;
 import org.apache.activemq.artemis.api.core.client.ServerLocator;
 import org.apache.activemq.artemis.core.client.impl.ClientSessionFactoryInternal;
 import org.apache.activemq.artemis.core.client.impl.ServerLocatorImpl;
@@ -56,13 +56,14 @@ import org.apache.activemq.artemis.core.server.cluster.qourum.QuorumVoteHandler;
 import org.apache.activemq.artemis.core.server.cluster.qourum.Vote;
 import org.apache.activemq.artemis.core.server.impl.Activation;
 import org.apache.activemq.artemis.spi.core.remoting.Acceptor;
+import org.jboss.logging.Logger;
 
 /**
  * used for creating and managing cluster control connections for each cluster connection and the replication connection
  */
 public class ClusterController implements ActiveMQComponent {
 
-   private static final boolean isTrace = ActiveMQServerLogger.LOGGER.isTraceEnabled();
+   private static final Logger logger = Logger.getLogger(ClusterController.class);
 
    private final QuorumManager quorumManager;
 
@@ -348,8 +349,8 @@ public class ClusterController implements ActiveMQComponent {
                else {
                   pair = new Pair<>(msg.getConnector(), msg.getBackupConnector());
                }
-               if (isTrace) {
-                  ActiveMQServerLogger.LOGGER.trace("Server " + server + " receiving nodeUp from NodeID=" + msg.getNodeID() + ", pair=" + pair);
+               if (logger.isTraceEnabled()) {
+                  logger.trace("Server " + server + " receiving nodeUp from NodeID=" + msg.getNodeID() + ", pair=" + pair);
                }
 
                if (acceptorUsed != null) {
@@ -359,11 +360,11 @@ public class ClusterController implements ActiveMQComponent {
                      clusterConn.nodeAnnounced(msg.getCurrentEventID(), msg.getNodeID(), msg.getBackupGroupName(), scaleDownGroupName, pair, msg.isBackup());
                   }
                   else {
-                     ActiveMQServerLogger.LOGGER.debug("Cluster connection is null on acceptor = " + acceptorUsed);
+                     logger.debug("Cluster connection is null on acceptor = " + acceptorUsed);
                   }
                }
                else {
-                  ActiveMQServerLogger.LOGGER.debug("there is no acceptor used configured at the CoreProtocolManager " + this);
+                  logger.debug("there is no acceptor used configured at the CoreProtocolManager " + this);
                }
             }
             else if (packet.getType() == PacketImpl.QUORUM_VOTE) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterManager.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterManager.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterManager.java
index 9ad1137..5f3c44b 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterManager.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/ClusterManager.java
@@ -65,6 +65,7 @@ import org.apache.activemq.artemis.spi.core.remoting.Acceptor;
 import org.apache.activemq.artemis.utils.ConcurrentHashSet;
 import org.apache.activemq.artemis.utils.ExecutorFactory;
 import org.apache.activemq.artemis.utils.FutureLatch;
+import org.jboss.logging.Logger;
 
 /**
  * A ClusterManager manages {@link ClusterConnection}s, {@link BroadcastGroup}s and {@link Bridge}s.
@@ -75,6 +76,8 @@ import org.apache.activemq.artemis.utils.FutureLatch;
  */
 public final class ClusterManager implements ActiveMQComponent {
 
+   private static final Logger logger = Logger.getLogger(ClusterManager.class);
+
    private ClusterController clusterController;
 
    private HAManager haManager;
@@ -474,7 +477,7 @@ public final class ClusterManager implements ActiveMQComponent {
       serverLocator.addIncomingInterceptor(new IncomingInterceptorLookingForExceptionMessage(this, executor));
 
       if (!config.isUseDuplicateDetection()) {
-         ActiveMQServerLogger.LOGGER.debug("Bridge " + config.getName() +
+         logger.debug("Bridge " + config.getName() +
                                               " is configured to not use duplicate detecion, it will send messages synchronously");
       }
 
@@ -605,8 +608,8 @@ public final class ClusterManager implements ActiveMQComponent {
          if (dg == null)
             return;
 
-         if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-            ActiveMQServerLogger.LOGGER.debug(this + " Starting a Discovery Group Cluster Connection, name=" +
+         if (logger.isDebugEnabled()) {
+            logger.debug(this + " Starting a Discovery Group Cluster Connection, name=" +
                                                  config.getDiscoveryGroupName() +
                                                  ", dg=" +
                                                  dg);
@@ -619,8 +622,8 @@ public final class ClusterManager implements ActiveMQComponent {
       else {
          TransportConfiguration[] tcConfigs = config.getTransportConfigurations(configuration);
 
-         if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-            ActiveMQServerLogger.LOGGER.debug(this + " defining cluster connection towards " + Arrays.toString(tcConfigs));
+         if (logger.isDebugEnabled()) {
+            logger.debug(this + " defining cluster connection towards " + Arrays.toString(tcConfigs));
          }
 
          clusterConnection = new ClusterConnectionImpl(this, tcConfigs, connector, new SimpleString(config.getName()), new SimpleString(config.getAddress()), config.getMinLargeMessageSize(), config.getClientFailureCheckPeriod(), config.getConnectionTTL(), config.getRetryInterval(), config.getRetryIntervalMultiplier(), config.getMaxRetryInterval(), config.getInitialConnectAttempts(), config.getReconnectAttempts(), config.getCallTimeout(), config.getCallFailoverTimeout(), config.isDuplicateDetection(), config.getMessageLoadBalancingType(), config.getConfirmationWindowSize(), executorFactory, server, postOffice, managementService, scheduledExecutor, config.getMaxHops(), nodeManager, server.getConfiguration().getClusterUser(), server.getConfiguration().getClusterPassword(), config.isAllowDirectConnectionsOnly(), config.getClusterNotificationInterval(), config.getClusterNotificationAttempts());
@@ -637,8 +640,8 @@ public final class ClusterManager implements ActiveMQComponent {
 
       clusterConnections.put(config.getName(), clusterConnection);
 
-      if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-         ActiveMQServerLogger.LOGGER.trace("ClusterConnection.start at " + clusterConnection, new Exception("trace"));
+      if (logger.isTraceEnabled()) {
+         logger.trace("ClusterConnection.start at " + clusterConnection, new Exception("trace"));
       }
    }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BridgeImpl.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BridgeImpl.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BridgeImpl.java
index 45df584..44e608c 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BridgeImpl.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BridgeImpl.java
@@ -65,6 +65,7 @@ import org.apache.activemq.artemis.utils.FutureLatch;
 import org.apache.activemq.artemis.utils.ReusableLatch;
 import org.apache.activemq.artemis.utils.TypedProperties;
 import org.apache.activemq.artemis.utils.UUID;
+import org.jboss.logging.Logger;
 
 /**
  * A Core BridgeImpl
@@ -73,7 +74,7 @@ import org.apache.activemq.artemis.utils.UUID;
 public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowledgementHandler, ReadyListener {
    // Constants -----------------------------------------------------
 
-   private static final boolean isTrace = ActiveMQServerLogger.LOGGER.isTraceEnabled();
+   private static final Logger logger = Logger.getLogger(BridgeImpl.class);
 
    // Attributes ----------------------------------------------------
 
@@ -282,12 +283,12 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
          refs.clear();
       }
 
-      if (isTrace) {
-         ActiveMQServerLogger.LOGGER.trace("BridgeImpl::cancelRefs cancelling " + list.size() + " references");
+      if (logger.isTraceEnabled()) {
+         logger.trace("BridgeImpl::cancelRefs cancelling " + list.size() + " references");
       }
 
-      if (isTrace && list.isEmpty()) {
-         ActiveMQServerLogger.LOGGER.trace("didn't have any references to cancel on bridge " + this);
+      if (logger.isTraceEnabled() && list.isEmpty()) {
+         logger.trace("didn't have any references to cancel on bridge " + this);
          return;
       }
 
@@ -300,8 +301,8 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
       while (listIterator.hasPrevious()) {
          MessageReference ref = listIterator.previous();
 
-         if (isTrace) {
-            ActiveMQServerLogger.LOGGER.trace("BridgeImpl::cancelRefs Cancelling reference " + ref + " on bridge " + this);
+         if (logger.isTraceEnabled()) {
+            logger.trace("BridgeImpl::cancelRefs Cancelling reference " + ref + " on bridge " + this);
          }
 
          refqueue = ref.getQueue();
@@ -340,7 +341,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
                   session.cleanUp(false);
                }
                catch (Exception dontcare) {
-                  ActiveMQServerLogger.LOGGER.debug(dontcare.getMessage(), dontcare);
+                  logger.debug(dontcare.getMessage(), dontcare);
                }
                session = null;
             }
@@ -349,7 +350,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
                   sessionConsumer.cleanUp(false);
                }
                catch (Exception dontcare) {
-                  ActiveMQServerLogger.LOGGER.debug(dontcare.getMessage(), dontcare);
+                  logger.debug(dontcare.getMessage(), dontcare);
                }
                sessionConsumer = null;
             }
@@ -378,8 +379,8 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
 
       stopping = true;
 
-      if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-         ActiveMQServerLogger.LOGGER.debug("Bridge " + this.name + " being stopped");
+      if (logger.isDebugEnabled()) {
+         logger.debug("Bridge " + this.name + " being stopped");
       }
 
       if (futureScheduledReconnection != null) {
@@ -403,8 +404,8 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
 
    @Override
    public void pause() throws Exception {
-      if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-         ActiveMQServerLogger.LOGGER.debug("Bridge " + this.name + " being paused");
+      if (logger.isDebugEnabled()) {
+         logger.debug("Bridge " + this.name + " being paused");
       }
 
       executor.execute(new PauseRunnable());
@@ -474,8 +475,8 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
 
    @Override
    public void sendAcknowledged(final Message message) {
-      if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-         ActiveMQServerLogger.LOGGER.trace("BridgeImpl::sendAcknowledged received confirmation for message " + message);
+      if (logger.isTraceEnabled()) {
+         logger.trace("BridgeImpl::sendAcknowledged received confirmation for message " + message);
       }
       if (active) {
          try {
@@ -487,15 +488,15 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
             }
 
             if (ref != null) {
-               if (isTrace) {
-                  ActiveMQServerLogger.LOGGER.trace("BridgeImpl::sendAcknowledged bridge " + this + " Acking " + ref + " on queue " + ref.getQueue());
+               if (logger.isTraceEnabled()) {
+                  logger.trace("BridgeImpl::sendAcknowledged bridge " + this + " Acking " + ref + " on queue " + ref.getQueue());
                }
                ref.getQueue().acknowledge(ref);
                pendingAcks.countDown();
             }
             else {
-               if (isTrace) {
-                  ActiveMQServerLogger.LOGGER.trace("BridgeImpl::sendAcknowledged bridge " + this + " could not find reference for message " + message);
+               if (logger.isTraceEnabled()) {
+                  logger.trace("BridgeImpl::sendAcknowledged bridge " + this + " could not find reference for message " + message);
                }
             }
          }
@@ -521,8 +522,8 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
       if (transformer != null) {
          final ServerMessage transformedMessage = transformer.transform(message);
          if (transformedMessage != message) {
-            if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-               ActiveMQServerLogger.LOGGER.debug("The transformer " + transformer +
+            if (logger.isDebugEnabled()) {
+               logger.debug("The transformer " + transformer +
                                                     " made a copy of the message " +
                                                     message +
                                                     " as transformedMessage");
@@ -548,8 +549,8 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
 
       synchronized (this) {
          if (!active || !session.isWritable(this)) {
-            if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-               ActiveMQServerLogger.LOGGER.debug(this + "::Ignoring reference on bridge as it is set to inactive ref=" + ref);
+            if (logger.isDebugEnabled()) {
+               logger.debug(this + "::Ignoring reference on bridge as it is set to inactive ref=" + ref);
             }
             return HandleStatus.BUSY;
          }
@@ -558,8 +559,8 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
             return HandleStatus.BUSY;
          }
 
-         if (isTrace) {
-            ActiveMQServerLogger.LOGGER.trace("Bridge " + this + " is handling reference=" + ref);
+         if (logger.isTraceEnabled()) {
+            logger.trace("Bridge " + this + " is handling reference=" + ref);
          }
 
          ref.handled();
@@ -639,7 +640,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
       if (scaleDownTargetNodeID != null && !scaleDownTargetNodeID.equals(nodeUUID.toString())) {
          synchronized (this) {
             try {
-               ActiveMQServerLogger.LOGGER.debug("Moving " + queue.getMessageCount() + " messages from " + queue.getName() + " to " + scaleDownTargetNodeID);
+               logger.debug("Moving " + queue.getMessageCount() + " messages from " + queue.getName() + " to " + scaleDownTargetNodeID);
                ((QueueImpl) queue).moveReferencesBetweenSnFQueues(SimpleString.toSimpleString(scaleDownTargetNodeID));
 
                // stop the bridge from trying to reconnect and clean up all the bindings
@@ -652,11 +653,11 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
       }
       else if (scaleDownTargetNodeID != null) {
          // the disconnected node is scaling down to me, no need to reconnect to it
-         ActiveMQServerLogger.LOGGER.debug("Received scaleDownTargetNodeID: " + scaleDownTargetNodeID + "; cancelling reconnect.");
+         logger.debug("Received scaleDownTargetNodeID: " + scaleDownTargetNodeID + "; cancelling reconnect.");
          fail(true);
       }
       else {
-         ActiveMQServerLogger.LOGGER.debug("Received invalid scaleDownTargetNodeID: " + scaleDownTargetNodeID);
+         logger.debug("Received invalid scaleDownTargetNodeID: " + scaleDownTargetNodeID);
 
          fail(me.getType() == ActiveMQExceptionType.DISCONNECTED);
       }
@@ -713,8 +714,8 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
       // from the acks so it will get resent, duplicate detection will cope
       // with any messages resent
 
-      if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-         ActiveMQServerLogger.LOGGER.trace("going to send message: " + message + " from " + this.getQueue());
+      if (logger.isTraceEnabled()) {
+         logger.trace("going to send message: " + message + " from " + this.getQueue());
       }
 
       try {
@@ -780,17 +781,17 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
    }
 
    protected void fail(final boolean permanently) {
-      ActiveMQServerLogger.LOGGER.debug(this + "\n\t::fail being called, permanently=" + permanently);
+      logger.debug(this + "\n\t::fail being called, permanently=" + permanently);
 
       if (queue != null) {
          try {
-            if (isTrace) {
-               ActiveMQServerLogger.LOGGER.trace("Removing consumer on fail " + this + " from queue " + queue);
+            if (logger.isTraceEnabled()) {
+               logger.trace("Removing consumer on fail " + this + " from queue " + queue);
             }
             queue.removeConsumer(this);
          }
          catch (Exception dontcare) {
-            ActiveMQServerLogger.LOGGER.debug(dontcare);
+            logger.debug(dontcare);
          }
       }
 
@@ -866,7 +867,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
          if (!keepConnecting)
             return;
 
-         ActiveMQServerLogger.LOGGER.debug("Connecting  " + this + " to its destination [" + nodeUUID.toString() + "], csf=" + this.csf);
+         logger.debug("Connecting  " + this + " to its destination [" + nodeUUID.toString() + "], csf=" + this.csf);
 
          retryCount++;
 
@@ -948,8 +949,8 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
                return;
             }
             else {
-               if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-                  ActiveMQServerLogger.LOGGER.debug("Bridge " + this + " is unable to connect to destination. Retrying", e);
+               if (logger.isDebugEnabled()) {
+                  logger.debug("Bridge " + this + " is unable to connect to destination. Retrying", e);
                }
 
                scheduleRetryConnect();
@@ -1002,7 +1003,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
          timeout = maxRetryInterval;
       }
 
-      ActiveMQServerLogger.LOGGER.debug("Bridge " + this +
+      logger.debug("Bridge " + this +
                                            " retrying connection #" +
                                            retryCount +
                                            ", maxRetry=" +
@@ -1025,8 +1026,8 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
       if (stopping)
          return;
 
-      if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-         ActiveMQServerLogger.LOGGER.debug("Scheduling retry for bridge " + this.name + " in " + milliseconds + " milliseconds");
+      if (logger.isDebugEnabled()) {
+         logger.debug("Scheduling retry for bridge " + this.name + " in " + milliseconds + " milliseconds");
       }
 
       futureScheduledReconnection = scheduledExecutor.schedule(new FutureConnectRunnable(executor, this), milliseconds, TimeUnit.MILLISECONDS);
@@ -1085,7 +1086,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
       @Override
       public void run() {
          try {
-            ActiveMQServerLogger.LOGGER.debug("stopping bridge " + BridgeImpl.this);
+            logger.debug("stopping bridge " + BridgeImpl.this);
             queue.removeConsumer(BridgeImpl.this);
 
             if (!pendingAcks.await(10, TimeUnit.SECONDS)) {
@@ -1093,7 +1094,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
             }
 
             synchronized (BridgeImpl.this) {
-               ActiveMQServerLogger.LOGGER.debug("Closing Session for bridge " + BridgeImpl.this.name);
+               logger.debug("Closing Session for bridge " + BridgeImpl.this.name);
 
                started = false;
 
@@ -1102,7 +1103,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
             }
 
             if (session != null) {
-               ActiveMQServerLogger.LOGGER.debug("Cleaning up session " + session);
+               logger.debug("Cleaning up session " + session);
                session.removeFailureListener(BridgeImpl.this);
                try {
                   session.close();
@@ -1113,7 +1114,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
             }
 
             if (sessionConsumer != null) {
-               ActiveMQServerLogger.LOGGER.debug("Cleaning up session " + session);
+               logger.debug("Cleaning up session " + session);
                try {
                   sessionConsumer.close();
                   sessionConsumer = null;
@@ -1132,8 +1133,8 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
                keepConnecting = true;
             }
 
-            if (isTrace) {
-               ActiveMQServerLogger.LOGGER.trace("Removing consumer on stopRunnable " + this + " from queue " + queue);
+            if (logger.isTraceEnabled()) {
+               logger.trace("Removing consumer on stopRunnable " + this + " from queue " + queue);
             }
             ActiveMQServerLogger.LOGGER.bridgeStopped(name);
          }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BroadcastGroupImpl.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BroadcastGroupImpl.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BroadcastGroupImpl.java
index 1dc98c8..4506357 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BroadcastGroupImpl.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/BroadcastGroupImpl.java
@@ -36,6 +36,7 @@ import org.apache.activemq.artemis.core.server.management.Notification;
 import org.apache.activemq.artemis.core.server.management.NotificationService;
 import org.apache.activemq.artemis.utils.TypedProperties;
 import org.apache.activemq.artemis.utils.UUIDGenerator;
+import org.jboss.logging.Logger;
 
 /**
  * <p>This class will use the {@link BroadcastEndpoint} to send periodical updates on the list for connections
@@ -46,6 +47,8 @@ import org.apache.activemq.artemis.utils.UUIDGenerator;
  */
 public class BroadcastGroupImpl implements BroadcastGroup, Runnable {
 
+   private static final Logger logger = Logger.getLogger(BroadcastGroupImpl.class);
+
    private final NodeManager nodeManager;
 
    private final String name;
@@ -215,7 +218,7 @@ public class BroadcastGroupImpl implements BroadcastGroup, Runnable {
             loggedBroadcastException = true;
          }
          else {
-            ActiveMQServerLogger.LOGGER.debug("Failed to broadcast connector configs...again", e);
+            logger.debug("Failed to broadcast connector configs...again", e);
          }
       }
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionBridge.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionBridge.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionBridge.java
index d10e4ac..a8c87b9 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionBridge.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionBridge.java
@@ -33,7 +33,6 @@ import org.apache.activemq.artemis.api.core.client.ClientProducer;
 import org.apache.activemq.artemis.api.core.management.CoreNotificationType;
 import org.apache.activemq.artemis.api.core.management.ManagementHelper;
 import org.apache.activemq.artemis.api.core.management.ResourceNames;
-import org.apache.activemq.artemis.core.client.ActiveMQClientLogger;
 import org.apache.activemq.artemis.core.client.impl.ClientSessionFactoryInternal;
 import org.apache.activemq.artemis.core.client.impl.ServerLocatorInternal;
 import org.apache.activemq.artemis.core.filter.Filter;
@@ -50,6 +49,7 @@ import org.apache.activemq.artemis.core.server.cluster.MessageFlowRecord;
 import org.apache.activemq.artemis.core.server.cluster.Transformer;
 import org.apache.activemq.artemis.utils.UUID;
 import org.apache.activemq.artemis.utils.UUIDGenerator;
+import org.jboss.logging.Logger;
 
 /**
  * A bridge with extra functionality only available when the server is clustered.
@@ -57,6 +57,7 @@ import org.apache.activemq.artemis.utils.UUIDGenerator;
  * Such as such adding extra properties and setting up notifications between the nodes.
  */
 public class ClusterConnectionBridge extends BridgeImpl {
+   private static final Logger logger = Logger.getLogger(ClusterConnectionBridge.class);
 
    private final ClusterConnection clusterConnection;
 
@@ -123,8 +124,8 @@ public class ClusterConnectionBridge extends BridgeImpl {
       // we need to disable DLQ check on the clustered bridges
       queue.setInternalQueue(true);
 
-      if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-         ActiveMQServerLogger.LOGGER.trace("Setting up bridge between " + clusterConnection.getConnector() + " and " + targetLocator, new Exception("trace"));
+      if (logger.isTraceEnabled()) {
+         logger.trace("Setting up bridge between " + clusterConnection.getConnector() + " and " + targetLocator, new Exception("trace"));
       }
    }
 
@@ -151,8 +152,8 @@ public class ClusterConnectionBridge extends BridgeImpl {
       // Note we must copy since same message may get routed to other nodes which require different headers
       ServerMessage messageCopy = message.copy();
 
-      if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-         ActiveMQServerLogger.LOGGER.trace("Clustered bridge  copied message " + message + " as " + messageCopy + " before delivery");
+      if (logger.isTraceEnabled()) {
+         logger.trace("Clustered bridge  copied message " + message + " as " + messageCopy + " before delivery");
       }
 
       // TODO - we can optimise this
@@ -181,8 +182,8 @@ public class ClusterConnectionBridge extends BridgeImpl {
    }
 
    private void setupNotificationConsumer() throws Exception {
-      if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-         ActiveMQServerLogger.LOGGER.debug("Setting up notificationConsumer between " + this.clusterConnection.getConnector() +
+      if (logger.isDebugEnabled()) {
+         logger.debug("Setting up notificationConsumer between " + this.clusterConnection.getConnector() +
                                               " and " +
                                               flowRecord.getBridge().getForwardingConnection() +
                                               " clusterConnection = " +
@@ -195,7 +196,7 @@ public class ClusterConnectionBridge extends BridgeImpl {
 
          if (notifConsumer != null) {
             try {
-               ActiveMQServerLogger.LOGGER.debug("Closing notification Consumer for reopening " + notifConsumer +
+               logger.debug("Closing notification Consumer for reopening " + notifConsumer +
                                                     " on bridge " +
                                                     this.getName());
                notifConsumer.close();
@@ -250,14 +251,14 @@ public class ClusterConnectionBridge extends BridgeImpl {
          sessionConsumer.start();
 
          ClientMessage message = sessionConsumer.createMessage(false);
-         if (ActiveMQClientLogger.LOGGER.isTraceEnabled()) {
-            ActiveMQClientLogger.LOGGER.trace("Requesting sendQueueInfoToQueue through " + this, new Exception("trace"));
+         if (logger.isTraceEnabled()) {
+            logger.trace("Requesting sendQueueInfoToQueue through " + this, new Exception("trace"));
          }
          ManagementHelper.putOperationInvocation(message, ResourceNames.CORE_SERVER, "sendQueueInfoToQueue", notifQueueName.toString(), flowRecord.getAddress());
 
          try (ClientProducer prod = sessionConsumer.createProducer(managementAddress)) {
-            if (ActiveMQClientLogger.LOGGER.isDebugEnabled()) {
-               ActiveMQClientLogger.LOGGER.debug("Cluster connection bridge on " + clusterConnection + " requesting information on queues");
+            if (logger.isDebugEnabled()) {
+               logger.debug("Cluster connection bridge on " + clusterConnection + " requesting information on queues");
             }
 
             prod.send(message);
@@ -348,11 +349,11 @@ public class ClusterConnectionBridge extends BridgeImpl {
 
    @Override
    protected void fail(final boolean permanently) {
-      ActiveMQServerLogger.LOGGER.debug("Cluster Bridge " + this.getName() + " failed, permanently=" + permanently);
+      logger.debug("Cluster Bridge " + this.getName() + " failed, permanently=" + permanently);
       super.fail(permanently);
 
       if (permanently) {
-         ActiveMQServerLogger.LOGGER.debug("cluster node for bridge " + this.getName() + " is permanently down");
+         logger.debug("cluster node for bridge " + this.getName() + " is permanently down");
          clusterConnection.removeRecord(targetNodeID);
       }
       else {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionImpl.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionImpl.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionImpl.java
index 64f99eb..2b09c4c 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionImpl.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/ClusterConnectionImpl.java
@@ -54,12 +54,12 @@ import org.apache.activemq.artemis.core.server.ActiveMQServer;
 import org.apache.activemq.artemis.core.server.ActiveMQServerLogger;
 import org.apache.activemq.artemis.core.server.NodeManager;
 import org.apache.activemq.artemis.core.server.Queue;
+import org.apache.activemq.artemis.core.server.cluster.ActiveMQServerSideProtocolManagerFactory;
 import org.apache.activemq.artemis.core.server.cluster.Bridge;
 import org.apache.activemq.artemis.core.server.cluster.ClusterConnection;
 import org.apache.activemq.artemis.core.server.cluster.ClusterControl;
 import org.apache.activemq.artemis.core.server.cluster.ClusterManager;
 import org.apache.activemq.artemis.core.server.cluster.ClusterManager.IncomingInterceptorLookingForExceptionMessage;
-import org.apache.activemq.artemis.core.server.cluster.ActiveMQServerSideProtocolManagerFactory;
 import org.apache.activemq.artemis.core.server.cluster.MessageFlowRecord;
 import org.apache.activemq.artemis.core.server.cluster.RemoteQueueBinding;
 import org.apache.activemq.artemis.core.server.group.impl.Proposal;
@@ -70,16 +70,17 @@ import org.apache.activemq.artemis.spi.core.protocol.RemotingConnection;
 import org.apache.activemq.artemis.utils.ExecutorFactory;
 import org.apache.activemq.artemis.utils.FutureLatch;
 import org.apache.activemq.artemis.utils.TypedProperties;
+import org.jboss.logging.Logger;
 
 public final class ClusterConnectionImpl implements ClusterConnection, AfterConnectInternalListener {
 
+   private static final Logger logger = Logger.getLogger(ClusterConnectionImpl.class);
+
    /** When getting member on node-up and down we have to remove the name from the transport config
     *  as the setting we build here doesn't need to consider the name, so use the same name on all
     *  the instances.  */
    private static final String TRANSPORT_CONFIG_NAME = "topology-member";
 
-   private static final boolean isTrace = ActiveMQServerLogger.LOGGER.isTraceEnabled();
-
    private final ExecutorFactory executorFactory;
 
    private final Executor executor;
@@ -396,15 +397,15 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
          return;
       }
       stopping = true;
-      if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-         ActiveMQServerLogger.LOGGER.debug(this + "::stopping ClusterConnection");
+      if (logger.isDebugEnabled()) {
+         logger.debug(this + "::stopping ClusterConnection");
       }
 
       if (serverLocator != null) {
          serverLocator.removeClusterTopologyListener(this);
       }
 
-      ActiveMQServerLogger.LOGGER.debug("Cluster connection being stopped for node" + nodeManager.getNodeId() +
+      logger.debug("Cluster connection being stopped for node" + nodeManager.getNodeId() +
                                            ", server = " +
                                            this.server +
                                            " serverLocator = " +
@@ -474,8 +475,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
                              final String scaleDownGroupName,
                              final Pair<TransportConfiguration, TransportConfiguration> connectorPair,
                              final boolean backup) {
-      if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-         ActiveMQServerLogger.LOGGER.debug(this + "::NodeAnnounced, backup=" + backup + nodeID + connectorPair);
+      if (logger.isDebugEnabled()) {
+         logger.debug(this + "::NodeAnnounced, backup=" + backup + nodeID + connectorPair);
       }
 
       TransportConfiguration live = connectorPair.getA();
@@ -563,8 +564,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
          return;
       }
 
-      if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-         ActiveMQServerLogger.LOGGER.debug("Activating cluster connection nodeID=" + nodeManager.getNodeId() + " for server=" + this.server);
+      if (logger.isDebugEnabled()) {
+         logger.debug("Activating cluster connection nodeID=" + nodeManager.getNodeId() + " for server=" + this.server);
       }
 
       liveNotifier = new LiveNotifier();
@@ -576,7 +577,7 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
       if (serverLocator != null) {
 
          if (!useDuplicateDetection) {
-            ActiveMQServerLogger.LOGGER.debug("DuplicateDetection is disabled, sending clustered messages blocked");
+            logger.debug("DuplicateDetection is disabled, sending clustered messages blocked");
          }
 
          final TopologyMember currentMember = topology.getMember(manager.getNodeId());
@@ -618,7 +619,7 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
          TypedProperties props = new TypedProperties();
          props.putSimpleStringProperty(new SimpleString("name"), name);
          Notification notification = new Notification(nodeManager.getNodeId().toString(), CoreNotificationType.CLUSTER_CONNECTION_STARTED, props);
-         ActiveMQServerLogger.LOGGER.debug("sending notification: " + notification);
+         logger.debug("sending notification: " + notification);
          managementService.sendNotification(notification);
       }
       //we add as a listener after we have sent the cluster start notif as the listener may start sending notifs before
@@ -646,15 +647,15 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
          return;
       }
       final String nodeID = topologyMember.getNodeId();
-      if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
+      if (logger.isDebugEnabled()) {
          String ClusterTestBase = "receiving nodeUP for nodeID=";
-         ActiveMQServerLogger.LOGGER.debug(this + ClusterTestBase + nodeID + " connectionPair=" + topologyMember);
+         logger.debug(this + ClusterTestBase + nodeID + " connectionPair=" + topologyMember);
       }
       // discard notifications about ourselves unless its from our backup
 
       if (nodeID.equals(nodeManager.getNodeId().toString())) {
-         if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-            ActiveMQServerLogger.LOGGER.trace(this + "::informing about backup to itself, nodeUUID=" +
+         if (logger.isTraceEnabled()) {
+            logger.trace(this + "::informing about backup to itself, nodeUUID=" +
                                                  nodeManager.getNodeId() + ", connectorPair=" + topologyMember + ", this = " + this);
          }
          return;
@@ -672,8 +673,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
       }
       /*we don't create bridges to backups*/
       if (topologyMember.getLive() == null) {
-         if (isTrace) {
-            ActiveMQServerLogger.LOGGER.trace(this + " ignoring call with nodeID=" + nodeID + ", topologyMember=" +
+         if (logger.isTraceEnabled()) {
+            logger.trace(this + " ignoring call with nodeID=" + nodeID + ", topologyMember=" +
                                                  topologyMember + ", last=" + last);
          }
          return;
@@ -684,8 +685,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
             MessageFlowRecord record = records.get(nodeID);
 
             if (record == null) {
-               if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-                  ActiveMQServerLogger.LOGGER.debug(this + "::Creating record for nodeID=" + nodeID + ", topologyMember=" +
+               if (logger.isDebugEnabled()) {
+                  logger.debug(this + "::Creating record for nodeID=" + nodeID + ", topologyMember=" +
                                                        topologyMember);
                }
 
@@ -713,8 +714,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
                createNewRecord(topologyMember.getUniqueEventID(), nodeID, topologyMember.getLive(), queueName, queue, true);
             }
             else {
-               if (isTrace) {
-                  ActiveMQServerLogger.LOGGER.trace(this + " ignored nodeUp record for " + topologyMember + " on nodeID=" +
+               if (logger.isTraceEnabled()) {
+                  logger.trace(this + " ignored nodeUp record for " + topologyMember + " on nodeID=" +
                                                        nodeID + " as the record already existed");
                }
             }
@@ -795,8 +796,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
 
       targetLocator.setIdentity("(Cluster-connection-bridge::" + bridge.toString() + "::" + this.toString() + ")");
 
-      if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-         ActiveMQServerLogger.LOGGER.debug("creating record between " + this.connector + " and " + connector + bridge);
+      if (logger.isDebugEnabled()) {
+         logger.debug("creating record between " + this.connector + " and " + connector + bridge);
       }
 
       record.setBridge(bridge);
@@ -923,8 +924,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
       * */
       @Override
       public void close() throws Exception {
-         if (isTrace) {
-            ActiveMQServerLogger.LOGGER.trace("Stopping bridge " + bridge);
+         if (logger.isTraceEnabled()) {
+            logger.trace("Stopping bridge " + bridge);
          }
 
          isClosed = true;
@@ -949,7 +950,7 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
                   }
                }
                catch (Exception ignored) {
-                  ActiveMQServerLogger.LOGGER.debug(ignored.getMessage(), ignored);
+                  logger.debug(ignored.getMessage(), ignored);
                }
             }
          });
@@ -976,8 +977,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
 
       @Override
       public synchronized void onMessage(final ClientMessage message) {
-         if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-            ActiveMQServerLogger.LOGGER.debug("ClusterCommunication::Flow record on " + clusterConnector + " Receiving message " + message);
+         if (logger.isDebugEnabled()) {
+            logger.debug("ClusterCommunication::Flow record on " + clusterConnector + " Receiving message " + message);
          }
          try {
             // Reset the bindings
@@ -992,7 +993,7 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
             }
 
             if (!reset) {
-               ActiveMQServerLogger.LOGGER.debug("Notification being ignored since first reset wasn't received yet: " + message);
+               logger.debug("Notification being ignored since first reset wasn't received yet: " + message);
                return;
             }
 
@@ -1121,21 +1122,21 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
       }
 
       private synchronized void clearBindings() throws Exception {
-         ActiveMQServerLogger.LOGGER.debug(ClusterConnectionImpl.this + " clearing bindings");
+         logger.debug(ClusterConnectionImpl.this + " clearing bindings");
          for (RemoteQueueBinding binding : new HashSet<>(bindings.values())) {
             removeBinding(binding.getClusterName());
          }
       }
 
       private synchronized void resetBindings() throws Exception {
-         ActiveMQServerLogger.LOGGER.debug(ClusterConnectionImpl.this + " reset bindings");
+         logger.debug(ClusterConnectionImpl.this + " reset bindings");
          for (RemoteQueueBinding binding : new HashSet<>(bindings.values())) {
             resetBinding(binding.getClusterName());
          }
       }
 
       private synchronized void clearDisconnectedBindings() throws Exception {
-         ActiveMQServerLogger.LOGGER.debug(ClusterConnectionImpl.this + " reset bindings");
+         logger.debug(ClusterConnectionImpl.this + " reset bindings");
          for (RemoteQueueBinding binding : new HashSet<>(bindings.values())) {
             if (!binding.isConnected()) {
                removeBinding(binding.getClusterName());
@@ -1145,7 +1146,7 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
 
       @Override
       public synchronized void disconnectBindings() throws Exception {
-         ActiveMQServerLogger.LOGGER.debug(ClusterConnectionImpl.this + " disconnect bindings");
+         logger.debug(ClusterConnectionImpl.this + " disconnect bindings");
          reset = false;
          for (RemoteQueueBinding binding : new HashSet<>(bindings.values())) {
             disconnectBinding(binding.getClusterName());
@@ -1153,8 +1154,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
       }
 
       private synchronized void doBindingAdded(final ClientMessage message) throws Exception {
-         if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-            ActiveMQServerLogger.LOGGER.trace(ClusterConnectionImpl.this + " Adding binding " + message);
+         if (logger.isTraceEnabled()) {
+            logger.trace(ClusterConnectionImpl.this + " Adding binding " + message);
          }
          if (!message.containsProperty(ManagementHelper.HDR_DISTANCE)) {
             throw new IllegalStateException("distance is null");
@@ -1206,8 +1207,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
 
          RemoteQueueBinding binding = new RemoteQueueBindingImpl(server.getStorageManager().generateID(), queueAddress, clusterName, routingName, queueID, filterString, queue, bridge.getName(), distance + 1);
 
-         if (isTrace) {
-            ActiveMQServerLogger.LOGGER.trace("Adding binding " + clusterName + " into " + ClusterConnectionImpl.this);
+         if (logger.isTraceEnabled()) {
+            logger.trace("Adding binding " + clusterName + " into " + ClusterConnectionImpl.this);
          }
 
          bindings.put(clusterName, binding);
@@ -1225,8 +1226,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
       }
 
       private void doBindingRemoved(final ClientMessage message) throws Exception {
-         if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-            ActiveMQServerLogger.LOGGER.trace(ClusterConnectionImpl.this + " Removing binding " + message);
+         if (logger.isTraceEnabled()) {
+            logger.trace(ClusterConnectionImpl.this + " Removing binding " + message);
          }
          if (!message.containsProperty(ManagementHelper.HDR_CLUSTER_NAME)) {
             throw new IllegalStateException("clusterName is null");
@@ -1266,8 +1267,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
       }
 
       private synchronized void doConsumerCreated(final ClientMessage message) throws Exception {
-         if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-            ActiveMQServerLogger.LOGGER.trace(ClusterConnectionImpl.this + " Consumer created " + message);
+         if (logger.isTraceEnabled()) {
+            logger.trace(ClusterConnectionImpl.this + " Consumer created " + message);
          }
          if (!message.containsProperty(ManagementHelper.HDR_DISTANCE)) {
             throw new IllegalStateException("distance is null");
@@ -1320,8 +1321,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
       }
 
       private synchronized void doConsumerClosed(final ClientMessage message) throws Exception {
-         if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-            ActiveMQServerLogger.LOGGER.trace(ClusterConnectionImpl.this + " Consumer closed " + message);
+         if (logger.isTraceEnabled()) {
+            logger.trace(ClusterConnectionImpl.this + " Consumer closed " + message);
          }
          if (!message.containsProperty(ManagementHelper.HDR_DISTANCE)) {
             throw new IllegalStateException("distance is null");
@@ -1424,8 +1425,8 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
       @Override
       public ServerLocatorInternal createServerLocator() {
          if (tcConfigs != null && tcConfigs.length > 0) {
-            if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-               ActiveMQServerLogger.LOGGER.debug(ClusterConnectionImpl.this + "Creating a serverLocator for " + Arrays.toString(tcConfigs));
+            if (logger.isDebugEnabled()) {
+               logger.debug(ClusterConnectionImpl.this + "Creating a serverLocator for " + Arrays.toString(tcConfigs));
             }
             ServerLocatorImpl locator = new ServerLocatorImpl(topology, true, tcConfigs);
             locator.setClusterConnection(true);
@@ -1462,7 +1463,7 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
 
    @Override
    public void removeRecord(String targetNodeID) {
-      ActiveMQServerLogger.LOGGER.debug("Removing record for: " + targetNodeID);
+      logger.debug("Removing record for: " + targetNodeID);
       MessageFlowRecord record = records.remove(targetNodeID);
       try {
          if (record != null) {
@@ -1476,7 +1477,7 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
 
    @Override
    public void disconnectRecord(String targetNodeID) {
-      ActiveMQServerLogger.LOGGER.debug("Disconnecting record for: " + targetNodeID);
+      logger.debug("Disconnecting record for: " + targetNodeID);
       MessageFlowRecord record = records.get(targetNodeID);
       try {
          if (record != null) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/RemoteQueueBindingImpl.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/RemoteQueueBindingImpl.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/RemoteQueueBindingImpl.java
index 6ff0733..d592103 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/RemoteQueueBindingImpl.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/cluster/impl/RemoteQueueBindingImpl.java
@@ -29,14 +29,16 @@ import org.apache.activemq.artemis.core.filter.impl.FilterImpl;
 import org.apache.activemq.artemis.core.message.impl.MessageImpl;
 import org.apache.activemq.artemis.core.postoffice.BindingType;
 import org.apache.activemq.artemis.core.server.Bindable;
-import org.apache.activemq.artemis.core.server.ActiveMQServerLogger;
 import org.apache.activemq.artemis.core.server.Queue;
 import org.apache.activemq.artemis.core.server.RoutingContext;
 import org.apache.activemq.artemis.core.server.ServerMessage;
 import org.apache.activemq.artemis.core.server.cluster.RemoteQueueBinding;
+import org.jboss.logging.Logger;
 
 public class RemoteQueueBindingImpl implements RemoteQueueBinding {
 
+   private static final Logger logger = Logger.getLogger(RemoteQueueBindingImpl.class);
+
    private final SimpleString address;
 
    private final Queue storeAndForwardQueue;
@@ -336,8 +338,8 @@ public class RemoteQueueBindingImpl implements RemoteQueueBinding {
 
       message.putBytesProperty(idsHeaderName, ids);
 
-      if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-         ActiveMQServerLogger.LOGGER.trace("Adding remoteQueue ID = " + remoteQueueID + " into message=" + message + " store-forward-queue=" + storeAndForwardQueue);
+      if (logger.isTraceEnabled()) {
+         logger.trace("Adding remoteQueue ID = " + remoteQueueID + " into message=" + message + " store-forward-queue=" + storeAndForwardQueue);
       }
    }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/group/impl/LocalGroupingHandler.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/group/impl/LocalGroupingHandler.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/group/impl/LocalGroupingHandler.java
index eb43313..9b2058c 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/group/impl/LocalGroupingHandler.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/group/impl/LocalGroupingHandler.java
@@ -20,8 +20,8 @@ import java.util.ArrayList;
 import java.util.Collections;
 import java.util.LinkedList;
 import java.util.List;
-import java.util.concurrent.ConcurrentMap;
 import java.util.concurrent.ConcurrentHashMap;
+import java.util.concurrent.ConcurrentMap;
 import java.util.concurrent.ScheduledExecutorService;
 import java.util.concurrent.ScheduledFuture;
 import java.util.concurrent.TimeUnit;
@@ -40,12 +40,15 @@ import org.apache.activemq.artemis.core.server.management.ManagementService;
 import org.apache.activemq.artemis.core.server.management.Notification;
 import org.apache.activemq.artemis.utils.ExecutorFactory;
 import org.apache.activemq.artemis.utils.TypedProperties;
+import org.jboss.logging.Logger;
 
 /**
  * A Local Grouping handler. All the Remote handlers will talk with us
  */
 public final class LocalGroupingHandler extends GroupHandlingAbstract {
 
+   private static final Logger logger = Logger.getLogger(LocalGroupingHandler.class);
+
    private final ConcurrentMap<SimpleString, GroupBinding> map = new ConcurrentHashMap<>();
 
    private final ConcurrentMap<SimpleString, List<GroupBinding>> groupMap = new ConcurrentHashMap<>();
@@ -189,7 +192,7 @@ public final class LocalGroupingHandler extends GroupHandlingAbstract {
 
    @Override
    public Response receive(final Proposal proposal, final int distance) throws Exception {
-      ActiveMQServerLogger.LOGGER.trace("received proposal " + proposal);
+      logger.trace("received proposal " + proposal);
       return propose(proposal);
    }
 
@@ -262,7 +265,7 @@ public final class LocalGroupingHandler extends GroupHandlingAbstract {
             expectedBindings.removeAll(bindingsAlreadyAdded);
 
             if (expectedBindings.size() > 0) {
-               ActiveMQServerLogger.LOGGER.debug("Waiting remote group bindings to arrive before starting the server. timeout=" + timeout + " milliseconds");
+               logger.debug("Waiting remote group bindings to arrive before starting the server. timeout=" + timeout + " milliseconds");
                //now we wait here for the rest to be received in onNotification, it will signal once all have been received.
                //if we arent signaled then bindingsAdded still has some groupids we need to remove.
                if (!awaitCondition.await(timeout, TimeUnit.MILLISECONDS)) {
@@ -296,20 +299,20 @@ public final class LocalGroupingHandler extends GroupHandlingAbstract {
             if (expectedBindings != null) {
                if (waitingForBindings) {
                   if (expectedBindings.remove(clusterName)) {
-                     ActiveMQServerLogger.LOGGER.debug("OnNotification for waitForbindings::Removed clusterName=" + clusterName + " from lis succesffully");
+                     logger.debug("OnNotification for waitForbindings::Removed clusterName=" + clusterName + " from lis succesffully");
                   }
                   else {
-                     ActiveMQServerLogger.LOGGER.debug("OnNotification for waitForbindings::Couldn't remove clusterName=" + clusterName + " as it wasn't on the original list");
+                     logger.debug("OnNotification for waitForbindings::Couldn't remove clusterName=" + clusterName + " as it wasn't on the original list");
                   }
                }
                else {
                   expectedBindings.add(clusterName);
-                  ActiveMQServerLogger.LOGGER.debug("Notification for waitForbindings::Adding previously known item clusterName=" + clusterName);
+                  logger.debug("Notification for waitForbindings::Adding previously known item clusterName=" + clusterName);
                }
 
-               if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
+               if (logger.isDebugEnabled()) {
                   for (SimpleString stillWaiting : expectedBindings) {
-                     ActiveMQServerLogger.LOGGER.debug("Notification for waitForbindings::Still waiting for clusterName=" + stillWaiting);
+                     logger.debug("Notification for waitForbindings::Still waiting for clusterName=" + stillWaiting);
                   }
                }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java
index 8914886..29f2e7a 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java
@@ -144,12 +144,15 @@ import org.apache.activemq.artemis.utils.ReusableLatch;
 import org.apache.activemq.artemis.utils.SecurityFormatter;
 import org.apache.activemq.artemis.utils.TimeUtils;
 import org.apache.activemq.artemis.utils.VersionLoader;
+import org.jboss.logging.Logger;
 
 /**
  * The ActiveMQ Artemis server implementation
  */
 public class ActiveMQServerImpl implements ActiveMQServer {
 
+   private static final Logger logger = Logger.getLogger(ActiveMQServerImpl.class);
+
    /**
     * JMS Topics (which are outside of the scope of the core API) will require a dumb subscription
     * with a dummy-filter at this current version as a way to keep its existence valid and TCK
@@ -378,7 +381,7 @@ public class ActiveMQServerImpl implements ActiveMQServer {
    @Override
    public final synchronized void start() throws Exception {
       if (state != SERVER_STATE.STOPPED) {
-         ActiveMQServerLogger.LOGGER.debug("Server already started!");
+         logger.debug("Server already started!");
          return;
       }
 
@@ -392,7 +395,7 @@ public class ActiveMQServerImpl implements ActiveMQServer {
 
       activationLatch.setCount(1);
 
-      ActiveMQServerLogger.LOGGER.debug("Starting server " + this);
+      logger.debug("Starting server " + this);
 
       OperationContextImpl.clearContext();
 
@@ -780,7 +783,7 @@ public class ActiveMQServerImpl implements ActiveMQServer {
             if (!threadPool.awaitTermination(10, TimeUnit.SECONDS)) {
                ActiveMQServerLogger.LOGGER.timedOutStoppingThreadpool(threadPool);
                for (Runnable r : threadPool.shutdownNow()) {
-                  ActiveMQServerLogger.LOGGER.debug("Cancelled the execution of " + r);
+                  logger.debug("Cancelled the execution of " + r);
                }
             }
          }
@@ -1373,8 +1376,8 @@ public class ActiveMQServerImpl implements ActiveMQServer {
          throw ActiveMQMessageBundle.BUNDLE.queueSubscriptionBelongsToDifferentFilter(name);
       }
 
-      if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-         ActiveMQServerLogger.LOGGER.debug("Transient Queue " + name + " created on address " + name +
+      if (logger.isDebugEnabled()) {
+         logger.debug("Transient Queue " + name + " created on address " + name +
                                               " with filter=" + filterString);
       }
 
@@ -2066,7 +2069,7 @@ public class ActiveMQServerImpl implements ActiveMQServer {
             }
          }
          catch (Throwable ignored) {
-            ActiveMQServerLogger.LOGGER.debug(ignored.getMessage(), ignored);
+            logger.debug(ignored.getMessage(), ignored);
          }
          throw e;
       }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/AnyLiveNodeLocatorForScaleDown.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/AnyLiveNodeLocatorForScaleDown.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/AnyLiveNodeLocatorForScaleDown.java
index 5f630a6..77a3e02 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/AnyLiveNodeLocatorForScaleDown.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/AnyLiveNodeLocatorForScaleDown.java
@@ -28,8 +28,8 @@ import org.apache.activemq.artemis.api.core.ActiveMQException;
 import org.apache.activemq.artemis.api.core.Pair;
 import org.apache.activemq.artemis.api.core.TransportConfiguration;
 import org.apache.activemq.artemis.api.core.client.TopologyMember;
-import org.apache.activemq.artemis.core.server.ActiveMQServerLogger;
 import org.apache.activemq.artemis.core.server.LiveNodeLocator;
+import org.jboss.logging.Logger;
 
 /**
  * This implementation looks for any available live node, once tried with no success it is marked as
@@ -37,6 +37,8 @@ import org.apache.activemq.artemis.core.server.LiveNodeLocator;
  */
 public class AnyLiveNodeLocatorForScaleDown extends LiveNodeLocator {
 
+   private static final Logger logger = Logger.getLogger(AnyLiveNodeLocatorForScaleDown.class);
+
    private final Lock lock = new ReentrantLock();
    private final Condition condition = lock.newCondition();
    private final ActiveMQServerImpl server;
@@ -88,8 +90,8 @@ public class AnyLiveNodeLocatorForScaleDown extends LiveNodeLocator {
          Pair<TransportConfiguration, TransportConfiguration> connector = new Pair<>(topologyMember.getLive(), topologyMember.getBackup());
 
          if (topologyMember.getNodeId().equals(myNodeID)) {
-            if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-               ActiveMQServerLogger.LOGGER.trace(this + "::informing node about itself, nodeUUID=" +
+            if (logger.isTraceEnabled()) {
+               logger.trace(this + "::informing node about itself, nodeUUID=" +
                                                     server.getNodeID() + ", connectorPair=" + topologyMember + ", this = " + this);
             }
             return;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/AutoCreatedQueueManagerImpl.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/AutoCreatedQueueManagerImpl.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/AutoCreatedQueueManagerImpl.java
index b57ae47..9895a30 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/AutoCreatedQueueManagerImpl.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/AutoCreatedQueueManagerImpl.java
@@ -22,9 +22,12 @@ import org.apache.activemq.artemis.core.server.ActiveMQServerLogger;
 import org.apache.activemq.artemis.core.server.AutoCreatedQueueManager;
 import org.apache.activemq.artemis.core.server.Queue;
 import org.apache.activemq.artemis.utils.ReferenceCounterUtil;
+import org.jboss.logging.Logger;
 
 public class AutoCreatedQueueManagerImpl implements AutoCreatedQueueManager {
 
+   private static final Logger logger = Logger.getLogger(AutoCreatedQueueManagerImpl.class);
+
    private final SimpleString queueName;
 
    private final ActiveMQServer server;
@@ -39,14 +42,14 @@ public class AutoCreatedQueueManagerImpl implements AutoCreatedQueueManager {
             boolean isAutoDeleteJmsQueues = server.getAddressSettingsRepository().getMatch(queueName.toString()).isAutoDeleteJmsQueues();
 
             if (server.locateQueue(queueName).getMessageCount() == 0 && isAutoDeleteJmsQueues) {
-               if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-                  ActiveMQServerLogger.LOGGER.debug("deleting auto-created queue \"" + queueName + ".\" consumerCount = " + consumerCount + "; messageCount = " + messageCount + "; isAutoDeleteJmsQueues = " + isAutoDeleteJmsQueues);
+               if (logger.isDebugEnabled()) {
+                  logger.debug("deleting auto-created queue \"" + queueName + ".\" consumerCount = " + consumerCount + "; messageCount = " + messageCount + "; isAutoDeleteJmsQueues = " + isAutoDeleteJmsQueues);
                }
 
                server.destroyQueue(queueName, null, false);
             }
-            else if (ActiveMQServerLogger.LOGGER.isDebugEnabled()) {
-               ActiveMQServerLogger.LOGGER.debug("NOT deleting auto-created queue \"" + queueName + ".\" consumerCount = " + consumerCount + "; messageCount = " + messageCount + "; isAutoDeleteJmsQueues = " + isAutoDeleteJmsQueues);
+            else if (logger.isDebugEnabled()) {
+               logger.debug("NOT deleting auto-created queue \"" + queueName + ".\" consumerCount = " + consumerCount + "; messageCount = " + messageCount + "; isAutoDeleteJmsQueues = " + isAutoDeleteJmsQueues);
             }
          }
          catch (Exception e) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/DivertImpl.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/DivertImpl.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/DivertImpl.java
index b90db75..4316a98 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/DivertImpl.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/DivertImpl.java
@@ -20,17 +20,19 @@ import org.apache.activemq.artemis.api.core.SimpleString;
 import org.apache.activemq.artemis.core.filter.Filter;
 import org.apache.activemq.artemis.core.persistence.StorageManager;
 import org.apache.activemq.artemis.core.postoffice.PostOffice;
-import org.apache.activemq.artemis.core.server.ActiveMQServerLogger;
 import org.apache.activemq.artemis.core.server.Divert;
 import org.apache.activemq.artemis.core.server.RoutingContext;
 import org.apache.activemq.artemis.core.server.ServerMessage;
 import org.apache.activemq.artemis.core.server.cluster.Transformer;
+import org.jboss.logging.Logger;
 
 /**
  * A DivertImpl simply diverts a message to a different forwardAddress
  */
 public class DivertImpl implements Divert {
 
+   private static final Logger logger = Logger.getLogger(DivertImpl.class);
+
    private final PostOffice postOffice;
 
    private final SimpleString forwardAddress;
@@ -77,8 +79,8 @@ public class DivertImpl implements Divert {
       // We must make a copy of the message, otherwise things like returning credits to the page won't work
       // properly on ack, since the original address will be overwritten
 
-      if (ActiveMQServerLogger.LOGGER.isTraceEnabled()) {
-         ActiveMQServerLogger.LOGGER.trace("Diverting message " + message + " into " + this);
+      if (logger.isTraceEnabled()) {
+         logger.trace("Diverting message " + message + " into " + this);
       }
 
       long id = storageManager.generateID();

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/f0df9d8c/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/FileLockNodeManager.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/FileLockNodeManager.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/FileLockNodeManager.java
index 6169cef..1992e81 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/FileLockNodeManager.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/FileLockNodeManager.java
@@ -27,9 +27,12 @@ import org.apache.activemq.artemis.core.server.ActivateCallback;
 import org.apache.activemq.artemis.core.server.ActiveMQServerLogger;
 import org.apache.activemq.artemis.core.server.NodeManager;
 import org.apache.activemq.artemis.utils.UUID;
+import org.jboss.logging.Logger;
 
 public class FileLockNodeManager extends NodeManager {
 
+   private static final Logger logger = Logger.getLogger(FileLockNodeManager.class);
+
    private static final int LIVE_LOCK_POS = 1;
 
    private static final int BACKUP_LOCK_POS = 2;
@@ -114,7 +117,7 @@ public class FileLockNodeManager extends NodeManager {
       do {
          byte state = getState();
          while (state == FileLockNodeManager.NOT_STARTED || state == FIRST_TIME_START) {
-            ActiveMQServerLogger.LOGGER.debug("awaiting live node startup state='" + state + "'");
+            logger.debug("awaiting live node startup state='" + state + "'");
             Thread.sleep(2000);
             state = getState();
          }
@@ -127,16 +130,16 @@ public class FileLockNodeManager extends NodeManager {
          state = getState();
          if (state == FileLockNodeManager.PAUSED) {
             liveLock.release();
-            ActiveMQServerLogger.LOGGER.debug("awaiting live node restarting");
+            logger.debug("awaiting live node restarting");
             Thread.sleep(2000);
          }
          else if (state == FileLockNodeManager.FAILINGBACK) {
             liveLock.release();
-            ActiveMQServerLogger.LOGGER.debug("awaiting live node failing back");
+            logger.debug("awaiting live node failing back");
             Thread.sleep(2000);
          }
          else if (state == FileLockNodeManager.LIVE) {
-            ActiveMQServerLogger.LOGGER.debug("acquired live node lock state = " + (char) state);
+            logger.debug("acquired live node lock state = " + (char) state);
             break;
          }
       } while (true);