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

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

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/Channel.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/Channel.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/Channel.java
index cf88d21..bb7b381 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/Channel.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/Channel.java
@@ -42,6 +42,7 @@ public interface Channel {
    /**
     * This number increases every time the channel reconnects successfully.
     * This is used to guarantee the integrity of the channel on sequential commands such as large messages.
+    *
     * @return
     */
    int getReconnectID();

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ActiveMQClientProtocolManager.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ActiveMQClientProtocolManager.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ActiveMQClientProtocolManager.java
index 30a0b7a..c79fc70 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ActiveMQClientProtocolManager.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ActiveMQClientProtocolManager.java
@@ -30,8 +30,8 @@ import org.apache.activemq.artemis.api.core.Interceptor;
 import org.apache.activemq.artemis.api.core.Pair;
 import org.apache.activemq.artemis.api.core.SimpleString;
 import org.apache.activemq.artemis.api.core.TransportConfiguration;
-import org.apache.activemq.artemis.api.core.client.ClientSessionFactory;
 import org.apache.activemq.artemis.api.core.client.ActiveMQClient;
+import org.apache.activemq.artemis.api.core.client.ClientSessionFactory;
 import org.apache.activemq.artemis.core.client.ActiveMQClientMessageBundle;
 import org.apache.activemq.artemis.core.client.impl.ClientSessionFactoryInternal;
 import org.apache.activemq.artemis.core.protocol.ClientPacketDecoder;
@@ -55,8 +55,8 @@ import org.apache.activemq.artemis.core.version.Version;
 import org.apache.activemq.artemis.spi.core.protocol.RemotingConnection;
 import org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager;
 import org.apache.activemq.artemis.spi.core.remoting.Connection;
-import org.apache.activemq.artemis.spi.core.remoting.TopologyResponseHandler;
 import org.apache.activemq.artemis.spi.core.remoting.SessionContext;
+import org.apache.activemq.artemis.spi.core.remoting.TopologyResponseHandler;
 import org.apache.activemq.artemis.utils.VersionLoader;
 import org.jboss.logging.Logger;
 
@@ -139,8 +139,7 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
    public Channel getChannel0() {
       if (connection == null) {
          return null;
-      }
-      else {
+      } else {
          return connection.getChannel(ChannelImpl.CHANNEL_ID.PING.id, -1);
       }
    }
@@ -153,8 +152,7 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
    public Channel getChannel1() {
       if (connection == null) {
          return null;
-      }
-      else {
+      } else {
          return connection.getChannel(1, -1);
       }
    }
@@ -175,13 +173,11 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
             }
 
             return lock;
-         }
-         finally {
+         } finally {
             localFailoverLock.unlock();
          }
          // We can now release the failoverLock
-      }
-      catch (InterruptedException e) {
+      } catch (InterruptedException e) {
          Thread.currentThread().interrupt();
          return null;
       }
@@ -239,8 +235,7 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
       for (Version clientVersion : VersionLoader.getClientVersions()) {
          try {
             return createSessionContext(clientVersion, name, username, password, xa, autoCommitSends, autoCommitAcks, preAcknowledge, minLargeMessageSize, confirmationWindowSize);
-         }
-         catch (ActiveMQException e) {
+         } catch (ActiveMQException e) {
             if (e.getType() != ActiveMQExceptionType.INCOMPATIBLE_CLIENT_SERVER_VERSIONS) {
                throw e;
             }
@@ -291,8 +286,7 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
             try {
                // channel1 reference here has to go away
                response = (CreateSessionResponseMessage) getChannel1().sendBlocking(request, PacketImpl.CREATESESSION_RESP);
-            }
-            catch (ActiveMQException cause) {
+            } catch (ActiveMQException cause) {
                if (!isAlive())
                   throw cause;
 
@@ -303,16 +297,14 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
                   retry = true;
 
                   continue;
-               }
-               else {
+               } else {
                   throw cause;
                }
             }
 
             sessionChannel = connection.getChannel(sessionChannelID, confirmationWindowSize);
 
-         }
-         catch (Throwable t) {
+         } catch (Throwable t) {
             if (lock != null) {
                lock.unlock();
                lock = null;
@@ -320,12 +312,10 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
 
             if (t instanceof ActiveMQException) {
                throw (ActiveMQException) t;
-            }
-            else {
+            } else {
                throw ActiveMQClientMessageBundle.BUNDLE.failedToCreateSession(t);
             }
-         }
-         finally {
+         } finally {
             if (lock != null) {
                lock.unlock();
             }
@@ -354,9 +344,9 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
    }
 
    protected SessionContext newSessionContext(String name,
-                                            int confirmationWindowSize,
-                                            Channel sessionChannel,
-                                            CreateSessionResponseMessage response) {
+                                              int confirmationWindowSize,
+                                              Channel sessionChannel,
+                                              CreateSessionResponseMessage response) {
       // these objects won't be null, otherwise it would keep retrying on the previous loop
       return new ActiveMQSessionContext(name, connection, sessionChannel, response.getServerVersion(), confirmationWindowSize);
    }
@@ -378,8 +368,7 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
             needToInterrupt = inCreateSession;
             exitLockLatch = inCreateSessionLatch;
          }
-      }
-      finally {
+      } finally {
          lock.unlock();
       }
 
@@ -395,8 +384,7 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
                if (exitLockLatch != null) {
                   exitLockLatch.await(500, TimeUnit.MILLISECONDS);
                }
-            }
-            catch (InterruptedException e1) {
+            } catch (InterruptedException e1) {
                throw new ActiveMQInterruptedException(e1);
             }
          }
@@ -464,20 +452,16 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
 
             if (topologyResponseHandler != null)
                topologyResponseHandler.nodeDisconnected(conn, nodeID == null ? null : nodeID.toString(), scaleDownTargetNodeID);
