You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by cl...@apache.org on 2022/05/16 18:53:09 UTC

[activemq-artemis] branch new-logging updated: Rest conv

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

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


The following commit(s) were added to refs/heads/new-logging by this push:
     new 3e5f9c12cd Rest conv
3e5f9c12cd is described below

commit 3e5f9c12cdb10ad682fbd989eb9983384ee44142
Author: Clebert Suconic <cl...@apache.org>
AuthorDate: Mon May 16 14:53:01 2022 -0400

    Rest conv
---
 .../activemq/artemis/ra/ActiveMQRALogger.java      |  1 -
 artemis-rest/pom.xml                               | 10 ++--
 .../activemq/artemis/rest/ActiveMQRestBundle.java  | 31 -----------
 .../activemq/artemis/rest/ActiveMQRestLogger.java  | 63 +++++++---------------
 .../artemis/rest/MessageServiceManager.java        |  8 ++-
 .../rest/queue/AcknowledgedQueueConsumer.java      |  8 ++-
 .../artemis/rest/queue/ConsumedMessage.java        |  6 ++-
 .../artemis/rest/queue/ConsumersResource.java      | 12 +++--
 .../activemq/artemis/rest/queue/PostMessage.java   | 10 ++--
 .../artemis/rest/queue/PostMessageDupsOk.java      |  8 ++-
 .../artemis/rest/queue/PostMessageNoDups.java      |  6 ++-
 .../activemq/artemis/rest/queue/QueueConsumer.java | 15 +++---
 .../rest/queue/QueueDestinationsResource.java      |  6 ++-
 .../activemq/artemis/rest/queue/QueueResource.java | 10 ++--
 .../queue/push/PushConsumerMessageHandler.java     | 12 +++--
 .../rest/queue/push/PushConsumerResource.java      | 10 ++--
 .../artemis/rest/queue/push/UriStrategy.java       | 16 +++---
 .../rest/topic/PushSubscriptionsResource.java      | 10 ++--
 .../artemis/rest/topic/SubscriptionsResource.java  | 18 ++++---
 .../rest/topic/TopicDestinationsResource.java      |  6 ++-
 .../activemq/artemis/rest/topic/TopicResource.java | 10 ++--
 .../artemis/rest/util/HttpMessageHelper.java       | 12 +++--
 .../activemq/artemis/rest/util/TimeoutTask.java    |  8 ++-
 23 files changed, 160 insertions(+), 136 deletions(-)

diff --git a/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRALogger.java b/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRALogger.java
index 115137bf22..0bd6680bb9 100644
--- a/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRALogger.java
+++ b/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRALogger.java
@@ -22,7 +22,6 @@ import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 import org.apache.activemq.artemis.logprocessor.annotation.Message;
 import org.apache.activemq.artemis.ra.inflow.ActiveMQActivationSpec;
-import org.slf4j.Logger;
 
 import javax.jms.IllegalStateException;
 
diff --git a/artemis-rest/pom.xml b/artemis-rest/pom.xml
index 980c21d4f3..fb2ef5a8a0 100644
--- a/artemis-rest/pom.xml
+++ b/artemis-rest/pom.xml
@@ -34,6 +34,12 @@
 
    <dependencies>
       <!-- logging -->
+      <dependency>
+         <groupId>org.apache.activemq</groupId>
+         <artifactId>artemis-log-processor</artifactId>
+         <version>${project.version}</version>
+         <scope>provided</scope>
+      </dependency>
       <dependency>
          <groupId>org.slf4j</groupId>
          <artifactId>slf4j-api</artifactId>
@@ -41,10 +47,8 @@
       <dependency>
          <groupId>org.apache.logging.log4j</groupId>
          <artifactId>log4j-slf4j-impl</artifactId>
-         <scope>test</scope>
+         <scope>runtime</scope> <!-- TODO: decide whether to only supply via assembly or here -->
       </dependency>
-
-
       <dependency>
          <groupId>org.apache.tomcat</groupId>
          <artifactId>tomcat-servlet-api</artifactId>
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/ActiveMQRestBundle.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/ActiveMQRestBundle.java
deleted file mode 100644
index f65f0a8d9e..0000000000
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/ActiveMQRestBundle.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements. See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License. You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.artemis.rest;
-
-import org.jboss.logging.annotations.MessageBundle;
-
-/**
- * Logger Code 19
- *
- * each message id must be 6 digits long starting with 19, the 3rd digit should be 9
- *
- * so 199000 to 199999
- */
-@MessageBundle(projectCode = "AMQ")
-public class ActiveMQRestBundle {
-
-}
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/ActiveMQRestLogger.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/ActiveMQRestLogger.java
index deb796a980..612ed06b89 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/ActiveMQRestLogger.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/ActiveMQRestLogger.java
@@ -17,78 +17,55 @@
 package org.apache.activemq.artemis.rest;
 
 import org.apache.activemq.artemis.api.core.ActiveMQException;
+import org.apache.activemq.artemis.logprocessor.CodeFactory;
 import org.apache.activemq.artemis.rest.queue.push.xml.XmlLink;
-import org.jboss.logging.BasicLogger;
-import org.jboss.logging.Logger;
-import org.jboss.logging.annotations.Cause;
-import org.jboss.logging.annotations.LogMessage;
-import org.jboss.logging.annotations.Message;
-import org.jboss.logging.annotations.MessageLogger;
+import org.apache.activemq.artemis.logprocessor.annotation.Cause;
+import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
+import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
+import org.apache.activemq.artemis.logprocessor.annotation.Message;
 
 /**
  * Logger Code 19
- *
- * each message id must be 6 digits long starting with 19, the 3rd digit donates the level so
- *
- * INF0  1
- * WARN  2
- * DEBUG 3
- * ERROR 4
- * TRACE 5
- * FATAL 6
- *
  * so an INFO message would be 191000 to 191999
  */
