You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ma...@apache.org on 2016/09/30 15:26:19 UTC

[19/52] [partial] activemq-artemis git commit: ARTEMIS-765 Improve Checkstyle

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/CertificateLoginModuleTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/CertificateLoginModuleTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/CertificateLoginModuleTest.java
index 102a364..14c0d6f 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/CertificateLoginModuleTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/CertificateLoginModuleTest.java
@@ -76,18 +76,15 @@ public class CertificateLoginModuleTest extends Assert {
             if (currentPrincipal.getName().equals(USER_NAME)) {
                if (!nameFound) {
                   nameFound = true;
-               }
-               else {
+               } else {
                   fail("UserPrincipal found twice.");
                }
 
-            }
-            else {
+            } else {
                fail("Unknown UserPrincipal found.");
             }
 
-         }
-         else if (currentPrincipal instanceof RolePrincipal) {
+         } else if (currentPrincipal instanceof RolePrincipal) {
             int principalIdx = ROLE_NAMES.indexOf(((RolePrincipal) currentPrincipal).getName());
 
             if (principalIdx < 0) {
@@ -96,12 +93,10 @@ public class CertificateLoginModuleTest extends Assert {
 
             if (!rolesFound[principalIdx]) {
                rolesFound[principalIdx] = true;
-            }
-            else {
+            } else {
                fail("RolePrincipal found twice.");
             }
-         }
-         else {
+         } else {
             fail("Unknown Principal type found.");
          }
       }
@@ -111,8 +106,7 @@ public class CertificateLoginModuleTest extends Assert {
    public void testLoginSuccess() throws IOException {
       try {
          loginWithCredentials(USER_NAME, new HashSet<>(ROLE_NAMES));
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          fail("Unable to login: " + e.getMessage());
       }
 
@@ -125,8 +119,7 @@ public class CertificateLoginModuleTest extends Assert {
 
       try {
          loginWithCredentials(null, new HashSet<String>());
-      }
-      catch (LoginException e) {
+      } catch (LoginException e) {
          loginFailed = true;
       }
 
@@ -139,8 +132,7 @@ public class CertificateLoginModuleTest extends Assert {
    public void testLogOut() throws IOException {
       try {
          loginWithCredentials(USER_NAME, new HashSet<>(ROLE_NAMES));
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          fail("Unable to login: " + e.getMessage());
       }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/LDAPLoginModuleTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/LDAPLoginModuleTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/LDAPLoginModuleTest.java
index 17eae10..e3ace3a 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/LDAPLoginModuleTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/LDAPLoginModuleTest.java
@@ -106,11 +106,9 @@ public class LDAPLoginModuleTest extends AbstractLdapTestUnit {
             for (int i = 0; i < callbacks.length; i++) {
                if (callbacks[i] instanceof NameCallback) {
                   ((NameCallback) callbacks[i]).setName("first");
-               }
-               else if (callbacks[i] instanceof PasswordCallback) {
+               } else if (callbacks[i] instanceof PasswordCallback) {
                   ((PasswordCallback) callbacks[i]).setPassword("secret".toCharArray());
-               }
-               else {
+               } else {
                   throw new UnsupportedCallbackException(callbacks[i]);
                }
             }
@@ -128,11 +126,9 @@ public class LDAPLoginModuleTest extends AbstractLdapTestUnit {
             for (int i = 0; i < callbacks.length; i++) {
                if (callbacks[i] instanceof NameCallback) {
                   ((NameCallback) callbacks[i]).setName("first");
-               }
-               else if (callbacks[i] instanceof PasswordCallback) {
+               } else if (callbacks[i] instanceof PasswordCallback) {
                   ((PasswordCallback) callbacks[i]).setPassword("secret".toCharArray());
-               }
-               else {
+               } else {
                   throw new UnsupportedCallbackException(callbacks[i]);
                }
             }
@@ -140,8 +136,7 @@ public class LDAPLoginModuleTest extends AbstractLdapTestUnit {
       });
       try {
          context.login();
-      }
-      catch (LoginException le) {
+      } catch (LoginException le) {
          assertEquals(le.getCause().getMessage(), "Empty password is not allowed");
          return;
       }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/LDAPModuleRoleExpansionTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/LDAPModuleRoleExpansionTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/LDAPModuleRoleExpansionTest.java
index afd723c..cc16ad6 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/LDAPModuleRoleExpansionTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/LDAPModuleRoleExpansionTest.java
@@ -106,11 +106,9 @@ public class LDAPModuleRoleExpansionTest extends AbstractLdapTestUnit {
             for (int i = 0; i < callbacks.length; i++) {
                if (callbacks[i] instanceof NameCallback) {
                   ((NameCallback) callbacks[i]).setName("first");
-               }
-               else if (callbacks[i] instanceof PasswordCallback) {
+               } else if (callbacks[i] instanceof PasswordCallback) {
                   ((PasswordCallback) callbacks[i]).setPassword("secret".toCharArray());
-               }
-               else {
+               } else {
                   throw new UnsupportedCallbackException(callbacks[i]);
                }
             }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/PropertiesLoginModuleRaceConditionTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/PropertiesLoginModuleRaceConditionTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/PropertiesLoginModuleRaceConditionTest.java
index 4fa9c71..03e60ff 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/PropertiesLoginModuleRaceConditionTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/PropertiesLoginModuleRaceConditionTest.java
@@ -97,11 +97,9 @@ public class PropertiesLoginModuleRaceConditionTest {
             module.initialize(subject, callback, new HashMap<String, Object>(), options);
             module.login();
             module.commit();
-         }
-         catch (Exception e) {
+         } catch (Exception e) {
             errors.offer(e);
-         }
-         finally {
+         } finally {
             finished.countDown();
          }
       }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/PropertiesLoginModuleTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/PropertiesLoginModuleTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/PropertiesLoginModuleTest.java
index 777ba50..9d35aea 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/PropertiesLoginModuleTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/PropertiesLoginModuleTest.java
@@ -117,8 +117,7 @@ public class PropertiesLoginModuleTest extends Assert {
       try {
          context.login();
          fail("Should have thrown a FailedLoginException");
-      }
-      catch (FailedLoginException doNothing) {
+      } catch (FailedLoginException doNothing) {
       }
 
    }
@@ -130,8 +129,7 @@ public class PropertiesLoginModuleTest extends Assert {
       try {
          context.login();
          fail("Should have thrown a FailedLoginException");
-      }
-      catch (FailedLoginException doNothing) {
+      } catch (FailedLoginException doNothing) {
       }
 
    }
@@ -151,11 +149,9 @@ public class PropertiesLoginModuleTest extends Assert {
          for (int i = 0; i < callbacks.length; i++) {
             if (callbacks[i] instanceof NameCallback) {
                ((NameCallback) callbacks[i]).setName(user);
-            }
-            else if (callbacks[i] instanceof PasswordCallback) {
+            } else if (callbacks[i] instanceof PasswordCallback) {
                ((PasswordCallback) callbacks[i]).setPassword(pass.toCharArray());
-            }
-            else {
+            } else {
                throw new UnsupportedCallbackException(callbacks[i]);
             }
          }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/RolePrincipalTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/RolePrincipalTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/RolePrincipalTest.java
index e23fe6a..9349e0d 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/RolePrincipalTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/RolePrincipalTest.java
@@ -31,8 +31,7 @@ public class RolePrincipalTest extends Assert {
       try {
          new RolePrincipal(null);
          fail("Should have thrown IllegalArgumentException");
-      }
-      catch (IllegalArgumentException ingore) {
+      } catch (IllegalArgumentException ingore) {
 
       }
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/TextFileCertificateLoginModuleTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/TextFileCertificateLoginModuleTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/TextFileCertificateLoginModuleTest.java
index 3dbe9ef..46a8756 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/TextFileCertificateLoginModuleTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/TextFileCertificateLoginModuleTest.java
@@ -113,11 +113,12 @@ public class TextFileCertificateLoginModuleTest {
       return new JaasCallbackHandler(null, null, new X509Certificate[]{cert});
    }
 
-   private Subject doAuthenticate(HashMap<String, ?> options, JaasCallbackHandler callbackHandler) throws LoginException {
+   private Subject doAuthenticate(HashMap<String, ?> options,
+                                  JaasCallbackHandler callbackHandler) throws LoginException {
       Subject mySubject = new Subject();
       loginModule.initialize(mySubject, callbackHandler, null, options);
       loginModule.login();
       loginModule.commit();
       return mySubject;
    }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/UserPrincipalTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/UserPrincipalTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/UserPrincipalTest.java
index 9a08141..bd6ecaf 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/UserPrincipalTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/security/jaas/UserPrincipalTest.java
@@ -31,8 +31,7 @@ public class UserPrincipalTest extends Assert {
       try {
          new UserPrincipal(null);
          fail("Should have thrown IllegalArgumentException");
-      }
-      catch (IllegalArgumentException ingore) {
+      } catch (IllegalArgumentException ingore) {
 
       }
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/cluster/impl/BroadcastGroupImplTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/cluster/impl/BroadcastGroupImplTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/cluster/impl/BroadcastGroupImplTest.java
index 222a11b..a373f4a 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/cluster/impl/BroadcastGroupImplTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/cluster/impl/BroadcastGroupImplTest.java
@@ -25,10 +25,13 @@ import org.apache.activemq.artemis.core.server.impl.InVMNodeManager;
 import org.apache.activemq.artemis.tests.util.ActiveMQTestBase;
 import org.junit.Test;
 
-/** Test the {@link BroadcastGroupImpl}.<br> */
+/**
+ * Test the {@link BroadcastGroupImpl}.<br>
+ */
 public class BroadcastGroupImplTest extends ActiveMQTestBase {
 
    static class BroadcastEndpointFactoryImpl implements BroadcastEndpointFactory {
+
       private static final long serialVersionUID = 1L;
       int sent = 0;
 
@@ -40,6 +43,7 @@ public class BroadcastGroupImplTest extends ActiveMQTestBase {
    }
 
    static class BroadcastEndpointImpl implements BroadcastEndpoint {
+
       private BroadcastEndpointFactoryImpl factory;
 
       BroadcastEndpointImpl(BroadcastEndpointFactoryImpl factory) {
@@ -47,13 +51,16 @@ public class BroadcastGroupImplTest extends ActiveMQTestBase {
       }
 
       @Override
-      public void openClient() { }
+      public void openClient() {
+      }
 
       @Override
-      public void openBroadcaster() { }
+      public void openBroadcaster() {
+      }
 
       @Override
-      public void close(boolean isBroadcast) { }
+      public void close(boolean isBroadcast) {
+      }
 
       @Override
       public void broadcast(byte[] data) throws Exception {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/files/FileMoveManagerTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/files/FileMoveManagerTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/files/FileMoveManagerTest.java
index b00efca..d53cdd9 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/files/FileMoveManagerTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/files/FileMoveManagerTest.java
@@ -58,7 +58,6 @@ public class FileMoveManagerTest {
    private File dataLocation;
    private FileMoveManager manager;
 
-
    @Before
    public void setUp() {
       dataLocation = new File(temporaryFolder.getRoot(), "data");
@@ -66,7 +65,6 @@ public class FileMoveManagerTest {
       manager = new FileMoveManager(dataLocation, 10);
    }
 
-
    public FileMoveManagerTest() {
       File parent = new File("./target/tmp");
       parent.mkdirs();
@@ -88,7 +86,6 @@ public class FileMoveManagerTest {
       Assert.assertEquals(12, manager.getFolders().length);
       Assert.assertEquals(12, manager.getNumberOfFolders());
 
-
       assertIDs(originalFiles, manager.getIDlist());
    }
 
@@ -153,7 +150,6 @@ public class FileMoveManagerTest {
       testMinMax();
    }
 
-
    @Test
    public void testNoFolders() {
       Assert.assertEquals(0, manager.getFolders().length);
@@ -165,7 +161,6 @@ public class FileMoveManagerTest {
       Assert.assertEquals(0, manager.getNumberOfFolders());
    }
 
-
    @Test
    public void testNoFiles() throws Exception {
       // nothing to be moved, so why to do a backup
@@ -207,12 +202,10 @@ public class FileMoveManagerTest {
       manager.setMaxFolders(1).checkOldFolders();
       Assert.assertEquals(1, manager.getNumberOfFolders());
 
-
       Assert.assertEquals(10, manager.getMaxID());
       Assert.assertEquals(10, manager.getMinID());
    }
 
-
    @Test
    public void testMoveFolders() throws Exception {
       manager.setMaxFolders(3);
@@ -262,7 +255,6 @@ public class FileMoveManagerTest {
       manager.setMaxFolders(1).checkOldFolders();
       Assert.assertEquals(1, manager.getNumberOfFolders());
 
-
       Assert.assertEquals(10, manager.getMaxID());
       Assert.assertEquals(10, manager.getMinID());
    }
@@ -310,9 +302,7 @@ public class FileMoveManagerTest {
 
             final StorageManager storageManager = new NullStorageManager();
 
-            PagingStoreFactoryNIO storeFactory =
-               new PagingStoreFactoryNIO(storageManager, dataLocation, 100, null,
-                  new OrderedExecutorFactory(threadPool), true, null);
+            PagingStoreFactoryNIO storeFactory = new PagingStoreFactoryNIO(storageManager, dataLocation, 100, null, new OrderedExecutorFactory(threadPool), true, null);
 
             PagingManagerImpl managerImpl = new PagingManagerImpl(storeFactory, addressSettings, -1);
 
@@ -332,16 +322,13 @@ public class FileMoveManagerTest {
          }
 
          Assert.assertFalse("The loggers are complaining about address.txt", AssertionLoggerHandler.findText("address.txt"));
-      }
-      finally {
+      } finally {
          AssertionLoggerHandler.stopCapture();
          threadPool.shutdown();
       }
 
-
    }
 
-
    private void assertIDs(int[] originalFiles, int[] ids) {
       Assert.assertEquals(originalFiles.length, ids.length);
       for (int i = 0; i < ids.length; i++) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/files/FileStoreMonitorTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/files/FileStoreMonitorTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/files/FileStoreMonitorTest.java
index 7b5629f..bc4017c 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/files/FileStoreMonitorTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/files/FileStoreMonitorTest.java
@@ -101,8 +101,7 @@ public class FileStoreMonitorTest extends ActiveMQTestBase {
          protected double calculateUsage(FileStore store) throws IOException {
             if (fakeReturn.get()) {
                return 1f;
-            }
-            else {
+            } else {
                return super.calculateUsage(store);
             }
          }
@@ -151,7 +150,6 @@ public class FileStoreMonitorTest extends ActiveMQTestBase {
       });
       storeMonitor.start();
 
-
       Assert.assertTrue(latch.await(1, TimeUnit.SECONDS));
 
       storeMonitor.stop();
@@ -160,7 +158,7 @@ public class FileStoreMonitorTest extends ActiveMQTestBase {
 
       Assert.assertFalse(latch.await(100, TimeUnit.MILLISECONDS));
 
-//      FileStoreMonitor monitor = new FileStoreMonitor()
+      //      FileStoreMonitor monitor = new FileStoreMonitor()
 
    }
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/group/impl/ClusteredResetMockTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/group/impl/ClusteredResetMockTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/group/impl/ClusteredResetMockTest.java
index 47b45fa..1211dee 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/group/impl/ClusteredResetMockTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/group/impl/ClusteredResetMockTest.java
@@ -16,6 +16,12 @@
  */
 package org.apache.activemq.artemis.core.server.group.impl;
 
+import javax.management.ObjectName;
+import java.util.HashSet;
+import java.util.Set;
+import java.util.concurrent.ScheduledExecutorService;
+import java.util.concurrent.TimeUnit;
+
 import org.apache.activemq.artemis.api.core.BroadcastGroupConfiguration;
 import org.apache.activemq.artemis.api.core.SimpleString;
 import org.apache.activemq.artemis.api.core.TransportConfiguration;
@@ -54,12 +60,6 @@ import org.apache.activemq.artemis.utils.ReusableLatch;
 import org.junit.Assert;
 import org.junit.Test;
 
-import javax.management.ObjectName;
-import java.util.HashSet;
-import java.util.Set;
-import java.util.concurrent.ScheduledExecutorService;
-import java.util.concurrent.TimeUnit;
-
 /**
  * this is testing the case for resending notifications from RemotingGroupHandler
  * There is a small window where you could receive notifications wrongly
@@ -126,8 +126,7 @@ public class ClusteredResetMockTest extends ActiveMQTestBase {
                throw sni.ex;
             }
          }
-      }
-      finally {
+      } finally {
 
          for (Sender sni : sn) {
             sni.interrupt();
@@ -157,12 +156,10 @@ public class ClusteredResetMockTest extends ActiveMQTestBase {
             Response response = handler.propose(proposal);
             if (response == null) {
                ex = new NullPointerException("expected value on " + getName());
-            }
-            else if (!response.getGroupId().equals(code)) {
+            } else if (!response.getGroupId().equals(code)) {
                ex = new IllegalStateException("expected code=" + code + " but it was " + response.getGroupId());
             }
-         }
-         catch (Throwable ex) {
+         } catch (Throwable ex) {
             ex.printStackTrace();
             this.ex = ex;
          }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/impl/EmbeddedServerTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/impl/EmbeddedServerTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/impl/EmbeddedServerTest.java
index 0f2e0f0..4b882cf 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/impl/EmbeddedServerTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/impl/EmbeddedServerTest.java
@@ -16,6 +16,10 @@
  */
 package org.apache.activemq.artemis.core.server.impl;
 
+import java.nio.file.Files;
+import java.nio.file.Path;
+import java.nio.file.Paths;
+
 import org.apache.activemq.artemis.api.core.TransportConfiguration;
 import org.apache.activemq.artemis.core.config.Configuration;
 import org.apache.activemq.artemis.core.config.impl.ConfigurationImpl;
@@ -27,10 +31,6 @@ import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
 
-import java.nio.file.Files;
-import java.nio.file.Path;
-import java.nio.file.Paths;
-
 public class EmbeddedServerTest {
 
    private static final String SERVER_LOCK_NAME = "server.lock";
@@ -46,8 +46,7 @@ public class EmbeddedServerTest {
       server = ActiveMQServers.newActiveMQServer(configuration);
       try {
          server.start();
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          Assert.fail();
       }
    }
@@ -56,8 +55,7 @@ public class EmbeddedServerTest {
    public void teardown() {
       try {
          server.stop();
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          // Do Nothing
       }
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/impl/ScheduledDeliveryHandlerTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/impl/ScheduledDeliveryHandlerTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/impl/ScheduledDeliveryHandlerTest.java
index 4e05b3a..91e5e7a 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/impl/ScheduledDeliveryHandlerTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/server/impl/ScheduledDeliveryHandlerTest.java
@@ -178,8 +178,7 @@ public class ScheduledDeliveryHandlerTest extends Assert {
             // it's better to run the test a few times instead of run millions of messages here
             internalSchedule(executor, scheduler);
          }
-      }
-      finally {
+      } finally {
          scheduler.shutdownNow();
          executor.shutdownNow();
       }
@@ -205,12 +204,10 @@ public class ScheduledDeliveryHandlerTest extends Assert {
                for (int i = 0; i < NUMBER_OF_MESSAGES; i++) {
                   checkAndSchedule(handler, i, now, false, fakeQueue);
                }
-            }
-            catch (Exception e) {
+            } catch (Exception e) {
                e.printStackTrace();
                error.incrementAndGet();
-            }
-            finally {
+            } finally {
                latchDone.countDown();
             }
 
@@ -257,7 +254,9 @@ public class ScheduledDeliveryHandlerTest extends Assert {
       handler.checkAndSchedule(refImpl, tail);
    }
 
-   private void debugList(boolean fail, ScheduledDeliveryHandlerImpl handler, long numberOfExpectedMessages) throws Exception {
+   private void debugList(boolean fail,
+                          ScheduledDeliveryHandlerImpl handler,
+                          long numberOfExpectedMessages) throws Exception {
       List<MessageReference> refs = handler.getScheduledReferences();
 
       HashSet<Long> messages = new HashSet<>();
@@ -270,8 +269,7 @@ public class ScheduledDeliveryHandlerTest extends Assert {
 
          if (fail) {
             assertTrue(ref.getScheduledDeliveryTime() >= lastTime);
-         }
-         else {
+         } else {
             if (ref.getScheduledDeliveryTime() < lastTime) {
                System.out.println("^^^fail at " + ref.getScheduledDeliveryTime());
             }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/settings/RepositoryTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/settings/RepositoryTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/settings/RepositoryTest.java
index ca01857..2f59240 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/settings/RepositoryTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/settings/RepositoryTest.java
@@ -16,6 +16,10 @@
  */
 package org.apache.activemq.artemis.core.settings;
 
+import java.util.ArrayList;
+import java.util.HashSet;
+import java.util.concurrent.atomic.AtomicInteger;
+
 import org.apache.activemq.artemis.core.security.Role;
 import org.apache.activemq.artemis.core.settings.impl.HierarchicalObjectRepository;
 import org.apache.activemq.artemis.tests.util.ActiveMQTestBase;
@@ -23,10 +27,6 @@ import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
 
-import java.util.ArrayList;
-import java.util.HashSet;
-import java.util.concurrent.atomic.AtomicInteger;
-
 public class RepositoryTest extends ActiveMQTestBase {
 
    HierarchicalRepository<HashSet<Role>> securityRepository;
@@ -217,15 +217,13 @@ public class RepositoryTest extends ActiveMQTestBase {
       try {
          repository.addMatch("hjhjhjhjh.#.hhh", "test");
          fail("expected exception");
-      }
-      catch (IllegalArgumentException e) {
+      } catch (IllegalArgumentException e) {
          // pass
       }
       try {
          repository.addMatch(null, "test");
          fail("expected exception");
-      }
-      catch (IllegalArgumentException e) {
+      } catch (IllegalArgumentException e) {
          // pass
       }
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/transaction/impl/TransactionImplTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/transaction/impl/TransactionImplTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/transaction/impl/TransactionImplTest.java
index 2a6837f..0c2fec5 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/transaction/impl/TransactionImplTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/transaction/impl/TransactionImplTest.java
@@ -120,8 +120,7 @@ public class TransactionImplTest extends ActiveMQTestBase {
          try {
             tx.commit();
             Assert.fail("Exception expected!");
-         }
-         catch (ActiveMQException expected) {
+         } catch (ActiveMQException expected) {
          }
       }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/core/version/impl/VersionImplTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/core/version/impl/VersionImplTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/core/version/impl/VersionImplTest.java
index f6ea5d0..caa8bba 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/core/version/impl/VersionImplTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/core/version/impl/VersionImplTest.java
@@ -16,14 +16,13 @@
  */
 package org.apache.activemq.artemis.core.version.impl;
 
-import org.junit.Test;
-
 import java.io.ByteArrayInputStream;
 import java.io.ByteArrayOutputStream;
 import java.io.ObjectInputStream;
 import java.io.ObjectOutputStream;
 
 import org.junit.Assert;
+import org.junit.Test;
 
 public class VersionImplTest extends Assert {
    // Constants -----------------------------------------------------

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/ActiveMQTestBase.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/ActiveMQTestBase.java b/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/ActiveMQTestBase.java
index 9d727a7..69ed8b6 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/ActiveMQTestBase.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/ActiveMQTestBase.java
@@ -223,12 +223,10 @@ public abstract class ActiveMQTestBase extends Assert {
    public void shutdownDerby() {
       try {
          DriverManager.getConnection("jdbc:derby:;shutdown=true");
-      }
-      catch (Exception ignored) {
+      } catch (Exception ignored) {
       }
    }
 
-
    static {
       Random random = new Random();
       DEFAULT_UDP_PORT = 6000 + random.nextInt(1000);
@@ -261,8 +259,7 @@ public abstract class ActiveMQTestBase extends Assert {
          assertAllClientConsumersAreClosed();
          assertAllClientProducersAreClosed();
          assertAllClientSessionsAreClosed();
-      }
-      finally {
+      } finally {
          synchronized (servers) {
             for (ActiveMQServer server : servers) {
                if (server == null) {
@@ -275,8 +272,7 @@ public abstract class ActiveMQTestBase extends Assert {
                         stopComponent(cc);
                      }
                   }
-               }
-               catch (Exception e) {
+               } catch (Exception e) {
                   // no-op
                }
                stopComponentOutputExceptions(server);
@@ -289,8 +285,7 @@ public abstract class ActiveMQTestBase extends Assert {
          ArrayList<Exception> exceptions;
          try {
             exceptions = checkCsfStopped();
-         }
-         finally {
+         } finally {
             cleanupPools();
          }
 
@@ -300,7 +295,6 @@ public abstract class ActiveMQTestBase extends Assert {
          InVMConnector.resetThreadPool();
          assertAllExecutorsFinished();
 
-
          //clean up pools before failing
          if (!exceptions.isEmpty()) {
             for (Exception exception : exceptions) {
@@ -323,8 +317,7 @@ public abstract class ActiveMQTestBase extends Assert {
                                                    this.getName() +
                                                    " on this following dump"));
                   fail("test '" + getName() + "' left serverlocator running, this could effect other tests");
-               }
-               else if (stackTraceElement.getMethodName().contains("BroadcastGroupImpl.run") && !alreadyFailedThread.contains(thread)) {
+               } else if (stackTraceElement.getMethodName().contains("BroadcastGroupImpl.run") && !alreadyFailedThread.contains(thread)) {
                   alreadyFailedThread.add(thread);
                   System.out.println(threadDump(this.getName() + " has left threads running. Look at thread " +
                                                    thread.getName() +
@@ -424,7 +417,6 @@ public abstract class ActiveMQTestBase extends Assert {
       return configuration;
    }
 
-
    protected Configuration createDefaultConfig(final int serverID, final boolean netty) throws Exception {
       ConfigurationImpl configuration = createBasicConfig(serverID).setJMXManagementEnabled(false).addAcceptorConfiguration(new TransportConfiguration(INVM_ACCEPTOR_FACTORY, generateInVMParams(serverID)));
 
@@ -487,16 +479,13 @@ public abstract class ActiveMQTestBase extends Assert {
                   statement.execute("DROP TABLE " + sqlProvider.getTableName());
                }
                connection.commit();
-            }
-            catch (SQLException e) {
+            } catch (SQLException e) {
                connection.rollback();
             }
          }
-      }
-      catch (Throwable e) {
+      } catch (Throwable e) {
          e.printStackTrace();
-      }
-      finally {
+      } finally {
          connection.close();
       }
    }
@@ -555,8 +544,7 @@ public abstract class ActiveMQTestBase extends Assert {
    public static JournalType getDefaultJournalType() {
       if (LibaioContext.isLoaded()) {
          return JournalType.ASYNCIO;
-      }
-      else {
+      } else {
          return JournalType.NIO;
       }
    }
@@ -565,7 +553,6 @@ public abstract class ActiveMQTestBase extends Assert {
       ThreadLeakCheckRule.forceGC();
    }
 
-
    /**
     * Verifies whether weak references are released after a few GCs.
     *
@@ -734,8 +721,7 @@ public abstract class ActiveMQTestBase extends Assert {
       try {
          context.lookup(binding);
          Assert.fail("there must be no resource to look up for " + binding);
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
       }
    }
 
@@ -770,16 +756,13 @@ public abstract class ActiveMQTestBase extends Assert {
          ServerSocket ssocket = null;
          try {
             ssocket = new ServerSocket(port);
-         }
-         catch (Exception e) {
+         } catch (Exception e) {
             throw new IllegalStateException("port " + port + " is bound", e);
-         }
-         finally {
+         } finally {
             if (ssocket != null) {
                try {
                   ssocket.close();
-               }
-               catch (IOException e) {
+               } catch (IOException e) {
                }
             }
          }
@@ -798,7 +781,7 @@ public abstract class ActiveMQTestBase extends Assert {
    }
 
    protected final String getJDBCClassName() {
-      return System.getProperty("jdbc.driver.class","org.apache.derby.jdbc.EmbeddedDriver");
+      return System.getProperty("jdbc.driver.class", "org.apache.derby.jdbc.EmbeddedDriver");
    }
 
    protected final File getTestDirfile() {
@@ -969,8 +952,7 @@ public abstract class ActiveMQTestBase extends Assert {
       try {
          action.run();
          Assert.fail(message);
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          Assert.assertTrue(e instanceof ActiveMQException);
          Assert.assertEquals(errorCode, ((ActiveMQException) e).getType());
       }
@@ -984,8 +966,7 @@ public abstract class ActiveMQTestBase extends Assert {
       try {
          action.run();
          Assert.fail("must throw a XAException with the expected errorCode: " + errorCode);
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          Assert.assertTrue(e instanceof XAException);
          Assert.assertEquals(errorCode, ((XAException) e).errorCode);
       }
@@ -1015,8 +996,7 @@ public abstract class ActiveMQTestBase extends Assert {
             }
             if (count++ < size) {
                return getSamplebyte(count - 1);
-            }
-            else {
+            } else {
                return -1;
             }
          }
@@ -1044,28 +1024,22 @@ public abstract class ActiveMQTestBase extends Assert {
 
          if (prop.getPropertyType() == String.class) {
             value = RandomUtil.randomString();
-         }
-         else if (prop.getPropertyType() == Integer.class || prop.getPropertyType() == Integer.TYPE) {
+         } else if (prop.getPropertyType() == Integer.class || prop.getPropertyType() == Integer.TYPE) {
             value = RandomUtil.randomInt();
-         }
-         else if (prop.getPropertyType() == Long.class || prop.getPropertyType() == Long.TYPE) {
+         } else if (prop.getPropertyType() == Long.class || prop.getPropertyType() == Long.TYPE) {
             value = RandomUtil.randomLong();
-         }
-         else if (prop.getPropertyType() == Boolean.class || prop.getPropertyType() == Boolean.TYPE) {
+         } else if (prop.getPropertyType() == Boolean.class || prop.getPropertyType() == Boolean.TYPE) {
             value = RandomUtil.randomBoolean();
-         }
-         else if (prop.getPropertyType() == Double.class || prop.getPropertyType() == Double.TYPE) {
+         } else if (prop.getPropertyType() == Double.class || prop.getPropertyType() == Double.TYPE) {
             value = RandomUtil.randomDouble();
-         }
-         else {
+         } else {
             System.out.println("Can't validate property of type " + prop.getPropertyType() + " on " + prop.getName());
             value = null;
          }
 
          if (value != null && prop.getWriteMethod() != null && prop.getReadMethod() == null) {
             System.out.println("WriteOnly property " + prop.getName() + " on " + pojo.getClass());
-         }
-         else if (value != null && prop.getWriteMethod() != null &&
+         } else if (value != null && prop.getWriteMethod() != null &&
             prop.getReadMethod() != null &&
             !ignoreSet.contains(prop.getName())) {
             System.out.println("Validating " + prop.getName() + " type = " + prop.getPropertyType());
@@ -1202,8 +1176,7 @@ public abstract class ActiveMQTestBase extends Assert {
 
       if (netty) {
          params.put(org.apache.activemq.artemis.core.remoting.impl.netty.TransportConstants.PORT_PROP_NAME, org.apache.activemq.artemis.core.remoting.impl.netty.TransportConstants.DEFAULT_PORT + node);
-      }
-      else {
+      } else {
          params.put(org.apache.activemq.artemis.core.remoting.impl.invm.TransportConstants.SERVER_ID_PROP_NAME, node);
       }
 
@@ -1240,16 +1213,13 @@ public abstract class ActiveMQTestBase extends Assert {
       if (netty) {
          if (acceptor) {
             className = NETTY_ACCEPTOR_FACTORY;
-         }
-         else {
+         } else {
             className = NETTY_CONNECTOR_FACTORY;
          }
-      }
-      else {
+      } else {
          if (acceptor) {
             className = INVM_ACCEPTOR_FACTORY;
-         }
-         else {
+         } else {
             className = INVM_CONNECTOR_FACTORY;
          }
       }
@@ -1276,7 +1246,6 @@ public abstract class ActiveMQTestBase extends Assert {
          fail("server didn't start: " + server);
       }
 
-
       if (activation) {
          if (!server.getHAPolicy().isBackup()) {
             if (!server.waitForActivation(wait, TimeUnit.MILLISECONDS))
@@ -1329,15 +1298,13 @@ public abstract class ActiveMQTestBase extends Assert {
          if (isReplicated) {
             if (activation instanceof SharedNothingBackupActivation) {
                isRemoteUpToDate = backup.isReplicaSync();
-            }
-            else {
+            } else {
                //we may have already failed over and changed the Activation
                if (actualServer.isStarted()) {
                   //let it fail a few time to have time to start stopping in the case of waiting to failback
                   isRemoteUpToDate = loop++ > 10;
-               }
-               //we could be waiting to failback or restart if the server is stopping
-               else {
+               } else {
+                  //we could be waiting to failback or restart if the server is stopping
                   isRemoteUpToDate = false;
                }
             }
@@ -1355,8 +1322,7 @@ public abstract class ActiveMQTestBase extends Assert {
          }
          try {
             Thread.sleep(100);
-         }
-         catch (InterruptedException e) {
+         } catch (InterruptedException e) {
             fail(e.getMessage());
          }
       }
@@ -1375,24 +1341,24 @@ public abstract class ActiveMQTestBase extends Assert {
          }
          try {
             Thread.sleep(100);
-         }
-         catch (InterruptedException e) {
+         } catch (InterruptedException e) {
             fail(e.getMessage());
          }
       }
    }
+
    protected final ActiveMQServer createServer(final boolean realFiles,
                                                final Configuration configuration,
                                                final long pageSize,
                                                final long maxAddressSize) {
-      return createServer(realFiles, configuration, pageSize, maxAddressSize, (Map<String, AddressSettings>)null);
+      return createServer(realFiles, configuration, pageSize, maxAddressSize, (Map<String, AddressSettings>) null);
    }
 
    protected ActiveMQServer createServer(final boolean realFiles,
-                                               final Configuration configuration,
-                                               final long pageSize,
-                                               final long maxAddressSize,
-                                               final Map<String, AddressSettings> settings) {
+                                         final Configuration configuration,
+                                         final long pageSize,
+                                         final long maxAddressSize,
+                                         final Map<String, AddressSettings> settings) {
       ActiveMQServer server = addServer(ActiveMQServers.newActiveMQServer(configuration, realFiles));
 
       if (settings != null) {
@@ -1436,7 +1402,9 @@ public abstract class ActiveMQTestBase extends Assert {
       return createServer(configuration.isPersistenceEnabled(), configuration, AddressSettings.DEFAULT_PAGE_SIZE, AddressSettings.DEFAULT_MAX_SIZE_BYTES);
    }
 
-   protected ActiveMQServer createServer(final boolean realFiles, boolean isNetty, StoreConfiguration.StoreType storeType) throws Exception {
+   protected ActiveMQServer createServer(final boolean realFiles,
+                                         boolean isNetty,
+                                         StoreConfiguration.StoreType storeType) throws Exception {
       Configuration configuration = storeType == StoreConfiguration.StoreType.DATABASE ? createDefaultJDBCConfig(isNetty) : createDefaultConfig(isNetty);
       return createServer(realFiles, configuration, AddressSettings.DEFAULT_PAGE_SIZE, AddressSettings.DEFAULT_MAX_SIZE_BYTES);
    }
@@ -1474,8 +1442,7 @@ public abstract class ActiveMQTestBase extends Assert {
          server.getAddressSettingsRepository().addMatch("#", defaultSetting);
 
          return server;
-      }
-      finally {
+      } finally {
          addServer(server);
       }
    }
@@ -1515,8 +1482,7 @@ public abstract class ActiveMQTestBase extends Assert {
          server.getAddressSettingsRepository().addMatch("#", defaultSetting);
 
          return server;
-      }
-      finally {
+      } finally {
          addServer(server);
       }
    }
@@ -1541,8 +1507,7 @@ public abstract class ActiveMQTestBase extends Assert {
    protected ServerLocator createFactory(final boolean isNetty) throws Exception {
       if (isNetty) {
          return createNettyNonHALocator();
-      }
-      else {
+      } else {
          return createInVMNonHALocator();
       }
    }
@@ -1553,8 +1518,7 @@ public abstract class ActiveMQTestBase extends Assert {
       ClientSession session = sf.createSession();
       try {
          session.createQueue(address, queue);
-      }
-      finally {
+      } finally {
          session.close();
          closeSessionFactory(sf);
          closeServerLocator(locator);
@@ -1681,14 +1645,12 @@ public abstract class ActiveMQTestBase extends Assert {
          messagesJournal.load(committedRecords, preparedTransactions, null, false);
 
          return new Pair<>(committedRecords, preparedTransactions);
-      }
-      finally {
+      } finally {
          try {
             if (messagesJournal != null) {
                messagesJournal.stop();
             }
-         }
-         catch (Throwable ignored) {
+         } catch (Throwable ignored) {
          }
       }
 
@@ -1744,8 +1706,7 @@ public abstract class ActiveMQTestBase extends Assert {
       if (messageJournal) {
          ff = new NIOSequentialFileFactory(config.getJournalLocation(), null, 1);
          journal = new JournalImpl(config.getJournalFileSize(), config.getJournalMinFiles(), config.getJournalPoolFiles(), 0, 0, ff, "activemq-data", "amq", 1);
-      }
-      else {
+      } else {
          ff = new NIOSequentialFileFactory(config.getBindingsLocation(), null, 1);
          journal = new JournalImpl(1024 * 1024, 2, config.getJournalCompactMinFiles(), config.getJournalPoolFiles(), config.getJournalCompactPercentage(), ff, "activemq-bindings", "bindings", 1);
       }
@@ -1960,8 +1921,7 @@ public abstract class ActiveMQTestBase extends Assert {
       while (!ClientSessionFactoryImpl.CLOSE_RUNNABLES.isEmpty() && time < waitUntil) {
          try {
             Thread.sleep(50);
-         }
-         catch (InterruptedException e) {
+         } catch (InterruptedException e) {
             //ignore
          }
          time = System.currentTimeMillis();
@@ -2008,8 +1968,7 @@ public abstract class ActiveMQTestBase extends Assert {
       while (LibaioContext.getTotalMaxIO() != 0 && System.currentTimeMillis() > timeout) {
          try {
             Thread.sleep(100);
-         }
-         catch (Exception ignored) {
+         } catch (Exception ignored) {
          }
       }
 
@@ -2033,16 +1992,14 @@ public abstract class ActiveMQTestBase extends Assert {
       // We shutdown the global pools to give a better isolation between tests
       try {
          ServerLocatorImpl.clearThreadPools();
-      }
-      catch (Throwable e) {
+      } catch (Throwable e) {
          log.info(threadDump(e.getMessage()));
          System.err.println(threadDump(e.getMessage()));
       }
 
       try {
          NettyConnector.clearThreadPools();
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          log.info(threadDump(e.getMessage()));
          System.err.println(threadDump(e.getMessage()));
       }
@@ -2069,8 +2026,7 @@ public abstract class ActiveMQTestBase extends Assert {
          for (String sub : subs) {
             copyRecursive(new File(from, sub), new File(to, sub));
          }
-      }
-      else {
+      } else {
          try (InputStream in = new BufferedInputStream(new FileInputStream(from));
               OutputStream out = new BufferedOutputStream(new FileOutputStream(to))) {
             int b;
@@ -2210,8 +2166,7 @@ public abstract class ActiveMQTestBase extends Assert {
          return;
       try {
          component.stop();
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          // no-op
       }
    }
@@ -2221,8 +2176,7 @@ public abstract class ActiveMQTestBase extends Assert {
          return;
       try {
          component.stop();
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          System.err.println("Exception closing " + component);
          e.printStackTrace();
       }
@@ -2344,8 +2298,7 @@ public abstract class ActiveMQTestBase extends Assert {
          return;
       try {
          locator.close();
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          e.printStackTrace();
       }
    }
@@ -2355,8 +2308,7 @@ public abstract class ActiveMQTestBase extends Assert {
          return;
       try {
          sf.close();
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          e.printStackTrace();
       }
    }
@@ -2387,13 +2339,11 @@ public abstract class ActiveMQTestBase extends Assert {
       ClientSession session = sf.createSession();
       try {
          crashAndWaitForFailure(server, session);
-      }
-      finally {
+      } finally {
          try {
             session.close();
             sf.close();
-         }
-         catch (Exception ignored) {
+         } catch (Exception ignored) {
          }
       }
    }
@@ -2420,8 +2370,7 @@ public abstract class ActiveMQTestBase extends Assert {
          public void run() {
             try {
                runner.run();
-            }
-            catch (Throwable t) {
+            } catch (Throwable t) {
                this.t = t;
             }
          }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/ColocatedActiveMQServer.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/ColocatedActiveMQServer.java b/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/ColocatedActiveMQServer.java
index 806e0f2..6130dcf 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/ColocatedActiveMQServer.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/ColocatedActiveMQServer.java
@@ -70,16 +70,13 @@ public class ColocatedActiveMQServer extends ActiveMQServerImpl {
       if (replicatingBackup) {
          if (getConfiguration().getJournalType() == JournalType.ASYNCIO && LibaioContext.isLoaded()) {
             return new AIOFileLockNodeManager(directory, replicatingBackup, getConfiguration().getJournalLockAcquisitionTimeout());
-         }
-         else {
+         } else {
             return new FileLockNodeManager(directory, replicatingBackup, getConfiguration().getJournalLockAcquisitionTimeout());
          }
-      }
-      else {
+      } else {
          if (backup) {
             return nodeManagerBackup;
-         }
-         else {
+         } else {
             return nodeManagerLive;
          }
       }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/InVMNodeManagerServer.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/InVMNodeManagerServer.java b/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/InVMNodeManagerServer.java
index a14cb52..1050250 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/InVMNodeManagerServer.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/InVMNodeManagerServer.java
@@ -17,7 +17,6 @@
 package org.apache.activemq.artemis.tests.util;
 
 import javax.management.MBeanServer;
-
 import java.io.File;
 
 import org.apache.activemq.artemis.core.config.Configuration;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/SimpleStringTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/SimpleStringTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/SimpleStringTest.java
index 7c220da..b367015 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/SimpleStringTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/tests/util/SimpleStringTest.java
@@ -16,15 +16,13 @@
  */
 package org.apache.activemq.artemis.tests.util;
 
-import org.junit.Test;
-
 import java.util.concurrent.CountDownLatch;
 
-import org.junit.Assert;
-
 import org.apache.activemq.artemis.api.core.SimpleString;
 import org.apache.activemq.artemis.utils.DataConstants;
 import org.apache.activemq.artemis.utils.RandomUtil;
+import org.junit.Assert;
+import org.junit.Test;
 
 public class SimpleStringTest extends Assert {
 
@@ -122,32 +120,28 @@ public class SimpleStringTest extends Assert {
       try {
          s1.charAt(-1);
          Assert.fail("Should throw exception");
-      }
-      catch (IndexOutOfBoundsException e) {
+      } catch (IndexOutOfBoundsException e) {
          // OK
       }
 
       try {
          s1.charAt(-2);
          Assert.fail("Should throw exception");
-      }
-      catch (IndexOutOfBoundsException e) {
+      } catch (IndexOutOfBoundsException e) {
          // OK
       }
 
       try {
          s1.charAt(s.length());
          Assert.fail("Should throw exception");
-      }
-      catch (IndexOutOfBoundsException e) {
+      } catch (IndexOutOfBoundsException e) {
          // OK
       }
 
       try {
          s1.charAt(s.length() + 1);
          Assert.fail("Should throw exception");
-      }
-      catch (IndexOutOfBoundsException e) {
+      } catch (IndexOutOfBoundsException e) {
          // OK
       }
 
@@ -169,40 +163,35 @@ public class SimpleStringTest extends Assert {
       try {
          s1.subSequence(-1, 2);
          Assert.fail("Should throw exception");
-      }
-      catch (IndexOutOfBoundsException e) {
+      } catch (IndexOutOfBoundsException e) {
          // OK
       }
 
       try {
          s1.subSequence(-4, -2);
          Assert.fail("Should throw exception");
-      }
-      catch (IndexOutOfBoundsException e) {
+      } catch (IndexOutOfBoundsException e) {
          // OK
       }
 
       try {
          s1.subSequence(0, s1.length() + 1);
          Assert.fail("Should throw exception");
-      }
-      catch (IndexOutOfBoundsException e) {
+      } catch (IndexOutOfBoundsException e) {
          // OK
       }
 
       try {
          s1.subSequence(0, s1.length() + 2);
          Assert.fail("Should throw exception");
-      }
-      catch (IndexOutOfBoundsException e) {
+      } catch (IndexOutOfBoundsException e) {
          // OK
       }
 
       try {
          s1.subSequence(5, 1);
          Assert.fail("Should throw exception");
-      }
-      catch (IndexOutOfBoundsException e) {
+      } catch (IndexOutOfBoundsException e) {
          // OK
       }
    }
@@ -379,8 +368,7 @@ public class SimpleStringTest extends Assert {
                   if (newhash != initialhash) {
                      failed = true;
                   }
-               }
-               catch (Exception e) {
+               } catch (Exception e) {
                   e.printStackTrace();
                   failed = true;
                }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/java/org/apache/activemq/artemis/uri/ClusterConnectionConfigurationTest.java
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/java/org/apache/activemq/artemis/uri/ClusterConnectionConfigurationTest.java b/artemis-server/src/test/java/org/apache/activemq/artemis/uri/ClusterConnectionConfigurationTest.java
index 3df2ecf..e6b97eb 100644
--- a/artemis-server/src/test/java/org/apache/activemq/artemis/uri/ClusterConnectionConfigurationTest.java
+++ b/artemis-server/src/test/java/org/apache/activemq/artemis/uri/ClusterConnectionConfigurationTest.java
@@ -6,7 +6,7 @@
  * (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
+ * 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,

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/ConfigurationTest-defaults.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/ConfigurationTest-defaults.xml b/artemis-server/src/test/resources/ConfigurationTest-defaults.xml
index cb97112..b18bc64 100644
--- a/artemis-server/src/test/resources/ConfigurationTest-defaults.xml
+++ b/artemis-server/src/test/resources/ConfigurationTest-defaults.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-   xmlns="urn:activemq"
-   xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-   xsi:schemaLocation="urn:activemq ../../src/schemas/artemis-server.xsd ">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../src/schemas/artemis-server.xsd ">
    <!-- just use the defaults -->
    <core xmlns="urn:activemq:core"/>
 </configuration>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/ConfigurationTest-full-config.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/ConfigurationTest-full-config.xml b/artemis-server/src/test/resources/ConfigurationTest-full-config.xml
index cc11029..8984405 100644
--- a/artemis-server/src/test/resources/ConfigurationTest-full-config.xml
+++ b/artemis-server/src/test/resources/ConfigurationTest-full-config.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <name>SomeNameForUseOnTheApplicationServer</name>
       <resolve-protocols>false</resolve-protocols>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/InvalidConfigurationTest0.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/InvalidConfigurationTest0.xml b/artemis-server/src/test/resources/InvalidConfigurationTest0.xml
index db2c2d3..9eabc9e 100644
--- a/artemis-server/src/test/resources/InvalidConfigurationTest0.xml
+++ b/artemis-server/src/test/resources/InvalidConfigurationTest0.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <name>SomeNameForUseOnTheApplicationServer</name>
       <scheduled-thread-pool-max-size>12345</scheduled-thread-pool-max-size>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/InvalidConfigurationTest1.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/InvalidConfigurationTest1.xml b/artemis-server/src/test/resources/InvalidConfigurationTest1.xml
index 907ff34..7080f37 100644
--- a/artemis-server/src/test/resources/InvalidConfigurationTest1.xml
+++ b/artemis-server/src/test/resources/InvalidConfigurationTest1.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <name>SomeNameForUseOnTheApplicationServer</name>
       <scheduled-thread-pool-max-size>12345</scheduled-thread-pool-max-size>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/InvalidConfigurationTest2.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/InvalidConfigurationTest2.xml b/artemis-server/src/test/resources/InvalidConfigurationTest2.xml
index b95c10e..3d3ae98 100644
--- a/artemis-server/src/test/resources/InvalidConfigurationTest2.xml
+++ b/artemis-server/src/test/resources/InvalidConfigurationTest2.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <name>SomeNameForUseOnTheApplicationServer</name>
       <scheduled-thread-pool-max-size>12345</scheduled-thread-pool-max-size>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/InvalidConfigurationTest3.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/InvalidConfigurationTest3.xml b/artemis-server/src/test/resources/InvalidConfigurationTest3.xml
index 000211a..7b3eb9b 100644
--- a/artemis-server/src/test/resources/InvalidConfigurationTest3.xml
+++ b/artemis-server/src/test/resources/InvalidConfigurationTest3.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <name>SomeNameForUseOnTheApplicationServer</name>
       <scheduled-thread-pool-max-size>12345</scheduled-thread-pool-max-size>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/InvalidConfigurationTest4.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/InvalidConfigurationTest4.xml b/artemis-server/src/test/resources/InvalidConfigurationTest4.xml
index b50ebb2..e6feced 100644
--- a/artemis-server/src/test/resources/InvalidConfigurationTest4.xml
+++ b/artemis-server/src/test/resources/InvalidConfigurationTest4.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <name>SomeNameForUseOnTheApplicationServer</name>
       <scheduled-thread-pool-max-size>12345</scheduled-thread-pool-max-size>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/InvalidConfigurationTest5.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/InvalidConfigurationTest5.xml b/artemis-server/src/test/resources/InvalidConfigurationTest5.xml
index 88590b1..1b4dc9c 100644
--- a/artemis-server/src/test/resources/InvalidConfigurationTest5.xml
+++ b/artemis-server/src/test/resources/InvalidConfigurationTest5.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <name>SomeNameForUseOnTheApplicationServer</name>
       <scheduled-thread-pool-max-size>12345</scheduled-thread-pool-max-size>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/InvalidConfigurationTest6.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/InvalidConfigurationTest6.xml b/artemis-server/src/test/resources/InvalidConfigurationTest6.xml
index db3799a..154a746 100644
--- a/artemis-server/src/test/resources/InvalidConfigurationTest6.xml
+++ b/artemis-server/src/test/resources/InvalidConfigurationTest6.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../src/config/common/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <security-settings>
          <security-setting match="a1">
@@ -26,7 +26,8 @@
          <security-setting match="a2">
             <permission type="deleteNonDurableQueue" roles="a2.1"/>
          </security-setting>
-         <security-setting-plugin class-name="org.apache.activemq.artemis.core.server.impl.LegacyLDAPSecuritySettingPlugin">
+         <security-setting-plugin
+                 class-name="org.apache.activemq.artemis.core.server.impl.LegacyLDAPSecuritySettingPlugin">
             <setting name="initialContextFactory" value="testInitialContextFactory"/>
             <setting name="connectionURL" value="testConnectionURL"/>
             <setting name="connectionUsername" value="testConnectionUsername"/>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/colocated-hapolicy-config-null-backup.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/colocated-hapolicy-config-null-backup.xml b/artemis-server/src/test/resources/colocated-hapolicy-config-null-backup.xml
index 5b6b6d5..6d779e9 100644
--- a/artemis-server/src/test/resources/colocated-hapolicy-config-null-backup.xml
+++ b/artemis-server/src/test/resources/colocated-hapolicy-config-null-backup.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <discovery-groups>
          <discovery-group name="wahey"/>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/colocated-hapolicy-config.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/colocated-hapolicy-config.xml b/artemis-server/src/test/resources/colocated-hapolicy-config.xml
index f7872d4..c27a81f 100644
--- a/artemis-server/src/test/resources/colocated-hapolicy-config.xml
+++ b/artemis-server/src/test/resources/colocated-hapolicy-config.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <discovery-groups>
          <discovery-group name="wahey"/>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/colocated-hapolicy-config2-null-backup.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/colocated-hapolicy-config2-null-backup.xml b/artemis-server/src/test/resources/colocated-hapolicy-config2-null-backup.xml
index e420033..87e1ff3 100644
--- a/artemis-server/src/test/resources/colocated-hapolicy-config2-null-backup.xml
+++ b/artemis-server/src/test/resources/colocated-hapolicy-config2-null-backup.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <ha-policy>
          <shared-store>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/colocated-hapolicy-config2.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/colocated-hapolicy-config2.xml b/artemis-server/src/test/resources/colocated-hapolicy-config2.xml
index ca13b65..9b00321 100644
--- a/artemis-server/src/test/resources/colocated-hapolicy-config2.xml
+++ b/artemis-server/src/test/resources/colocated-hapolicy-config2.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <ha-policy>
          <shared-store>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/database-store-config.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/database-store-config.xml b/artemis-server/src/test/resources/database-store-config.xml
index c3be405..1fa3bd6 100644
--- a/artemis-server/src/test/resources/database-store-config.xml
+++ b/artemis-server/src/test/resources/database-store-config.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../main/resources/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../main/resources/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <store>
          <database-store>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/divertRoutingNameNotRequired.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/divertRoutingNameNotRequired.xml b/artemis-server/src/test/resources/divertRoutingNameNotRequired.xml
index d9b7063..b34ecd1 100644
--- a/artemis-server/src/test/resources/divertRoutingNameNotRequired.xml
+++ b/artemis-server/src/test/resources/divertRoutingNameNotRequired.xml
@@ -15,8 +15,8 @@
   limitations under the License.
 -->
 <configuration xmlns="urn:activemq"
-            xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-            xsi:schemaLocation="urn:activemq /schema/artemis-configuration.xsd">
+               xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+               xsi:schemaLocation="urn:activemq /schema/artemis-configuration.xsd">
 
    <core xmlns="urn:activemq:core">
 
@@ -53,7 +53,7 @@
       before the JMS queue is deployed, so the first time, it otherwise won't find the queue -->
       <queues>
          <queue name="jms.queue.priceForwarding">
-             <address>jms.queue.priceForwarding</address>
+            <address>jms.queue.priceForwarding</address>
          </queue>
       </queues>
 
@@ -68,7 +68,8 @@
             <address>jms.topic.priceUpdates</address>
             <forwarding-address>jms.queue.priceForwarding</forwarding-address>
             <filter string="office='New York'"/>
-            <transformer-class-name>org.apache.activemq.artemis.jms.example.AddForwardingTimeTransformer</transformer-class-name>
+            <transformer-class-name>org.apache.activemq.artemis.jms.example.AddForwardingTimeTransformer
+            </transformer-class-name>
             <exclusive>true</exclusive>
          </divert>
       </diverts>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/live-only-hapolicy-config.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/live-only-hapolicy-config.xml b/artemis-server/src/test/resources/live-only-hapolicy-config.xml
index 356b486..ab9bb20 100644
--- a/artemis-server/src/test/resources/live-only-hapolicy-config.xml
+++ b/artemis-server/src/test/resources/live-only-hapolicy-config.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <discovery-groups>
          <discovery-group name="wahey"/>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/live-only-hapolicy-config2.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/live-only-hapolicy-config2.xml b/artemis-server/src/test/resources/live-only-hapolicy-config2.xml
index b1de311..b713eb4 100644
--- a/artemis-server/src/test/resources/live-only-hapolicy-config2.xml
+++ b/artemis-server/src/test/resources/live-only-hapolicy-config2.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <ha-policy>
          <!--only one of the following-->

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/live-only-hapolicy-config3.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/live-only-hapolicy-config3.xml b/artemis-server/src/test/resources/live-only-hapolicy-config3.xml
index 6cd2554..eaafb88 100644
--- a/artemis-server/src/test/resources/live-only-hapolicy-config3.xml
+++ b/artemis-server/src/test/resources/live-only-hapolicy-config3.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <ha-policy>
          <!--only one of the following-->

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/live-only-hapolicy-config4.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/live-only-hapolicy-config4.xml b/artemis-server/src/test/resources/live-only-hapolicy-config4.xml
index 19def04..0267571 100644
--- a/artemis-server/src/test/resources/live-only-hapolicy-config4.xml
+++ b/artemis-server/src/test/resources/live-only-hapolicy-config4.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <ha-policy/>
    </core>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/live-only-hapolicy-config5.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/live-only-hapolicy-config5.xml b/artemis-server/src/test/resources/live-only-hapolicy-config5.xml
index 6fa80ff..a4463a6 100644
--- a/artemis-server/src/test/resources/live-only-hapolicy-config5.xml
+++ b/artemis-server/src/test/resources/live-only-hapolicy-config5.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
 
    <core xmlns="urn:activemq:core"/>
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/replica-hapolicy-config.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/replica-hapolicy-config.xml b/artemis-server/src/test/resources/replica-hapolicy-config.xml
index 03983fc..3b2c3ba 100644
--- a/artemis-server/src/test/resources/replica-hapolicy-config.xml
+++ b/artemis-server/src/test/resources/replica-hapolicy-config.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <discovery-groups>
          <discovery-group name="wahey"/>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/replica-hapolicy-config2.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/replica-hapolicy-config2.xml b/artemis-server/src/test/resources/replica-hapolicy-config2.xml
index 95df78b..22d5c45 100644
--- a/artemis-server/src/test/resources/replica-hapolicy-config2.xml
+++ b/artemis-server/src/test/resources/replica-hapolicy-config2.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
 
    <core xmlns="urn:activemq:core">
       <ha-policy>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/replica-hapolicy-config3.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/replica-hapolicy-config3.xml b/artemis-server/src/test/resources/replica-hapolicy-config3.xml
index 369eca6..b0e9f00 100644
--- a/artemis-server/src/test/resources/replica-hapolicy-config3.xml
+++ b/artemis-server/src/test/resources/replica-hapolicy-config3.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
 
    <core xmlns="urn:activemq:core">
       <ha-policy>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/replicated-hapolicy-config.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/replicated-hapolicy-config.xml b/artemis-server/src/test/resources/replicated-hapolicy-config.xml
index 8195e45..fb2a602 100644
--- a/artemis-server/src/test/resources/replicated-hapolicy-config.xml
+++ b/artemis-server/src/test/resources/replicated-hapolicy-config.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq /schema/artemis-server.xsd">
 
    <core xmlns="urn:activemq:core">
       <ha-policy>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/securitySettingPlugin.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/securitySettingPlugin.xml b/artemis-server/src/test/resources/securitySettingPlugin.xml
index 25207d5..81eeb9c 100644
--- a/artemis-server/src/test/resources/securitySettingPlugin.xml
+++ b/artemis-server/src/test/resources/securitySettingPlugin.xml
@@ -15,12 +15,13 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <security-settings>
-         <security-setting-plugin class-name="org.apache.activemq.artemis.core.server.impl.LegacyLDAPSecuritySettingPlugin">
+         <security-setting-plugin
+                 class-name="org.apache.activemq.artemis.core.server.impl.LegacyLDAPSecuritySettingPlugin">
             <setting name="initialContextFactory" value="testInitialContextFactory"/>
             <setting name="connectionURL" value="testConnectionURL"/>
             <setting name="connectionUsername" value="testConnectionUsername"/>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/shared-store-master-hapolicy-config.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/shared-store-master-hapolicy-config.xml b/artemis-server/src/test/resources/shared-store-master-hapolicy-config.xml
index 132cd00..1fe7c59 100644
--- a/artemis-server/src/test/resources/shared-store-master-hapolicy-config.xml
+++ b/artemis-server/src/test/resources/shared-store-master-hapolicy-config.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <ha-policy>
          <shared-store>

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-server/src/test/resources/shared-store-slave-hapolicy-config.xml
----------------------------------------------------------------------
diff --git a/artemis-server/src/test/resources/shared-store-slave-hapolicy-config.xml b/artemis-server/src/test/resources/shared-store-slave-hapolicy-config.xml
index 28c6051..6029640 100644
--- a/artemis-server/src/test/resources/shared-store-slave-hapolicy-config.xml
+++ b/artemis-server/src/test/resources/shared-store-slave-hapolicy-config.xml
@@ -15,9 +15,9 @@
   limitations under the License.
 -->
 <configuration
-      xmlns="urn:activemq"
-      xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-      xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
+        xmlns="urn:activemq"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="urn:activemq ../../../../activemq-server/src/main/resources/schema/artemis-server.xsd">
    <core xmlns="urn:activemq:core">
       <discovery-groups>
          <discovery-group name="wahey"/>