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:42 UTC

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

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/UUIDTimer.java
----------------------------------------------------------------------
diff --git a/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/UUIDTimer.java b/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/UUIDTimer.java
index 2af53ce..b60174f 100644
--- a/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/UUIDTimer.java
+++ b/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/UUIDTimer.java
@@ -65,8 +65,7 @@ import java.util.Random;
  * synchronized context (caller locks on either this object, or a similar timer
  * lock), and so has no method synchronization.
  */
-public class UUIDTimer
-{
+public class UUIDTimer {
    // // // Constants
 
    /**
@@ -126,8 +125,7 @@ public class UUIDTimer
     */
    private int mClockCounter = 0;
 
-   UUIDTimer(final Random rnd)
-   {
+   UUIDTimer(final Random rnd) {
       mRnd = rnd;
       initCounters(rnd);
       mLastSystemTimestamp = 0L;
@@ -135,8 +133,7 @@ public class UUIDTimer
       mLastUsedTimestamp = 0L;
    }
 
-   private void initCounters(final Random rnd)
-   {
+   private void initCounters(final Random rnd) {
       /*
        * Let's generate the clock sequence field now; as with counter, this
        * reduces likelihood of collisions (as explained in UUID specs)
@@ -152,8 +149,7 @@ public class UUIDTimer
       mClockCounter = mClockSequence[2] & 0xFF;
    }
 
-   public void getTimestamp(final byte[] uuidData)
-   {
+   public void getTimestamp(final byte[] uuidData) {
       // First the clock sequence:
       uuidData[UUID.INDEX_CLOCK_SEQUENCE] = mClockSequence[0];
       uuidData[UUID.INDEX_CLOCK_SEQUENCE + 1] = mClockSequence[1];
@@ -164,8 +160,7 @@ public class UUIDTimer
        * Let's first verify that the system time is not going backwards;
        * independent of whether we can use it:
        */
-      if (systime < mLastSystemTimestamp)
-      {
+      if (systime < mLastSystemTimestamp) {
          // Logger.logWarning("System time going backwards! (got value
          // "+systime+", last "+mLastSystemTimestamp);
          // Let's write it down, still
@@ -177,18 +172,15 @@ public class UUIDTimer
        * used (when generating UUIDs fast with coarse clock resolution; or if
        * clock has gone backwards over reboot etc).
        */
-      if (systime <= mLastUsedTimestamp)
-      {
+      if (systime <= mLastUsedTimestamp) {
          /*
           * Can we just use the last time stamp (ok if the counter hasn't hit
           * max yet)
           */
-         if (mClockCounter < UUIDTimer.kClockMultiplier)
-         { // yup, still have room
+         if (mClockCounter < UUIDTimer.kClockMultiplier) { // yup, still have room
             systime = mLastUsedTimestamp;
          }
-         else
-         { // nope, have to roll over to next value and maybe wait
+         else { // nope, have to roll over to next value and maybe wait
             long actDiff = mLastUsedTimestamp - systime;
             long origTime = systime;
             systime = mLastUsedTimestamp + 1L;
@@ -209,14 +201,12 @@ public class UUIDTimer
              * been moved backwards, or when coarse clock resolution has forced
              * us to advance virtual timer too far)
              */
-            if (actDiff >= UUIDTimer.kMaxClockAdvance)
-            {
+            if (actDiff >= UUIDTimer.kMaxClockAdvance) {
                UUIDTimer.slowDown(origTime, actDiff);
             }
          }
       }
-      else
-      {
+      else {
          /*
           * Clock has advanced normally; just need to make sure counter is reset
           * to a low value (need not be 0; good to leave a small residual to
@@ -270,10 +260,8 @@ public class UUIDTimer
     * Delay is kept to just a millisecond or two, to prevent excessive blocking;
     * but that should be enough to eventually synchronize physical clock with
     * virtual clock values used for UUIDs.
-    *
     */
-   private static void slowDown(final long startTime, final long actDiff)
-   {
+   private static void slowDown(final long startTime, final long actDiff) {
       /*
        * First, let's determine how long we'd like to wait. This is based on how
        * far ahead are we as of now.
@@ -281,45 +269,36 @@ public class UUIDTimer
       long ratio = actDiff / UUIDTimer.kMaxClockAdvance;
       long delay;
 
-      if (ratio < 2L)
-      { // 200 msecs or less
+      if (ratio < 2L) { // 200 msecs or less
          delay = 1L;
       }
-      else if (ratio < 10L)
-      { // 1 second or less
+      else if (ratio < 10L) { // 1 second or less
          delay = 2L;
       }
-      else if (ratio < 600L)
-      { // 1 minute or less
+      else if (ratio < 600L) { // 1 minute or less
          delay = 3L;
       }
-      else
-      {
+      else {
          delay = 5L;
       }
       // Logger.logWarning("Need to wait for "+delay+" milliseconds; virtual
       // clock advanced too far in the future");
       long waitUntil = startTime + delay;
       int counter = 0;
-      do
-      {
-         try
-         {
+      do {
+         try {
             Thread.sleep(delay);
          }
-         catch (InterruptedException ie)
-         {
+         catch (InterruptedException ie) {
          }
          delay = 1L;
          /*
           * This is just a sanity check: don't want an "infinite" loop if clock
           * happened to be moved backwards by, say, an hour...
           */
-         if (++counter > UUIDTimer.MAX_WAIT_COUNT)
-         {
+         if (++counter > UUIDTimer.MAX_WAIT_COUNT) {
             break;
          }
-      }
-      while (System.currentTimeMillis() < waitUntil);
+      } while (System.currentTimeMillis() < waitUntil);
    }
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/SchemaConstants.java
----------------------------------------------------------------------
diff --git a/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/SchemaConstants.java b/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/SchemaConstants.java
index eee4a17..0114b8a 100644
--- a/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/SchemaConstants.java
+++ b/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/SchemaConstants.java
@@ -16,8 +16,8 @@
  */
 package org.apache.activemq.artemis.utils.uri;
 
-public class SchemaConstants
-{
+public class SchemaConstants {
+
    public static final String TCP = "tcp";
 
    public static final String UDP = "udp";

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/URIFactory.java
----------------------------------------------------------------------
diff --git a/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/URIFactory.java b/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/URIFactory.java
index b3ff1b6..dae6faa 100644
--- a/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/URIFactory.java
+++ b/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/URIFactory.java
@@ -22,70 +22,57 @@ import java.net.URISyntaxException;
 import java.util.Map;
 import java.util.concurrent.ConcurrentHashMap;
 
-public class URIFactory<T, P>
-{
+public class URIFactory<T, P> {
 
    private URI defaultURI;
 
    private final Map<String, URISchema<T, P>> schemas = new ConcurrentHashMap<>();
 
-   public URI getDefaultURI()
-   {
+   public URI getDefaultURI() {
       return defaultURI;
    }
 
-   public void setDefaultURI(URI uri)
-   {
+   public void setDefaultURI(URI uri) {
       this.defaultURI = uri;
    }
 
-   public void registerSchema(URISchema<T, P> schemaFactory)
-   {
+   public void registerSchema(URISchema<T, P> schemaFactory) {
       schemas.put(schemaFactory.getSchemaName(), schemaFactory);
       schemaFactory.setFactory(this);
    }
 
-   public void removeSchema(final SchemaConstants schemaName)
-   {
+   public void removeSchema(final SchemaConstants schemaName) {
       schemas.remove(schemaName);
    }
 
-   public URI expandURI(String uriString) throws Exception
-   {
+   public URI expandURI(String uriString) throws Exception {
       return normalise(uriString);
    }
 
-   public T newObject(URI uri, P param) throws Exception
-   {
+   public T newObject(URI uri, P param) throws Exception {
       URISchema<T, P> schemaFactory = schemas.get(uri.getScheme());
 
-      if (schemaFactory == null)
-      {
+      if (schemaFactory == null) {
          throw new NullPointerException("Schema " + uri.getScheme() + " not found");
       }
 
-
       return schemaFactory.newObject(uri, param);
    }
 
-   public void populateObject(URI uri, T bean) throws Exception
-   {
+   public void populateObject(URI uri, T bean) throws Exception {
       URISchema<T, P> schemaFactory = schemas.get(uri.getScheme());
 
-      if (schemaFactory == null)
-      {
+      if (schemaFactory == null) {
          throw new NullPointerException("Schema " + uri.getScheme() + " not found");
       }
 
       schemaFactory.populateObject(uri, bean);
    }
 
-   public URI createSchema(String scheme, T bean) throws Exception
-   {
+   public URI createSchema(String scheme, T bean) throws Exception {
       URISchema<T, P> schemaFactory = schemas.get(scheme);
 
-      if (schemaFactory == null)
-      {
+      if (schemaFactory == null) {
          throw new NullPointerException("Schema " + scheme + " not found");
       }
       return schemaFactory.newURI(bean);
@@ -101,32 +88,24 @@ public class URIFactory<T, P>
    *
    * It is the job of the URISchema implementation to handle these fragments as needed.
    * */
-   private URI normalise(String uri) throws URISyntaxException
-   {
-      if (uri.startsWith("("))
-      {
+   private URI normalise(String uri) throws URISyntaxException {
+      if (uri.startsWith("(")) {
          String[] split = uri.split("\\)");
          String[] connectorURIS = split[0].substring(split[0].indexOf('(') + 1).split(",");
          String factoryQuery = split.length > 1 ? split[1] : "";
          StringBuilder builder = new StringBuilder(connectorURIS[0]);
-         if (factoryQuery != null && factoryQuery.length() > 0)
-         {
-            if (connectorURIS[0].contains("?"))
-            {
+         if (factoryQuery != null && factoryQuery.length() > 0) {
+            if (connectorURIS[0].contains("?")) {
                builder.append("&").append(factoryQuery.substring(1));
             }
-            else
-            {
+            else {
                builder.append(factoryQuery);
             }
          }
-         if (connectorURIS.length > 1)
-         {
+         if (connectorURIS.length > 1) {
             builder.append("#");
-            for (int i = 1; i < connectorURIS.length; i++)
-            {
-               if (i > 1)
-               {
+            for (int i = 1; i < connectorURIS.length; i++) {
+               if (i > 1) {
                   builder.append(",");
                }
                builder.append(connectorURIS[i]);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/URISchema.java
----------------------------------------------------------------------
diff --git a/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/URISchema.java b/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/URISchema.java
index e7ee1c1..3358331 100644
--- a/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/URISchema.java
+++ b/artemis-commons/src/main/java/org/apache/activemq/artemis/utils/uri/URISchema.java
@@ -29,67 +29,53 @@ import java.util.Set;
 import org.apache.commons.beanutils.BeanUtilsBean;
 import org.apache.commons.beanutils.FluentPropertyBeanIntrospector;
 
-public abstract class URISchema<T, P>
-{
+public abstract class URISchema<T, P> {
+
    public abstract String getSchemaName();
 
-   public T newObject(URI uri, P param) throws Exception
-   {
+   public T newObject(URI uri, P param) throws Exception {
       return newObject(uri, null, param);
    }
 
-   public void populateObject(URI uri, T bean) throws Exception
-   {
+   public void populateObject(URI uri, T bean) throws Exception {
       setData(uri, bean, parseQuery(uri.getQuery(), null));
    }
 
-   public URI newURI(T bean) throws Exception
-   {
+   public URI newURI(T bean) throws Exception {
       return internalNewURI(bean);
    }
 
    private URIFactory<T, P> parentFactory;
 
-
-   void setFactory(URIFactory<T, P> factory)
-   {
+   void setFactory(URIFactory<T, P> factory) {
       this.parentFactory = factory;
    }
 
-   protected URIFactory<T, P> getFactory()
-   {
+   protected URIFactory<T, P> getFactory() {
       return parentFactory;
    }
 
-
-   protected String getHost(URI uri)
-   {
+   protected String getHost(URI uri) {
       URI defaultFactory = getDefaultURI();
-      if (defaultFactory != null && uri.getHost() == null && defaultFactory.getScheme().equals(uri.getScheme()))
-      {
+      if (defaultFactory != null && uri.getHost() == null && defaultFactory.getScheme().equals(uri.getScheme())) {
          uri = defaultFactory;
       }
       return uri.getHost();
    }
 
-   protected URI getDefaultURI()
-   {
+   protected URI getDefaultURI() {
       URIFactory<T, P> factory = getFactory();
-      if (factory == null)
-      {
+      if (factory == null) {
          return null;
       }
-      else
-      {
+      else {
          return factory.getDefaultURI();
       }
    }
 
-   protected int getPort(URI uri)
-   {
+   protected int getPort(URI uri) {
       URI defaultFactory = getDefaultURI();
-      if (defaultFactory != null && uri.getPort() < 0 && defaultFactory.getScheme().equals(uri.getScheme()))
-      {
+      if (defaultFactory != null && uri.getPort() < 0 && defaultFactory.getScheme().equals(uri.getScheme())) {
          uri = defaultFactory;
       }
       return uri.getPort();
@@ -98,13 +84,13 @@ public abstract class URISchema<T, P>
    /**
     * It will create a new Object for the URI selected schema.
     * the propertyOverrides is used to replace whatever was defined on the URL string
-    * @param uri The URI
-    * @param propertyOverrides  used to replace whatever was defined on the URL string
+    *
+    * @param uri               The URI
+    * @param propertyOverrides used to replace whatever was defined on the URL string
     * @return new Object
     * @throws Exception On error
     */
-   public  T newObject(URI uri, Map<String, String> propertyOverrides, P param) throws Exception
-   {
+   public T newObject(URI uri, Map<String, String> propertyOverrides, P param) throws Exception {
       return internalNewObject(uri, parseQuery(uri.getQuery(), propertyOverrides), param);
    }
 
@@ -114,83 +100,63 @@ public abstract class URISchema<T, P>
 
    private static final BeanUtilsBean beanUtils = new BeanUtilsBean();
 
-
-   static
-   {
+   static {
       // This is to customize the BeanUtils to use Fluent Proeprties as well
       beanUtils.getPropertyUtils().addBeanIntrospector(new FluentPropertyBeanIntrospector());
    }
 
-
-   public static Map<String, String> parseQuery(String uri, Map<String, String> propertyOverrides) throws URISyntaxException
-   {
-      try
-      {
+   public static Map<String, String> parseQuery(String uri,
+                                                Map<String, String> propertyOverrides) throws URISyntaxException {
+      try {
          Map<String, String> rc = new HashMap<String, String>();
-         if (uri != null && !uri.isEmpty())
-         {
+         if (uri != null && !uri.isEmpty()) {
             String[] parameters = uri.split("&");
-            for (int i = 0; i < parameters.length; i++)
-            {
+            for (int i = 0; i < parameters.length; i++) {
                int p = parameters[i].indexOf("=");
-               if (p >= 0)
-               {
+               if (p >= 0) {
                   String name = URLDecoder.decode(parameters[i].substring(0, p), "UTF-8");
                   String value = URLDecoder.decode(parameters[i].substring(p + 1), "UTF-8");
                   rc.put(name, value);
                }
-               else
-               {
-                  if (!parameters[i].trim().isEmpty())
-                  {
+               else {
+                  if (!parameters[i].trim().isEmpty()) {
                      rc.put(parameters[i], null);
                   }
                }
             }
          }
 
-         if (propertyOverrides != null)
-         {
-            for (Map.Entry<String, String> entry: propertyOverrides.entrySet())
-            {
+         if (propertyOverrides != null) {
+            for (Map.Entry<String, String> entry : propertyOverrides.entrySet()) {
                rc.put(entry.getKey(), entry.getValue());
             }
          }
          return rc;
       }
-      catch (UnsupportedEncodingException e)
-      {
+      catch (UnsupportedEncodingException e) {
          throw (URISyntaxException) new URISyntaxException(e.toString(), "Invalid encoding").initCause(e);
       }
    }
 
-
-
-   protected String printQuery(Map<String, String> query)
-   {
+   protected String printQuery(Map<String, String> query) {
       StringBuffer buffer = new StringBuffer();
-      for (Map.Entry<String, String> entry : query.entrySet())
-      {
+      for (Map.Entry<String, String> entry : query.entrySet()) {
          buffer.append(entry.getKey() + "=" + entry.getValue());
          buffer.append("\n");
       }
 
-      return  buffer.toString();
+      return buffer.toString();
    }
 
-   protected static <P> P copyData(P source, P target) throws Exception
-   {
-      synchronized (beanUtils)
-      {
+   protected static <P> P copyData(P source, P target) throws Exception {
+      synchronized (beanUtils) {
          beanUtils.copyProperties(source, target);
       }
       return target;
    }
 
-   protected static <P> P setData(URI uri, P obj, Map<String, String> query) throws Exception
-   {
-      synchronized (beanUtils)
-      {
+   protected static <P> P setData(URI uri, P obj, Map<String, String> query) throws Exception {
+      synchronized (beanUtils) {
          beanUtils.setProperty(obj, "host", uri.getHost());
          beanUtils.setProperty(obj, "port", uri.getPort());
          beanUtils.setProperty(obj, "userInfo", uri.getUserInfo());
@@ -199,46 +165,36 @@ public abstract class URISchema<T, P>
       return obj;
    }
 
-   public static void setData(URI uri, HashMap<String, Object> properties, Set<String> allowableProperties, Map<String, String> query)
-   {
-      if (allowableProperties.contains("host"))
-      {
+   public static void setData(URI uri,
+                              HashMap<String, Object> properties,
+                              Set<String> allowableProperties,
+                              Map<String, String> query) {
+      if (allowableProperties.contains("host")) {
          properties.put("host", "" + uri.getHost());
       }
-      if (allowableProperties.contains("port"))
-      {
+      if (allowableProperties.contains("port")) {
          properties.put("port", "" + uri.getPort());
       }
-      if (allowableProperties.contains("userInfo"))
-      {
+      if (allowableProperties.contains("userInfo")) {
          properties.put("userInfo", "" + uri.getUserInfo());
       }
-      for (Map.Entry<String, String> entry : query.entrySet())
-      {
-         if (allowableProperties.contains(entry.getKey()))
-         {
+      for (Map.Entry<String, String> entry : query.entrySet()) {
+         if (allowableProperties.contains(entry.getKey())) {
             properties.put(entry.getKey(), entry.getValue());
          }
       }
    }
 
-   public static String getData(List<String> ignored, Object... beans) throws Exception
-   {
+   public static String getData(List<String> ignored, Object... beans) throws Exception {
       StringBuilder sb = new StringBuilder();
-      synchronized (beanUtils)
-      {
-         for (Object bean : beans)
-         {
-            if (bean != null)
-            {
+      synchronized (beanUtils) {
+         for (Object bean : beans) {
+            if (bean != null) {
                PropertyDescriptor[] descriptors = beanUtils.getPropertyUtils().getPropertyDescriptors(bean);
-               for (PropertyDescriptor descriptor : descriptors)
-               {
-                  if (descriptor.getReadMethod() != null && isWriteable(descriptor, ignored))
-                  {
+               for (PropertyDescriptor descriptor : descriptors) {
+                  if (descriptor.getReadMethod() != null && isWriteable(descriptor, ignored)) {
                      String value = beanUtils.getProperty(bean, descriptor.getName());
-                     if (value != null)
-                     {
+                     if (value != null) {
                         sb.append("&").append(descriptor.getName()).append("=").append(value);
                      }
                   }
@@ -249,23 +205,21 @@ public abstract class URISchema<T, P>
       return sb.toString();
    }
 
-   private static boolean isWriteable(PropertyDescriptor descriptor, List<String> ignored)
-   {
-      if (ignored != null && ignored.contains(descriptor.getName()))
-      {
+   private static boolean isWriteable(PropertyDescriptor descriptor, List<String> ignored) {
+      if (ignored != null && ignored.contains(descriptor.getName())) {
          return false;
       }
       Class<?> type = descriptor.getPropertyType();
       return (type == Double.class) ||
-             (type == double.class) ||
-             (type == Long.class) ||
-             (type == long.class) ||
-             (type == Integer.class) ||
-             (type == int.class) ||
-             (type == Float.class) ||
-             (type == float.class) ||
-             (type == Boolean.class) ||
-             (type == boolean.class) ||
-             (type == String.class);
+         (type == double.class) ||
+         (type == Long.class) ||
+         (type == long.class) ||
+         (type == Integer.class) ||
+         (type == int.class) ||
+         (type == Float.class) ||
+         (type == float.class) ||
+         (type == Boolean.class) ||
+         (type == boolean.class) ||
+         (type == String.class);
    }
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/ByteUtilTest.java
----------------------------------------------------------------------
diff --git a/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/ByteUtilTest.java b/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/ByteUtilTest.java
index 3b54fe7..ada02f4 100644
--- a/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/ByteUtilTest.java
+++ b/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/ByteUtilTest.java
@@ -19,31 +19,25 @@ package org.apache.activemq.artemis.utils;
 import org.junit.Assert;
 import org.junit.Test;
 
-public class ByteUtilTest
-{
+public class ByteUtilTest {
+
    @Test
-   public void testBytesToString()
-   {
-      byte[] byteArray = new byte[] {0, 1, 2, 3};
+   public void testBytesToString() {
+      byte[] byteArray = new byte[]{0, 1, 2, 3};
 
       testEquals("0001 0203", ByteUtil.bytesToHex(byteArray, 2));
       testEquals("00 01 02 03", ByteUtil.bytesToHex(byteArray, 1));
       testEquals("000102 03", ByteUtil.bytesToHex(byteArray, 3));
    }
 
-
    @Test
-   public void testMaxString()
-   {
+   public void testMaxString() {
       byte[] byteArray = new byte[20 * 1024];
-      System.out.println(ByteUtil.maxString(ByteUtil.bytesToHex(byteArray, 2),150));
+      System.out.println(ByteUtil.maxString(ByteUtil.bytesToHex(byteArray, 2), 150));
    }
 
-
-   void testEquals(String string1, String string2)
-   {
-      if (!string1.equals(string2))
-      {
+   void testEquals(String string1, String string2) {
+      if (!string1.equals(string2)) {
          Assert.fail("String are not the same:=" + string1 + "!=" + string2);
       }
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/PairTest.java
----------------------------------------------------------------------
diff --git a/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/PairTest.java b/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/PairTest.java
index ed33a80..b441c7b 100644
--- a/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/PairTest.java
+++ b/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/PairTest.java
@@ -21,13 +21,10 @@ import org.junit.Test;
 import org.junit.Assert;
 import org.apache.activemq.artemis.api.core.Pair;
 
-
-public class PairTest extends Assert
-{
+public class PairTest extends Assert {
 
    @Test
-   public void testPair()
-   {
+   public void testPair() {
       Pair<Integer, Integer> p = new Pair<Integer, Integer>(Integer.valueOf(12), Integer.valueOf(13));
       int hash = p.hashCode();
       p.setA(null);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/ReferenceCounterTest.java
----------------------------------------------------------------------
diff --git a/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/ReferenceCounterTest.java b/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/ReferenceCounterTest.java
index 30f6377..c338fb3 100644
--- a/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/ReferenceCounterTest.java
+++ b/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/ReferenceCounterTest.java
@@ -26,39 +26,34 @@ import java.util.concurrent.atomic.AtomicInteger;
 import org.junit.Assert;
 import org.junit.Test;
 
-public class ReferenceCounterTest extends Assert
-{
+public class ReferenceCounterTest extends Assert {
+
+   class LatchRunner implements Runnable {
 
-   class LatchRunner implements Runnable
-   {
       final CountDownLatch latch = new CountDownLatch(1);
       final AtomicInteger counts = new AtomicInteger(0);
       volatile Thread lastThreadUsed;
 
-      public void run()
-      {
+      public void run() {
          counts.incrementAndGet();
          latch.countDown();
       }
    }
 
    @Test
-   public void testReferenceNoExecutor() throws Exception
-   {
+   public void testReferenceNoExecutor() throws Exception {
       internalTestReferenceNoExecutor(null);
    }
 
    @Test
-   public void testReferenceWithExecutor() throws Exception
-   {
+   public void testReferenceWithExecutor() throws Exception {
       ExecutorService executor = Executors.newSingleThreadExecutor();
       internalTestReferenceNoExecutor(executor);
       executor.shutdown();
    }
 
    @Test
-   public void testReferenceValidExecutorUsed() throws Exception
-   {
+   public void testReferenceValidExecutorUsed() throws Exception {
       ExecutorService executor = Executors.newSingleThreadExecutor();
       LatchRunner runner = new LatchRunner();
       ReferenceCounterUtil counter = new ReferenceCounterUtil(runner, executor);
@@ -72,54 +67,43 @@ public class ReferenceCounterTest extends Assert
       executor.shutdown();
    }
 
-   public void internalTestReferenceNoExecutor(Executor executor) throws Exception
-   {
+   public void internalTestReferenceNoExecutor(Executor executor) throws Exception {
       LatchRunner runner = new LatchRunner();
 
       final ReferenceCounterUtil ref;
 
-      if (executor == null)
-      {
+      if (executor == null) {
          ref = new ReferenceCounterUtil(runner);
       }
-      else
-      {
+      else {
          ref = new ReferenceCounterUtil(runner, executor);
       }
 
       Thread[] t = new Thread[100];
 
-      for (int i = 0; i < t.length; i++)
-      {
-         t[i] = new Thread()
-         {
-            public void run()
-            {
+      for (int i = 0; i < t.length; i++) {
+         t[i] = new Thread() {
+            public void run() {
                ref.increment();
             }
          };
          t[i].start();
       }
 
-      for (Thread tx : t)
-      {
+      for (Thread tx : t) {
          tx.join();
       }
 
-      for (int i = 0; i < t.length; i++)
-      {
-         t[i] = new Thread()
-         {
-            public void run()
-            {
+      for (int i = 0; i < t.length; i++) {
+         t[i] = new Thread() {
+            public void run() {
                ref.decrement();
             }
          };
          t[i].start();
       }
 
-      for (Thread tx : t)
-      {
+      for (Thread tx : t) {
          tx.join();
       }
 
@@ -127,6 +111,5 @@ public class ReferenceCounterTest extends Assert
 
       assertEquals(1, runner.counts.get());
 
-
    }
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/URIParserTest.java
----------------------------------------------------------------------
diff --git a/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/URIParserTest.java b/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/URIParserTest.java
index 3155fa2..5e4849d 100644
--- a/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/URIParserTest.java
+++ b/artemis-commons/src/test/java/org/apache/activemq/artemis/utils/URIParserTest.java
@@ -25,8 +25,7 @@ import org.junit.Test;
 import java.net.URI;
 import java.util.Map;
 
-public class URIParserTest
-{
+public class URIParserTest {
 
    /**
     * this is just a simple test to validate the model
@@ -34,10 +33,9 @@ public class URIParserTest
     * @throws Throwable
     */
    @Test
-   public void testSchemaFruit() throws Throwable
-   {
+   public void testSchemaFruit() throws Throwable {
       FruitParser parser = new FruitParser();
-      Fruit fruit = (Fruit)parser.newObject(new URI("fruit://some:guy@fair-market:3030?color=green&fluentName=something"), null);
+      Fruit fruit = (Fruit) parser.newObject(new URI("fruit://some:guy@fair-market:3030?color=green&fluentName=something"), null);
 
       Assert.assertEquals("fruit", fruit.getName());
       Assert.assertEquals(3030, fruit.getPort());
@@ -46,7 +44,6 @@ public class URIParserTest
       Assert.assertEquals("green", fruit.getColor());
       Assert.assertEquals("something", fruit.getFluentName());
 
-
    }
 
    /**
@@ -55,8 +52,7 @@ public class URIParserTest
     * @throws Throwable
     */
    @Test
-   public void testSchemaNoHosPropertyt() throws Throwable
-   {
+   public void testSchemaNoHosPropertyt() throws Throwable {
       FruitParser parser = new FruitParser();
       FruitBase fruit = parser.newObject(new URI("base://some:guy@fair-market:3030?color=green&fluentName=something"), null);
       Assert.assertEquals("base", fruit.getName());
@@ -70,10 +66,9 @@ public class URIParserTest
     * @throws Throwable
     */
    @Test
-   public void testSchemaNoHostOnURL() throws Throwable
-   {
+   public void testSchemaNoHostOnURL() throws Throwable {
       FruitParser parser = new FruitParser();
-      Fruit fruit = (Fruit)parser.newObject(new URI("fruit://some:guy@port?color=green&fluentName=something"), null);
+      Fruit fruit = (Fruit) parser.newObject(new URI("fruit://some:guy@port?color=green&fluentName=something"), null);
 
       System.out.println("fruit:" + fruit);
       Assert.assertEquals("fruit", fruit.getName());
@@ -81,104 +76,84 @@ public class URIParserTest
       Assert.assertEquals("something", fruit.getFluentName());
    }
 
+   class FruitParser extends URIFactory<FruitBase, String> {
 
-   class FruitParser extends URIFactory<FruitBase, String>
-   {
-      FruitParser()
-      {
+      FruitParser() {
          this.registerSchema(new FruitSchema());
          this.registerSchema(new FruitBaseSchema());
       }
    }
 
-   class FruitSchema extends URISchema<FruitBase, String>
-   {
+   class FruitSchema extends URISchema<FruitBase, String> {
+
       @Override
-      public String getSchemaName()
-      {
+      public String getSchemaName() {
          return "fruit";
       }
 
-
       @Override
-      public FruitBase internalNewObject(URI uri, Map<String, String> query, String fruitName) throws Exception
-      {
+      public FruitBase internalNewObject(URI uri, Map<String, String> query, String fruitName) throws Exception {
          return setData(uri, new Fruit(getSchemaName()), query);
       }
 
       @Override
-      protected URI internalNewURI(FruitBase bean)
-      {
+      protected URI internalNewURI(FruitBase bean) {
          return null;
       }
    }
 
-   class FruitBaseSchema extends URISchema<FruitBase, String>
-   {
+   class FruitBaseSchema extends URISchema<FruitBase, String> {
+
       @Override
-      public String getSchemaName()
-      {
+      public String getSchemaName() {
          return "base";
       }
 
-
       @Override
-      public FruitBase internalNewObject(URI uri, Map<String, String> query, String fruitName) throws Exception
-      {
+      public FruitBase internalNewObject(URI uri, Map<String, String> query, String fruitName) throws Exception {
          return setData(uri, new FruitBase(getSchemaName()), query);
       }
 
       @Override
-      protected URI internalNewURI(FruitBase bean)
-      {
+      protected URI internalNewURI(FruitBase bean) {
          return null;
       }
    }
 
+   public static class FruitBase {
 
-   public static class FruitBase
-   {
       final String name;
       String fluentName;
       String color;
 
-      FruitBase(final String name)
-      {
+      FruitBase(final String name) {
          this.name = name;
       }
 
-
-      public String getName()
-      {
+      public String getName() {
          return name;
       }
 
-
-      public String getColor()
-      {
+      public String getColor() {
          return color;
       }
 
-      public void setColor(String color)
-      {
+      public void setColor(String color) {
          this.color = color;
       }
 
-      public String getFluentName()
-      {
+      public String getFluentName() {
          return fluentName;
       }
 
-      public FruitBase setFluentName(String name)
-      {
+      public FruitBase setFluentName(String name) {
          this.fluentName = name;
 
          return this;
       }
 
       @Override
-      public String toString()
-      {
+      public String toString() {
          return "FruitBase{" +
             "name='" + name + '\'' +
             ", fluentName='" + fluentName + '\'' +
@@ -187,12 +162,9 @@ public class URIParserTest
       }
    }
 
-   public static class Fruit extends FruitBase
-   {
-
+   public static class Fruit extends FruitBase {
 
-      public Fruit(String name)
-      {
+      public Fruit(String name) {
          super(name);
       }
 
@@ -200,41 +172,32 @@ public class URIParserTest
       int port;
       String userInfo;
 
-
-
-      public void setHost(String host)
-      {
+      public void setHost(String host) {
          this.host = host;
       }
 
-      public String getHost()
-      {
+      public String getHost() {
          return host;
       }
 
-      public void setPort(int port)
-      {
+      public void setPort(int port) {
          this.port = port;
       }
 
-      public int getPort()
-      {
+      public int getPort() {
          return port;
       }
 
-      public void setUserInfo(String userInfo)
-      {
+      public void setUserInfo(String userInfo) {
          this.userInfo = userInfo;
       }
 
-      public String getUserInfo()
-      {
+      public String getUserInfo() {
          return userInfo;
       }
 
       @Override
-      public String toString()
-      {
+      public String toString() {
          return "Fruit{" +
             "host='" + host + '\'' +
             ", port=" + port +

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/config/ActiveMQDefaultConfiguration.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/config/ActiveMQDefaultConfiguration.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/config/ActiveMQDefaultConfiguration.java
index adb2861..6b1bb5c 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/config/ActiveMQDefaultConfiguration.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/config/ActiveMQDefaultConfiguration.java
@@ -22,8 +22,7 @@ import org.apache.activemq.artemis.core.journal.impl.JournalConstants;
 /**
  * Default values of ActiveMQ Artemis configuration parameters.
  */
-public final class ActiveMQDefaultConfiguration
-{
+public final class ActiveMQDefaultConfiguration {
    /*
     * <p> In order to avoid compile time in-lining of constants, all access is done through methods
     * and all fields are PRIVATE STATIC but not FINAL. This is done following the recommendation at
@@ -32,74 +31,61 @@ public final class ActiveMQDefaultConfiguration
     * @see http://docs.oracle.com/javase/specs/jls/se7/html/jls-13.html#jls-13.4.9
     */
 
-   private ActiveMQDefaultConfiguration()
-   {
+   private ActiveMQDefaultConfiguration() {
       // Utility class
    }
 
-   public static long getDefaultClientFailureCheckPeriod()
-   {
+   public static long getDefaultClientFailureCheckPeriod() {
       return DEFAULT_CLIENT_FAILURE_CHECK_PERIOD;
    }
 
-   public static long getDefaultFileDeployerScanPeriod()
-   {
+   public static long getDefaultFileDeployerScanPeriod() {
       return DEFAULT_FILE_DEPLOYER_SCAN_PERIOD;
    }
 
-   public static int getDefaultJournalMaxIoAio()
-   {
+   public static int getDefaultJournalMaxIoAio() {
       return DEFAULT_JOURNAL_MAX_IO_AIO;
    }
 
-   public static int getDefaultJournalBufferTimeoutAio()
-   {
+   public static int getDefaultJournalBufferTimeoutAio() {
       return DEFAULT_JOURNAL_BUFFER_TIMEOUT_AIO;
    }
 
-   public static int getDefaultJournalBufferSizeAio()
-   {
+   public static int getDefaultJournalBufferSizeAio() {
       return DEFAULT_JOURNAL_BUFFER_SIZE_AIO;
    }
 
-   public static int getDefaultJournalMaxIoNio()
-   {
+   public static int getDefaultJournalMaxIoNio() {
       return DEFAULT_JOURNAL_MAX_IO_NIO;
    }
 
-   public static int getDefaultJournalBufferTimeoutNio()
-   {
+   public static int getDefaultJournalBufferTimeoutNio() {
       return DEFAULT_JOURNAL_BUFFER_TIMEOUT_NIO;
    }
 
-   public static int getDefaultJournalBufferSizeNio()
-   {
+   public static int getDefaultJournalBufferSizeNio() {
       return DEFAULT_JOURNAL_BUFFER_SIZE_NIO;
    }
 
-   public static String getPropMaskPassword()
-   {
+   public static String getPropMaskPassword() {
       return PROP_MASK_PASSWORD;
    }
 
-   public static String getPropPasswordCodec()
-   {
+   public static String getPropPasswordCodec() {
       return PROP_PASSWORD_CODEC;
    }
 
    /**
     * what kind of HA Policy should we use
     */
-   public static String getDefaultHapolicyType()
-   {
+   public static String getDefaultHapolicyType() {
       return DEFAULT_HAPOLICY_TYPE;
    }
 
    /**
     * The backup strategy to use if we are a backup or for any colocated backups.
     */
-   public static String getDefaultHapolicyBackupStrategy()
-   {
+   public static String getDefaultHapolicyBackupStrategy() {
       return DEFAULT_HAPOLICY_BACKUP_STRATEGY;
    }
 
@@ -124,7 +110,6 @@ public final class ActiveMQDefaultConfiguration
    private static String PROP_MASK_PASSWORD = "activemq.usemaskedpassword";
    private static String PROP_PASSWORD_CODEC = "activemq.passwordcodec";
 
-
    // what kind of HA Policy should we use
    private static String DEFAULT_HAPOLICY_TYPE = "NONE";
 
@@ -407,729 +392,637 @@ public final class ActiveMQDefaultConfiguration
    // How often the reaper will be run to check for timed out group bindings. Only valid for LOCAL handlers
    private static long DEFAULT_GROUPING_HANDLER_REAPER_PERIOD = 30000;
 
-
    /**
     * If true then the ActiveMQ Artemis Server will make use of any Protocol Managers that are in available on the classpath. If false then only the core protocol will be available, unless in Embedded mode where users can inject their own Protocol Managers.
     */
-   public static boolean isDefaultResolveProtocols()
-   {
+   public static boolean isDefaultResolveProtocols() {
       return DEFAULT_RESOLVE_PROTOCOLS;
    }
 
    /**
     * true means that the server will load configuration from the configuration files
     */
-   public static boolean isDefaultFileDeploymentEnabled()
-   {
+   public static boolean isDefaultFileDeploymentEnabled() {
       return DEFAULT_FILE_DEPLOYMENT_ENABLED;
    }
 
    /**
     * true means that the server will use the file based journal for persistence.
     */
-   public static boolean isDefaultPersistenceEnabled()
-   {
+   public static boolean isDefaultPersistenceEnabled() {
       return DEFAULT_PERSISTENCE_ENABLED;
    }
 
    /**
     * Maximum number of threads to use for the scheduled thread pool
     */
-   public static int getDefaultScheduledThreadPoolMaxSize()
-   {
+   public static int getDefaultScheduledThreadPoolMaxSize() {
       return DEFAULT_SCHEDULED_THREAD_POOL_MAX_SIZE;
    }
 
    /**
     * Maximum number of threads to use for the thread pool. -1 means 'no limits'.
     */
-   public static int getDefaultThreadPoolMaxSize()
-   {
+   public static int getDefaultThreadPoolMaxSize() {
       return DEFAULT_THREAD_POOL_MAX_SIZE;
    }
 
    /**
     * true means that security is enabled
     */
-   public static boolean isDefaultSecurityEnabled()
-   {
+   public static boolean isDefaultSecurityEnabled() {
       return DEFAULT_SECURITY_ENABLED;
    }
 
    /**
     * true means that graceful shutdown is enabled
     */
-   public static boolean isDefaultGracefulShutdownEnabled()
-   {
+   public static boolean isDefaultGracefulShutdownEnabled() {
       return DEFAULT_GRACEFUL_SHUTDOWN_ENABLED;
    }
 
    /**
     * true means that graceful shutdown is enabled
     */
-   public static long getDefaultGracefulShutdownTimeout()
-   {
+   public static long getDefaultGracefulShutdownTimeout() {
       return DEFAULT_GRACEFUL_SHUTDOWN_TIMEOUT;
    }
 
    /**
     * how long (in ms) to wait before invalidating the security cache
     */
-   public static long getDefaultSecurityInvalidationInterval()
-   {
+   public static long getDefaultSecurityInvalidationInterval() {
       return DEFAULT_SECURITY_INVALIDATION_INTERVAL;
    }
 
    /**
     * how long (in ms) to wait to acquire a file lock on the journal
     */
-   public static long getDefaultJournalLockAcquisitionTimeout()
-   {
+   public static long getDefaultJournalLockAcquisitionTimeout() {
       return DEFAULT_JOURNAL_LOCK_ACQUISITION_TIMEOUT;
    }
 
    /**
     * true means that the server supports wild card routing
     */
-   public static boolean isDefaultWildcardRoutingEnabled()
-   {
+   public static boolean isDefaultWildcardRoutingEnabled() {
       return DEFAULT_WILDCARD_ROUTING_ENABLED;
    }
 
    /**
     * the name of the management address to send management messages to. It is prefixed with "jms.queue" so that JMS clients can send messages to it.
     */
-   public static SimpleString getDefaultManagementAddress()
-   {
+   public static SimpleString getDefaultManagementAddress() {
       return DEFAULT_MANAGEMENT_ADDRESS;
    }
 
    /**
     * the name of the address that consumers bind to receive management notifications
     */
-   public static SimpleString getDefaultManagementNotificationAddress()
-   {
+   public static SimpleString getDefaultManagementNotificationAddress() {
       return DEFAULT_MANAGEMENT_NOTIFICATION_ADDRESS;
    }
 
    /**
     * Cluster username. It applies to all cluster configurations.
     */
-   public static String getDefaultClusterUser()
-   {
+   public static String getDefaultClusterUser() {
       return DEFAULT_CLUSTER_USER;
    }
 
    /**
     * Cluster password. It applies to all cluster configurations.
     */
-   public static String getDefaultClusterPassword()
-   {
+   public static String getDefaultClusterPassword() {
       return DEFAULT_CLUSTER_PASSWORD;
    }
 
    /**
     * This option controls whether passwords in server configuration need be masked. If set to "true" the passwords are masked.
     */
-   public static boolean isDefaultMaskPassword()
-   {
+   public static boolean isDefaultMaskPassword() {
       return DEFAULT_MASK_PASSWORD;
    }
 
    /**
     * true means that the management API is available via JMX
     */
-   public static boolean isDefaultJmxManagementEnabled()
-   {
+   public static boolean isDefaultJmxManagementEnabled() {
       return DEFAULT_JMX_MANAGEMENT_ENABLED;
    }
 
    /**
     * the JMX domain used to registered ActiveMQ Artemis MBeans in the MBeanServer
     */
-   public static String getDefaultJmxDomain()
-   {
+   public static String getDefaultJmxDomain() {
       return DEFAULT_JMX_DOMAIN;
    }
 
    /**
     * true means that message counters are enabled
     */
-   public static boolean isDefaultMessageCounterEnabled()
-   {
+   public static boolean isDefaultMessageCounterEnabled() {
       return DEFAULT_MESSAGE_COUNTER_ENABLED;
    }
 
    /**
     * the sample period (in ms) to use for message counters
     */
-   public static long getDefaultMessageCounterSamplePeriod()
-   {
+   public static long getDefaultMessageCounterSamplePeriod() {
       return DEFAULT_MESSAGE_COUNTER_SAMPLE_PERIOD;
    }
 
    /**
     * how many days to keep message counter history
     */
-   public static int getDefaultMessageCounterMaxDayHistory()
-   {
+   public static int getDefaultMessageCounterMaxDayHistory() {
       return DEFAULT_MESSAGE_COUNTER_MAX_DAY_HISTORY;
    }
 
    /**
     * if set, this will override how long (in ms) to keep a connection alive without receiving a ping. -1 disables this setting.
     */
-   public static long getDefaultConnectionTtlOverride()
-   {
+   public static long getDefaultConnectionTtlOverride() {
       return DEFAULT_CONNECTION_TTL_OVERRIDE;
    }
 
    /**
     * should certain incoming packets on the server be handed off to a thread from the thread pool for processing or should they be handled on the remoting thread?
     */
-   public static boolean isDefaultAsyncConnectionExecutionEnabled()
-   {
+   public static boolean isDefaultAsyncConnectionExecutionEnabled() {
       return DEFAULT_ASYNC_CONNECTION_EXECUTION_ENABLED;
    }
 
    /**
     * how long (in ms) before a transaction can be removed from the resource manager after create time
     */
-   public static long getDefaultTransactionTimeout()
-   {
+   public static long getDefaultTransactionTimeout() {
       return DEFAULT_TRANSACTION_TIMEOUT;
    }
 
    /**
     * how often (in ms) to scan for timeout transactions
     */
-   public static long getDefaultTransactionTimeoutScanPeriod()
-   {
+   public static long getDefaultTransactionTimeoutScanPeriod() {
       return DEFAULT_TRANSACTION_TIMEOUT_SCAN_PERIOD;
    }
 
    /**
     * how often (in ms) to scan for expired messages
     */
-   public static long getDefaultMessageExpiryScanPeriod()
-   {
+   public static long getDefaultMessageExpiryScanPeriod() {
       return DEFAULT_MESSAGE_EXPIRY_SCAN_PERIOD;
    }
 
    /**
     * the priority of the thread expiring messages
     */
-   public static int getDefaultMessageExpiryThreadPriority()
-   {
+   public static int getDefaultMessageExpiryThreadPriority() {
       return DEFAULT_MESSAGE_EXPIRY_THREAD_PRIORITY;
    }
 
    /**
     * the size of the cache for pre-creating message ID's
     */
-   public static int getDefaultIdCacheSize()
-   {
+   public static int getDefaultIdCacheSize() {
       return DEFAULT_ID_CACHE_SIZE;
    }
 
    /**
     * true means that ID's are persisted to the journal
     */
-   public static boolean isDefaultPersistIdCache()
-   {
+   public static boolean isDefaultPersistIdCache() {
       return DEFAULT_PERSIST_ID_CACHE;
    }
 
    /**
     * True means that the delivery count is persisted before delivery. False means that this only happens after a message has been cancelled.
     */
-   public static boolean isDefaultPersistDeliveryCountBeforeDelivery()
-   {
+   public static boolean isDefaultPersistDeliveryCountBeforeDelivery() {
       return DEFAULT_PERSIST_DELIVERY_COUNT_BEFORE_DELIVERY;
    }
 
    /**
     * the directory to store paged messages in
     */
-   public static String getDefaultPagingDir()
-   {
+   public static String getDefaultPagingDir() {
       return DEFAULT_PAGING_DIR;
    }
 
    /**
     * the directory to store the persisted bindings to
     */
-   public static String getDefaultBindingsDirectory()
-   {
+   public static String getDefaultBindingsDirectory() {
       return DEFAULT_BINDINGS_DIRECTORY;
    }
 
    /**
     * true means that the server will create the bindings directory on start up
     */
-   public static boolean isDefaultCreateBindingsDir()
-   {
+   public static boolean isDefaultCreateBindingsDir() {
       return DEFAULT_CREATE_BINDINGS_DIR;
    }
 
    /**
     * The max number of concurrent reads allowed on paging
     */
-   public static int getDefaultMaxConcurrentPageIo()
-   {
+   public static int getDefaultMaxConcurrentPageIo() {
       return DEFAULT_MAX_CONCURRENT_PAGE_IO;
    }
 
    /**
     * the directory to store the journal files in
     */
-   public static String getDefaultJournalDir()
-   {
+   public static String getDefaultJournalDir() {
       return DEFAULT_JOURNAL_DIR;
    }
 
    /**
     * true means that the journal directory will be created
     */
-   public static boolean isDefaultCreateJournalDir()
-   {
+   public static boolean isDefaultCreateJournalDir() {
       return DEFAULT_CREATE_JOURNAL_DIR;
    }
 
    /**
     * if true wait for transaction data to be synchronized to the journal before returning response to client
     */
-   public static boolean isDefaultJournalSyncTransactional()
-   {
+   public static boolean isDefaultJournalSyncTransactional() {
       return DEFAULT_JOURNAL_SYNC_TRANSACTIONAL;
    }
 
    /**
     * if true wait for non transaction data to be synced to the journal before returning response to client.
     */
-   public static boolean isDefaultJournalSyncNonTransactional()
-   {
+   public static boolean isDefaultJournalSyncNonTransactional() {
       return DEFAULT_JOURNAL_SYNC_NON_TRANSACTIONAL;
    }
 
    /**
     * Whether to log messages about the journal write rate
     */
-   public static boolean isDefaultJournalLogWriteRate()
-   {
+   public static boolean isDefaultJournalLogWriteRate() {
       return DEFAULT_JOURNAL_LOG_WRITE_RATE;
    }
 
    /**
     * the size (in bytes) of each journal file
     */
-   public static int getDefaultJournalFileSize()
-   {
+   public static int getDefaultJournalFileSize() {
       return DEFAULT_JOURNAL_FILE_SIZE;
    }
 
    /**
     * how many journal files to pre-create
     */
-   public static int getDefaultJournalMinFiles()
-   {
+   public static int getDefaultJournalMinFiles() {
       return DEFAULT_JOURNAL_MIN_FILES;
    }
 
    /**
     * The percentage of live data on which we consider compacting the journal
     */
-   public static int getDefaultJournalCompactPercentage()
-   {
+   public static int getDefaultJournalCompactPercentage() {
       return DEFAULT_JOURNAL_COMPACT_PERCENTAGE;
    }
 
    /**
     * The minimal number of data files before we can start compacting
     */
-   public static int getDefaultJournalCompactMinFiles()
-   {
+   public static int getDefaultJournalCompactMinFiles() {
       return DEFAULT_JOURNAL_COMPACT_MIN_FILES;
    }
 
    /**
     * XXX Only meant to be used by project developers
     */
-   public static int getDefaultJournalPerfBlastPages()
-   {
+   public static int getDefaultJournalPerfBlastPages() {
       return DEFAULT_JOURNAL_PERF_BLAST_PAGES;
    }
 
    /**
     * XXX Only meant to be used by project developers
     */
-   public static boolean isDefaultRunSyncSpeedTest()
-   {
+   public static boolean isDefaultRunSyncSpeedTest() {
       return DEFAULT_RUN_SYNC_SPEED_TEST;
    }
 
    /**
     * Interval to log server specific information (e.g. memory usage etc)
     */
-   public static long getDefaultServerDumpInterval()
-   {
+   public static long getDefaultServerDumpInterval() {
       return DEFAULT_SERVER_DUMP_INTERVAL;
    }
 
    /**
     * Percentage of available memory which will trigger a warning log
     */
-   public static int getDefaultMemoryWarningThreshold()
-   {
+   public static int getDefaultMemoryWarningThreshold() {
       return DEFAULT_MEMORY_WARNING_THRESHOLD;
    }
 
    /**
     * frequency to sample JVM memory in ms (or -1 to disable memory sampling)
     */
-   public static long getDefaultMemoryMeasureInterval()
-   {
+   public static long getDefaultMemoryMeasureInterval() {
       return DEFAULT_MEMORY_MEASURE_INTERVAL;
    }
 
    /**
     * the directory to store large messages
     */
-   public static String getDefaultLargeMessagesDir()
-   {
+   public static String getDefaultLargeMessagesDir() {
       return DEFAULT_LARGE_MESSAGES_DIR;
    }
 
    /**
     * period in milliseconds between consecutive broadcasts
     */
-   public static long getDefaultBroadcastPeriod()
-   {
+   public static long getDefaultBroadcastPeriod() {
       return DEFAULT_BROADCAST_PERIOD;
    }
 
    /**
     * Period the discovery group waits after receiving the last broadcast from a particular server before removing that servers connector pair entry from its list.
     */
-   public static int getDefaultBroadcastRefreshTimeout()
-   {
+   public static int getDefaultBroadcastRefreshTimeout() {
       return DEFAULT_BROADCAST_REFRESH_TIMEOUT;
    }
 
    /**
     * how long to keep a connection alive in the absence of any data arriving from the client. This should be greater than the ping period.
     */
-   public static long getDefaultConnectionTtl()
-   {
+   public static long getDefaultConnectionTtl() {
       return DEFAULT_CONNECTION_TTL;
    }
 
    /**
     * multiplier to apply to successive retry intervals
     */
-   public static double getDefaultRetryIntervalMultiplier()
-   {
+   public static double getDefaultRetryIntervalMultiplier() {
       return DEFAULT_RETRY_INTERVAL_MULTIPLIER;
    }
 
    /**
     * Limit to the retry-interval growth (due to retry-interval-multiplier)
     */
-   public static long getDefaultMaxRetryInterval()
-   {
+   public static long getDefaultMaxRetryInterval() {
       return DEFAULT_MAX_RETRY_INTERVAL;
    }
 
    /**
     * maximum number of initial connection attempts, -1 means 'no limits'
     */
-   public static int getDefaultBridgeInitialConnectAttempts()
-   {
+   public static int getDefaultBridgeInitialConnectAttempts() {
       return DEFAULT_BRIDGE_INITIAL_CONNECT_ATTEMPTS;
    }
 
    /**
     * maximum number of retry attempts, -1 means 'no limits'
     */
-   public static int getDefaultBridgeReconnectAttempts()
-   {
+   public static int getDefaultBridgeReconnectAttempts() {
       return DEFAULT_BRIDGE_RECONNECT_ATTEMPTS;
    }
 
    /**
     * should duplicate detection headers be inserted in forwarded messages?
     */
-   public static boolean isDefaultBridgeDuplicateDetection()
-   {
+   public static boolean isDefaultBridgeDuplicateDetection() {
       return DEFAULT_BRIDGE_DUPLICATE_DETECTION;
    }
 
    /**
     * Once the bridge has received this many bytes, it sends a confirmation
     */
-   public static int getDefaultBridgeConfirmationWindowSize()
-   {
+   public static int getDefaultBridgeConfirmationWindowSize() {
       return DEFAULT_BRIDGE_CONFIRMATION_WINDOW_SIZE;
    }
 
    /**
     * Upon reconnection this configures the number of time the same node on the topology will be retried before reseting the server locator and using the initial connectors
     */
-   public static int getDefaultBridgeConnectSameNode()
-   {
+   public static int getDefaultBridgeConnectSameNode() {
       return DEFAULT_BRIDGE_CONNECT_SAME_NODE;
    }
 
    /**
     * The period (in milliseconds) used to check if the cluster connection has failed to receive pings from another server
     */
-   public static long getDefaultClusterFailureCheckPeriod()
-   {
+   public static long getDefaultClusterFailureCheckPeriod() {
       return DEFAULT_CLUSTER_FAILURE_CHECK_PERIOD;
    }
 
    /**
     * how long to keep a connection alive in the absence of any data arriving from the client
     */
-   public static long getDefaultClusterConnectionTtl()
-   {
+   public static long getDefaultClusterConnectionTtl() {
       return DEFAULT_CLUSTER_CONNECTION_TTL;
    }
 
    /**
     * How long to wait for a reply
     */
-   public static long getDefaultClusterCallTimeout()
-   {
+   public static long getDefaultClusterCallTimeout() {
       return DEFAULT_CLUSTER_CALL_TIMEOUT;
    }
 
    /**
     * period (in ms) between successive retries
     */
-   public static long getDefaultClusterRetryInterval()
-   {
+   public static long getDefaultClusterRetryInterval() {
       return DEFAULT_CLUSTER_RETRY_INTERVAL;
    }
 
    /**
     * multiplier to apply to the retry-interval
     */
-   public static double getDefaultClusterRetryIntervalMultiplier()
-   {
+   public static double getDefaultClusterRetryIntervalMultiplier() {
       return DEFAULT_CLUSTER_RETRY_INTERVAL_MULTIPLIER;
    }
 
    /**
     * Maximum value for retry-interval
     */
-   public static long getDefaultClusterMaxRetryInterval()
-   {
+   public static long getDefaultClusterMaxRetryInterval() {
       return DEFAULT_CLUSTER_MAX_RETRY_INTERVAL;
    }
 
    /**
     * How many attempts should be made to connect initially
     */
-   public static int getDefaultClusterInitialConnectAttempts()
-   {
+   public static int getDefaultClusterInitialConnectAttempts() {
       return DEFAULT_CLUSTER_INITIAL_CONNECT_ATTEMPTS;
    }
 
    /**
     * How many attempts should be made to reconnect after failure
     */
-   public static int getDefaultClusterReconnectAttempts()
-   {
+   public static int getDefaultClusterReconnectAttempts() {
       return DEFAULT_CLUSTER_RECONNECT_ATTEMPTS;
    }
 
    /**
     * should duplicate detection headers be inserted in forwarded messages?
     */
-   public static boolean isDefaultClusterDuplicateDetection()
-   {
+   public static boolean isDefaultClusterDuplicateDetection() {
       return DEFAULT_CLUSTER_DUPLICATE_DETECTION;
    }
 
-   public static boolean isDefaultClusterForwardWhenNoConsumers()
-   {
+   public static boolean isDefaultClusterForwardWhenNoConsumers() {
       return DEFAULT_CLUSTER_FORWARD_WHEN_NO_CONSUMERS;
    }
 
    /**
     * should messages be load balanced if there are no matching consumers on target?
     */
-   public static String getDefaultClusterMessageLoadBalancingType()
-   {
+   public static String getDefaultClusterMessageLoadBalancingType() {
       return DEFAULT_CLUSTER_MESSAGE_LOAD_BALANCING_TYPE;
    }
 
    /**
     * maximum number of hops cluster topology is propagated
     */
-   public static int getDefaultClusterMaxHops()
-   {
+   public static int getDefaultClusterMaxHops() {
       return DEFAULT_CLUSTER_MAX_HOPS;
    }
 
    /**
     * The size (in bytes) of the window used for confirming data from the server connected to.
     */
-   public static int getDefaultClusterConfirmationWindowSize()
-   {
+   public static int getDefaultClusterConfirmationWindowSize() {
       return DEFAULT_CLUSTER_CONFIRMATION_WINDOW_SIZE;
    }
 
    /**
     * How long to wait for a reply if in the middle of a fail-over. -1 means wait forever.
     */
-   public static long getDefaultClusterCallFailoverTimeout()
-   {
+   public static long getDefaultClusterCallFailoverTimeout() {
       return DEFAULT_CLUSTER_CALL_FAILOVER_TIMEOUT;
    }
 
    /**
     * how often the cluster connection will notify the cluster of its existence right after joining the cluster
     */
-   public static long getDefaultClusterNotificationInterval()
-   {
+   public static long getDefaultClusterNotificationInterval() {
       return DEFAULT_CLUSTER_NOTIFICATION_INTERVAL;
    }
 
    /**
     * how many times this cluster connection will notify the cluster of its existence right after joining the cluster
     */
-   public static int getDefaultClusterNotificationAttempts()
-   {
+   public static int getDefaultClusterNotificationAttempts() {
       return DEFAULT_CLUSTER_NOTIFICATION_ATTEMPTS;
    }
 
    /**
     * whether this is an exclusive divert
     */
-   public static boolean isDefaultDivertExclusive()
-   {
+   public static boolean isDefaultDivertExclusive() {
       return DEFAULT_DIVERT_EXCLUSIVE;
    }
 
    /**
     * If true then the server will request a backup on another node
     */
-   public static boolean isDefaultHapolicyRequestBackup()
-   {
+   public static boolean isDefaultHapolicyRequestBackup() {
       return DEFAULT_HAPOLICY_REQUEST_BACKUP;
    }
 
    /**
     * How many times the live server will try to request a backup, -1 means for ever.
     */
-   public static int getDefaultHapolicyBackupRequestRetries()
-   {
+   public static int getDefaultHapolicyBackupRequestRetries() {
       return DEFAULT_HAPOLICY_BACKUP_REQUEST_RETRIES;
    }
 
    /**
     * How long to wait for retries between attempts to request a backup server.
     */
-   public static long getDefaultHapolicyBackupRequestRetryInterval()
-   {
+   public static long getDefaultHapolicyBackupRequestRetryInterval() {
       return DEFAULT_HAPOLICY_BACKUP_REQUEST_RETRY_INTERVAL;
    }
 
    /**
     * Whether or not this live server will accept backup requests from other live servers.
     */
-   public static int getDefaultHapolicyMaxBackups()
-   {
+   public static int getDefaultHapolicyMaxBackups() {
       return DEFAULT_HAPOLICY_MAX_BACKUPS;
    }
 
    /**
     * The offset to use for the Connectors and Acceptors when creating a new backup server.
     */
-   public static int getDefaultHapolicyBackupPortOffset()
-   {
+   public static int getDefaultHapolicyBackupPortOffset() {
       return DEFAULT_HAPOLICY_BACKUP_PORT_OFFSET;
    }
 
    /**
     * Whether to check the cluster for a (live) server using our own server ID when starting up. This option is only necessary for performing 'fail-back' on replicating servers. Strictly speaking this setting only applies to live servers and not to backups.
     */
-   public static boolean isDefaultCheckForLiveServer()
-   {
+   public static boolean isDefaultCheckForLiveServer() {
       return DEFAULT_CHECK_FOR_LIVE_SERVER;
    }
 
    /**
     * This specifies how many times a replicated backup server can restart after moving its files on start. Once there are this number of backup journal files the server will stop permanently after if fails back.
     */
-   public static int getDefaultMaxSavedReplicatedJournalsSize()
-   {
+   public static int getDefaultMaxSavedReplicatedJournalsSize() {
       return DEFAULT_MAX_SAVED_REPLICATED_JOURNALS_SIZE;
    }
 
    /**
     * Will this server, if a backup, restart once it has been stopped because of failback or scaling down.
     */
-   public static boolean isDefaultRestartBackup()
-   {
+   public static boolean isDefaultRestartBackup() {
       return DEFAULT_RESTART_BACKUP;
    }
 
    /**
     * Whether a server will automatically stop when another places a request to take over its place. The use case is when a regular server stops and its backup takes over its duties, later the main server restarts and requests the server (the former backup) to stop operating.
     */
-   public static boolean isDefaultAllowAutoFailback()
-   {
+   public static boolean isDefaultAllowAutoFailback() {
       return DEFAULT_ALLOW_AUTO_FAILBACK;
    }
 
    /**
     * if we have to start as a replicated server this is the delay to wait before fail-back occurs
     */
-   public static long getDefaultFailbackDelay()
-   {
+   public static long getDefaultFailbackDelay() {
       return DEFAULT_FAILBACK_DELAY;
    }
 
    /**
     * Will this backup server come live on a normal server shutdown
     */
-   public static boolean isDefaultFailoverOnServerShutdown()
-   {
+   public static boolean isDefaultFailoverOnServerShutdown() {
       return DEFAULT_FAILOVER_ON_SERVER_SHUTDOWN;
    }
 
    /**
     * its possible that you only want a server to partake in scale down as a receiver, via a group. In this case set scale-down to false
     */
-   public static boolean isDefaultScaleDownEnabled()
-   {
+   public static boolean isDefaultScaleDownEnabled() {
       return DEFAULT_SCALE_DOWN_ENABLED;
    }
 
    /**
     * How long to wait for a decision
     */
-   public static int getDefaultGroupingHandlerTimeout()
-   {
+   public static int getDefaultGroupingHandlerTimeout() {
       return DEFAULT_GROUPING_HANDLER_TIMEOUT;
    }
 
    /**
     * How long a group binding will be used, -1 means for ever. Bindings are removed after this wait elapses. On the remote node this is used to determine how often you should re-query the main coordinator in order to update the last time used accordingly.
     */
-   public static int getDefaultGroupingHandlerGroupTimeout()
-   {
+   public static int getDefaultGroupingHandlerGroupTimeout() {
       return DEFAULT_GROUPING_HANDLER_GROUP_TIMEOUT;
    }
 
    /**
     * How often the reaper will be run to check for timed out group bindings. Only valid for LOCAL handlers
     */
-   public static long getDefaultGroupingHandlerReaperPeriod()
-   {
+   public static long getDefaultGroupingHandlerReaperPeriod() {
       return DEFAULT_GROUPING_HANDLER_REAPER_PERIOD;
    }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BaseInterceptor.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BaseInterceptor.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BaseInterceptor.java
index 11635c8..200e6b5 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BaseInterceptor.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BaseInterceptor.java
@@ -19,8 +19,8 @@ package org.apache.activemq.artemis.api.core;
 
 import org.apache.activemq.artemis.spi.core.protocol.RemotingConnection;
 
-public interface BaseInterceptor<P>
-{
+public interface BaseInterceptor<P> {
+
    /**
     * Intercepts a packet which is received before it is sent to the channel
     *

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastEndpoint.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastEndpoint.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastEndpoint.java
index 7d1a6a8..7a275a4 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastEndpoint.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastEndpoint.java
@@ -36,8 +36,8 @@ import java.util.concurrent.TimeUnit;
  *
  * @see JGroupsBroadcastEndpoint
  */
-public interface BroadcastEndpoint
-{
+public interface BroadcastEndpoint {
+
    /**
     * This method initializes a BroadcastEndpoint as
     * a receiving end for broadcasts. After that data can be

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastEndpointFactory.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastEndpointFactory.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastEndpointFactory.java
index a68d231..6c33a9e 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastEndpointFactory.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastEndpointFactory.java
@@ -16,10 +16,9 @@
  */
 package org.apache.activemq.artemis.api.core;
 
-
 import java.io.Serializable;
 
-public interface BroadcastEndpointFactory extends Serializable
-{
+public interface BroadcastEndpointFactory extends Serializable {
+
    BroadcastEndpoint createBroadcastEndpoint() throws Exception;
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastGroupConfiguration.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastGroupConfiguration.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastGroupConfiguration.java
index 14e187b..095deb0 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastGroupConfiguration.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/BroadcastGroupConfiguration.java
@@ -21,13 +21,12 @@ import java.util.List;
 
 import org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration;
 
-
 /**
  * The basic configuration used to determine how the server will broadcast members
  * This is analogous to {@link DiscoveryGroupConfiguration}
  */
-public final class BroadcastGroupConfiguration implements Serializable
-{
+public final class BroadcastGroupConfiguration implements Serializable {
+
    private static final long serialVersionUID = 2335634694112319124L;
 
    private String name = null;
@@ -38,60 +37,50 @@ public final class BroadcastGroupConfiguration implements Serializable
 
    private List<String> connectorInfos = null;
 
-   public BroadcastGroupConfiguration()
-   {
+   public BroadcastGroupConfiguration() {
    }
 
-   public String getName()
-   {
+   public String getName() {
       return name;
    }
 
-   public long getBroadcastPeriod()
-   {
+   public long getBroadcastPeriod() {
       return broadcastPeriod;
    }
 
-   public List<String> getConnectorInfos()
-   {
+   public List<String> getConnectorInfos() {
       return connectorInfos;
    }
 
-   public BroadcastGroupConfiguration setName(final String name)
-   {
+   public BroadcastGroupConfiguration setName(final String name) {
       this.name = name;
       return this;
    }
 
-   public BroadcastGroupConfiguration setBroadcastPeriod(final long broadcastPeriod)
-   {
+   public BroadcastGroupConfiguration setBroadcastPeriod(final long broadcastPeriod) {
       this.broadcastPeriod = broadcastPeriod;
       return this;
    }
 
-   public BroadcastGroupConfiguration setConnectorInfos(final List<String> connectorInfos)
-   {
+   public BroadcastGroupConfiguration setConnectorInfos(final List<String> connectorInfos) {
       this.connectorInfos = connectorInfos;
       return this;
    }
 
-   public BroadcastEndpointFactory getEndpointFactory()
-   {
+   public BroadcastEndpointFactory getEndpointFactory() {
       return endpointFactory;
    }
 
-   public BroadcastGroupConfiguration setEndpointFactory(BroadcastEndpointFactory endpointFactory)
-   {
+   public BroadcastGroupConfiguration setEndpointFactory(BroadcastEndpointFactory endpointFactory) {
       this.endpointFactory = endpointFactory;
       return this;
    }
 
    @Override
-   public int hashCode()
-   {
+   public int hashCode() {
       final int prime = 31;
       int result = 1;
-      result = prime * result + (int)(broadcastPeriod ^ (broadcastPeriod >>> 32));
+      result = prime * result + (int) (broadcastPeriod ^ (broadcastPeriod >>> 32));
       result = prime * result + ((connectorInfos == null) ? 0 : connectorInfos.hashCode());
       result = prime * result + ((endpointFactory == null) ? 0 : endpointFactory.hashCode());
       result = prime * result + ((name == null) ? 0 : name.hashCode());
@@ -99,33 +88,29 @@ public final class BroadcastGroupConfiguration implements Serializable
    }
 
    @Override
-   public boolean equals(Object obj)
-   {
+   public boolean equals(Object obj) {
       if (this == obj)
          return true;
       if (obj == null)
          return false;
       if (getClass() != obj.getClass())
          return false;
-      BroadcastGroupConfiguration other = (BroadcastGroupConfiguration)obj;
+      BroadcastGroupConfiguration other = (BroadcastGroupConfiguration) obj;
       if (broadcastPeriod != other.broadcastPeriod)
          return false;
-      if (connectorInfos == null)
-      {
+      if (connectorInfos == null) {
          if (other.connectorInfos != null)
             return false;
       }
       else if (!connectorInfos.equals(other.connectorInfos))
          return false;
-      if (endpointFactory == null)
-      {
+      if (endpointFactory == null) {
          if (other.endpointFactory != null)
             return false;
       }
       else if (!endpointFactory.equals(other.endpointFactory))
          return false;
-      if (name == null)
-      {
+      if (name == null) {
          if (other.name != null)
             return false;
       }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/ChannelBroadcastEndpointFactory.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/ChannelBroadcastEndpointFactory.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/ChannelBroadcastEndpointFactory.java
index 69f22de..be5e04c 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/ChannelBroadcastEndpointFactory.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/ChannelBroadcastEndpointFactory.java
@@ -23,31 +23,27 @@ import org.jgroups.JChannel;
  *
  * Note - the underlying JChannel is not closed in this implementation.
  */
-public class ChannelBroadcastEndpointFactory implements BroadcastEndpointFactory
-{
+public class ChannelBroadcastEndpointFactory implements BroadcastEndpointFactory {
+
    private final JChannel channel;
 
    private final String channelName;
 
-   public ChannelBroadcastEndpointFactory(JChannel channel, String channelName)
-   {
+   public ChannelBroadcastEndpointFactory(JChannel channel, String channelName) {
       this.channel = channel;
       this.channelName = channelName;
    }
 
-   public JChannel getChannel()
-   {
+   public JChannel getChannel() {
       return channel;
    }
 
-   public String getChannelName()
-   {
+   public String getChannelName() {
       return channelName;
    }
 
    @Override
-   public BroadcastEndpoint createBroadcastEndpoint() throws Exception
-   {
+   public BroadcastEndpoint createBroadcastEndpoint() throws Exception {
       return new JGroupsChannelBroadcastEndpoint(channel, channelName).initChannel();
    }
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/DiscoveryGroupConfiguration.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/DiscoveryGroupConfiguration.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/DiscoveryGroupConfiguration.java
index 715fee1..11985fb 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/DiscoveryGroupConfiguration.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/DiscoveryGroupConfiguration.java
@@ -32,8 +32,8 @@ import org.apache.activemq.artemis.utils.UUIDGenerator;
  * If by any reason, both properties are filled, the JGroups takes precedence. That means, if
  * {@code jgroupsFile != null} then the Grouping method used will be JGroups.
  */
-public final class DiscoveryGroupConfiguration implements Serializable
-{
+public final class DiscoveryGroupConfiguration implements Serializable {
+
    private static final long serialVersionUID = 8657206421727863400L;
 
    private String name = UUIDGenerator.getInstance().generateStringUUID();
@@ -47,25 +47,21 @@ public final class DiscoveryGroupConfiguration implements Serializable
    * */
    private BroadcastEndpointFactory endpointFactory;
 
-   public DiscoveryGroupConfiguration()
-   {
+   public DiscoveryGroupConfiguration() {
    }
 
-   public String getName()
-   {
+   public String getName() {
       return name;
    }
 
-   public long getRefreshTimeout()
-   {
+   public long getRefreshTimeout() {
       return refreshTimeout;
    }
 
    /**
     * @param name the name to set
     */
-   public DiscoveryGroupConfiguration setName(final String name)
-   {
+   public DiscoveryGroupConfiguration setName(final String name) {
       this.name = name;
       return this;
    }
@@ -73,8 +69,7 @@ public final class DiscoveryGroupConfiguration implements Serializable
    /**
     * @param refreshTimeout the refreshTimeout to set
     */
-   public DiscoveryGroupConfiguration setRefreshTimeout(final long refreshTimeout)
-   {
+   public DiscoveryGroupConfiguration setRefreshTimeout(final long refreshTimeout) {
       this.refreshTimeout = refreshTimeout;
       return this;
    }
@@ -82,49 +77,48 @@ public final class DiscoveryGroupConfiguration implements Serializable
    /**
     * @return the discoveryInitialWaitTimeout
     */
-   public long getDiscoveryInitialWaitTimeout()
-   {
+   public long getDiscoveryInitialWaitTimeout() {
       return discoveryInitialWaitTimeout;
    }
 
    /**
     * @param discoveryInitialWaitTimeout the discoveryInitialWaitTimeout to set
     */
-   public DiscoveryGroupConfiguration setDiscoveryInitialWaitTimeout(long discoveryInitialWaitTimeout)
-   {
+   public DiscoveryGroupConfiguration setDiscoveryInitialWaitTimeout(long discoveryInitialWaitTimeout) {
       this.discoveryInitialWaitTimeout = discoveryInitialWaitTimeout;
       return this;
    }
 
-   public BroadcastEndpointFactory getBroadcastEndpointFactory()
-   {
+   public BroadcastEndpointFactory getBroadcastEndpointFactory() {
       return endpointFactory;
    }
 
-   public DiscoveryGroupConfiguration setBroadcastEndpointFactory(BroadcastEndpointFactory endpointFactory)
-   {
+   public DiscoveryGroupConfiguration setBroadcastEndpointFactory(BroadcastEndpointFactory endpointFactory) {
       this.endpointFactory = endpointFactory;
       return this;
    }
 
    @Override
-   public boolean equals(Object o)
-   {
-      if (this == o) return true;
-      if (o == null || getClass() != o.getClass()) return false;
+   public boolean equals(Object o) {
+      if (this == o)
+         return true;
+      if (o == null || getClass() != o.getClass())
+         return false;
 
       DiscoveryGroupConfiguration that = (DiscoveryGroupConfiguration) o;
 
-      if (discoveryInitialWaitTimeout != that.discoveryInitialWaitTimeout) return false;
-      if (refreshTimeout != that.refreshTimeout) return false;
-      if (name != null ? !name.equals(that.name) : that.name != null) return false;
+      if (discoveryInitialWaitTimeout != that.discoveryInitialWaitTimeout)
+         return false;
+      if (refreshTimeout != that.refreshTimeout)
+         return false;
+      if (name != null ? !name.equals(that.name) : that.name != null)
+         return false;
 
       return true;
    }
 
    @Override
-   public int hashCode()
-   {
+   public int hashCode() {
       int result = name != null ? name.hashCode() : 0;
       result = 31 * result + (int) (refreshTimeout ^ (refreshTimeout >>> 32));
       result = 31 * result + (int) (discoveryInitialWaitTimeout ^ (discoveryInitialWaitTimeout >>> 32));
@@ -132,8 +126,7 @@ public final class DiscoveryGroupConfiguration implements Serializable
    }
 
    @Override
-   public String toString()
-   {
+   public String toString() {
       return "DiscoveryGroupConfiguration{" +
          "name='" + name + '\'' +
          ", refreshTimeout=" + refreshTimeout +

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/FilterConstants.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/FilterConstants.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/FilterConstants.java
index 0992b7b..0fbd35f 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/FilterConstants.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/FilterConstants.java
@@ -20,8 +20,8 @@ package org.apache.activemq.artemis.api.core;
  * Constants representing pre-defined message attributes that can be referenced in ActiveMQ Artemis core
  * filter expressions.
  */
-public final class FilterConstants
-{
+public final class FilterConstants {
+
    /**
     * Name of the ActiveMQ Artemis UserID header.
     */
@@ -67,8 +67,7 @@ public final class FilterConstants
     */
    public static final SimpleString ACTIVEMQ_PREFIX = new SimpleString("AMQ");
 
-   private FilterConstants()
-   {
+   private FilterConstants() {
       // Utility class
    }
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/bac96047/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/Interceptor.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/Interceptor.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/Interceptor.java
index b86d319..9db3df2 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/Interceptor.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/api/core/Interceptor.java
@@ -25,6 +25,6 @@ import org.apache.activemq.artemis.core.protocol.core.Packet;
  * {@literal broker.xml}.<br>
  * To add it to a client, use {@link org.apache.activemq.artemis.api.core.client.ServerLocator#addIncomingInterceptor(Interceptor)}
  */
-public interface Interceptor extends BaseInterceptor<Packet>
-{
+public interface Interceptor extends BaseInterceptor<Packet> {
+
 }