-@MessageLogger(projectCode = "AMQ")
-public interface ActiveMQRestLogger extends BasicLogger {
+@LogBundle(projectCode = "AMQ")
+public interface ActiveMQRestLogger {
 
-   ActiveMQRestLogger LOGGER = Logger.getMessageLogger(ActiveMQRestLogger.class, ActiveMQRestLogger.class.getPackage().getName());
+   ActiveMQRestLogger LOGGER = CodeFactory.getCodeClass(ActiveMQRestLogger.class, ActiveMQRestLogger.class.getPackage().getName());
 
-   @LogMessage(level = Logger.Level.INFO)
-   @Message(id = 181000, value = "Loading REST push store from: {0}", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 181000, value = "Loading REST push store from: {0}", level = LogMessage.Level.INFO)
    void loadingRestStore(String path);
 
-   @LogMessage(level = Logger.Level.INFO)
-   @Message(id = 181001, value = "adding REST push registration: {0}", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 181001, value = "adding REST push registration: {0}", level = LogMessage.Level.INFO)
    void addingPushRegistration(String id);
 
-   @LogMessage(level = Logger.Level.INFO)
-   @Message(id = 181002, value = "Push consumer started for: {0}", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 181002, value = "Push consumer started for: {0}", level = LogMessage.Level.INFO)
    void startingPushConsumer(XmlLink link);
 
-   @LogMessage(level = Logger.Level.WARN)
-   @Message(id = 182000, value = "shutdown REST consumer because of timeout for: {0}", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 182000, value = "shutdown REST consumer because of timeout for: {0}", level = LogMessage.Level.WARN)
    void shutdownRestConsumer(String id);
 
-   @LogMessage(level = Logger.Level.WARN)
-   @Message(id = 182001, value = "shutdown REST subscription because of timeout for: {0}", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 182001, value = "shutdown REST subscription because of timeout for: {0}", level = LogMessage.Level.WARN)
    void shutdownRestSubscription(String id);
 
-   @LogMessage(level = Logger.Level.WARN)
-   @Message(id = 182002, value = "Failed to push message to {0}", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 182002, value = "Failed to push message to {0}", level = LogMessage.Level.WARN)
    void failedToPushMessageToUri(String uri, @Cause Exception e);
 
-   @LogMessage(level = Logger.Level.WARN)
-   @Message(id = 182003, value = "Failed to build Message from object", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 182003, value = "Failed to build Message from object", level = LogMessage.Level.WARN)
    void failedToBuildMessageFromObject(@Cause Exception e);
 
-   @LogMessage(level = Logger.Level.WARN)
-   @Message(id = 182004, value = "REST configuration parameter ''{0}'' is deprecated. Use ''{1}'' instead.", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 182004, value = "REST configuration parameter ''{0}'' is deprecated. Use ''{1}'' instead.", level = LogMessage.Level.WARN)
    void deprecatedConfiguration(String oldConfigParameter, String newConfigParameter);
 
-   @LogMessage(level = Logger.Level.ERROR)
-   @Message(id = 184000, value = "Failed to load push store {0}, it is probably corrupted", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 184000, value = "Failed to load push store {0}, it is probably corrupted", level = LogMessage.Level.ERROR)
    void errorLoadingStore(@Cause Exception e, String name);
 
-   @LogMessage(level = Logger.Level.ERROR)
-   @Message(id = 184001, value = "Error updating store", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 184001, value = "Error updating store", level = LogMessage.Level.ERROR)
    void errorUpdatingStore(@Cause Exception e);
 
-   @LogMessage(level = Logger.Level.ERROR)
-   @Message(id = 184002, value = "Failed to push message to {0} disabling push registration...", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 184002, value = "Failed to push message to {0} disabling push registration...", level = LogMessage.Level.ERROR)
    void errorPushingMessage(XmlLink link);
 
-   @LogMessage(level = Logger.Level.ERROR)
-   @Message(id = 184003, value = "Error deleting Subscriber queue", format = Message.Format.MESSAGE_FORMAT)
+   @LogMessage(id = 184003, value = "Error deleting Subscriber queue", level = LogMessage.Level.ERROR)
    void errorDeletingSubscriberQueue(@Cause ActiveMQException e);
 }
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/MessageServiceManager.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/MessageServiceManager.java
index f6e6a09f37..c01e8da3dc 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/MessageServiceManager.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/MessageServiceManager.java
@@ -39,9 +39,13 @@ import org.apache.activemq.artemis.rest.util.TimeoutTask;
 import org.apache.activemq.artemis.spi.core.naming.BindingRegistry;
 import org.apache.activemq.artemis.utils.ActiveMQThreadFactory;
 import org.apache.activemq.artemis.utils.XMLUtil;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class MessageServiceManager {
 
+   private static final Logger logger = LoggerFactory.getLogger(MessageServiceManager.class);
+
    private ExecutorService threadPool;
    private QueueServiceManager queueManager;
    private TopicServiceManager topicManager;
@@ -146,10 +150,10 @@ public class MessageServiceManager {
          consumerLocator.setConsumerWindowSize(configuration.getConsumerWindowSize());
       }
 
-      ActiveMQRestLogger.LOGGER.debug("Created ServerLocator: " + consumerLocator);
+      logger.debug("Created ServerLocator: " + consumerLocator);
 
       consumerSessionFactory = consumerLocator.createSessionFactory();
-      ActiveMQRestLogger.LOGGER.debug("Created ClientSessionFactory: " + consumerSessionFactory);
+      logger.debug("Created ClientSessionFactory: " + consumerSessionFactory);
 
       ServerLocator defaultLocator = ActiveMQClient.createServerLocator(configuration.getUrl());
 
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/AcknowledgedQueueConsumer.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/AcknowledgedQueueConsumer.java
index 3068f8bae7..9ad3c1f1c9 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/AcknowledgedQueueConsumer.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/AcknowledgedQueueConsumer.java
@@ -37,9 +37,13 @@ import org.apache.activemq.artemis.api.core.client.ClientSessionFactory;
 import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
 import org.apache.activemq.artemis.rest.util.Constants;
 import org.apache.activemq.artemis.rest.util.LinkStrategy;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class AcknowledgedQueueConsumer extends QueueConsumer {
 
+   private static final Logger logger = LoggerFactory.getLogger( AcknowledgedQueueConsumer.class );
+
    protected long counter;
    protected String startup = Long.toString(System.currentTimeMillis());
    protected volatile Acknowledgement ack;
@@ -63,7 +67,7 @@ public class AcknowledgedQueueConsumer extends QueueConsumer {
    public synchronized Response poll(@HeaderParam(Constants.WAIT_HEADER) @DefaultValue("0") long wait,
                                      @PathParam("index") long index,
                                      @Context UriInfo info) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + info.getPath() + "\"");
+      logger.debug("Handling POST request for \"" + info.getPath() + "\"");
 
       if (closed) {
          UriBuilder builder = info.getBaseUriBuilder();
@@ -91,7 +95,7 @@ public class AcknowledgedQueueConsumer extends QueueConsumer {
    public synchronized Response acknowledge(@PathParam("ackToken") String ackToken,
                                             @FormParam("acknowledge") boolean doAcknowledge,
                                             @Context UriInfo uriInfo) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
 
       ping(0);
       String basePath = uriInfo.getMatchedURIs().get(1);
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/ConsumedMessage.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/ConsumedMessage.java
index d30248a49d..e481aed05a 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/ConsumedMessage.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/ConsumedMessage.java
@@ -24,9 +24,13 @@ import org.apache.activemq.artemis.api.core.client.ClientMessage;
 import org.apache.activemq.artemis.jms.client.ConnectionFactoryOptions;
 import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
 import org.apache.activemq.artemis.rest.HttpHeaderProperty;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public abstract class ConsumedMessage {
 
+   private static final Logger logger = LoggerFactory.getLogger(ConsumedMessage.class);
+
    public static final String POSTED_AS_HTTP_MESSAGE = "postedAsHttpMessage";
    protected ClientMessage message;
 
@@ -48,7 +52,7 @@ public abstract class ConsumedMessage {
             continue;
          }
          builder.header(headerName, message.getStringProperty(k));
-         ActiveMQRestLogger.LOGGER.debug("Adding " + headerName + "=" + message.getStringProperty(k));
+         logger.debug("Adding " + headerName + "=" + message.getStringProperty(k));
       }
    }
 
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/ConsumersResource.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/ConsumersResource.java
index 05849724d8..ffc7fb083f 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/ConsumersResource.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/ConsumersResource.java
@@ -37,8 +37,12 @@ import org.apache.activemq.artemis.api.core.ActiveMQException;
 import org.apache.activemq.artemis.api.core.client.ClientSessionFactory;
 import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
 import org.apache.activemq.artemis.rest.util.TimeoutTask;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class ConsumersResource implements TimeoutTask.Callback {
+   
+   private static final Logger logger = LoggerFactory.getLogger( ConsumersResource.class );
 
    protected ConcurrentMap<String, QueueConsumer> queueConsumers = new ConcurrentHashMap<>();
    protected ClientSessionFactory sessionFactory;
@@ -124,7 +128,7 @@ public class ConsumersResource implements TimeoutTask.Callback {
    public Response createSubscription(@FormParam("autoAck") @DefaultValue("true") boolean autoAck,
                                       @FormParam("selector") String selector,
                                       @Context UriInfo uriInfo) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
 
       try {
          QueueConsumer consumer = null;
@@ -184,7 +188,7 @@ public class ConsumersResource implements TimeoutTask.Callback {
    public Response getConsumer(@PathParam("attributes") int attributes,
                                @PathParam("consumer-id") String consumerId,
                                @Context UriInfo uriInfo) throws Exception {
-      ActiveMQRestLogger.LOGGER.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
 
       return headConsumer(attributes, consumerId, uriInfo);
    }
@@ -194,7 +198,7 @@ public class ConsumersResource implements TimeoutTask.Callback {
    public Response headConsumer(@PathParam("attributes") int attributes,
                                 @PathParam("consumer-id") String consumerId,
                                 @Context UriInfo uriInfo) throws Exception {
-      ActiveMQRestLogger.LOGGER.debug("Handling HEAD request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling HEAD request for \"" + uriInfo.getPath() + "\"");
 
       QueueConsumer consumer = findConsumer(attributes, consumerId, uriInfo);
       Response.ResponseBuilder builder = Response.noContent();
@@ -258,7 +262,7 @@ public class ConsumersResource implements TimeoutTask.Callback {
    @Path("attributes-{attributes}/{consumer-id}")
    @DELETE
    public void closeSession(@PathParam("consumer-id") String consumerId, @Context UriInfo uriInfo) {
-      ActiveMQRestLogger.LOGGER.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
 
       QueueConsumer consumer = queueConsumers.remove(consumerId);
       if (consumer == null) {
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessage.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessage.java
index 6f72d81479..ef237a63f1 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessage.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessage.java
@@ -42,9 +42,13 @@ import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
 import org.apache.activemq.artemis.rest.util.HttpMessageHelper;
 import org.apache.activemq.artemis.utils.UUID;
 import org.apache.activemq.artemis.utils.UUIDGenerator;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class PostMessage {
 
+   private static final Logger logger = LoggerFactory.getLogger(PostMessage.class);
+
    protected ClientSessionFactory sessionFactory;
    protected String destination;
    protected boolean defaultDurable = false;
@@ -83,7 +87,7 @@ public class PostMessage {
          ClientMessage message = createActiveMQMessage(headers, body, durable, ttl, expiration, priority, pooled.session);
          message.putStringProperty(Message.HDR_DUPLICATE_DETECTION_ID.toString(), dup);
          producer.send(message);
-         ActiveMQRestLogger.LOGGER.debug("Sent message: " + message);
+         logger.debug("Sent message: " + message);
          pool.add(pooled);
       } catch (Exception ex) {
          try {
@@ -105,7 +109,7 @@ public class PostMessage {
                              @Context HttpHeaders headers,
                              @Context UriInfo uriInfo,
                              byte[] body) {
-      ActiveMQRestLogger.LOGGER.debug("Handling PUT request for \"" + uriInfo.getRequestUri() + "\"");
+      logger.debug("Handling PUT request for \"" + uriInfo.getRequestUri() + "\"");
 
       return internalPostWithId(dupId, durable, ttl, expiration, priority, headers, uriInfo, body);
    }
@@ -120,7 +124,7 @@ public class PostMessage {
                               @Context HttpHeaders headers,
                               @Context UriInfo uriInfo,
                               byte[] body) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + uriInfo.getRequestUri() + "\"");
+      logger.debug("Handling POST request for \"" + uriInfo.getRequestUri() + "\"");
 
       return internalPostWithId(dupId, durable, ttl, expiration, priority, headers, uriInfo, body);
    }
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageDupsOk.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageDupsOk.java
index e11881d1b9..85f64a46f5 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageDupsOk.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageDupsOk.java
@@ -30,12 +30,16 @@ import org.apache.activemq.artemis.api.core.ActiveMQException;
 import org.apache.activemq.artemis.api.core.client.ClientMessage;
 import org.apache.activemq.artemis.api.core.client.ClientProducer;
 import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 /**
  * Implements simple "create" link.  Returns 201 with Location of created resource as per HTTP
  */
 public class PostMessageDupsOk extends PostMessage {
 
+   private static final Logger logger = LoggerFactory.getLogger(PostMessageDupsOk.class);
+
    public void publish(HttpHeaders headers,
                        byte[] body,
                        boolean durable,
@@ -47,7 +51,7 @@ public class PostMessageDupsOk extends PostMessage {
          ClientProducer producer = pooled.producer;
          ClientMessage message = createActiveMQMessage(headers, body, durable, ttl, expiration, priority, pooled.session);
          producer.send(message);
-         ActiveMQRestLogger.LOGGER.debug("Sent message: " + message);
+         logger.debug("Sent message: " + message);
          pool.add(pooled);
       } catch (Exception ex) {
          try {
@@ -67,7 +71,7 @@ public class PostMessageDupsOk extends PostMessage {
                           @QueryParam("priority") Integer priority,
                           @Context UriInfo uriInfo,
                           byte[] body) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + uriInfo.getRequestUri() + "\"");
+      logger.debug("Handling POST request for \"" + uriInfo.getRequestUri() + "\"");
 
       try {
          boolean isDurable = defaultDurable;
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageNoDups.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageNoDups.java
index a0e3819a6b..e00430e6c6 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageNoDups.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/PostMessageNoDups.java
@@ -22,15 +22,19 @@ import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
 import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 /**
  * implements reliable "create", "create-next" pattern defined by REST-* Messaging specification
  */
 public class PostMessageNoDups extends PostMessage {
 
+   private static final Logger logger = LoggerFactory.getLogger(PostMessageNoDups.class);
+
    @POST
    public Response redirectCreation(@Context UriInfo uriInfo) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
 
       String id = generateDupId();
       Response.ResponseBuilder res = Response.status(Response.Status.TEMPORARY_REDIRECT.getStatusCode());
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueConsumer.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueConsumer.java
index d4e0f8705b..d7f4d71e1a 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueConsumer.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueConsumer.java
@@ -38,11 +38,14 @@ import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
 import org.apache.activemq.artemis.rest.util.Constants;
 import org.apache.activemq.artemis.rest.util.LinkStrategy;
 import org.apache.activemq.artemis.utils.SelectorTranslator;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 /**
  * Auto-acknowledged consumer
  */
 public class QueueConsumer {
+   private static final Logger logger = LoggerFactory.getLogger( QueueConsumer.class );
 
    protected ClientSessionFactory factory;
    protected ClientSession session;
@@ -113,13 +116,13 @@ public class QueueConsumer {
       previousIndex = -2;
       try {
          consumer.close();
-         ActiveMQRestLogger.LOGGER.debug("Closed consumer: " + consumer);
+         logger.debug("Closed consumer: " + consumer);
       } catch (Exception e) {
       }
 
       try {
          session.close();
-         ActiveMQRestLogger.LOGGER.debug("Closed session: " + session);
+         logger.debug("Closed session: " + session);
       } catch (Exception e) {
       }
       session = null;
@@ -131,7 +134,7 @@ public class QueueConsumer {
    public synchronized Response poll(@HeaderParam(Constants.WAIT_HEADER) @DefaultValue("0") long wait,
                                      @PathParam("index") long index,
                                      @Context UriInfo info) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + info.getRequestUri() + "\"");
+      logger.debug("Handling POST request for \"" + info.getRequestUri() + "\"");
 
       if (closed) {
          UriBuilder builder = info.getBaseUriBuilder();
@@ -191,13 +194,13 @@ public class QueueConsumer {
 
    protected void createSession() throws ActiveMQException {
       session = factory.createSession(true, true, 0);
-      ActiveMQRestLogger.LOGGER.debug("Created session: " + session);
+      logger.debug("Created session: " + session);
       if (selector == null) {
          consumer = session.createConsumer(destination);
       } else {
          consumer = session.createConsumer(destination, SelectorTranslator.convertToActiveMQFilterString(selector));
       }
-      ActiveMQRestLogger.LOGGER.debug("Created consumer: " + consumer);
+      logger.debug("Created consumer: " + consumer);
       session.start();
    }
 
@@ -209,7 +212,7 @@ public class QueueConsumer {
          m = consumer.receive(timeoutSecs * 1000);
       }
 
-      ActiveMQRestLogger.LOGGER.debug("Returning message " + m + " from consumer: " + consumer);
+      logger.debug("Returning message " + m + " from consumer: " + consumer);
 
       return m;
    }
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueDestinationsResource.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueDestinationsResource.java
index 9f79624f46..1d31cfce84 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueDestinationsResource.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueDestinationsResource.java
@@ -41,11 +41,15 @@ import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
 import org.apache.activemq.artemis.rest.queue.push.PushConsumerResource;
 import org.apache.activemq.artemis.rest.queue.push.xml.PushRegistration;
 import org.apache.activemq.artemis.rest.util.Constants;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 import org.w3c.dom.Document;
 
 @Path(Constants.PATH_FOR_QUEUES)
 public class QueueDestinationsResource {
 
+   private static final Logger logger = LoggerFactory.getLogger(QueueDestinationsResource.class);
+
    private final Map<String, QueueResource> queues = new ConcurrentHashMap<>();
    private final QueueServiceManager manager;
 
@@ -56,7 +60,7 @@ public class QueueDestinationsResource {
    @POST
    @Consumes("application/activemq.jms.queue+xml")
    public Response createJmsQueue(@Context UriInfo uriInfo, Document document) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
 
       try {
          JMSQueueConfiguration queue = FileJMSConfiguration.parseQueueConfiguration(document.getDocumentElement());
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueResource.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueResource.java
index 74eec85463..980b8900e3 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueResource.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/QueueResource.java
@@ -31,9 +31,13 @@ import org.apache.activemq.artemis.api.core.SimpleString;
 import org.apache.activemq.artemis.api.core.client.ClientSession;
 import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
 import org.apache.activemq.artemis.rest.queue.push.PushConsumerResource;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class QueueResource extends DestinationResource {
 
+   private static final Logger logger = LoggerFactory.getLogger(QueueResource.class);
+
    protected ConsumersResource consumers;
    protected PushConsumerResource pushConsumers;
    private QueueDestinationsResource queueDestinationsResource;
@@ -50,7 +54,7 @@ public class QueueResource extends DestinationResource {
    @GET
    @Produces("application/xml")
    public Response get(@Context UriInfo uriInfo, @Context HttpServletRequest requestContext) {
-      ActiveMQRestLogger.LOGGER.debug("Handling GET request for \"" + destination + "\" from " + requestContext.getRemoteAddr() + ":" + requestContext.getRemotePort());
+      logger.debug("Handling GET request for \"" + destination + "\" from " + requestContext.getRemoteAddr() + ":" + requestContext.getRemotePort());
 
       StringBuilder msg = new StringBuilder();
       msg.append("<queue>").append("<name>").append(destination).append("</name>").append("<atom:link rel=\"create\" href=\"").append(createSenderLink(uriInfo)).append("\"/>").append("<atom:link rel=\"create-with-id\" href=\"").append(createSenderWithIdLink(uriInfo)).append("\"/>").append("<atom:link rel=\"pull-consumers\" href=\"").append(createConsumersLink(uriInfo)).append("\"/>").append("<atom:link rel=\"push-consumers\" href=\"").append(createPushConsumersLink(uriInfo)).append("\"/>")
@@ -68,7 +72,7 @@ public class QueueResource extends DestinationResource {
    @HEAD
    @Produces("application/xml")
    public Response head(@Context UriInfo uriInfo) {
-      ActiveMQRestLogger.LOGGER.debug("Handling HEAD request for \"" + uriInfo.getRequestUri() + "\"");
+      logger.debug("Handling HEAD request for \"" + uriInfo.getRequestUri() + "\"");
 
       Response.ResponseBuilder builder = Response.ok();
       setSenderLink(builder, uriInfo);
@@ -156,7 +160,7 @@ public class QueueResource extends DestinationResource {
 
    @DELETE
    public void deleteQueue(@Context UriInfo uriInfo) throws Exception {
-      ActiveMQRestLogger.LOGGER.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
 
       queueDestinationsResource.getQueues().remove(destination);
       stop();
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/PushConsumerMessageHandler.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/PushConsumerMessageHandler.java
index 8f38dee675..95636f5e65 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/PushConsumerMessageHandler.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/PushConsumerMessageHandler.java
@@ -21,9 +21,13 @@ import org.apache.activemq.artemis.api.core.client.ClientMessage;
 import org.apache.activemq.artemis.api.core.client.ClientSession;
 import org.apache.activemq.artemis.api.core.client.MessageHandler;
 import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class PushConsumerMessageHandler implements MessageHandler {
 
+   private static final Logger logger = LoggerFactory.getLogger(PushConsumerMessageHandler.class);
+
    private ClientSession session;
    private PushConsumer pushConsumer;
 
@@ -34,21 +38,21 @@ public class PushConsumerMessageHandler implements MessageHandler {
 
    @Override
    public void onMessage(ClientMessage clientMessage) {
-      ActiveMQRestLogger.LOGGER.debug(this + ": receiving " + clientMessage);
+      logger.debug(this + ": receiving " + clientMessage);
 
       try {
          clientMessage.acknowledge();
-         ActiveMQRestLogger.LOGGER.debug(this + ": acknowledged " + clientMessage);
+         logger.debug(this + ": acknowledged " + clientMessage);
       } catch (ActiveMQException e) {
          throw new RuntimeException(e.getMessage(), e);
       }
 
-      ActiveMQRestLogger.LOGGER.debug(this + ": pushing " + clientMessage + " via " + pushConsumer.getStrategy());
+      logger.debug(this + ": pushing " + clientMessage + " via " + pushConsumer.getStrategy());
       boolean acknowledge = pushConsumer.getStrategy().push(clientMessage);
 
       if (acknowledge) {
          try {
-            ActiveMQRestLogger.LOGGER.debug("Acknowledging: " + clientMessage.getMessageID());
+            logger.debug("Acknowledging: " + clientMessage.getMessageID());
             session.commit();
             return;
          } catch (ActiveMQException e) {
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/PushConsumerResource.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/PushConsumerResource.java
index 859b22b8ef..69430e642a 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/PushConsumerResource.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/PushConsumerResource.java
@@ -36,9 +36,13 @@ import org.apache.activemq.artemis.api.core.client.ClientSessionFactory;
 import org.apache.activemq.artemis.jms.client.ConnectionFactoryOptions;
 import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
 import org.apache.activemq.artemis.rest.queue.push.xml.PushRegistration;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class PushConsumerResource {
 
+   private static final Logger logger = LoggerFactory.getLogger(PushConsumerResource.class);
+
    protected Map<String, PushConsumer> consumers = new ConcurrentHashMap<>();
    protected ClientSessionFactory sessionFactory;
    protected String destination;
@@ -77,7 +81,7 @@ public class PushConsumerResource {
    @POST
    @Consumes("application/xml")
    public Response create(@Context UriInfo uriInfo, PushRegistration registration) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
 
       // todo put some logic here to check for duplicates
       String genId = sessionCounter.getAndIncrement() + "-" + startup;
@@ -104,7 +108,7 @@ public class PushConsumerResource {
    @Path("{consumer-id}")
    @Produces("application/xml")
    public PushRegistration getConsumer(@Context UriInfo uriInfo, @PathParam("consumer-id") String consumerId) {
-      ActiveMQRestLogger.LOGGER.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
 
       PushConsumer consumer = consumers.get(consumerId);
       if (consumer == null) {
@@ -116,7 +120,7 @@ public class PushConsumerResource {
    @DELETE
    @Path("{consumer-id}")
    public void deleteConsumer(@Context UriInfo uriInfo, @PathParam("consumer-id") String consumerId) {
-      ActiveMQRestLogger.LOGGER.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
 
       PushConsumer consumer = consumers.remove(consumerId);
       if (consumer == null) {
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/UriStrategy.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/UriStrategy.java
index 591c8e29d9..9413b2144b 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/UriStrategy.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/queue/push/UriStrategy.java
@@ -48,9 +48,13 @@ import org.jboss.resteasy.client.ClientRequest;
 import org.jboss.resteasy.client.ClientResponse;
 import org.jboss.resteasy.client.core.executors.ApacheHttpClient4Executor;
 import org.jboss.resteasy.specimpl.ResteasyUriBuilder;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class UriStrategy implements PushStrategy {
 
+   private static final Logger logger = LoggerFactory.getLogger(UriStrategy.class);
+
    ThreadSafeClientConnManager connManager = new ThreadSafeClientConnManager();
    protected HttpClient client = new DefaultHttpClient(connManager);
    protected BasicHttpContext localContext;
@@ -115,26 +119,26 @@ public class UriStrategy implements PushStrategy {
 
    @Override
    public boolean push(ClientMessage message) {
-      ActiveMQRestLogger.LOGGER.debug("Pushing " + message);
+      logger.debug("Pushing " + message);
       String uri = createUri(message);
       for (int i = 0; i < registration.getMaxRetries(); i++) {
          long wait = registration.getRetryWaitMillis();
          System.out.println("Creating request from " + uri);
          ClientRequest request = executor.createRequest(uri);
          request.followRedirects(false);
-         ActiveMQRestLogger.LOGGER.debug("Created request " + request);
+         logger.debug("Created request " + request);
 
          for (XmlHttpHeader header : registration.getHeaders()) {
-            ActiveMQRestLogger.LOGGER.debug("Setting XmlHttpHeader: " + header.getName() + "=" + header.getValue());
+            logger.debug("Setting XmlHttpHeader: " + header.getName() + "=" + header.getValue());
             request.header(header.getName(), header.getValue());
          }
          HttpMessageHelper.buildMessage(message, request, contentType, jmsOptions);
          ClientResponse<?> res = null;
          try {
-            ActiveMQRestLogger.LOGGER.debug(method + " " + uri);
+            logger.debug(method + " " + uri);
             res = request.httpMethod(method);
             int status = res.getStatus();
-            ActiveMQRestLogger.LOGGER.debug("Status of push: " + status);
+            logger.debug("Status of push: " + status);
             if (status == 503) {
                String retryAfter = res.getStringHeaders().getFirst("Retry-After");
                if (retryAfter != null) {
@@ -144,7 +148,7 @@ public class UriStrategy implements PushStrategy {
                uri = res.getLocation().toString();
                wait = 0;
             } else if ((status >= 200 && status < 299) || status == 303 || status == 304) {
-               ActiveMQRestLogger.LOGGER.debug("Success");
+               logger.debug("Success");
                return true;
             } else if (status >= 400) {
                switch (status) {
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/PushSubscriptionsResource.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/PushSubscriptionsResource.java
index dd9cfd6be3..42cbdb48ea 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/PushSubscriptionsResource.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/PushSubscriptionsResource.java
@@ -39,9 +39,13 @@ import org.apache.activemq.artemis.api.core.client.ClientSessionFactory;
 import org.apache.activemq.artemis.jms.client.ConnectionFactoryOptions;
 import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
 import org.apache.activemq.artemis.rest.queue.push.PushConsumer;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class PushSubscriptionsResource {
 
+   private static final Logger logger = LoggerFactory.getLogger(PushSubscriptionsResource.class);
+
    protected Map<String, PushSubscription> consumers = new ConcurrentHashMap<>();
    protected ClientSessionFactory sessionFactory;
    protected String destination;
@@ -120,7 +124,7 @@ public class PushSubscriptionsResource {
 
    @POST
    public Response create(@Context UriInfo uriInfo, PushTopicRegistration registration) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
 
       //System.out.println("PushRegistration: " + registration);
       // todo put some logic here to check for duplicates
@@ -156,7 +160,7 @@ public class PushSubscriptionsResource {
    @Path("{consumer-id}")
    @Produces("application/xml")
    public PushTopicRegistration getConsumer(@Context UriInfo uriInfo, @PathParam("consumer-id") String consumerId) {
-      ActiveMQRestLogger.LOGGER.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
 
       PushConsumer consumer = consumers.get(consumerId);
       if (consumer == null) {
@@ -168,7 +172,7 @@ public class PushSubscriptionsResource {
    @DELETE
    @Path("{consumer-id}")
    public void deleteConsumer(@Context UriInfo uriInfo, @PathParam("consumer-id") String consumerId) {
-      ActiveMQRestLogger.LOGGER.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
 
       PushConsumer consumer = consumers.remove(consumerId);
       if (consumer == null) {
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/SubscriptionsResource.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/SubscriptionsResource.java
index 9862e3e639..12ba19f09e 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/SubscriptionsResource.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/SubscriptionsResource.java
@@ -44,9 +44,13 @@ import org.apache.activemq.artemis.rest.queue.Acknowledgement;
 import org.apache.activemq.artemis.rest.queue.DestinationServiceManager;
 import org.apache.activemq.artemis.rest.queue.QueueConsumer;
 import org.apache.activemq.artemis.rest.util.TimeoutTask;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class SubscriptionsResource implements TimeoutTask.Callback {
 
+   private static final Logger logger = LoggerFactory.getLogger(SubscriptionsResource.class);
+
    protected ConcurrentMap<String, QueueConsumer> queueConsumers = new ConcurrentHashMap<>();
    protected ClientSessionFactory sessionFactory;
    protected String destination;
@@ -146,7 +150,7 @@ public class SubscriptionsResource implements TimeoutTask.Callback {
                                       @FormParam("delete-when-idle") Boolean destroyWhenIdle,
                                       @FormParam("idle-timeout") Long timeout,
                                       @Context UriInfo uriInfo) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
 
       if (timeout == null)
          timeout = Long.valueOf((long) consumerTimeoutSeconds * 1000);
@@ -245,7 +249,7 @@ public class SubscriptionsResource implements TimeoutTask.Callback {
    @GET
    public Response getAutoAckSubscription(@PathParam("consumer-id") String consumerId,
                                           @Context UriInfo uriInfo) throws Exception {
-      ActiveMQRestLogger.LOGGER.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
 
       return internalHeadAutoAckSubscription(uriInfo, consumerId);
    }
@@ -254,7 +258,7 @@ public class SubscriptionsResource implements TimeoutTask.Callback {
    @HEAD
    public Response headAutoAckSubscription(@PathParam("consumer-id") String consumerId,
                                            @Context UriInfo uriInfo) throws Exception {
-      ActiveMQRestLogger.LOGGER.debug("Handling HEAD request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling HEAD request for \"" + uriInfo.getPath() + "\"");
 
       return internalHeadAutoAckSubscription(uriInfo, consumerId);
    }
@@ -291,7 +295,7 @@ public class SubscriptionsResource implements TimeoutTask.Callback {
    @GET
    public Response getAcknowledgedConsumer(@PathParam("consumer-id") String consumerId,
                                            @Context UriInfo uriInfo) throws Exception {
-      ActiveMQRestLogger.LOGGER.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
 
       return internalHeadAcknowledgedConsumer(uriInfo, consumerId);
    }
@@ -300,7 +304,7 @@ public class SubscriptionsResource implements TimeoutTask.Callback {
    @HEAD
    public Response headAcknowledgedConsumer(@PathParam("consumer-id") String consumerId,
                                             @Context UriInfo uriInfo) throws Exception {
-      ActiveMQRestLogger.LOGGER.debug("Handling HEAD request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling HEAD request for \"" + uriInfo.getPath() + "\"");
 
       return internalHeadAcknowledgedConsumer(uriInfo, consumerId);
    }
@@ -380,7 +384,7 @@ public class SubscriptionsResource implements TimeoutTask.Callback {
    @Path("acknowledged/{subscription-id}")
    @DELETE
    public void deleteAckSubscription(@Context UriInfo uriInfo, @PathParam("subscription-id") String consumerId) {
-      ActiveMQRestLogger.LOGGER.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
 
       internalDeleteSubscription(consumerId);
    }
@@ -388,7 +392,7 @@ public class SubscriptionsResource implements TimeoutTask.Callback {
    @Path("auto-ack/{subscription-id}")
    @DELETE
    public void deleteSubscription(@Context UriInfo uriInfo, @PathParam("subscription-id") String consumerId) {
-      ActiveMQRestLogger.LOGGER.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
 
       internalDeleteSubscription(consumerId);
    }
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/TopicDestinationsResource.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/TopicDestinationsResource.java
index 651dd444ac..7777071c61 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/TopicDestinationsResource.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/TopicDestinationsResource.java
@@ -42,11 +42,15 @@ import org.apache.activemq.artemis.rest.queue.DestinationSettings;
 import org.apache.activemq.artemis.rest.queue.PostMessage;
 import org.apache.activemq.artemis.rest.queue.PostMessageDupsOk;
 import org.apache.activemq.artemis.rest.queue.PostMessageNoDups;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 import org.w3c.dom.Document;
 
 @Path("/topics")
 public class TopicDestinationsResource {
 
+   private static final Logger logger = LoggerFactory.getLogger(TopicDestinationsResource.class);
+
    private final Map<String, TopicResource> topics = new ConcurrentHashMap<>();
    private final TopicServiceManager manager;
 
@@ -57,7 +61,7 @@ public class TopicDestinationsResource {
    @POST
    @Consumes("application/activemq.jms.topic+xml")
    public Response createJmsTopic(@Context UriInfo uriInfo, Document document) {
-      ActiveMQRestLogger.LOGGER.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling POST request for \"" + uriInfo.getPath() + "\"");
 
       try {
          TopicConfiguration topic = FileJMSConfiguration.parseTopicConfiguration(document.getDocumentElement());
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/TopicResource.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/TopicResource.java
index 038bf8695e..40a2107ab5 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/TopicResource.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/topic/TopicResource.java
@@ -31,9 +31,13 @@ import org.apache.activemq.artemis.api.core.client.ClientSession;
 import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
 import org.apache.activemq.artemis.rest.queue.DestinationResource;
 import org.apache.activemq.artemis.rest.queue.PostMessage;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class TopicResource extends DestinationResource {
 
+   private static final Logger logger = LoggerFactory.getLogger(TopicResource.class);
+
    protected SubscriptionsResource subscriptions;
    protected PushSubscriptionsResource pushSubscriptions;
    private TopicDestinationsResource topicDestinationsResource;
@@ -50,7 +54,7 @@ public class TopicResource extends DestinationResource {
    @GET
    @Produces("application/xml")
    public Response get(@Context UriInfo uriInfo) {
-      ActiveMQRestLogger.LOGGER.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling GET request for \"" + uriInfo.getPath() + "\"");
 
       StringBuilder msg = new StringBuilder();
       msg.append("<topic>").append("<name>").append(destination).append("</name>").append("<atom:link rel=\"create\" href=\"").append(createSenderLink(uriInfo)).append("\"/>").append("<atom:link rel=\"create-with-id\" href=\"").append(createSenderWithIdLink(uriInfo)).append("\"/>").append("<atom:link rel=\"pull-consumers\" href=\"").append(createSubscriptionsLink(uriInfo)).append("\"/>").append("<atom:link rel=\"push-consumers\" href=\"").append(createPushSubscriptionsLink(uriInfo)).appe [...]
@@ -68,7 +72,7 @@ public class TopicResource extends DestinationResource {
    @HEAD
    @Produces("application/xml")
    public Response head(@Context UriInfo uriInfo) {
-      ActiveMQRestLogger.LOGGER.debug("Handling HEAD request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling HEAD request for \"" + uriInfo.getPath() + "\"");
 
       Response.ResponseBuilder builder = Response.ok();
       setSenderLink(builder, uriInfo);
@@ -152,7 +156,7 @@ public class TopicResource extends DestinationResource {
 
    @DELETE
    public void deleteTopic(@Context UriInfo uriInfo) throws Exception {
-      ActiveMQRestLogger.LOGGER.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
+      logger.debug("Handling DELETE request for \"" + uriInfo.getPath() + "\"");
 
       topicDestinationsResource.getTopics().remove(destination);
 
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/util/HttpMessageHelper.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/util/HttpMessageHelper.java
index 4e5a2784d7..31eb787c46 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/util/HttpMessageHelper.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/util/HttpMessageHelper.java
@@ -29,11 +29,15 @@ import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
 import org.apache.activemq.artemis.rest.HttpHeaderProperty;
 import org.apache.activemq.artemis.utils.ObjectInputStreamWithClassLoader;
 import org.jboss.resteasy.client.ClientRequest;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 import static org.apache.activemq.artemis.rest.HttpHeaderProperty.MESSAGE_PROPERTY_DISCRIMINATOR;
 
 public class HttpMessageHelper {
 
+   private static final Logger logger = LoggerFactory.getLogger(HttpMessageHelper.class);
+
    public static final String POSTED_AS_HTTP_MESSAGE = "postedAsHttpMessage";
 
    public static boolean isTransferableHttpHeader(String key) {
@@ -58,11 +62,11 @@ public class HttpMessageHelper {
          String value = message.getStringProperty(k);
 
          request.header(headerName, value);
-         ActiveMQRestLogger.LOGGER.debug("Examining " + headerName + ": " + value);
+         logger.debug("Examining " + headerName + ": " + value);
          // override default content type if it is set as a message property
          if (headerName.equalsIgnoreCase("content-type")) {
             contentType = value;
-            ActiveMQRestLogger.LOGGER.debug("Using contentType: " + contentType);
+            logger.debug("Using contentType: " + contentType);
          }
       }
       int size = message.getBodySize();
@@ -71,7 +75,7 @@ public class HttpMessageHelper {
          if (aBoolean != null && aBoolean.booleanValue()) {
             byte[] body = new byte[size];
             message.getBodyBuffer().readBytes(body);
-            ActiveMQRestLogger.LOGGER.debug("Building Message from HTTP message");
+            logger.debug("Building Message from HTTP message");
             request.body(contentType, body);
          } else {
             // assume posted as a JMS or ActiveMQ Artemis object message
@@ -86,7 +90,7 @@ public class HttpMessageHelper {
                   ois.setWhiteList(jmsOptions.getDeserializationWhiteList());
                }
                obj = ois.readObject();
-               ActiveMQRestLogger.LOGGER.debug("**** Building Message from object: " + obj.toString());
+               logger.debug("**** Building Message from object: " + obj.toString());
                request.body(contentType, obj);
             } catch (Exception e) {
                ActiveMQRestLogger.LOGGER.failedToBuildMessageFromObject(e);
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/util/TimeoutTask.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/util/TimeoutTask.java
index cb42c9525c..fbc06919a2 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/util/TimeoutTask.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/util/TimeoutTask.java
@@ -24,9 +24,13 @@ import java.util.concurrent.locks.Lock;
 import java.util.concurrent.locks.ReentrantLock;
 
 import org.apache.activemq.artemis.rest.ActiveMQRestLogger;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 
 public class TimeoutTask implements Runnable {
 
+   private static final Logger logger = LoggerFactory.getLogger( TimeoutTask.class );
+
    protected boolean running = true;
    protected int interval = 10;
    protected final Lock callbacksLock = new ReentrantLock();
@@ -126,7 +130,7 @@ public class TimeoutTask implements Runnable {
                   liveConsumers += 1;
                }
             }
-            ActiveMQRestLogger.LOGGER.debug("Finished testing callbacks for timeouts in " +
+            logger.debug("Finished testing callbacks for timeouts in " +
                                                (System.currentTimeMillis() - startTime) + "ms. " +
                                                "(Live: " + liveConsumers + ", Expired: " + deadConsumers + ")");
 
@@ -134,7 +138,7 @@ public class TimeoutTask implements Runnable {
             pendingCallbacksLock.lock();
             try {
                if (pendingCallbacks.size() > 0) {
-                  ActiveMQRestLogger.LOGGER.debug("Found " + pendingCallbacks.size() + " callbacks to add.");
+                  logger.debug("Found " + pendingCallbacks.size() + " callbacks to add.");
                   callbacks.putAll(pendingCallbacks);
                   pendingCallbacks.clear();
                }