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 2015/08/10 17:13:10 UTC

[11/53] [abbrv] [partial] activemq-artemis git commit: automatic checkstyle change

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/management/impl/JMSTopicControlImpl.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/management/impl/JMSTopicControlImpl.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/management/impl/JMSTopicControlImpl.java
index 2c583cf..213f243 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/management/impl/JMSTopicControlImpl.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/management/impl/JMSTopicControlImpl.java
@@ -40,8 +40,8 @@ import org.apache.activemq.artemis.jms.server.JMSServerManager;
 import org.apache.activemq.artemis.utils.json.JSONArray;
 import org.apache.activemq.artemis.utils.json.JSONObject;
 
-public class JMSTopicControlImpl extends StandardMBean implements TopicControl
-{
+public class JMSTopicControlImpl extends StandardMBean implements TopicControl {
+
    private final ActiveMQDestination managedTopic;
 
    private final AddressControl addressControl;
@@ -52,10 +52,8 @@ public class JMSTopicControlImpl extends StandardMBean implements TopicControl
 
    // Static --------------------------------------------------------
 
-   public static String createFilterFromJMSSelector(final String selectorStr) throws ActiveMQException
-   {
-      return selectorStr == null || selectorStr.trim().length() == 0 ? null
-                                                                    : SelectorTranslator.convertToActiveMQFilterString(selectorStr);
+   public static String createFilterFromJMSSelector(final String selectorStr) throws ActiveMQException {
+      return selectorStr == null || selectorStr.trim().length() == 0 ? null : SelectorTranslator.convertToActiveMQFilterString(selectorStr);
    }
 
    // Constructors --------------------------------------------------
@@ -63,8 +61,7 @@ public class JMSTopicControlImpl extends StandardMBean implements TopicControl
    public JMSTopicControlImpl(final ActiveMQDestination topic,
                               final JMSServerManager jmsServerManager,
                               final AddressControl addressControl,
-                              final ManagementService managementService) throws Exception
-   {
+                              final ManagementService managementService) throws Exception {
       super(TopicControl.class);
       this.jmsServerManager = jmsServerManager;
       managedTopic = topic;
@@ -75,118 +72,95 @@ public class JMSTopicControlImpl extends StandardMBean implements TopicControl
    // TopicControlMBean implementation ------------------------------
 
    @Override
-   public void addBinding(String binding) throws Exception
-   {
+   public void addBinding(String binding) throws Exception {
       jmsServerManager.addTopicToBindingRegistry(managedTopic.getName(), binding);
    }
 
-   public String[] getRegistryBindings()
-   {
+   public String[] getRegistryBindings() {
       return jmsServerManager.getBindingsOnTopic(managedTopic.getName());
    }
 
-   public String getName()
-   {
+   public String getName() {
       return managedTopic.getName();
    }
 
-   public boolean isTemporary()
-   {
+   public boolean isTemporary() {
       return managedTopic.isTemporary();
    }
 
-   public String getAddress()
-   {
+   public String getAddress() {
       return managedTopic.getAddress();
    }
 
-   public long getMessageCount()
-   {
+   public long getMessageCount() {
       return getMessageCount(DurabilityType.ALL);
    }
 
-   public int getDeliveringCount()
-   {
+   public int getDeliveringCount() {
       List<QueueControl> queues = getQueues(DurabilityType.ALL);
       int count = 0;
-      for (QueueControl queue : queues)
-      {
+      for (QueueControl queue : queues) {
          count += queue.getDeliveringCount();
       }
       return count;
    }
 
-   public long getMessagesAdded()
-   {
+   public long getMessagesAdded() {
       List<QueueControl> queues = getQueues(DurabilityType.ALL);
       int count = 0;
-      for (QueueControl queue : queues)
-      {
+      for (QueueControl queue : queues) {
          count += queue.getMessagesAdded();
       }
       return count;
    }
 
-   public int getDurableMessageCount()
-   {
+   public int getDurableMessageCount() {
       return getMessageCount(DurabilityType.DURABLE);
    }
 
-   public int getNonDurableMessageCount()
-   {
+   public int getNonDurableMessageCount() {
       return getMessageCount(DurabilityType.NON_DURABLE);
    }
 
-   public int getSubscriptionCount()
-   {
+   public int getSubscriptionCount() {
       return getQueues(DurabilityType.ALL).size();
    }
 
-   public int getDurableSubscriptionCount()
-   {
+   public int getDurableSubscriptionCount() {
       return getQueues(DurabilityType.DURABLE).size();
    }
 
-   public int getNonDurableSubscriptionCount()
-   {
+   public int getNonDurableSubscriptionCount() {
       return getQueues(DurabilityType.NON_DURABLE).size();
    }
 
-   public Object[] listAllSubscriptions()
-   {
+   public Object[] listAllSubscriptions() {
       return listSubscribersInfos(DurabilityType.ALL);
    }
 
-   public String listAllSubscriptionsAsJSON() throws Exception
-   {
+   public String listAllSubscriptionsAsJSON() throws Exception {
       return listSubscribersInfosAsJSON(DurabilityType.ALL);
    }
 
-   public Object[] listDurableSubscriptions()
-   {
+   public Object[] listDurableSubscriptions() {
       return listSubscribersInfos(DurabilityType.DURABLE);
    }
 
-   public String listDurableSubscriptionsAsJSON() throws Exception
-   {
+   public String listDurableSubscriptionsAsJSON() throws Exception {
       return listSubscribersInfosAsJSON(DurabilityType.DURABLE);
    }
 
-   public Object[] listNonDurableSubscriptions()
-   {
+   public Object[] listNonDurableSubscriptions() {
       return listSubscribersInfos(DurabilityType.NON_DURABLE);
    }
 
-   public String listNonDurableSubscriptionsAsJSON() throws Exception
-   {
+   public String listNonDurableSubscriptionsAsJSON() throws Exception {
       return listSubscribersInfosAsJSON(DurabilityType.NON_DURABLE);
    }
 
-   public Map<String, Object>[] listMessagesForSubscription(final String queueName) throws Exception
-   {
-      QueueControl coreQueueControl = (QueueControl)managementService.getResource(ResourceNames.CORE_QUEUE + queueName);
-      if (coreQueueControl == null)
-      {
+   public Map<String, Object>[] listMessagesForSubscription(final String queueName) throws Exception {
+      QueueControl coreQueueControl = (QueueControl) managementService.getResource(ResourceNames.CORE_QUEUE + queueName);
+      if (coreQueueControl == null) {
          throw new IllegalArgumentException("No subscriptions with name " + queueName);
       }
 
@@ -196,40 +170,35 @@ public class JMSTopicControlImpl extends StandardMBean implements TopicControl
 
       int i = 0;
 
-      for (Map<String, Object> coreMessage : coreMessages)
-      {
+      for (Map<String, Object> coreMessage : coreMessages) {
          jmsMessages[i++] = ActiveMQMessage.coreMaptoJMSMap(coreMessage);
       }
       return jmsMessages;
    }
 
-   public String listMessagesForSubscriptionAsJSON(final String queueName) throws Exception
-   {
+   public String listMessagesForSubscriptionAsJSON(final String queueName) throws Exception {
       return JMSQueueControlImpl.toJSON(listMessagesForSubscription(queueName));
    }
 
-   public int countMessagesForSubscription(final String clientID, final String subscriptionName, final String filterStr) throws Exception
-   {
+   public int countMessagesForSubscription(final String clientID,
+                                           final String subscriptionName,
+                                           final String filterStr) throws Exception {
       String queueName = ActiveMQDestination.createQueueNameForDurableSubscription(true, clientID, subscriptionName);
-      QueueControl coreQueueControl = (QueueControl)managementService.getResource(ResourceNames.CORE_QUEUE + queueName);
-      if (coreQueueControl == null)
-      {
+      QueueControl coreQueueControl = (QueueControl) managementService.getResource(ResourceNames.CORE_QUEUE + queueName);
+      if (coreQueueControl == null) {
          throw new IllegalArgumentException("No subscriptions with name " + queueName + " for clientID " + clientID);
       }
       String filter = JMSTopicControlImpl.createFilterFromJMSSelector(filterStr);
       return coreQueueControl.listMessages(filter).length;
    }
 
-   public int removeMessages(final String filterStr) throws Exception
-   {
+   public int removeMessages(final String filterStr) throws Exception {
       String filter = JMSTopicControlImpl.createFilterFromJMSSelector(filterStr);
       int count = 0;
       String[] queues = addressControl.getQueueNames();
-      for (String queue : queues)
-      {
-         QueueControl coreQueueControl = (QueueControl)managementService.getResource(ResourceNames.CORE_QUEUE + queue);
-         if (coreQueueControl != null)
-         {
+      for (String queue : queues) {
+         QueueControl coreQueueControl = (QueueControl) managementService.getResource(ResourceNames.CORE_QUEUE + queue);
+         if (coreQueueControl != null) {
             count += coreQueueControl.removeMessages(filter);
          }
       }
@@ -237,28 +206,23 @@ public class JMSTopicControlImpl extends StandardMBean implements TopicControl
       return count;
    }
 
-   public void dropDurableSubscription(final String clientID, final String subscriptionName) throws Exception
-   {
+   public void dropDurableSubscription(final String clientID, final String subscriptionName) throws Exception {
       String queueName = ActiveMQDestination.createQueueNameForDurableSubscription(true, clientID, subscriptionName);
-      QueueControl coreQueueControl = (QueueControl)managementService.getResource(ResourceNames.CORE_QUEUE + queueName);
-      if (coreQueueControl == null)
-      {
+      QueueControl coreQueueControl = (QueueControl) managementService.getResource(ResourceNames.CORE_QUEUE + queueName);
+      if (coreQueueControl == null) {
          throw new IllegalArgumentException("No subscriptions with name " + queueName + " for clientID " + clientID);
       }
-      ActiveMQServerControl serverControl = (ActiveMQServerControl)managementService.getResource(ResourceNames.CORE_SERVER);
+      ActiveMQServerControl serverControl = (ActiveMQServerControl) managementService.getResource(ResourceNames.CORE_SERVER);
       serverControl.destroyQueue(queueName);
    }
 
-   public void dropAllSubscriptions() throws Exception
-   {
-      ActiveMQServerControl serverControl = (ActiveMQServerControl)managementService.getResource(ResourceNames.CORE_SERVER);
+   public void dropAllSubscriptions() throws Exception {
+      ActiveMQServerControl serverControl = (ActiveMQServerControl) managementService.getResource(ResourceNames.CORE_SERVER);
       String[] queues = addressControl.getQueueNames();
-      for (String queue : queues)
-      {
+      for (String queue : queues) {
          // Drop all subscription shouldn't delete the dummy queue used to identify if the topic exists on the core queues.
          // we will just ignore this queue
-         if (!queue.equals(managedTopic.getAddress()))
-         {
+         if (!queue.equals(managedTopic.getAddress())) {
             serverControl.destroyQueue(queue);
          }
       }
@@ -270,20 +234,16 @@ public class JMSTopicControlImpl extends StandardMBean implements TopicControl
 
    // Private -------------------------------------------------------
 
-   private Object[] listSubscribersInfos(final DurabilityType durability)
-   {
+   private Object[] listSubscribersInfos(final DurabilityType durability) {
       List<QueueControl> queues = getQueues(durability);
       List<Object[]> subInfos = new ArrayList<Object[]>(queues.size());
 
-      for (QueueControl queue : queues)
-      {
+      for (QueueControl queue : queues) {
          String clientID = null;
          String subName = null;
 
-         if (queue.isDurable())
-         {
-            Pair<String, String> pair = ActiveMQDestination.decomposeQueueNameForDurableSubscription(queue.getName()
-                                                                                                        .toString());
+         if (queue.isDurable()) {
+            Pair<String, String> pair = ActiveMQDestination.decomposeQueueNameForDurableSubscription(queue.getName().toString());
             clientID = pair.getA();
             subName = pair.getB();
          }
@@ -302,27 +262,21 @@ public class JMSTopicControlImpl extends StandardMBean implements TopicControl
       return subInfos.toArray(new Object[subInfos.size()]);
    }
 
-   private String listSubscribersInfosAsJSON(final DurabilityType durability) throws Exception
-   {
-      try
-      {
+   private String listSubscribersInfosAsJSON(final DurabilityType durability) throws Exception {
+      try {
          List<QueueControl> queues = getQueues(durability);
          JSONArray array = new JSONArray();
 
-         for (QueueControl queue : queues)
-         {
+         for (QueueControl queue : queues) {
             String clientID = null;
             String subName = null;
 
-            if (queue.isDurable() && !queue.getName().startsWith(ResourceNames.JMS_TOPIC))
-            {
-               Pair<String, String> pair = ActiveMQDestination.decomposeQueueNameForDurableSubscription(queue.getName()
-                                                                                                           .toString());
+            if (queue.isDurable() && !queue.getName().startsWith(ResourceNames.JMS_TOPIC)) {
+               Pair<String, String> pair = ActiveMQDestination.decomposeQueueNameForDurableSubscription(queue.getName().toString());
                clientID = pair.getA();
                subName = pair.getB();
             }
-            else if (queue.getName().startsWith(ResourceNames.JMS_TOPIC))
-            {
+            else if (queue.getName().startsWith(ResourceNames.JMS_TOPIC)) {
                // in the case of heirarchical topics the queue name will not follow the <part>.<part> pattern of normal
                // durable subscribers so skip decomposing the name for the client ID and subscription name and just
                // hard-code it
@@ -341,76 +295,58 @@ public class JMSTopicControlImpl extends StandardMBean implements TopicControl
             info.put("durable", queue.isDurable());
             info.put("messageCount", queue.getMessageCount());
             info.put("deliveringCount", queue.getDeliveringCount());
-            info.put("consumers", new JSONArray(queue.listConsumersAsJSON()) );
+            info.put("consumers", new JSONArray(queue.listConsumersAsJSON()));
             array.put(info);
          }
 
          return array.toString();
       }
-      catch (Exception e)
-      {
+      catch (Exception e) {
          e.printStackTrace();
          return e.toString();
       }
    }
 
-   private int getMessageCount(final DurabilityType durability)
-   {
+   private int getMessageCount(final DurabilityType durability) {
       List<QueueControl> queues = getQueues(durability);
       int count = 0;
-      for (QueueControl queue : queues)
-      {
+      for (QueueControl queue : queues) {
          count += queue.getMessageCount();
       }
       return count;
    }
 
-   private List<QueueControl> getQueues(final DurabilityType durability)
-   {
-      try
-      {
+   private List<QueueControl> getQueues(final DurabilityType durability) {
+      try {
          List<QueueControl> matchingQueues = new ArrayList<QueueControl>();
          String[] queues = addressControl.getQueueNames();
-         for (String queue : queues)
-         {
-            QueueControl coreQueueControl = (QueueControl)managementService.getResource(ResourceNames.CORE_QUEUE + queue);
+         for (String queue : queues) {
+            QueueControl coreQueueControl = (QueueControl) managementService.getResource(ResourceNames.CORE_QUEUE + queue);
 
             // Ignore the "special" subscription
-            if (coreQueueControl != null && !coreQueueControl.getName().equals(addressControl.getAddress()))
-            {
-               if (durability == DurabilityType.ALL || durability == DurabilityType.DURABLE &&
-                   coreQueueControl.isDurable() ||
-                   durability == DurabilityType.NON_DURABLE &&
-                   !coreQueueControl.isDurable())
-               {
+            if (coreQueueControl != null && !coreQueueControl.getName().equals(addressControl.getAddress())) {
+               if (durability == DurabilityType.ALL || durability == DurabilityType.DURABLE && coreQueueControl.isDurable() ||
+                  durability == DurabilityType.NON_DURABLE && !coreQueueControl.isDurable()) {
                   matchingQueues.add(coreQueueControl);
                }
             }
          }
          return matchingQueues;
       }
-      catch (Exception e)
-      {
+      catch (Exception e) {
          return Collections.emptyList();
       }
    }
 
    @Override
-   public MBeanInfo getMBeanInfo()
-   {
+   public MBeanInfo getMBeanInfo() {
       MBeanInfo info = super.getMBeanInfo();
-      return new MBeanInfo(info.getClassName(),
-                           info.getDescription(),
-                           info.getAttributes(),
-                           info.getConstructors(),
-                           MBeanInfoHelper.getMBeanOperationsInfo(TopicControl.class),
-                           info.getNotifications());
+      return new MBeanInfo(info.getClassName(), info.getDescription(), info.getAttributes(), info.getConstructors(), MBeanInfoHelper.getMBeanOperationsInfo(TopicControl.class), info.getNotifications());
    }
 
    // Inner classes -------------------------------------------------
 
-   private enum DurabilityType
-   {
+   private enum DurabilityType {
       ALL, DURABLE, NON_DURABLE
    }
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/JMSStorageManager.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/JMSStorageManager.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/JMSStorageManager.java
index 278fb38..5a084e4 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/JMSStorageManager.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/JMSStorageManager.java
@@ -24,8 +24,7 @@ import org.apache.activemq.artemis.jms.persistence.config.PersistedDestination;
 import org.apache.activemq.artemis.jms.persistence.config.PersistedBindings;
 import org.apache.activemq.artemis.jms.persistence.config.PersistedType;
 
-public interface JMSStorageManager extends ActiveMQComponent
-{
+public interface JMSStorageManager extends ActiveMQComponent {
 
    void load() throws Exception;
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedBindings.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedBindings.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedBindings.java
index 6528c10..bdf999b 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedBindings.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedBindings.java
@@ -24,8 +24,7 @@ import org.apache.activemq.artemis.core.journal.EncodingSupport;
 import org.apache.activemq.artemis.utils.BufferHelper;
 import org.apache.activemq.artemis.utils.DataConstants;
 
-public class PersistedBindings implements EncodingSupport
-{
+public class PersistedBindings implements EncodingSupport {
 
    // Constants -----------------------------------------------------
 
@@ -43,16 +42,14 @@ public class PersistedBindings implements EncodingSupport
 
    // Constructors --------------------------------------------------
 
-   public PersistedBindings()
-   {
+   public PersistedBindings() {
    }
 
    /**
     * @param type
     * @param name
     */
-   public PersistedBindings(PersistedType type, String name)
-   {
+   public PersistedBindings(PersistedType type, String name) {
       super();
       this.type = type;
       this.name = name;
@@ -60,45 +57,38 @@ public class PersistedBindings implements EncodingSupport
 
    // Public --------------------------------------------------------
    @Override
-   public void decode(ActiveMQBuffer buffer)
-   {
+   public void decode(ActiveMQBuffer buffer) {
       type = PersistedType.getType(buffer.readByte());
       name = buffer.readSimpleString().toString();
       int bindingArraySize = buffer.readInt();
       bindings = new ArrayList<String>(bindingArraySize);
 
-      for (int i = 0; i < bindingArraySize; i++)
-      {
+      for (int i = 0; i < bindingArraySize; i++) {
          bindings.add(buffer.readSimpleString().toString());
       }
    }
 
    @Override
-   public void encode(ActiveMQBuffer buffer)
-   {
+   public void encode(ActiveMQBuffer buffer) {
       buffer.writeByte(type.getType());
       BufferHelper.writeAsSimpleString(buffer, name);
       buffer.writeInt(bindings.size());
-      for (String bindingsEl : bindings)
-      {
+      for (String bindingsEl : bindings) {
          BufferHelper.writeAsSimpleString(buffer, bindingsEl);
       }
    }
 
    @Override
-   public int getEncodeSize()
-   {
+   public int getEncodeSize() {
       return DataConstants.SIZE_BYTE +
          BufferHelper.sizeOfSimpleString(name) +
          sizeOfBindings();
    }
 
-   private int sizeOfBindings()
-   {
+   private int sizeOfBindings() {
       int size = DataConstants.SIZE_INT; // for the number of elements written
 
-      for (String str : bindings)
-      {
+      for (String str : bindings) {
          size += BufferHelper.sizeOfSimpleString(str);
       }
 
@@ -108,50 +98,43 @@ public class PersistedBindings implements EncodingSupport
    /**
     * @return the id
     */
-   public long getId()
-   {
+   public long getId() {
       return id;
    }
 
    /**
     * @param id the id to set
     */
-   public void setId(long id)
-   {
+   public void setId(long id) {
       this.id = id;
    }
 
    /**
     * @return the type
     */
-   public PersistedType getType()
-   {
+   public PersistedType getType() {
       return type;
    }
 
    /**
     * @return the name
     */
-   public String getName()
-   {
+   public String getName() {
       return name;
    }
 
    /**
     * @return the bindings
     */
-   public List<String> getBindings()
-   {
+   public List<String> getBindings() {
       return bindings;
    }
 
-   public void addBinding(String address)
-   {
+   public void addBinding(String address) {
       bindings.add(address);
    }
 
-   public void deleteBinding(String address)
-   {
+   public void deleteBinding(String address) {
       bindings.remove(address);
    }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedConnectionFactory.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedConnectionFactory.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedConnectionFactory.java
index 406cb57..3e7e100 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedConnectionFactory.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedConnectionFactory.java
@@ -21,8 +21,7 @@ import org.apache.activemq.artemis.core.journal.EncodingSupport;
 import org.apache.activemq.artemis.jms.server.config.ConnectionFactoryConfiguration;
 import org.apache.activemq.artemis.jms.server.config.impl.ConnectionFactoryConfigurationImpl;
 
-public class PersistedConnectionFactory implements EncodingSupport
-{
+public class PersistedConnectionFactory implements EncodingSupport {
 
    // Constants -----------------------------------------------------
 
@@ -32,16 +31,14 @@ public class PersistedConnectionFactory implements EncodingSupport
 
    private ConnectionFactoryConfiguration config;
 
-   public PersistedConnectionFactory()
-   {
+   public PersistedConnectionFactory() {
       super();
    }
 
    /**
     * @param config
     */
-   public PersistedConnectionFactory(final ConnectionFactoryConfiguration config)
-   {
+   public PersistedConnectionFactory(final ConnectionFactoryConfiguration config) {
       super();
       this.config = config;
    }
@@ -55,45 +52,38 @@ public class PersistedConnectionFactory implements EncodingSupport
    /**
     * @return the id
     */
-   public long getId()
-   {
+   public long getId() {
       return id;
    }
 
-   public void setId(final long id)
-   {
+   public void setId(final long id) {
       this.id = id;
    }
 
-   public String getName()
-   {
+   public String getName() {
       return config.getName();
    }
 
    /**
     * @return the config
     */
-   public ConnectionFactoryConfiguration getConfig()
-   {
+   public ConnectionFactoryConfiguration getConfig() {
       return config;
    }
 
    @Override
-   public void decode(final ActiveMQBuffer buffer)
-   {
+   public void decode(final ActiveMQBuffer buffer) {
       config = new ConnectionFactoryConfigurationImpl();
       config.decode(buffer);
    }
 
    @Override
-   public void encode(final ActiveMQBuffer buffer)
-   {
+   public void encode(final ActiveMQBuffer buffer) {
       config.encode(buffer);
    }
 
    @Override
-   public int getEncodeSize()
-   {
+   public int getEncodeSize() {
       return config.getEncodeSize();
    }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedDestination.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedDestination.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedDestination.java
index b66baba..a1097fe 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedDestination.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedDestination.java
@@ -22,9 +22,7 @@ import org.apache.activemq.artemis.core.journal.EncodingSupport;
 import org.apache.activemq.artemis.utils.BufferHelper;
 import org.apache.activemq.artemis.utils.DataConstants;
 
-public class PersistedDestination implements EncodingSupport
-{
-
+public class PersistedDestination implements EncodingSupport {
 
    // Constants -----------------------------------------------------
 
@@ -43,17 +41,17 @@ public class PersistedDestination implements EncodingSupport
 
    // Constructors --------------------------------------------------
 
-   public PersistedDestination()
-   {
+   public PersistedDestination() {
    }
 
-   public PersistedDestination(final PersistedType type, final String name)
-   {
+   public PersistedDestination(final PersistedType type, final String name) {
       this(type, name, null, true);
    }
 
-   public PersistedDestination(final PersistedType type, final String name, final String selector, final boolean durable)
-   {
+   public PersistedDestination(final PersistedType type,
+                               final String name,
+                               final String selector,
+                               final boolean durable) {
       this.type = type;
       this.name = name;
       this.selector = selector;
@@ -69,55 +67,45 @@ public class PersistedDestination implements EncodingSupport
 
    // Inner classes -------------------------------------------------
 
-
-   public long getId()
-   {
+   public long getId() {
       return id;
    }
 
-   public void setId(final long id)
-   {
+   public void setId(final long id) {
       this.id = id;
    }
 
-   public String getName()
-   {
+   public String getName() {
       return name;
    }
 
-   public PersistedType getType()
-   {
+   public PersistedType getType() {
       return type;
    }
 
-   public String getSelector()
-   {
+   public String getSelector() {
       return selector;
    }
 
-   public boolean isDurable()
-   {
+   public boolean isDurable() {
       return durable;
    }
 
-   public int getEncodeSize()
-   {
+   public int getEncodeSize() {
       return DataConstants.SIZE_BYTE +
-            BufferHelper.sizeOfSimpleString(name) +
-            BufferHelper.sizeOfNullableSimpleString(selector) +
-            DataConstants.SIZE_BOOLEAN;
+         BufferHelper.sizeOfSimpleString(name) +
+         BufferHelper.sizeOfNullableSimpleString(selector) +
+         DataConstants.SIZE_BOOLEAN;
    }
 
-   public void encode(final ActiveMQBuffer buffer)
-   {
+   public void encode(final ActiveMQBuffer buffer) {
       buffer.writeByte(type.getType());
       buffer.writeSimpleString(SimpleString.toSimpleString(name));
       buffer.writeNullableSimpleString(SimpleString.toSimpleString(selector));
       buffer.writeBoolean(durable);
    }
 
-   public void decode(final ActiveMQBuffer buffer)
-   {
+   public void decode(final ActiveMQBuffer buffer) {
       type = PersistedType.getType(buffer.readByte());
       name = buffer.readSimpleString().toString();
       SimpleString selectorStr = buffer.readNullableSimpleString();

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedType.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedType.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedType.java
index beeff60..b7e52b1 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedType.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/config/PersistedType.java
@@ -16,14 +16,11 @@
  */
 package org.apache.activemq.artemis.jms.persistence.config;
 
-public enum PersistedType
-{
+public enum PersistedType {
    ConnectionFactory, Topic, Queue;
 
-   public byte getType()
-   {
-      switch (this)
-      {
+   public byte getType() {
+      switch (this) {
          case ConnectionFactory:
             return 0;
          case Topic:
@@ -35,10 +32,8 @@ public enum PersistedType
       }
    }
 
-   public static PersistedType getType(byte type)
-   {
-      switch (type)
-      {
+   public static PersistedType getType(byte type) {
+      switch (type) {
          case 0:
             return ConnectionFactory;
          case 1:

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/impl/journal/JMSJournalStorageManagerImpl.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/impl/journal/JMSJournalStorageManagerImpl.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/impl/journal/JMSJournalStorageManagerImpl.java
index 2d884e7..7d7c37d 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/impl/journal/JMSJournalStorageManagerImpl.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/impl/journal/JMSJournalStorageManagerImpl.java
@@ -42,8 +42,7 @@ import org.apache.activemq.artemis.jms.persistence.config.PersistedBindings;
 import org.apache.activemq.artemis.jms.persistence.config.PersistedType;
 import org.apache.activemq.artemis.utils.IDGenerator;
 
-public final class JMSJournalStorageManagerImpl implements JMSStorageManager
-{
+public final class JMSJournalStorageManagerImpl implements JMSStorageManager {
 
    // Constants -----------------------------------------------------
 
@@ -76,10 +75,8 @@ public final class JMSJournalStorageManagerImpl implements JMSStorageManager
    // Constructors --------------------------------------------------
    public JMSJournalStorageManagerImpl(final IDGenerator idGenerator,
                                        final Configuration config,
-                                       final ReplicationManager replicator)
-   {
-      if (config.getJournalType() != JournalType.NIO && config.getJournalType() != JournalType.ASYNCIO)
-      {
+                                       final ReplicationManager replicator) {
+      if (config.getJournalType() != JournalType.NIO && config.getJournalType() != JournalType.ASYNCIO) {
          throw new IllegalArgumentException("Only NIO and AsyncIO are supported journals");
       }
 
@@ -89,39 +86,27 @@ public final class JMSJournalStorageManagerImpl implements JMSStorageManager
 
       SequentialFileFactory bindingsJMS = new NIOSequentialFileFactory(config.getBindingsLocation(), 1);
 
-      Journal localJMS = new JournalImpl(1024 * 1024,
-                                         2,
-                                         config.getJournalCompactMinFiles(),
-                                         config.getJournalCompactPercentage(),
-                                         bindingsJMS,
-                                         "activemq-jms",
-                                         "jms",
-                                         1);
-
-      if (replicator != null)
-      {
+      Journal localJMS = new JournalImpl(1024 * 1024, 2, config.getJournalCompactMinFiles(), config.getJournalCompactPercentage(), bindingsJMS, "activemq-jms", "jms", 1);
+
+      if (replicator != null) {
          jmsJournal = new ReplicatedJournal((byte) 2, localJMS, replicator);
       }
-      else
-      {
+      else {
          jmsJournal = localJMS;
       }
 
       this.idGenerator = idGenerator;
    }
 
-
    // Public --------------------------------------------------------
    @Override
-   public List<PersistedConnectionFactory> recoverConnectionFactories()
-   {
+   public List<PersistedConnectionFactory> recoverConnectionFactories() {
       List<PersistedConnectionFactory> cfs = new ArrayList<PersistedConnectionFactory>(mapFactories.values());
       return cfs;
    }
 
    @Override
-   public void storeConnectionFactory(final PersistedConnectionFactory connectionFactory) throws Exception
-   {
+   public void storeConnectionFactory(final PersistedConnectionFactory connectionFactory) throws Exception {
       deleteConnectionFactory(connectionFactory.getName());
       long id = idGenerator.generateID();
       connectionFactory.setId(id);
@@ -129,25 +114,21 @@ public final class JMSJournalStorageManagerImpl implements JMSStorageManager
       mapFactories.put(connectionFactory.getName(), connectionFactory);
    }
 
-   public void deleteConnectionFactory(final String cfName) throws Exception
-   {
+   public void deleteConnectionFactory(final String cfName) throws Exception {
       PersistedConnectionFactory oldCF = mapFactories.remove(cfName);
-      if (oldCF != null)
-      {
+      if (oldCF != null) {
          jmsJournal.appendDeleteRecord(oldCF.getId(), false);
       }
    }
 
    @Override
-   public List<PersistedDestination> recoverDestinations()
-   {
+   public List<PersistedDestination> recoverDestinations() {
       List<PersistedDestination> destinations = new ArrayList<PersistedDestination>(this.destinations.values());
       return destinations;
    }
 
    @Override
-   public void storeDestination(final PersistedDestination destination) throws Exception
-   {
+   public void storeDestination(final PersistedDestination destination) throws Exception {
       deleteDestination(destination.getType(), destination.getName());
       long id = idGenerator.generateID();
       destination.setId(id);
@@ -155,36 +136,30 @@ public final class JMSJournalStorageManagerImpl implements JMSStorageManager
       destinations.put(new Pair<PersistedType, String>(destination.getType(), destination.getName()), destination);
    }
 
-   public List<PersistedBindings> recoverPersistedBindings() throws Exception
-   {
+   public List<PersistedBindings> recoverPersistedBindings() throws Exception {
       ArrayList<PersistedBindings> list = new ArrayList<PersistedBindings>(mapBindings.values());
       return list;
    }
 
-   public void addBindings(PersistedType type, String name, String... address) throws Exception
-   {
+   public void addBindings(PersistedType type, String name, String... address) throws Exception {
       Pair<PersistedType, String> key = new Pair<PersistedType, String>(type, name);
 
       long tx = idGenerator.generateID();
 
       PersistedBindings currentBindings = mapBindings.get(key);
-      if (currentBindings != null)
-      {
+      if (currentBindings != null) {
          jmsJournal.appendDeleteRecordTransactional(tx, currentBindings.getId());
       }
-      else
-      {
+      else {
          currentBindings = new PersistedBindings(type, name);
       }
 
       mapBindings.put(key, currentBindings);
 
-      for (String adItem : address)
-      {
+      for (String adItem : address) {
          currentBindings.addBinding(adItem);
       }
 
-
       long newId = idGenerator.generateID();
 
       currentBindings.setId(newId);
@@ -194,30 +169,25 @@ public final class JMSJournalStorageManagerImpl implements JMSStorageManager
       jmsJournal.appendCommitRecord(tx, true);
    }
 
-   public void deleteBindings(PersistedType type, String name, String address) throws Exception
-   {
+   public void deleteBindings(PersistedType type, String name, String address) throws Exception {
       Pair<PersistedType, String> key = new Pair<PersistedType, String>(type, name);
 
       long tx = idGenerator.generateID();
 
       PersistedBindings currentBindings = mapBindings.get(key);
-      if (currentBindings == null)
-      {
+      if (currentBindings == null) {
          return;
       }
-      else
-      {
+      else {
          jmsJournal.appendDeleteRecordTransactional(tx, currentBindings.getId());
       }
 
       currentBindings.deleteBinding(address);
 
-      if (currentBindings.getBindings().size() == 0)
-      {
+      if (currentBindings.getBindings().size() == 0) {
          mapBindings.remove(key);
       }
-      else
-      {
+      else {
          long newId = idGenerator.generateID();
          currentBindings.setId(newId);
          jmsJournal.appendAddRecordTransactional(tx, newId, BINDING_RECORD, currentBindings);
@@ -226,38 +196,30 @@ public final class JMSJournalStorageManagerImpl implements JMSStorageManager
       jmsJournal.appendCommitRecord(tx, true);
    }
 
-
-   public void deleteBindings(PersistedType type, String name) throws Exception
-   {
+   public void deleteBindings(PersistedType type, String name) throws Exception {
       Pair<PersistedType, String> key = new Pair<PersistedType, String>(type, name);
 
       PersistedBindings currentBindings = mapBindings.remove(key);
 
-      if (currentBindings != null)
-      {
+      if (currentBindings != null) {
          jmsJournal.appendDeleteRecord(currentBindings.getId(), true);
       }
    }
 
-   public void deleteDestination(final PersistedType type, final String name) throws Exception
-   {
+   public void deleteDestination(final PersistedType type, final String name) throws Exception {
       PersistedDestination destination = destinations.remove(new Pair<PersistedType, String>(type, name));
-      if (destination != null)
-      {
+      if (destination != null) {
          jmsJournal.appendDeleteRecord(destination.getId(), false);
       }
    }
 
    @Override
-   public boolean isStarted()
-   {
+   public boolean isStarted() {
       return started;
    }
 
-
    @Override
-   public void start() throws Exception
-   {
+   public void start() throws Exception {
       checkAndCreateDir(config.getBindingsLocation(), createDir);
 
       jmsJournal.start();
@@ -266,14 +228,12 @@ public final class JMSJournalStorageManagerImpl implements JMSStorageManager
    }
 
    @Override
-   public void stop() throws Exception
-   {
+   public void stop() throws Exception {
       this.started = false;
       jmsJournal.stop();
    }
 
-   public void load() throws Exception
-   {
+   public void load() throws Exception {
       mapFactories.clear();
 
       List<RecordInfo> data = new ArrayList<RecordInfo>();
@@ -282,38 +242,33 @@ public final class JMSJournalStorageManagerImpl implements JMSStorageManager
 
       jmsJournal.load(data, list, null);
 
-      for (RecordInfo record : data)
-      {
+      for (RecordInfo record : data) {
          long id = record.id;
 
          ActiveMQBuffer buffer = ActiveMQBuffers.wrappedBuffer(record.data);
 
          byte rec = record.getUserRecordType();
 
-         if (rec == CF_RECORD)
-         {
+         if (rec == CF_RECORD) {
             PersistedConnectionFactory cf = new PersistedConnectionFactory();
             cf.decode(buffer);
             cf.setId(id);
             mapFactories.put(cf.getName(), cf);
          }
-         else if (rec == DESTINATION_RECORD)
-         {
+         else if (rec == DESTINATION_RECORD) {
             PersistedDestination destination = new PersistedDestination();
             destination.decode(buffer);
             destination.setId(id);
             destinations.put(new Pair<PersistedType, String>(destination.getType(), destination.getName()), destination);
          }
-         else if (rec == BINDING_RECORD)
-         {
+         else if (rec == BINDING_RECORD) {
             PersistedBindings bindings = new PersistedBindings();
             bindings.decode(buffer);
             bindings.setId(id);
             Pair<PersistedType, String> key = new Pair<PersistedType, String>(bindings.getType(), bindings.getName());
             mapBindings.put(key, bindings);
          }
-         else
-         {
+         else {
             throw new IllegalStateException("Invalid record type " + rec);
          }
 
@@ -327,27 +282,20 @@ public final class JMSJournalStorageManagerImpl implements JMSStorageManager
 
    // Private -------------------------------------------------------
 
+   private void checkAndCreateDir(final File dir, final boolean create) {
 
-   private void checkAndCreateDir(final File dir, final boolean create)
-   {
-
-      if (!dir.exists())
-      {
-         if (create)
-         {
-            if (!dir.mkdirs())
-            {
+      if (!dir.exists()) {
+         if (create) {
+            if (!dir.mkdirs()) {
                throw new IllegalStateException("Failed to create directory " + dir);
             }
          }
-         else
-         {
+         else {
             throw new IllegalArgumentException("Directory " + dir + " does not exist and will not create it");
          }
       }
    }
 
-
    // Inner classes -------------------------------------------------
 
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/impl/nullpm/NullJMSStorageManagerImpl.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/impl/nullpm/NullJMSStorageManagerImpl.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/impl/nullpm/NullJMSStorageManagerImpl.java
index 0816379..d1b69c1 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/impl/nullpm/NullJMSStorageManagerImpl.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/persistence/impl/nullpm/NullJMSStorageManagerImpl.java
@@ -25,81 +25,66 @@ import org.apache.activemq.artemis.jms.persistence.config.PersistedDestination;
 import org.apache.activemq.artemis.jms.persistence.config.PersistedBindings;
 import org.apache.activemq.artemis.jms.persistence.config.PersistedType;
 
-public class NullJMSStorageManagerImpl implements JMSStorageManager
-{
+public class NullJMSStorageManagerImpl implements JMSStorageManager {
 
    @Override
-   public void deleteConnectionFactory(String connectionFactory) throws Exception
-   {
+   public void deleteConnectionFactory(String connectionFactory) throws Exception {
 
    }
 
    @Override
-   public List<PersistedConnectionFactory> recoverConnectionFactories()
-   {
+   public List<PersistedConnectionFactory> recoverConnectionFactories() {
       return Collections.emptyList();
    }
 
    @Override
-   public List<PersistedDestination> recoverDestinations()
-   {
+   public List<PersistedDestination> recoverDestinations() {
       return Collections.emptyList();
    }
 
    @Override
-   public void storeConnectionFactory(PersistedConnectionFactory connectionFactory) throws Exception
-   {
+   public void storeConnectionFactory(PersistedConnectionFactory connectionFactory) throws Exception {
    }
 
    @Override
-   public void storeDestination(PersistedDestination destination)
-   {
+   public void storeDestination(PersistedDestination destination) {
    }
 
    @Override
-   public boolean isStarted()
-   {
+   public boolean isStarted() {
       return true;
    }
 
    @Override
-   public void start() throws Exception
-   {
+   public void start() throws Exception {
    }
 
    @Override
-   public void stop() throws Exception
-   {
+   public void stop() throws Exception {
    }
 
    @Override
-   public void addBindings(PersistedType type, String name, String... address) throws Exception
-   {
+   public void addBindings(PersistedType type, String name, String... address) throws Exception {
    }
 
    @Override
-   public void deleteBindings(PersistedType type, String name, String address) throws Exception
-   {
+   public void deleteBindings(PersistedType type, String name, String address) throws Exception {
    }
 
    @Override
-   public void deleteDestination(PersistedType type, String name) throws Exception
-   {
+   public void deleteDestination(PersistedType type, String name) throws Exception {
    }
 
    @Override
-   public void deleteBindings(PersistedType type, String name) throws Exception
-   {
+   public void deleteBindings(PersistedType type, String name) throws Exception {
    }
 
    @Override
-   public List<PersistedBindings> recoverPersistedBindings() throws Exception
-   {
+   public List<PersistedBindings> recoverPersistedBindings() throws Exception {
       return Collections.emptyList();
    }
 
    @Override
-   public void load() throws Exception
-   {
+   public void load() throws Exception {
    }
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerBundle.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerBundle.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerBundle.java
index 11a2ed7..e591fa4 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerBundle.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerBundle.java
@@ -16,7 +16,6 @@
  */
 package org.apache.activemq.artemis.jms.server;
 
-
 import org.apache.activemq.artemis.api.core.ActiveMQAddressExistsException;
 import org.apache.activemq.artemis.api.core.ActiveMQIllegalStateException;
 import org.apache.activemq.artemis.api.core.ActiveMQInternalErrorException;
@@ -33,11 +32,11 @@ import org.jboss.logging.Messages;
  * so 129000 to 129999
  */
 @MessageBundle(projectCode = "AMQ")
-public interface ActiveMQJMSServerBundle
-{
+public interface ActiveMQJMSServerBundle {
+
    ActiveMQJMSServerBundle BUNDLE = Messages.getBundle(ActiveMQJMSServerBundle.class);
 
-   @Message(id = 129000, value =  "Connection Factory {0} does not exist" , format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 129000, value = "Connection Factory {0} does not exist", format = Message.Format.MESSAGE_FORMAT)
    ActiveMQInternalErrorException cfDoesntExist(String name);
 
    @Message(id = 129003, value = "Discovery Group ''{0}'' does not exist on main config", format = Message.Format.MESSAGE_FORMAT)
@@ -46,10 +45,10 @@ public interface ActiveMQJMSServerBundle
    @Message(id = 129004, value = "No Connector name configured on create ConnectionFactory")
    ActiveMQIllegalStateException noConnectorNameOnCF();
 
-   @Message(id = 129005, value = "Connector ''{0}'' not found on the main configuration file" , format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 129005, value = "Connector ''{0}'' not found on the main configuration file", format = Message.Format.MESSAGE_FORMAT)
    ActiveMQIllegalStateException noConnectorNameConfiguredOnCF(String name);
 
-   @Message(id = 129006, value =  "Binding {0} is already being used by another connection factory", format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 129006, value = "Binding {0} is already being used by another connection factory", format = Message.Format.MESSAGE_FORMAT)
    ActiveMQAddressExistsException cfBindingsExists(String name);
 
    @Message(id = 129007, value = "Error decoding password using codec instance")

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerLogger.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerLogger.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerLogger.java
index 3e81866..d17add9 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerLogger.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerLogger.java
@@ -40,8 +40,8 @@ import org.w3c.dom.Node;
  * so an INFO message would be 121000 to 121999
  */
 @MessageLogger(projectCode = "AMQ")
-public interface ActiveMQJMSServerLogger extends BasicLogger
-{
+public interface ActiveMQJMSServerLogger extends BasicLogger {
+
    /**
     * The default logger.
     */
@@ -49,65 +49,64 @@ public interface ActiveMQJMSServerLogger extends BasicLogger
 
    @LogMessage(level = Logger.Level.INFO)
    @Message(id = 121004, value = "JMS Server Manager Caching command for {0} since the JMS Server is not active yet",
-            format = Message.Format.MESSAGE_FORMAT)
+      format = Message.Format.MESSAGE_FORMAT)
    void serverCachingCommand(Object runnable);
 
    @LogMessage(level = Logger.Level.INFO)
    @Message(id = 121005, value = "Invalid \"host\" value \"0.0.0.0\" detected for \"{0}\" connector. Switching to \"{1}\". If this new address is incorrect please manually configure the connector to use the proper one.",
-            format = Message.Format.MESSAGE_FORMAT)
+      format = Message.Format.MESSAGE_FORMAT)
    void invalidHostForConnector(String name, String newHost);
 
    @LogMessage(level = Logger.Level.WARN)
-   @Message(id = 122007, value = "Queue {0} does not exist on the topic {1}. It was deleted manually probably." , format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 122007, value = "Queue {0} does not exist on the topic {1}. It was deleted manually probably.", format = Message.Format.MESSAGE_FORMAT)
    void noQueueOnTopic(String queueName, String name);
 
    @LogMessage(level = Logger.Level.WARN)
-   @Message(id = 122008, value = "XA Recovery can not connect to any broker on recovery {0}"  , format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 122008, value = "XA Recovery can not connect to any broker on recovery {0}", format = Message.Format.MESSAGE_FORMAT)
    void recoveryConnectFailed(String s);
 
    @LogMessage(level = Logger.Level.WARN)
-   @Message(id = 122011, value = "error unbinding {0} from Registry" , format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 122011, value = "error unbinding {0} from Registry", format = Message.Format.MESSAGE_FORMAT)
    void bindingsUnbindError(@Cause Exception e, String key);
 
    @LogMessage(level = Logger.Level.WARN)
-   @Message(id = 122012, value = "JMS Server Manager error" , format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 122012, value = "JMS Server Manager error", format = Message.Format.MESSAGE_FORMAT)
    void jmsServerError(@Cause Exception e);
 
    @LogMessage(level = Logger.Level.WARN)
-   @Message(id = 122013, value = "Error in XA Recovery recover" , format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 122013, value = "Error in XA Recovery recover", format = Message.Format.MESSAGE_FORMAT)
    void xaRecoverError(@Cause Exception e);
 
    @LogMessage(level = Logger.Level.WARN)
    @Message(id = 122014, value = "Notified of connection failure in xa recovery connectionFactory for provider {0} will attempt reconnect on next pass",
-            format = Message.Format.MESSAGE_FORMAT)
+      format = Message.Format.MESSAGE_FORMAT)
    void xaRecoverConnectionError(@Cause Exception e, ClientSessionFactory csf);
 
    @LogMessage(level = Logger.Level.DEBUG)
-   @Message(id = 122016, value = "Error in XA Recovery" , format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 122016, value = "Error in XA Recovery", format = Message.Format.MESSAGE_FORMAT)
    void xaRecoveryError(@Cause Exception e);
 
    @LogMessage(level = Logger.Level.WARN)
    @Message(id = 122017, value = "Tried to correct invalid \"host\" value \"0.0.0.0\" for \"{0}\" connector, but received an exception.",
-            format = Message.Format.MESSAGE_FORMAT)
+      format = Message.Format.MESSAGE_FORMAT)
    void failedToCorrectHost(@Cause Exception e, String name);
 
    @LogMessage(level = Logger.Level.WARN)
    @Message(id = 122018,
-           value = "Failed to send notification: {0}",
-           format = Message.Format.MESSAGE_FORMAT)
+      value = "Failed to send notification: {0}",
+      format = Message.Format.MESSAGE_FORMAT)
    void failedToSendNotification(String notification);
 
    @LogMessage(level = Logger.Level.DEBUG)
-   @Message(id = 123000, value = "JMS Server Manager Running cached command for {0}." +
-           "(In the event of failover after failback has occurred, this message may be output multiple times.)",
-           format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 123000, value = "JMS Server Manager Running cached command for {0}." + "(In the event of failover after failback has occurred, this message may be output multiple times.)",
+      format = Message.Format.MESSAGE_FORMAT)
    void serverRunningCachedCommand(Runnable run);
 
    @LogMessage(level = Logger.Level.ERROR)
-   @Message(id = 124000, value = "key attribute missing for JMS configuration {0}" , format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 124000, value = "key attribute missing for JMS configuration {0}", format = Message.Format.MESSAGE_FORMAT)
    void jmsConfigMissingKey(Node e);
 
    @LogMessage(level = Logger.Level.ERROR)
-   @Message(id = 124002, value = "Failed to start JMS deployer" , format = Message.Format.MESSAGE_FORMAT)
+   @Message(id = 124002, value = "Failed to start JMS deployer", format = Message.Format.MESSAGE_FORMAT)
    void jmsDeployerStartError(@Cause Exception e);
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/JMSServerConfigParser.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/JMSServerConfigParser.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/JMSServerConfigParser.java
index d740e1a..3ca65fe 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/JMSServerConfigParser.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/JMSServerConfigParser.java
@@ -23,8 +23,8 @@ import org.apache.activemq.artemis.jms.server.config.JMSQueueConfiguration;
 import org.apache.activemq.artemis.jms.server.config.TopicConfiguration;
 import org.w3c.dom.Node;
 
-public interface JMSServerConfigParser
-{
+public interface JMSServerConfigParser {
+
    /**
     * Parse the JMS Configuration XML as a JMSConfiguration object
     */
@@ -37,6 +37,7 @@ public interface JMSServerConfigParser
 
    /**
     * Parse the topic node as a TopicConfiguration object
+    *
     * @param node
     * @return {@link TopicConfiguration} parsed from the node
     * @throws Exception
@@ -45,6 +46,7 @@ public interface JMSServerConfigParser
 
    /**
     * Parse the Queue Configuration node as a QueueConfiguration object
+    *
     * @param node
     * @return {@link JMSQueueConfiguration} parsed from the node
     * @throws Exception

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/JMSServerManager.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/JMSServerManager.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/JMSServerManager.java
index 7182543..7f6bb88 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/JMSServerManager.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/JMSServerManager.java
@@ -31,8 +31,8 @@ import org.apache.activemq.artemis.spi.core.naming.BindingRegistry;
 /**
  * The JMS Management interface.
  */
-public interface JMSServerManager extends ActiveMQComponent
-{
+public interface JMSServerManager extends ActiveMQComponent {
+
    String getVersion();
 
    /**
@@ -45,16 +45,18 @@ public interface JMSServerManager extends ActiveMQComponent
    /**
     * Creates a JMS Queue.
     *
-    * @param queueName
-    *           The name of the queue to create
+    * @param queueName      The name of the queue to create
     * @param selectorString
     * @param durable
     * @return true if the queue is created or if it existed and was added to
-    *         the Binding Registry
-    * @throws Exception
-    *            if problems were encountered creating the queue.
+    * the Binding Registry
+    * @throws Exception if problems were encountered creating the queue.
     */
-   boolean createQueue(boolean storeConfig, String queueName, String selectorString, boolean durable, String ...bindings) throws Exception;
+   boolean createQueue(boolean storeConfig,
+                       String queueName,
+                       String selectorString,
+                       boolean durable,
+                       String... bindings) throws Exception;
 
    boolean addTopicToBindingRegistry(final String topicName, final String binding) throws Exception;
 
@@ -65,26 +67,21 @@ public interface JMSServerManager extends ActiveMQComponent
    /**
     * Creates a JMS Topic
     *
-    * @param topicName
-    *           the name of the topic
-    * @param bindings
-    *           the names of the binding for the Binding Registry or BindingRegistry
+    * @param topicName the name of the topic
+    * @param bindings  the names of the binding for the Binding Registry or BindingRegistry
     * @return true if the topic was created or if it existed and was added to
-    *         the Binding Registry
-    * @throws Exception
-    *            if a problem occurred creating the topic
+    * the Binding Registry
+    * @throws Exception if a problem occurred creating the topic
     */
-   boolean createTopic(boolean storeConfig, String topicName, String ... bindings) throws Exception;
+   boolean createTopic(boolean storeConfig, String topicName, String... bindings) throws Exception;
 
    /**
     * Remove the topic from the Binding Registry or BindingRegistry.
     * Calling this method does <em>not</em> destroy the destination.
     *
-    * @param name
-    *           the name of the destination to remove from the BindingRegistry
+    * @param name the name of the destination to remove from the BindingRegistry
     * @return true if removed
-    * @throws Exception
-    *            if a problem occurred removing the destination
+    * @throws Exception if a problem occurred removing the destination
     */
    boolean removeTopicFromBindingRegistry(String name, String binding) throws Exception;
 
@@ -92,11 +89,9 @@ public interface JMSServerManager extends ActiveMQComponent
     * Remove the topic from the BindingRegistry.
     * Calling this method does <em>not</em> destroy the destination.
     *
-    * @param name
-    *           the name of the destination to remove from the BindingRegistry
+    * @param name the name of the destination to remove from the BindingRegistry
     * @return true if removed
-    * @throws Exception
-    *            if a problem occurred removing the destination
+    * @throws Exception if a problem occurred removing the destination
     */
    boolean removeTopicFromBindingRegistry(String name) throws Exception;
 
@@ -104,11 +99,9 @@ public interface JMSServerManager extends ActiveMQComponent
     * Remove the queue from the BindingRegistry.
     * Calling this method does <em>not</em> destroy the destination.
     *
-    * @param name
-    *           the name of the destination to remove from the BindingRegistry
+    * @param name the name of the destination to remove from the BindingRegistry
     * @return true if removed
-    * @throws Exception
-    *            if a problem occurred removing the destination
+    * @throws Exception if a problem occurred removing the destination
     */
    boolean removeQueueFromBindingRegistry(String name, String binding) throws Exception;
 
@@ -116,11 +109,9 @@ public interface JMSServerManager extends ActiveMQComponent
     * Remove the queue from the BindingRegistry.
     * Calling this method does <em>not</em> destroy the destination.
     *
-    * @param name
-    *           the name of the destination to remove from the BindingRegistry
+    * @param name the name of the destination to remove from the BindingRegistry
     * @return true if removed
-    * @throws Exception
-    *            if a problem occurred removing the destination
+    * @throws Exception if a problem occurred removing the destination
     */
    boolean removeQueueFromBindingRegistry(String name) throws Exception;
 
@@ -131,11 +122,9 @@ public interface JMSServerManager extends ActiveMQComponent
    /**
     * destroys a queue and removes it from the BindingRegistry
     *
-    * @param name
-    *           the name of the queue to destroy
+    * @param name the name of the queue to destroy
     * @return true if destroyed
-    * @throws Exception
-    *            if a problem occurred destroying the queue
+    * @throws Exception if a problem occurred destroying the queue
     */
    boolean destroyQueue(String name) throws Exception;
 
@@ -143,11 +132,9 @@ public interface JMSServerManager extends ActiveMQComponent
     * destroys a queue and removes it from the BindingRegistry.
     * disconnects any consumers connected to the queue.
     *
-    * @param name
-    *           the name of the queue to destroy
+    * @param name the name of the queue to destroy
     * @return true if destroyed
-    * @throws Exception
-    *            if a problem occurred destroying the queue
+    * @throws Exception if a problem occurred destroying the queue
     */
    boolean destroyQueue(String name, boolean removeConsumers) throws Exception;
 
@@ -160,36 +147,39 @@ public interface JMSServerManager extends ActiveMQComponent
    /**
     * destroys a topic and removes it from the BindingRegistry
     *
-    * @param name
-    *           the name of the topic to destroy
+    * @param name the name of the topic to destroy
     * @return true if the topic was destroyed
-    * @throws Exception
-    *            if a problem occurred destroying the topic
+    * @throws Exception if a problem occurred destroying the topic
     */
    boolean destroyTopic(String name, boolean removeConsumers) throws Exception;
 
    /**
     * destroys a topic and removes it from theBindingRegistry
     *
-    * @param name
-    *           the name of the topic to destroy
+    * @param name the name of the topic to destroy
     * @return true if the topic was destroyed
-    * @throws Exception
-    *            if a problem occurred destroying the topic
+    * @throws Exception if a problem occurred destroying the topic
     */
    boolean destroyTopic(String name) throws Exception;
 
-   /** Call this method to have a CF rebound to the Binding Registry and stored on the Journal
-    * @throws Exception */
-   ActiveMQConnectionFactory recreateCF(String name,  ConnectionFactoryConfiguration cf) throws Exception;
+   /**
+    * Call this method to have a CF rebound to the Binding Registry and stored on the Journal
+    *
+    * @throws Exception
+    */
+   ActiveMQConnectionFactory recreateCF(String name, ConnectionFactoryConfiguration cf) throws Exception;
 
-   void createConnectionFactory(String name, boolean ha, JMSFactoryType cfType, String discoveryGroupName, String ... bindings) throws Exception;
+   void createConnectionFactory(String name,
+                                boolean ha,
+                                JMSFactoryType cfType,
+                                String discoveryGroupName,
+                                String... bindings) throws Exception;
 
    void createConnectionFactory(String name,
                                 boolean ha,
                                 JMSFactoryType cfType,
                                 List<String> connectorNames,
-                                String ... bindings) throws Exception;
+                                String... bindings) throws Exception;
 
    void createConnectionFactory(String name,
                                 boolean ha,
@@ -225,7 +215,7 @@ public interface JMSServerManager extends ActiveMQComponent
                                 int reconnectAttempts,
                                 boolean failoverOnInitialConnection,
                                 String groupId,
-                                String ... bindings) throws Exception;
+                                String... bindings) throws Exception;
 
    void createConnectionFactory(String name,
                                 boolean ha,
@@ -261,18 +251,18 @@ public interface JMSServerManager extends ActiveMQComponent
                                 int reconnectAttempts,
                                 boolean failoverOnInitialConnection,
                                 String groupId,
-                                String ... bindings) throws Exception;
+                                String... bindings) throws Exception;
 
-   void createConnectionFactory(boolean storeConfig, ConnectionFactoryConfiguration cfConfig, String... bindings) throws Exception;
+   void createConnectionFactory(boolean storeConfig,
+                                ConnectionFactoryConfiguration cfConfig,
+                                String... bindings) throws Exception;
 
    /**
     * destroys a connection factory.
     *
-    * @param name
-    *           the name of the connection factory to destroy
+    * @param name the name of the connection factory to destroy
     * @return true if the connection factory was destroyed
-    * @throws Exception
-    *            if a problem occurred destroying the connection factory
+    * @throws Exception if a problem occurred destroying the connection factory
     */
    boolean destroyConnectionFactory(String name) throws Exception;
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/ConnectionFactoryConfiguration.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/ConnectionFactoryConfiguration.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/ConnectionFactoryConfiguration.java
index ea7ab93..57a955f 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/ConnectionFactoryConfiguration.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/ConnectionFactoryConfiguration.java
@@ -24,8 +24,8 @@ import org.apache.activemq.artemis.core.journal.EncodingSupport;
 /**
  * A ConnectionFactoryConfiguration for {@link javax.jms.ConnectionFactory} objects.
  */
-public interface ConnectionFactoryConfiguration extends EncodingSupport
-{
+public interface ConnectionFactoryConfiguration extends EncodingSupport {
+
    boolean isPersisted();
 
    String getName();

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/JMSConfiguration.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/JMSConfiguration.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/JMSConfiguration.java
index 2ddffc5..3fd0298 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/JMSConfiguration.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/JMSConfiguration.java
@@ -18,8 +18,8 @@ package org.apache.activemq.artemis.jms.server.config;
 
 import java.util.List;
 
-public interface JMSConfiguration
-{
+public interface JMSConfiguration {
+
    List<JMSQueueConfiguration> getQueueConfigurations();
 
    JMSConfiguration setQueueConfigurations(List<JMSQueueConfiguration> queueConfigurations);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/JMSQueueConfiguration.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/JMSQueueConfiguration.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/JMSQueueConfiguration.java
index a8bbb1a..0f5d427 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/JMSQueueConfiguration.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/JMSQueueConfiguration.java
@@ -16,8 +16,8 @@
  */
 package org.apache.activemq.artemis.jms.server.config;
 
-public interface JMSQueueConfiguration
-{
+public interface JMSQueueConfiguration {
+
    String getName();
 
    JMSQueueConfiguration setName(String name);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/TopicConfiguration.java
----------------------------------------------------------------------
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/TopicConfiguration.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/TopicConfiguration.java
index c9bdc70..cbd7974 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/TopicConfiguration.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/config/TopicConfiguration.java
@@ -16,8 +16,8 @@
  */
 package org.apache.activemq.artemis.jms.server.config;
 
-public interface TopicConfiguration
-{
+public interface TopicConfiguration {
+
    String getName();
 
    TopicConfiguration setName(String name);