-         }
-         else if (type == PacketImpl.CLUSTER_TOPOLOGY) {
+         } else if (type == PacketImpl.CLUSTER_TOPOLOGY) {
             ClusterTopologyChangeMessage topMessage = (ClusterTopologyChangeMessage) packet;
             notifyTopologyChange(topMessage);
-         }
-         else if (type == PacketImpl.CLUSTER_TOPOLOGY_V2) {
+         } else if (type == PacketImpl.CLUSTER_TOPOLOGY_V2) {
             ClusterTopologyChangeMessage_V2 topMessage = (ClusterTopologyChangeMessage_V2) packet;
             notifyTopologyChange(topMessage);
-         }
-         else if (type == PacketImpl.CLUSTER_TOPOLOGY || type == PacketImpl.CLUSTER_TOPOLOGY_V2 || type == PacketImpl.CLUSTER_TOPOLOGY_V3) {
+         } else if (type == PacketImpl.CLUSTER_TOPOLOGY || type == PacketImpl.CLUSTER_TOPOLOGY_V2 || type == PacketImpl.CLUSTER_TOPOLOGY_V3) {
             ClusterTopologyChangeMessage topMessage = (ClusterTopologyChangeMessage) packet;
             notifyTopologyChange(topMessage);
-         }
-         else if (type == PacketImpl.CHECK_FOR_FAILOVER_REPLY) {
+         } else if (type == PacketImpl.CHECK_FOR_FAILOVER_REPLY) {
             System.out.println("Channel0Handler.handlePacket");
          }
       }
@@ -493,13 +477,11 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
             eventUID = ((ClusterTopologyChangeMessage_V3) topMessage).getUniqueEventID();
             backupGroupName = ((ClusterTopologyChangeMessage_V3) topMessage).getBackupGroupName();
             scaleDownGroupName = ((ClusterTopologyChangeMessage_V3) topMessage).getScaleDownGroupName();
-         }
-         else if (topMessage instanceof ClusterTopologyChangeMessage_V2) {
+         } else if (topMessage instanceof ClusterTopologyChangeMessage_V2) {
             eventUID = ((ClusterTopologyChangeMessage_V2) topMessage).getUniqueEventID();
             backupGroupName = ((ClusterTopologyChangeMessage_V2) topMessage).getBackupGroupName();
             scaleDownGroupName = null;
-         }
-         else {
+         } else {
             eventUID = System.currentTimeMillis();
             backupGroupName = null;
             scaleDownGroupName = null;
@@ -513,8 +495,7 @@ public class ActiveMQClientProtocolManager implements ClientProtocolManager {
             if (topologyResponseHandler != null) {
                topologyResponseHandler.notifyNodeDown(eventUID, topMessage.getNodeID());
             }
-         }
-         else {
+         } else {
             Pair<TransportConfiguration, TransportConfiguration> transportConfig = topMessage.getPair();
             if (transportConfig.getA() == null && transportConfig.getB() == null) {
                transportConfig = new Pair<>(conn.getTransportConnection().getConnectorConfig(), null);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ActiveMQSessionContext.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ActiveMQSessionContext.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ActiveMQSessionContext.java
index 32f2d14..c03f76c 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ActiveMQSessionContext.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ActiveMQSessionContext.java
@@ -133,7 +133,6 @@ public class ActiveMQSessionContext extends SessionContext {
       this.name = name;
    }
 
-
    protected int getConfirmationWindow() {
       return confirmationWindow;
 
@@ -178,8 +177,7 @@ public class ActiveMQSessionContext extends SessionContext {
          if (packet.getType() == PacketImpl.SESS_SEND) {
             SessionSendMessage ssm = (SessionSendMessage) packet;
             callSendAck(ssm.getHandler(), ssm.getMessage());
-         }
-         else if (packet.getType() == PacketImpl.SESS_SEND_CONTINUATION) {
+         } else if (packet.getType() == PacketImpl.SESS_SEND_CONTINUATION) {
             SessionSendContinuationMessage scm = (SessionSendContinuationMessage) packet;
             if (!scm.isContinues()) {
                callSendAck(scm.getHandler(), scm.getMessage());
@@ -190,8 +188,7 @@ public class ActiveMQSessionContext extends SessionContext {
       private void callSendAck(SendAcknowledgementHandler handler, final Message message) {
          if (handler != null) {
             handler.sendAcknowledged(message);
-         }
-         else if (sendAckHandler != null) {
+         } else if (sendAckHandler != null) {
             sendAckHandler.sendAcknowledged(message);
          }
       }
@@ -363,14 +360,11 @@ public class ActiveMQSessionContext extends SessionContext {
       Packet packet;
       if (flags == XAResource.TMSUSPEND) {
          packet = new PacketImpl(PacketImpl.SESS_XA_SUSPEND);
-      }
-      else if (flags == XAResource.TMSUCCESS) {
+      } else if (flags == XAResource.TMSUCCESS) {
          packet = new SessionXAEndMessage(xid, false);
-      }
-      else if (flags == XAResource.TMFAIL) {
+      } else if (flags == XAResource.TMFAIL) {
          packet = new SessionXAEndMessage(xid, true);
-      }
-      else {
+      } else {
          throw new XAException(XAException.XAER_INVAL);
       }
 
@@ -410,8 +404,7 @@ public class ActiveMQSessionContext extends SessionContext {
 
       if (sendBlocking) {
          sessionChannel.sendBlocking(packet, PacketImpl.NULL_RESPONSE);
-      }
-      else {
+      } else {
          sessionChannel.sendBatched(packet);
       }
    }
@@ -439,8 +432,7 @@ public class ActiveMQSessionContext extends SessionContext {
       if (requiresResponse) {
          // When sending it blocking, only the last chunk will be blocking.
          sessionChannel.sendBlocking(chunkPacket, reconnectID, PacketImpl.NULL_RESPONSE);
-      }
-      else {
+      } else {
          sessionChannel.send(chunkPacket, reconnectID);
       }
 
@@ -448,15 +440,19 @@ public class ActiveMQSessionContext extends SessionContext {
    }
 
    @Override
-   public int sendServerLargeMessageChunk(MessageInternal msgI, long messageBodySize, boolean sendBlocking, boolean lastChunk, byte[] chunk, SendAcknowledgementHandler messageHandler) throws ActiveMQException {
+   public int sendServerLargeMessageChunk(MessageInternal msgI,
+                                          long messageBodySize,
+                                          boolean sendBlocking,
+                                          boolean lastChunk,
+                                          byte[] chunk,
+                                          SendAcknowledgementHandler messageHandler) throws ActiveMQException {
       final boolean requiresResponse = lastChunk && sendBlocking;
       final SessionSendContinuationMessage chunkPacket = new SessionSendContinuationMessage(msgI, chunk, !lastChunk, requiresResponse, messageBodySize, messageHandler);
 
       if (requiresResponse) {
          // When sending it blocking, only the last chunk will be blocking.
          sessionChannel.sendBlocking(chunkPacket, PacketImpl.NULL_RESPONSE);
-      }
-      else {
+      } else {
          sessionChannel.send(chunkPacket);
       }
 
@@ -471,15 +467,13 @@ public class ActiveMQSessionContext extends SessionContext {
       PacketImpl messagePacket;
       if (individual) {
          messagePacket = new SessionIndividualAcknowledgeMessage(getConsumerID(consumer), message.getMessageID(), block);
-      }
-      else {
+      } else {
          messagePacket = new SessionAcknowledgeMessage(getConsumerID(consumer), message.getMessageID(), block);
       }
 
       if (block) {
          sessionChannel.sendBlocking(messagePacket, PacketImpl.NULL_RESPONSE);
-      }
-      else {
+      } else {
          sessionChannel.sendBatched(messagePacket);
       }
    }
@@ -513,8 +507,7 @@ public class ActiveMQSessionContext extends SessionContext {
 
       if (response.isError()) {
          throw new XAException(response.getResponseCode());
-      }
-      else {
+      } else {
          return response.getResponseCode();
       }
    }
@@ -546,15 +539,12 @@ public class ActiveMQSessionContext extends SessionContext {
       Packet packet;
       if (flags == XAResource.TMJOIN) {
          packet = new SessionXAJoinMessage(xid);
-      }
-      else if (flags == XAResource.TMRESUME) {
+      } else if (flags == XAResource.TMRESUME) {
          packet = new SessionXAResumeMessage(xid);
-      }
-      else if (flags == XAResource.TMNOFLAGS) {
+      } else if (flags == XAResource.TMNOFLAGS) {
          // Don't need to flush since the previous end will have done this
          packet = new SessionXAStartMessage(xid);
-      }
-      else {
+      } else {
          throw new XAException(XAException.XAER_INVAL);
       }
 
@@ -610,8 +600,7 @@ public class ActiveMQSessionContext extends SessionContext {
          sessionChannel.replayCommands(response.getLastConfirmedCommandID());
 
          return true;
-      }
-      else {
+      } else {
          ActiveMQClientLogger.LOGGER.reconnectCreatingNewSession(sessionChannel.getID());
 
          sessionChannel.clearCommands();
@@ -636,8 +625,7 @@ public class ActiveMQSessionContext extends SessionContext {
          try {
             getCreateChannel().sendBlocking(createRequest, PacketImpl.CREATESESSION_RESP);
             retry = false;
-         }
-         catch (ActiveMQException e) {
+         } catch (ActiveMQException e) {
             // the session was created while its server was starting, retry it:
             if (e.getType() == ActiveMQExceptionType.SESSION_CREATION_REJECTED) {
                ActiveMQClientLogger.LOGGER.retryCreateSessionSeverStarting(name);
@@ -645,13 +633,11 @@ public class ActiveMQSessionContext extends SessionContext {
                // sleep a little bit to avoid spinning too much
                try {
                   Thread.sleep(10);
-               }
-               catch (InterruptedException ie) {
+               } catch (InterruptedException ie) {
                   Thread.currentThread().interrupt();
                   throw e;
                }
-            }
-            else {
+            } else {
                throw e;
             }
          }
@@ -692,8 +678,7 @@ public class ActiveMQSessionContext extends SessionContext {
          SessionConsumerFlowCreditMessage packet = new SessionConsumerFlowCreditMessage(getConsumerID(consumerInternal), clientWindowSize);
 
          sendPacketWithoutLock(sessionChannel, packet);
-      }
-      else {
+      } else {
          // https://jira.jboss.org/browse/HORNETQ-522
          SessionConsumerFlowCreditMessage packet = new SessionConsumerFlowCreditMessage(getConsumerID(consumerInternal), 1);
          sendPacketWithoutLock(sessionChannel, packet);
@@ -830,8 +815,7 @@ public class ActiveMQSessionContext extends SessionContext {
                   throw new IllegalStateException("Invalid packet: " + type);
                }
             }
-         }
-         catch (Exception e) {
+         } catch (Exception e) {
             ActiveMQClientLogger.LOGGER.failedToHandlePacket(e);
          }
 
@@ -859,20 +843,16 @@ public class ActiveMQSessionContext extends SessionContext {
          // No flow control - buffer can increase without bound! Only use with
          // caution for very fast consumers
          clientWindowSize = -1;
-      }
-      else if (windowSize == 0) {
+      } else if (windowSize == 0) {
          // Slow consumer - no buffering
          clientWindowSize = 0;
-      }
-      else if (windowSize == 1) {
+      } else if (windowSize == 1) {
          // Slow consumer = buffer 1
          clientWindowSize = 1;
-      }
-      else if (windowSize > 1) {
+      } else if (windowSize > 1) {
          // Client window size is half server window size
          clientWindowSize = windowSize >> 1;
-      }
-      else {
+      } else {
          throw ActiveMQClientMessageBundle.BUNDLE.invalidWindowSize(windowSize);
       }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ChannelImpl.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ChannelImpl.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ChannelImpl.java
index 751dee0..a51b7b9 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ChannelImpl.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/ChannelImpl.java
@@ -43,6 +43,7 @@ import org.apache.activemq.artemis.utils.ConcurrentUtil;
 import org.jboss.logging.Logger;
 
 public final class ChannelImpl implements Channel {
+
    private static final Logger logger = Logger.getLogger(ChannelImpl.class);
 
    public enum CHANNEL_ID {
@@ -84,7 +85,9 @@ public final class ChannelImpl implements Channel {
 
    private volatile long id;
 
-   /** This is used in */
+   /**
+    * This is used in
+    */
    private final AtomicInteger reconnectID = new AtomicInteger(0);
 
    private ChannelHandler handler;
@@ -135,8 +138,7 @@ public final class ChannelImpl implements Channel {
 
       if (confWindowSize != -1) {
          resendCache = new ConcurrentLinkedQueue<>();
-      }
-      else {
+      } else {
          resendCache = null;
       }
 
@@ -205,8 +207,7 @@ public final class ChannelImpl implements Channel {
          response = new ActiveMQExceptionMessage(ActiveMQClientMessageBundle.BUNDLE.unblockingACall(cause));
 
          sendCondition.signal();
-      }
-      finally {
+      } finally {
          lock.unlock();
       }
    }
@@ -245,12 +246,10 @@ public final class ChannelImpl implements Channel {
             while (failingOver) {
                failoverCondition.await();
             }
-         }
-         else if (!ConcurrentUtil.await(failoverCondition, connection.getBlockingCallFailoverTimeout())) {
+         } else if (!ConcurrentUtil.await(failoverCondition, connection.getBlockingCallFailoverTimeout())) {
             logger.debug(timeoutMsg);
          }
-      }
-      catch (InterruptedException e) {
+      } catch (InterruptedException e) {
          throw new ActiveMQInterruptedException(e);
       }
    }
@@ -285,8 +284,7 @@ public final class ChannelImpl implements Channel {
             if (resendCache != null && packet.isRequiresConfirmations()) {
                addResendPacket(packet);
             }
-         }
-         finally {
+         } finally {
             lock.unlock();
          }
 
@@ -321,7 +319,9 @@ public final class ChannelImpl implements Channel {
     * The expectedPacket will be used to filter out undesirable packets that would belong to previous calls.
     */
    @Override
-   public Packet sendBlocking(final Packet packet, final int reconnectID, byte expectedPacket) throws ActiveMQException {
+   public Packet sendBlocking(final Packet packet,
+                              final int reconnectID,
+                              byte expectedPacket) throws ActiveMQException {
       String interceptionResult = invokeInterceptors(packet, interceptors, connection);
 
       if (interceptionResult != null) {
@@ -371,8 +371,7 @@ public final class ChannelImpl implements Channel {
             while (!closed && (response == null || (response.getType() != PacketImpl.EXCEPTION && response.getType() != expectedPacket)) && toWait > 0) {
                try {
                   sendCondition.await(toWait, TimeUnit.MILLISECONDS);
-               }
-               catch (InterruptedException e) {
+               } catch (InterruptedException e) {
                   throw new ActiveMQInterruptedException(e);
                }
 
@@ -404,8 +403,7 @@ public final class ChannelImpl implements Channel {
 
                throw e;
             }
-         }
-         finally {
+         } finally {
             lock.unlock();
          }
 
@@ -437,8 +435,7 @@ public final class ChannelImpl implements Channel {
                if (!callNext) {
                   return interceptor.getClass().getName();
                }
-            }
-            catch (final Throwable e) {
+            } catch (final Throwable e) {
                ActiveMQClientLogger.LOGGER.errorCallingInterceptor(e, interceptor);
             }
          }
@@ -608,8 +605,7 @@ public final class ChannelImpl implements Channel {
          }
 
          return;
-      }
-      else {
+      } else {
          if (packet.isResponse()) {
             confirm(packet);
 
@@ -618,12 +614,10 @@ public final class ChannelImpl implements Channel {
             try {
                response = packet;
                sendCondition.signal();
-            }
-            finally {
+            } finally {
                lock.unlock();
             }
-         }
-         else if (handler != null) {
+         } else if (handler != null) {
             handler.handlePacket(packet);
          }
       }
@@ -648,8 +642,8 @@ public final class ChannelImpl implements Channel {
 
       if (logger.isTraceEnabled()) {
          logger.trace("ChannelImpl::clearUpTo lastReceived commandID=" + lastReceivedCommandID +
-                                              " first commandID=" + firstStoredCommandID +
-                                              " number to clear " + numberToClear);
+                         " first commandID=" + firstStoredCommandID +
+                         " number to clear " + numberToClear);
       }
 
       for (int i = 0; i < numberToClear; i++) {

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/PacketDecoder.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/PacketDecoder.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/PacketDecoder.java
index e04f3d0..54c2022 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/PacketDecoder.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/PacketDecoder.java
@@ -16,76 +16,12 @@
  */
 package org.apache.activemq.artemis.core.protocol.core.impl;
 
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CLUSTER_TOPOLOGY;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CLUSTER_TOPOLOGY_V2;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CLUSTER_TOPOLOGY_V3;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CREATESESSION;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CREATESESSION_RESP;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CREATE_QUEUE;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CREATE_SHARED_QUEUE;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.DELETE_QUEUE;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.DISCONNECT;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.DISCONNECT_V2;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.DISCONNECT_CONSUMER;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.EXCEPTION;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.NULL_RESPONSE;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.PACKETS_CONFIRMED;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.PING;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.REATTACH_SESSION;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.REATTACH_SESSION_RESP;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CHECK_FOR_FAILOVER;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_ACKNOWLEDGE;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_ADD_METADATA;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_ADD_METADATA2;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_BINDINGQUERY;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_BINDINGQUERY_RESP;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_BINDINGQUERY_RESP_V2;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_BINDINGQUERY_RESP_V3;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_CLOSE;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_COMMIT;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_CONSUMER_CLOSE;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_CREATECONSUMER;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_EXPIRED;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_FLOWTOKEN;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_FORCE_CONSUMER_DELIVERY;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_INDIVIDUAL_ACKNOWLEDGE;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_PRODUCER_CREDITS;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_PRODUCER_FAIL_CREDITS;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_PRODUCER_REQUEST_CREDITS;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_QUEUEQUERY;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_QUEUEQUERY_RESP;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_QUEUEQUERY_RESP_V2;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_RECEIVE_CONTINUATION;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_ROLLBACK;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_SEND_CONTINUATION;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_START;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_STOP;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_UNIQUE_ADD_METADATA;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_COMMIT;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_END;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_FAILED;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_FORGET;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_GET_TIMEOUT;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_GET_TIMEOUT_RESP;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_INDOUBT_XIDS;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_INDOUBT_XIDS_RESP;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_JOIN;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_PREPARE;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_RESP;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_RESUME;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_ROLLBACK;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_SET_TIMEOUT;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_SET_TIMEOUT_RESP;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_START;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_SUSPEND;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SUBSCRIBE_TOPOLOGY;
-import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SUBSCRIBE_TOPOLOGY_V2;
-
 import java.io.Serializable;
 
 import org.apache.activemq.artemis.api.core.ActiveMQBuffer;
 import org.apache.activemq.artemis.core.client.ActiveMQClientMessageBundle;
 import org.apache.activemq.artemis.core.protocol.core.Packet;
+import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.ActiveMQExceptionMessage;
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.CheckFailoverMessage;
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.CheckFailoverReplyMessage;
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage;
@@ -98,7 +34,6 @@ import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.CreateShar
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.DisconnectConsumerMessage;
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.DisconnectMessage;
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.DisconnectMessage_V2;
-import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.ActiveMQExceptionMessage;
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.NullResponseMessage;
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.PacketsConfirmedMessage;
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.Ping;
@@ -147,6 +82,71 @@ import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.SessionXAS
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.SubscribeClusterTopologyUpdatesMessage;
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.SubscribeClusterTopologyUpdatesMessageV2;
 
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CHECK_FOR_FAILOVER;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CLUSTER_TOPOLOGY;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CLUSTER_TOPOLOGY_V2;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CLUSTER_TOPOLOGY_V3;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CREATESESSION;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CREATESESSION_RESP;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CREATE_QUEUE;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.CREATE_SHARED_QUEUE;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.DELETE_QUEUE;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.DISCONNECT;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.DISCONNECT_CONSUMER;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.DISCONNECT_V2;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.EXCEPTION;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.NULL_RESPONSE;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.PACKETS_CONFIRMED;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.PING;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.REATTACH_SESSION;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.REATTACH_SESSION_RESP;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_ACKNOWLEDGE;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_ADD_METADATA;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_ADD_METADATA2;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_BINDINGQUERY;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_BINDINGQUERY_RESP;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_BINDINGQUERY_RESP_V2;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_BINDINGQUERY_RESP_V3;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_CLOSE;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_COMMIT;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_CONSUMER_CLOSE;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_CREATECONSUMER;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_EXPIRED;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_FLOWTOKEN;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_FORCE_CONSUMER_DELIVERY;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_INDIVIDUAL_ACKNOWLEDGE;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_PRODUCER_CREDITS;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_PRODUCER_FAIL_CREDITS;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_PRODUCER_REQUEST_CREDITS;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_QUEUEQUERY;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_QUEUEQUERY_RESP;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_QUEUEQUERY_RESP_V2;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_RECEIVE_CONTINUATION;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_ROLLBACK;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_SEND_CONTINUATION;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_START;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_STOP;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_UNIQUE_ADD_METADATA;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_COMMIT;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_END;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_FAILED;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_FORGET;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_GET_TIMEOUT;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_GET_TIMEOUT_RESP;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_INDOUBT_XIDS;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_INDOUBT_XIDS_RESP;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_JOIN;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_PREPARE;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_RESP;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_RESUME;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_ROLLBACK;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_SET_TIMEOUT;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_SET_TIMEOUT_RESP;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_START;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SESS_XA_SUSPEND;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SUBSCRIBE_TOPOLOGY;
+import static org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl.SUBSCRIBE_TOPOLOGY_V2;
+
 public abstract class PacketDecoder implements Serializable {
 
    public abstract Packet decode(final ActiveMQBuffer in);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/RemotingConnectionImpl.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/RemotingConnectionImpl.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/RemotingConnectionImpl.java
index 2a3522f..8bd62ca 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/RemotingConnectionImpl.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/RemotingConnectionImpl.java
@@ -43,6 +43,7 @@ import org.apache.activemq.artemis.utils.SimpleIDGenerator;
 import org.jboss.logging.Logger;
 
 public class RemotingConnectionImpl extends AbstractRemotingConnection implements CoreRemotingConnection {
+
    private static final Logger logger = Logger.getLogger(RemotingConnectionImpl.class);
 
    private final PacketDecoder packetDecoder;
@@ -198,8 +199,7 @@ public class RemotingConnectionImpl extends AbstractRemotingConnection implement
 
       try {
          transportConnection.forceClose();
-      }
-      catch (Throwable e) {
+      } catch (Throwable e) {
          ActiveMQClientLogger.LOGGER.warn(e.getMessage(), e);
       }
 
@@ -247,8 +247,7 @@ public class RemotingConnectionImpl extends AbstractRemotingConnection implement
 
       if (!criticalError) {
          removeAllChannels();
-      }
-      else {
+      } else {
          // We can't hold a lock if a critical error is happening...
          // as other threads will be holding the lock while hanging on IO
          channels.clear();
@@ -265,8 +264,7 @@ public class RemotingConnectionImpl extends AbstractRemotingConnection implement
 
       if (channel0.supports(PacketImpl.DISCONNECT_V2)) {
          disconnect = new DisconnectMessage_V2(nodeID, scaleDownNodeID);
-      }
-      else {
+      } else {
          disconnect = new DisconnectMessage(nodeID);
       }
       channel0.sendAndFlush(disconnect);
@@ -358,8 +356,7 @@ public class RemotingConnectionImpl extends AbstractRemotingConnection implement
          doBufferReceived(packet);
 
          super.bufferReceived(connectionID, buffer);
-      }
-      catch (Exception e) {
+      } catch (Exception e) {
          ActiveMQClientLogger.LOGGER.errorDecodingPacket(e);
       }
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ActiveMQExceptionMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ActiveMQExceptionMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ActiveMQExceptionMessage.java
index f99b465..da34d2e 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ActiveMQExceptionMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ActiveMQExceptionMessage.java
@@ -93,8 +93,7 @@ public class ActiveMQExceptionMessage extends PacketImpl {
          if (other.exception != null) {
             return false;
          }
-      }
-      else if (!exception.equals(other.exception)) {
+      } else if (!exception.equals(other.exception)) {
          return false;
       }
       return true;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage.java
index b799f6e..a441eee 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage.java
@@ -94,15 +94,13 @@ public class ClusterTopologyChangeMessage extends PacketImpl {
          if (pair.getA() != null) {
             buffer.writeBoolean(true);
             pair.getA().encode(buffer);
-         }
-         else {
+         } else {
             buffer.writeBoolean(false);
          }
          if (pair.getB() != null) {
             buffer.writeBoolean(true);
             pair.getB().encode(buffer);
-         }
-         else {
+         } else {
             buffer.writeBoolean(false);
          }
          buffer.writeBoolean(last);
@@ -119,8 +117,7 @@ public class ClusterTopologyChangeMessage extends PacketImpl {
          if (hasLive) {
             a = new TransportConfiguration();
             a.decode(buffer);
-         }
-         else {
+         } else {
             a = null;
          }
          boolean hasBackup = buffer.readBoolean();
@@ -128,8 +125,7 @@ public class ClusterTopologyChangeMessage extends PacketImpl {
          if (hasBackup) {
             b = new TransportConfiguration();
             b.decode(buffer);
-         }
-         else {
+         } else {
             b = null;
          }
          pair = new Pair<>(a, b);
@@ -181,16 +177,14 @@ public class ClusterTopologyChangeMessage extends PacketImpl {
          if (other.nodeID != null) {
             return false;
          }
-      }
-      else if (!nodeID.equals(other.nodeID)) {
+      } else if (!nodeID.equals(other.nodeID)) {
          return false;
       }
       if (pair == null) {
          if (other.pair != null) {
             return false;
          }
-      }
-      else if (!pair.equals(other.pair)) {
+      } else if (!pair.equals(other.pair)) {
          return false;
       }
       return true;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage_V2.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage_V2.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage_V2.java
index 7e0450a..3a38145 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage_V2.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage_V2.java
@@ -86,15 +86,13 @@ public class ClusterTopologyChangeMessage_V2 extends ClusterTopologyChangeMessag
          if (pair.getA() != null) {
             buffer.writeBoolean(true);
             pair.getA().encode(buffer);
-         }
-         else {
+         } else {
             buffer.writeBoolean(false);
          }
          if (pair.getB() != null) {
             buffer.writeBoolean(true);
             pair.getB().encode(buffer);
-         }
-         else {
+         } else {
             buffer.writeBoolean(false);
          }
          buffer.writeBoolean(last);
@@ -113,8 +111,7 @@ public class ClusterTopologyChangeMessage_V2 extends ClusterTopologyChangeMessag
          if (hasLive) {
             a = new TransportConfiguration();
             a.decode(buffer);
-         }
-         else {
+         } else {
             a = null;
          }
          boolean hasBackup = buffer.readBoolean();
@@ -122,8 +119,7 @@ public class ClusterTopologyChangeMessage_V2 extends ClusterTopologyChangeMessag
          if (hasBackup) {
             b = new TransportConfiguration();
             b.decode(buffer);
-         }
-         else {
+         } else {
             b = null;
          }
          pair = new Pair<>(a, b);
@@ -175,8 +171,7 @@ public class ClusterTopologyChangeMessage_V2 extends ClusterTopologyChangeMessag
          if (other.backupGroupName != null) {
             return false;
          }
-      }
-      else if (!backupGroupName.equals(other.backupGroupName)) {
+      } else if (!backupGroupName.equals(other.backupGroupName)) {
          return false;
       }
       return true;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage_V3.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage_V3.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage_V3.java
index d5ade55..d371eb5 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage_V3.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ClusterTopologyChangeMessage_V3.java
@@ -105,8 +105,7 @@ public class ClusterTopologyChangeMessage_V3 extends ClusterTopologyChangeMessag
          if (other.scaleDownGroupName != null) {
             return false;
          }
-      }
-      else if (!scaleDownGroupName.equals(other.scaleDownGroupName)) {
+      } else if (!scaleDownGroupName.equals(other.scaleDownGroupName)) {
          return false;
       }
       return true;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateQueueMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateQueueMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateQueueMessage.java
index 5f65fbe..e837d55 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateQueueMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateQueueMessage.java
@@ -157,22 +157,19 @@ public class CreateQueueMessage extends PacketImpl {
       if (address == null) {
          if (other.address != null)
             return false;
-      }
-      else if (!address.equals(other.address))
+      } else if (!address.equals(other.address))
          return false;
       if (durable != other.durable)
          return false;
       if (filterString == null) {
          if (other.filterString != null)
             return false;
-      }
-      else if (!filterString.equals(other.filterString))
+      } else if (!filterString.equals(other.filterString))
          return false;
       if (queueName == null) {
          if (other.queueName != null)
             return false;
-      }
-      else if (!queueName.equals(other.queueName))
+      } else if (!queueName.equals(other.queueName))
          return false;
       if (requiresResponse != other.requiresResponse)
          return false;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateSessionMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateSessionMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateSessionMessage.java
index 57bae7c..949645b 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateSessionMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateSessionMessage.java
@@ -229,22 +229,19 @@ public class CreateSessionMessage extends PacketImpl {
       if (defaultAddress == null) {
          if (other.defaultAddress != null)
             return false;
-      }
-      else if (!defaultAddress.equals(other.defaultAddress))
+      } else if (!defaultAddress.equals(other.defaultAddress))
          return false;
       if (minLargeMessageSize != other.minLargeMessageSize)
          return false;
       if (name == null) {
          if (other.name != null)
             return false;
-      }
-      else if (!name.equals(other.name))
+      } else if (!name.equals(other.name))
          return false;
       if (password == null) {
          if (other.password != null)
             return false;
-      }
-      else if (!password.equals(other.password))
+      } else if (!password.equals(other.password))
          return false;
       if (preAcknowledge != other.preAcknowledge)
          return false;
@@ -253,8 +250,7 @@ public class CreateSessionMessage extends PacketImpl {
       if (username == null) {
          if (other.username != null)
             return false;
-      }
-      else if (!username.equals(other.username))
+      } else if (!username.equals(other.username))
          return false;
       if (version != other.version)
          return false;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateSharedQueueMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateSharedQueueMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateSharedQueueMessage.java
index 9911490..f896102 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateSharedQueueMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/CreateSharedQueueMessage.java
@@ -138,20 +138,17 @@ public class CreateSharedQueueMessage extends PacketImpl {
       if (address == null) {
          if (other.address != null)
             return false;
-      }
-      else if (!address.equals(other.address))
+      } else if (!address.equals(other.address))
          return false;
       if (filterString == null) {
          if (other.filterString != null)
             return false;
-      }
-      else if (!filterString.equals(other.filterString))
+      } else if (!filterString.equals(other.filterString))
          return false;
       if (queueName == null) {
          if (other.queueName != null)
             return false;
-      }
-      else if (!queueName.equals(other.queueName))
+      } else if (!queueName.equals(other.queueName))
          return false;
       if (durable != other.durable)
          return false;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectConsumerWithKillMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectConsumerWithKillMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectConsumerWithKillMessage.java
index ce55bbd..3663172 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectConsumerWithKillMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectConsumerWithKillMessage.java
@@ -24,7 +24,7 @@ public class DisconnectConsumerWithKillMessage extends PacketImpl {
 
    private SimpleString nodeID;
 
-   public  static final int VERSION_INTRODUCED = 128;
+   public static final int VERSION_INTRODUCED = 128;
 
    public DisconnectConsumerWithKillMessage(final SimpleString nodeID) {
       super(DISCONNECT_CONSUMER_KILL);

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectMessage.java
index 13fdc08..eb5f7cc 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectMessage.java
@@ -98,8 +98,7 @@ public class DisconnectMessage extends PacketImpl {
          if (other.nodeID != null) {
             return false;
          }
-      }
-      else if (!nodeID.equals(other.nodeID)) {
+      } else if (!nodeID.equals(other.nodeID)) {
          return false;
       }
       return true;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectMessage_V2.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectMessage_V2.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectMessage_V2.java
index 8d50ed1..806c913 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectMessage_V2.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/DisconnectMessage_V2.java
@@ -86,8 +86,7 @@ public class DisconnectMessage_V2 extends DisconnectMessage {
          if (other.scaleDownNodeID != null) {
             return false;
          }
-      }
-      else if (!scaleDownNodeID.equals(other.scaleDownNodeID)) {
+      } else if (!scaleDownNodeID.equals(other.scaleDownNodeID)) {
          return false;
       }
       return true;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/MessagePacket.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/MessagePacket.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/MessagePacket.java
index 72f3602..6a52a27 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/MessagePacket.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/MessagePacket.java
@@ -40,5 +40,4 @@ public abstract class MessagePacket extends PacketImpl implements MessagePacketI
       return super.getParentString() + ", message=" + message;
    }
 
-
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/MessagePacketI.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/MessagePacketI.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/MessagePacketI.java
index ea1146f..161274d 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/MessagePacketI.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/MessagePacketI.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,
@@ -20,5 +20,6 @@ package org.apache.activemq.artemis.core.protocol.core.impl.wireformat;
 import org.apache.activemq.artemis.api.core.Message;
 
 public interface MessagePacketI {
+
    Message getMessage();
 }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ReattachSessionMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ReattachSessionMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ReattachSessionMessage.java
index 406347b..c062771 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ReattachSessionMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/ReattachSessionMessage.java
@@ -94,8 +94,7 @@ public class ReattachSessionMessage extends PacketImpl {
       if (name == null) {
          if (other.name != null)
             return false;
-      }
-      else if (!name.equals(other.name))
+      } else if (!name.equals(other.name))
          return false;
       return true;
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionAddMetaDataMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionAddMetaDataMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionAddMetaDataMessage.java
index 76a28f8..1b3faed 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionAddMetaDataMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionAddMetaDataMessage.java
@@ -94,14 +94,12 @@ public class SessionAddMetaDataMessage extends PacketImpl {
       if (data == null) {
          if (other.data != null)
             return false;
-      }
-      else if (!data.equals(other.data))
+      } else if (!data.equals(other.data))
          return false;
       if (key == null) {
          if (other.key != null)
             return false;
-      }
-      else if (!key.equals(other.key))
+      } else if (!key.equals(other.key))
          return false;
       return true;
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionAddMetaDataMessageV2.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionAddMetaDataMessageV2.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionAddMetaDataMessageV2.java
index eb16eda..5882fdc 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionAddMetaDataMessageV2.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionAddMetaDataMessageV2.java
@@ -119,14 +119,12 @@ public class SessionAddMetaDataMessageV2 extends PacketImpl {
       if (data == null) {
          if (other.data != null)
             return false;
-      }
-      else if (!data.equals(other.data))
+      } else if (!data.equals(other.data))
          return false;
       if (key == null) {
          if (other.key != null)
             return false;
-      }
-      else if (!key.equals(other.key))
+      } else if (!key.equals(other.key))
          return false;
       if (requiresConfirmation != other.requiresConfirmation)
          return false;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionBindingQueryMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionBindingQueryMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionBindingQueryMessage.java
index 6a901ae..0bb06e2 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionBindingQueryMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionBindingQueryMessage.java
@@ -76,8 +76,7 @@ public class SessionBindingQueryMessage extends PacketImpl {
       if (address == null) {
          if (other.address != null)
             return false;
-      }
-      else if (!address.equals(other.address))
+      } else if (!address.equals(other.address))
          return false;
       return true;
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionBindingQueryResponseMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionBindingQueryResponseMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionBindingQueryResponseMessage.java
index 410dac1..4cccfdc 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionBindingQueryResponseMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionBindingQueryResponseMessage.java
@@ -112,8 +112,7 @@ public class SessionBindingQueryResponseMessage extends PacketImpl {
       if (queueNames == null) {
          if (other.queueNames != null)
             return false;
-      }
-      else if (!queueNames.equals(other.queueNames))
+      } else if (!queueNames.equals(other.queueNames))
          return false;
       return true;
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionContinuationMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionContinuationMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionContinuationMessage.java
index 135aac5..fcdd943 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionContinuationMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionContinuationMessage.java
@@ -49,8 +49,7 @@ public abstract class SessionContinuationMessage extends PacketImpl {
    public byte[] getBody() {
       if (size <= 0) {
          return new byte[0];
-      }
-      else {
+      } else {
          return body;
       }
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionCreateConsumerMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionCreateConsumerMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionCreateConsumerMessage.java
index 42ff65a..afff162 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionCreateConsumerMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionCreateConsumerMessage.java
@@ -138,16 +138,14 @@ public class SessionCreateConsumerMessage extends PacketImpl {
       if (filterString == null) {
          if (other.filterString != null)
             return false;
-      }
-      else if (!filterString.equals(other.filterString))
+      } else if (!filterString.equals(other.filterString))
          return false;
       if (id != other.id)
          return false;
       if (queueName == null) {
          if (other.queueName != null)
             return false;
-      }
-      else if (!queueName.equals(other.queueName))
+      } else if (!queueName.equals(other.queueName))
          return false;
       if (requiresResponse != other.requiresResponse)
          return false;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionDeleteQueueMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionDeleteQueueMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionDeleteQueueMessage.java
index def97d8..4934459 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionDeleteQueueMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionDeleteQueueMessage.java
@@ -76,8 +76,7 @@ public class SessionDeleteQueueMessage extends PacketImpl {
       if (queueName == null) {
          if (other.queueName != null)
             return false;
-      }
-      else if (!queueName.equals(other.queueName))
+      } else if (!queueName.equals(other.queueName))
          return false;
       return true;
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionProducerCreditsFailMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionProducerCreditsFailMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionProducerCreditsFailMessage.java
index 6c194b8..6825923 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionProducerCreditsFailMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionProducerCreditsFailMessage.java
@@ -88,8 +88,7 @@ public class SessionProducerCreditsFailMessage extends PacketImpl {
       if (address == null) {
          if (other.address != null)
             return false;
-      }
-      else if (!address.equals(other.address))
+      } else if (!address.equals(other.address))
          return false;
       if (credits != other.credits)
          return false;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionProducerCreditsMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionProducerCreditsMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionProducerCreditsMessage.java
index d672b0e..d057ad1 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionProducerCreditsMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionProducerCreditsMessage.java
@@ -88,8 +88,7 @@ public class SessionProducerCreditsMessage extends PacketImpl {
       if (address == null) {
          if (other.address != null)
             return false;
-      }
-      else if (!address.equals(other.address))
+      } else if (!address.equals(other.address))
          return false;
       if (credits != other.credits)
          return false;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionQueueQueryMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionQueueQueryMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionQueueQueryMessage.java
index 98ae946..172f29f 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionQueueQueryMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionQueueQueryMessage.java
@@ -76,8 +76,7 @@ public class SessionQueueQueryMessage extends PacketImpl {
       if (queueName == null) {
          if (other.queueName != null)
             return false;
-      }
-      else if (!queueName.equals(other.queueName))
+      } else if (!queueName.equals(other.queueName))
          return false;
       return true;
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionQueueQueryResponseMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionQueueQueryResponseMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionQueueQueryResponseMessage.java
index e66b4eb..b8313b2 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionQueueQueryResponseMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionQueueQueryResponseMessage.java
@@ -187,8 +187,7 @@ public class SessionQueueQueryResponseMessage extends PacketImpl {
       if (address == null) {
          if (other.address != null)
             return false;
-      }
-      else if (!address.equals(other.address))
+      } else if (!address.equals(other.address))
          return false;
       if (consumerCount != other.consumerCount)
          return false;
@@ -199,16 +198,14 @@ public class SessionQueueQueryResponseMessage extends PacketImpl {
       if (filterString == null) {
          if (other.filterString != null)
             return false;
-      }
-      else if (!filterString.equals(other.filterString))
+      } else if (!filterString.equals(other.filterString))
          return false;
       if (messageCount != other.messageCount)
          return false;
       if (name == null) {
          if (other.name != null)
             return false;
-      }
-      else if (!name.equals(other.name))
+      } else if (!name.equals(other.name))
          return false;
       if (temporary != other.temporary)
          return false;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionReceiveContinuationMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionReceiveContinuationMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionReceiveContinuationMessage.java
index 6748201..9141ae1 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionReceiveContinuationMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionReceiveContinuationMessage.java
@@ -80,8 +80,7 @@ public class SessionReceiveContinuationMessage extends SessionContinuationMessag
       if (size == -1) {
          // This packet was created by the LargeMessageController
          return 0;
-      }
-      else {
+      } else {
          return size;
       }
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionReceiveLargeMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionReceiveLargeMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionReceiveLargeMessage.java
index 06805f0..64f96f9 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionReceiveLargeMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionReceiveLargeMessage.java
@@ -137,8 +137,7 @@ public class SessionReceiveLargeMessage extends PacketImpl implements MessagePac
       if (message == null) {
          if (other.message != null)
             return false;
-      }
-      else if (!message.equals(other.message))
+      } else if (!message.equals(other.message))
          return false;
       return true;
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionRequestProducerCreditsMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionRequestProducerCreditsMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionRequestProducerCreditsMessage.java
index 1627dfd..fc495fe 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionRequestProducerCreditsMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionRequestProducerCreditsMessage.java
@@ -95,8 +95,7 @@ public class SessionRequestProducerCreditsMessage extends PacketImpl {
       if (address == null) {
          if (other.address != null)
             return false;
-      }
-      else if (!address.equals(other.address))
+      } else if (!address.equals(other.address))
          return false;
       if (credits != other.credits)
          return false;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendContinuationMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendContinuationMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendContinuationMessage.java
index dc7e1f0..16fd073 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendContinuationMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendContinuationMessage.java
@@ -145,8 +145,7 @@ public class SessionSendContinuationMessage extends SessionContinuationMessage {
       if (message == null) {
          if (other.message != null)
             return false;
-      }
-      else if (!message.equals(other.message))
+      } else if (!message.equals(other.message))
          return false;
       if (messageBodySize != other.messageBodySize)
          return false;

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendLargeMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendLargeMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendLargeMessage.java
index 9154a7d..bf4290b 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendLargeMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendLargeMessage.java
@@ -87,8 +87,7 @@ public class SessionSendLargeMessage extends PacketImpl implements MessagePacket
       if (largeMessage == null) {
          if (other.largeMessage != null)
             return false;
-      }
-      else if (!largeMessage.equals(other.largeMessage))
+      } else if (!largeMessage.equals(other.largeMessage))
          return false;
       return true;
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendMessage.java
index 4674ce0..91d43a5 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionSendMessage.java
@@ -67,8 +67,7 @@ public class SessionSendMessage extends MessagePacket {
       if (connection == null) {
          // this is for unit tests only
          bufferWrite = buffer.copy(0, buffer.capacity());
-      }
-      else {
+      } else {
          bufferWrite = connection.createTransportBuffer(buffer.writerIndex() + 1); // 1 for the requireResponse
       }
       bufferWrite.writeBytes(buffer, 0, buffer.writerIndex());

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXAAfterFailedMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXAAfterFailedMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXAAfterFailedMessage.java
index 1727e42..32f23a9 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXAAfterFailedMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXAAfterFailedMessage.java
@@ -90,8 +90,7 @@ public class SessionXAAfterFailedMessage extends PacketImpl {
       if (xid == null) {
          if (other.xid != null)
             return false;
-      }
-      else if (!xid.equals(other.xid))
+      } else if (!xid.equals(other.xid))
          return false;
       return true;
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXACommitMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXACommitMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXACommitMessage.java
index 1e1ad76..29f7a3b 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXACommitMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXACommitMessage.java
@@ -87,8 +87,7 @@ public class SessionXACommitMessage extends PacketImpl {
       if (xid == null) {
          if (other.xid != null)
             return false;
-      }
-      else if (!xid.equals(other.xid))
+      } else if (!xid.equals(other.xid))
          return false;
       return true;
    }

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/ec48f9ed/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXAEndMessage.java
----------------------------------------------------------------------
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXAEndMessage.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXAEndMessage.java
index 5e99eb9..991a1f9 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXAEndMessage.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/protocol/core/impl/wireformat/SessionXAEndMessage.java
@@ -88,8 +88,7 @@ public class SessionXAEndMessage extends PacketImpl {
       if (xid == null) {
          if (other.xid != null)
             return false;
-      }
-      else if (!xid.equals(other.xid))
+      } else if (!xid.equals(other.xid))
          return false;
       return true;
    }