You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@nifi.apache.org by jo...@apache.org on 2015/04/22 17:46:52 UTC

[09/11] incubator-nifi git commit: NIFI-271 checkpoint

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/NodeProtocolSenderImpl.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/NodeProtocolSenderImpl.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/NodeProtocolSenderImpl.java
index dc86d24..993dea5 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/NodeProtocolSenderImpl.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/NodeProtocolSenderImpl.java
@@ -41,38 +41,38 @@ import org.apache.nifi.io.socket.SocketUtils;
 import org.apache.nifi.io.socket.multicast.DiscoverableService;
 
 public class NodeProtocolSenderImpl implements NodeProtocolSender {
+
     private final SocketConfiguration socketConfiguration;
     private final ClusterServiceLocator clusterManagerProtocolServiceLocator;
     private final ProtocolContext<ProtocolMessage> protocolContext;
-    
-    public NodeProtocolSenderImpl(final ClusterServiceLocator clusterManagerProtocolServiceLocator, 
+
+    public NodeProtocolSenderImpl(final ClusterServiceLocator clusterManagerProtocolServiceLocator,
             final SocketConfiguration socketConfiguration, final ProtocolContext<ProtocolMessage> protocolContext) {
-        if(clusterManagerProtocolServiceLocator == null) {
+        if (clusterManagerProtocolServiceLocator == null) {
             throw new IllegalArgumentException("Protocol Service Locator may not be null.");
-        } else if(socketConfiguration == null) {
+        } else if (socketConfiguration == null) {
             throw new IllegalArgumentException("Socket configuration may not be null.");
-        } else if(protocolContext == null) {
+        } else if (protocolContext == null) {
             throw new IllegalArgumentException("Protocol Context may not be null.");
         }
-        
+
         this.clusterManagerProtocolServiceLocator = clusterManagerProtocolServiceLocator;
         this.socketConfiguration = socketConfiguration;
         this.protocolContext = protocolContext;
     }
-    
-    
+
     @Override
     public ConnectionResponseMessage requestConnection(final ConnectionRequestMessage msg) throws ProtocolException, UnknownServiceAddressException {
         Socket socket = null;
         try {
             socket = createSocket();
-            
+
             String ncmDn = null;
-            if ( socket instanceof SSLSocket ) {
+            if (socket instanceof SSLSocket) {
                 final SSLSocket sslSocket = (SSLSocket) socket;
                 try {
                     final X509Certificate[] certChains = sslSocket.getSession().getPeerCertificateChain();
-                    if ( certChains != null && certChains.length > 0 ) {
+                    if (certChains != null && certChains.length > 0) {
                         ncmDn = certChains[0].getSubjectDN().getName();
                     }
                 } catch (final ProtocolException pe) {
@@ -81,25 +81,25 @@ public class NodeProtocolSenderImpl implements NodeProtocolSender {
                     throw new ProtocolException(e);
                 }
             }
-            
+
             try {
                 // marshal message to output stream
                 final ProtocolMessageMarshaller<ProtocolMessage> marshaller = protocolContext.createMarshaller();
                 marshaller.marshal(msg, socket.getOutputStream());
-            } catch(final IOException ioe) {
+            } catch (final IOException ioe) {
                 throw new ProtocolException("Failed marshalling '" + msg.getType() + "' protocol message due to: " + ioe, ioe);
-            } 
-            
+            }
+
             final ProtocolMessage response;
             try {
                 // unmarshall response and return
                 final ProtocolMessageUnmarshaller<ProtocolMessage> unmarshaller = protocolContext.createUnmarshaller();
                 response = unmarshaller.unmarshal(socket.getInputStream());
-            } catch(final IOException ioe) {
+            } catch (final IOException ioe) {
                 throw new ProtocolException("Failed unmarshalling '" + MessageType.CONNECTION_RESPONSE + "' protocol message due to: " + ioe, ioe);
-            } 
-            
-            if(MessageType.CONNECTION_RESPONSE == response.getType()) {
+            }
+
+            if (MessageType.CONNECTION_RESPONSE == response.getType()) {
                 final ConnectionResponseMessage connectionResponse = (ConnectionResponseMessage) response;
                 connectionResponse.setClusterManagerDN(ncmDn);
                 return connectionResponse;
@@ -110,8 +110,7 @@ public class NodeProtocolSenderImpl implements NodeProtocolSender {
             SocketUtils.closeQuietly(socket);
         }
     }
-    
-    
+
     @Override
     public void heartbeat(final HeartbeatMessage msg) throws ProtocolException, UnknownServiceAddressException {
         sendProtocolMessage(msg);
@@ -131,22 +130,22 @@ public class NodeProtocolSenderImpl implements NodeProtocolSender {
     public void notifyReconnectionFailure(ReconnectionFailureMessage msg) throws ProtocolException, UnknownServiceAddressException {
         sendProtocolMessage(msg);
     }
-    
+
     private Socket createSocket() {
         // determine the cluster manager's address
-        final DiscoverableService service = clusterManagerProtocolServiceLocator.getService(); 
-        if(service == null) {
+        final DiscoverableService service = clusterManagerProtocolServiceLocator.getService();
+        if (service == null) {
             throw new UnknownServiceAddressException("Cluster Manager's service is not known.  Verify a cluster manager is running.");
         }
-        
+
         try {
             // create a socket
-            return SocketUtils.createSocket(service.getServiceAddress(), socketConfiguration); 
-        } catch(final IOException ioe) {
+            return SocketUtils.createSocket(service.getServiceAddress(), socketConfiguration);
+        } catch (final IOException ioe) {
             throw new ProtocolException("Failed to create socket due to: " + ioe, ioe);
         }
     }
-    
+
     private void sendProtocolMessage(final ProtocolMessage msg) {
         Socket socket = null;
         try {
@@ -156,16 +155,16 @@ public class NodeProtocolSenderImpl implements NodeProtocolSender {
                 // marshal message to output stream
                 final ProtocolMessageMarshaller<ProtocolMessage> marshaller = protocolContext.createMarshaller();
                 marshaller.marshal(msg, socket.getOutputStream());
-            } catch(final IOException ioe) {
+            } catch (final IOException ioe) {
                 throw new ProtocolException("Failed marshalling '" + msg.getType() + "' protocol message due to: " + ioe, ioe);
             }
         } finally {
             SocketUtils.closeQuietly(socket);
         }
     }
-    
+
     public SocketConfiguration getSocketConfiguration() {
         return socketConfiguration;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/NodeProtocolSenderListener.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/NodeProtocolSenderListener.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/NodeProtocolSenderListener.java
index 4b359f4..2992e38 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/NodeProtocolSenderListener.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/NodeProtocolSenderListener.java
@@ -33,14 +33,14 @@ import org.apache.nifi.cluster.protocol.message.ReconnectionFailureMessage;
 import org.apache.nifi.reporting.BulletinRepository;
 
 public class NodeProtocolSenderListener implements NodeProtocolSender, ProtocolListener {
-    
+
     private final NodeProtocolSender sender;
     private final ProtocolListener listener;
-    
+
     public NodeProtocolSenderListener(final NodeProtocolSender sender, final ProtocolListener listener) {
-        if(sender == null) {
+        if (sender == null) {
             throw new IllegalArgumentException("NodeProtocolSender may not be null.");
-        } else if(listener == null) {
+        } else if (listener == null) {
             throw new IllegalArgumentException("ProtocolListener may not be null.");
         }
         this.sender = sender;
@@ -49,7 +49,7 @@ public class NodeProtocolSenderListener implements NodeProtocolSender, ProtocolL
 
     @Override
     public void stop() throws IOException {
-        if(!isRunning()) {
+        if (!isRunning()) {
             throw new IllegalStateException("Instance is already stopped.");
         }
         listener.stop();
@@ -57,7 +57,7 @@ public class NodeProtocolSenderListener implements NodeProtocolSender, ProtocolL
 
     @Override
     public void start() throws IOException {
-        if(isRunning()) {
+        if (isRunning()) {
             throw new IllegalStateException("Instance is already started.");
         }
         listener.start();
@@ -92,12 +92,12 @@ public class NodeProtocolSenderListener implements NodeProtocolSender, ProtocolL
     public ConnectionResponseMessage requestConnection(final ConnectionRequestMessage msg) throws ProtocolException, UnknownServiceAddressException {
         return sender.requestConnection(msg);
     }
-    
+
     @Override
     public void notifyControllerStartupFailure(final ControllerStartupFailureMessage msg) throws ProtocolException, UnknownServiceAddressException {
         sender.notifyControllerStartupFailure(msg);
     }
-    
+
     @Override
     public void notifyReconnectionFailure(final ReconnectionFailureMessage msg) throws ProtocolException, UnknownServiceAddressException {
         sender.notifyReconnectionFailure(msg);

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/SocketProtocolListener.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/SocketProtocolListener.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/SocketProtocolListener.java
index ca30d9b..172f459 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/SocketProtocolListener.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/impl/SocketProtocolListener.java
@@ -47,8 +47,8 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * Implements a listener for protocol messages sent over unicast socket. 
- * 
+ * Implements a listener for protocol messages sent over unicast socket.
+ *
  * @author unattributed
  */
 public class SocketProtocolListener extends SocketListener implements ProtocolListener {
@@ -57,7 +57,7 @@ public class SocketProtocolListener extends SocketListener implements ProtocolLi
     private final ProtocolContext<ProtocolMessage> protocolContext;
     private final Collection<ProtocolHandler> handlers = new CopyOnWriteArrayList<>();
     private volatile BulletinRepository bulletinRepository;
-    
+
     public SocketProtocolListener(
             final int numThreads,
             final int port,
@@ -65,11 +65,11 @@ public class SocketProtocolListener extends SocketListener implements ProtocolLi
             final ProtocolContext<ProtocolMessage> protocolContext) {
 
         super(numThreads, port, configuration);
-        
-        if(protocolContext == null) {
+
+        if (protocolContext == null) {
             throw new IllegalArgumentException("Protocol Context may not be null.");
         }
-        
+
         this.protocolContext = protocolContext;
     }
 
@@ -77,24 +77,24 @@ public class SocketProtocolListener extends SocketListener implements ProtocolLi
     public void setBulletinRepository(final BulletinRepository bulletinRepository) {
         this.bulletinRepository = bulletinRepository;
     }
-    
+
     @Override
     public void start() throws IOException {
 
-        if(super.isRunning()) {
+        if (super.isRunning()) {
             throw new IllegalStateException("Instance is already started.");
         }
-        
+
         super.start();
     }
 
     @Override
     public void stop() throws IOException {
 
-        if(super.isRunning() == false) {
+        if (super.isRunning() == false) {
             throw new IOException("Instance is already stopped.");
         }
-        
+
         super.stop();
 
     }
@@ -106,12 +106,12 @@ public class SocketProtocolListener extends SocketListener implements ProtocolLi
 
     @Override
     public void addHandler(final ProtocolHandler handler) {
-        if(handler == null) {
+        if (handler == null) {
             throw new NullPointerException("Protocol handler may not be null.");
         }
         handlers.add(handler);
     }
-    
+
     @Override
     public boolean removeHandler(final ProtocolHandler handler) {
         return handlers.remove(handler);
@@ -127,13 +127,13 @@ public class SocketProtocolListener extends SocketListener implements ProtocolLi
             hostname = socket.getInetAddress().getHostName();
             final String requestId = UUID.randomUUID().toString();
             logger.info("Received request {} from {}", requestId, hostname);
-            
+
             String requestorDn = null;
-            if ( socket instanceof SSLSocket ) {
+            if (socket instanceof SSLSocket) {
                 final SSLSocket sslSocket = (SSLSocket) socket;
                 try {
                     final X509Certificate[] certChains = sslSocket.getSession().getPeerCertificateChain();
-                    if ( certChains != null && certChains.length > 0 ) {
+                    if (certChains != null && certChains.length > 0) {
                         requestorDn = certChains[0].getSubjectDN().getName();
                     }
                 } catch (final ProtocolException pe) {
@@ -142,22 +142,22 @@ public class SocketProtocolListener extends SocketListener implements ProtocolLi
                     throw new ProtocolException(e);
                 }
             }
-            
+
             // unmarshall message
             final ProtocolMessageUnmarshaller<ProtocolMessage> unmarshaller = protocolContext.createUnmarshaller();
             final InputStream inStream = socket.getInputStream();
             final CopyingInputStream copyingInputStream = new CopyingInputStream(inStream, maxMsgBuffer); // don't copy more than 1 MB
             logger.debug("Request {} has a message length of {}", requestId, copyingInputStream.getNumberOfBytesCopied());
-            
+
             final ProtocolMessage request;
             try {
                 request = unmarshaller.unmarshal(copyingInputStream);
             } finally {
                 receivedMessage = copyingInputStream.getBytesRead();
             }
-            
+
             request.setRequestorDN(requestorDn);
-            
+
             // dispatch message to handler
             ProtocolHandler desiredHandler = null;
             for (final ProtocolHandler handler : getHandlers()) {
@@ -172,10 +172,10 @@ public class SocketProtocolListener extends SocketListener implements ProtocolLi
                 throw new ProtocolException("No handler assigned to handle message type: " + request.getType());
             } else {
                 final ProtocolMessage response = desiredHandler.handle(request);
-                if(response != null) {
+                if (response != null) {
                     try {
                         logger.debug("Sending response for request {}", requestId);
-                            
+
                         // marshal message to output stream
                         final ProtocolMessageMarshaller<ProtocolMessage> marshaller = protocolContext.createMarshaller();
                         marshaller.marshal(response, socket.getOutputStream());
@@ -184,19 +184,19 @@ public class SocketProtocolListener extends SocketListener implements ProtocolLi
                     }
                 }
             }
-            
+
             stopWatch.stop();
             logger.info("Finished processing request {} (type={}, length={} bytes) in {} millis", requestId, request.getType(), receivedMessage.length, stopWatch.getDuration(TimeUnit.MILLISECONDS));
         } catch (final IOException e) {
             logger.warn("Failed processing protocol message from " + hostname + " due to " + e, e);
-            
-            if ( bulletinRepository != null ) {
+
+            if (bulletinRepository != null) {
                 final Bulletin bulletin = BulletinFactory.createBulletin("Clustering", "WARNING", String.format("Failed to process protocol message from %s due to: %s", hostname, e.toString()));
                 bulletinRepository.addBulletin(bulletin);
             }
         } catch (final ProtocolException e) {
             logger.warn("Failed processing protocol message from " + hostname + " due to " + e, e);
-            if ( bulletinRepository != null ) {
+            if (bulletinRepository != null) {
                 final Bulletin bulletin = BulletinFactory.createBulletin("Clustering", "WARNING", String.format("Failed to process protocol message from %s due to: %s", hostname, e.toString()));
                 bulletinRepository.addBulletin(bulletin);
             }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/JaxbProtocolContext.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/JaxbProtocolContext.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/JaxbProtocolContext.java
index bc68630..4d44b4e 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/JaxbProtocolContext.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/JaxbProtocolContext.java
@@ -38,28 +38,27 @@ import org.apache.nifi.cluster.protocol.ProtocolMessageUnmarshaller;
 /**
  * Implements a context for communicating internally amongst the cluster using
  * JAXB.
- * 
+ *
  * @param <T> The type of protocol message.
  *
- * @author unattributed
  */
 public class JaxbProtocolContext<T> implements ProtocolContext {
 
     private static final int BUF_SIZE = (int) Math.pow(2, 10);  // 1k
-    
+
     /*
      * A sentinel is used to detect corrupted messages.  Relying on the integrity
-     * of the message size can cause memory issues if the value is corrupted 
+     * of the message size can cause memory issues if the value is corrupted
      * and equal to a number larger than the memory size.
      */
     private static final byte MESSAGE_PROTOCOL_START_SENTINEL = 0x5A;
-    
+
     private final JAXBContext jaxbCtx;
-    
+
     public JaxbProtocolContext(final JAXBContext jaxbCtx) {
         this.jaxbCtx = jaxbCtx;
     }
-    
+
     @Override
     public ProtocolMessageMarshaller<T> createMarshaller() {
         return new ProtocolMessageMarshaller<T>() {
@@ -78,7 +77,7 @@ public class JaxbProtocolContext<T> implements ProtocolContext {
 
                     // write message protocol sentinel
                     dos.write(MESSAGE_PROTOCOL_START_SENTINEL);
-                    
+
                     // write message size in bytes
                     dos.writeInt(msgBytes.size());
 
@@ -108,14 +107,14 @@ public class JaxbProtocolContext<T> implements ProtocolContext {
 
                     // check for the presence of the message protocol sentinel
                     final byte sentinel = (byte) dis.read();
-                    if ( sentinel == -1 ) {
+                    if (sentinel == -1) {
                         throw new EOFException();
                     }
 
-                    if(MESSAGE_PROTOCOL_START_SENTINEL != sentinel) {
+                    if (MESSAGE_PROTOCOL_START_SENTINEL != sentinel) {
                         throw new IOException("Failed reading protocol message due to malformed header");
                     }
-                    
+
                     // read the message size
                     final int msgBytesSize = dis.readInt();
 

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedConnectionRequest.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedConnectionRequest.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedConnectionRequest.java
index d9de24f..c81c7e0 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedConnectionRequest.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedConnectionRequest.java
@@ -23,10 +23,11 @@ import org.apache.nifi.cluster.protocol.NodeIdentifier;
  * @author unattributed
  */
 public class AdaptedConnectionRequest {
-    
+
     private NodeIdentifier nodeIdentifier;
-    
-    public AdaptedConnectionRequest() {}
+
+    public AdaptedConnectionRequest() {
+    }
 
     @XmlJavaTypeAdapter(NodeIdentifierAdapter.class)
     public NodeIdentifier getNodeIdentifier() {

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedConnectionResponse.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedConnectionResponse.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedConnectionResponse.java
index c7c783b..6c8b49d 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedConnectionResponse.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedConnectionResponse.java
@@ -25,7 +25,7 @@ import org.apache.nifi.cluster.protocol.StandardDataFlow;
  * @author unattributed
  */
 public class AdaptedConnectionResponse {
-    
+
     private StandardDataFlow dataFlow;
     private NodeIdentifier nodeIdentifier;
     private boolean blockedByFirewall;
@@ -34,8 +34,9 @@ public class AdaptedConnectionResponse {
     private Integer managerRemoteInputPort;
     private Boolean managerRemoteCommsSecure;
     private String instanceId;
-    
-    public AdaptedConnectionResponse() {}
+
+    public AdaptedConnectionResponse() {
+    }
 
     @XmlJavaTypeAdapter(DataFlowAdapter.class)
     public StandardDataFlow getDataFlow() {
@@ -82,27 +83,27 @@ public class AdaptedConnectionResponse {
     public boolean shouldTryLater() {
         return tryLaterSeconds > 0;
     }
-    
+
     public void setManagerRemoteInputPort(Integer managerRemoteInputPort) {
         this.managerRemoteInputPort = managerRemoteInputPort;
     }
-    
+
     public Integer getManagerRemoteInputPort() {
         return managerRemoteInputPort;
     }
-    
+
     public void setManagerRemoteCommsSecure(Boolean secure) {
         this.managerRemoteCommsSecure = secure;
     }
-    
+
     public Boolean isManagerRemoteCommsSecure() {
         return managerRemoteCommsSecure;
     }
-    
+
     public void setInstanceId(String instanceId) {
         this.instanceId = instanceId;
     }
-    
+
     public String getInstanceId() {
         return instanceId;
     }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedCounter.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedCounter.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedCounter.java
index 89d903b..72d716c 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedCounter.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedCounter.java
@@ -20,14 +20,15 @@ package org.apache.nifi.cluster.protocol.jaxb.message;
  * @author unattributed
  */
 public class AdaptedCounter {
-    
+
     private String groupName;
-    
+
     private String name;
-    
+
     private long value;
 
-    public AdaptedCounter() {}
+    public AdaptedCounter() {
+    }
 
     public String getGroupName() {
         return groupName;
@@ -52,5 +53,5 @@ public class AdaptedCounter {
     public void setValue(long value) {
         this.value = value;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedDataFlow.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedDataFlow.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedDataFlow.java
index bb97619..571d846 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedDataFlow.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedDataFlow.java
@@ -20,14 +20,15 @@ package org.apache.nifi.cluster.protocol.jaxb.message;
  * @author unattributed
  */
 public class AdaptedDataFlow {
-    
+
     private byte[] flow;
     private byte[] templates;
     private byte[] snippets;
-    
+
     private boolean autoStartProcessors;
-    
-    public AdaptedDataFlow() {}
+
+    public AdaptedDataFlow() {
+    }
 
     public byte[] getFlow() {
         return flow;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedHeartbeat.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedHeartbeat.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedHeartbeat.java
index 5b9d9b7..81714f5 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedHeartbeat.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedHeartbeat.java
@@ -23,13 +23,14 @@ import org.apache.nifi.cluster.protocol.NodeIdentifier;
  * @author unattributed
  */
 public class AdaptedHeartbeat {
-    
+
     private NodeIdentifier nodeIdentifier;
     private byte[] payload;
     private boolean primary;
     private boolean connected;
-    
-    public AdaptedHeartbeat() {}
+
+    public AdaptedHeartbeat() {
+    }
 
     @XmlJavaTypeAdapter(NodeIdentifierAdapter.class)
     public NodeIdentifier getNodeIdentifier() {
@@ -39,7 +40,7 @@ public class AdaptedHeartbeat {
     public void setNodeIdentifier(NodeIdentifier nodeIdentifier) {
         this.nodeIdentifier = nodeIdentifier;
     }
-    
+
     public boolean isPrimary() {
         return primary;
     }
@@ -51,11 +52,11 @@ public class AdaptedHeartbeat {
     public boolean isConnected() {
         return connected;
     }
-    
+
     public void setConnected(boolean connected) {
         this.connected = connected;
     }
-    
+
     public byte[] getPayload() {
         return payload;
     }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedNodeBulletins.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedNodeBulletins.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedNodeBulletins.java
index 98e2438..d9f3577 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedNodeBulletins.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedNodeBulletins.java
@@ -23,12 +23,13 @@ import org.apache.nifi.cluster.protocol.NodeIdentifier;
  * @author unattributed
  */
 public class AdaptedNodeBulletins {
-    
+
     private NodeIdentifier nodeIdentifier;
-    
+
     private byte[] payload;
-    
-    public AdaptedNodeBulletins() {}
+
+    public AdaptedNodeBulletins() {
+    }
 
     @XmlJavaTypeAdapter(NodeIdentifierAdapter.class)
     public NodeIdentifier getNodeIdentifier() {
@@ -38,7 +39,7 @@ public class AdaptedNodeBulletins {
     public void setNodeIdentifier(NodeIdentifier nodeIdentifier) {
         this.nodeIdentifier = nodeIdentifier;
     }
-    
+
     public byte[] getPayload() {
         return payload;
     }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedNodeIdentifier.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedNodeIdentifier.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedNodeIdentifier.java
index 8134ea3..8d0eddd 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedNodeIdentifier.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/AdaptedNodeIdentifier.java
@@ -20,18 +20,19 @@ package org.apache.nifi.cluster.protocol.jaxb.message;
  * @author unattributed
  */
 public class AdaptedNodeIdentifier {
-    
+
     private String id;
-    
+
     private String apiAddress;
 
-    private int apiPort;    
+    private int apiPort;
 
     private String socketAddress;
-    
+
     private int socketPort;
-    
-    public AdaptedNodeIdentifier() {}
+
+    public AdaptedNodeIdentifier() {
+    }
 
     public String getApiAddress() {
         return apiAddress;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ConnectionRequestAdapter.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ConnectionRequestAdapter.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ConnectionRequestAdapter.java
index 1f91cf1..37256a3 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ConnectionRequestAdapter.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ConnectionRequestAdapter.java
@@ -27,7 +27,7 @@ public class ConnectionRequestAdapter extends XmlAdapter<AdaptedConnectionReques
     @Override
     public AdaptedConnectionRequest marshal(final ConnectionRequest cr) {
         final AdaptedConnectionRequest aCr = new AdaptedConnectionRequest();
-        if(cr != null) {
+        if (cr != null) {
             aCr.setNodeIdentifier(cr.getProposedNodeIdentifier());
         }
         return aCr;
@@ -37,5 +37,5 @@ public class ConnectionRequestAdapter extends XmlAdapter<AdaptedConnectionReques
     public ConnectionRequest unmarshal(final AdaptedConnectionRequest aCr) {
         return new ConnectionRequest(aCr.getNodeIdentifier());
     }
- 
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ConnectionResponseAdapter.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ConnectionResponseAdapter.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ConnectionResponseAdapter.java
index 143bab0..633f81a 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ConnectionResponseAdapter.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ConnectionResponseAdapter.java
@@ -27,7 +27,7 @@ public class ConnectionResponseAdapter extends XmlAdapter<AdaptedConnectionRespo
     @Override
     public AdaptedConnectionResponse marshal(final ConnectionResponse cr) {
         final AdaptedConnectionResponse aCr = new AdaptedConnectionResponse();
-        if(cr != null) {
+        if (cr != null) {
             aCr.setDataFlow(cr.getDataFlow());
             aCr.setNodeIdentifier(cr.getNodeIdentifier());
             aCr.setTryLaterSeconds(cr.getTryLaterSeconds());
@@ -42,14 +42,14 @@ public class ConnectionResponseAdapter extends XmlAdapter<AdaptedConnectionRespo
 
     @Override
     public ConnectionResponse unmarshal(final AdaptedConnectionResponse aCr) {
-        if(aCr.shouldTryLater()) {
+        if (aCr.shouldTryLater()) {
             return new ConnectionResponse(aCr.getTryLaterSeconds());
-        } else if(aCr.isBlockedByFirewall()) {
+        } else if (aCr.isBlockedByFirewall()) {
             return ConnectionResponse.createBlockedByFirewallResponse();
         } else {
-            return new ConnectionResponse(aCr.getNodeIdentifier(), aCr.getDataFlow(), aCr.isPrimary(), 
-                aCr.getManagerRemoteInputPort(), aCr.isManagerRemoteCommsSecure(), aCr.getInstanceId());
+            return new ConnectionResponse(aCr.getNodeIdentifier(), aCr.getDataFlow(), aCr.isPrimary(),
+                    aCr.getManagerRemoteInputPort(), aCr.isManagerRemoteCommsSecure(), aCr.getInstanceId());
         }
     }
- 
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/DataFlowAdapter.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/DataFlowAdapter.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/DataFlowAdapter.java
index 8d9467f..dbc83b8 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/DataFlowAdapter.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/DataFlowAdapter.java
@@ -27,16 +27,16 @@ public class DataFlowAdapter extends XmlAdapter<AdaptedDataFlow, StandardDataFlo
 
     @Override
     public AdaptedDataFlow marshal(final StandardDataFlow df) {
-        
+
         final AdaptedDataFlow aDf = new AdaptedDataFlow();
-        
-        if(df != null) {
+
+        if (df != null) {
             aDf.setFlow(df.getFlow());
             aDf.setTemplates(df.getTemplates());
             aDf.setSnippets(df.getSnippets());
             aDf.setAutoStartProcessors(df.isAutoStartProcessors());
         }
-        
+
         return aDf;
     }
 
@@ -46,5 +46,5 @@ public class DataFlowAdapter extends XmlAdapter<AdaptedDataFlow, StandardDataFlo
         dataFlow.setAutoStartProcessors(aDf.isAutoStartProcessors());
         return dataFlow;
     }
- 
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/HeartbeatAdapter.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/HeartbeatAdapter.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/HeartbeatAdapter.java
index 0e073b6..989d827 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/HeartbeatAdapter.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/HeartbeatAdapter.java
@@ -26,23 +26,23 @@ public class HeartbeatAdapter extends XmlAdapter<AdaptedHeartbeat, Heartbeat> {
 
     @Override
     public AdaptedHeartbeat marshal(final Heartbeat hb) {
-        
+
         final AdaptedHeartbeat aHb = new AdaptedHeartbeat();
-        
-        if(hb != null) {
+
+        if (hb != null) {
             // set node identifier
             aHb.setNodeIdentifier(hb.getNodeIdentifier());
 
             // set payload
             aHb.setPayload(hb.getPayload());
-            
+
             // set leader flag
             aHb.setPrimary(hb.isPrimary());
-            
+
             // set connected flag
             aHb.setConnected(hb.isConnected());
         }
-        
+
         return aHb;
     }
 
@@ -50,5 +50,5 @@ public class HeartbeatAdapter extends XmlAdapter<AdaptedHeartbeat, Heartbeat> {
     public Heartbeat unmarshal(final AdaptedHeartbeat aHb) {
         return new Heartbeat(aHb.getNodeIdentifier(), aHb.isPrimary(), aHb.isConnected(), aHb.getPayload());
     }
- 
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/JaxbProtocolUtils.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/JaxbProtocolUtils.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/JaxbProtocolUtils.java
index c3a57f5..565882d 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/JaxbProtocolUtils.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/JaxbProtocolUtils.java
@@ -23,11 +23,11 @@ import javax.xml.bind.JAXBException;
  * @author unattributed
  */
 public final class JaxbProtocolUtils {
-    
+
     public static final String JAXB_CONTEXT_PATH = ObjectFactory.class.getPackage().getName();
 
     public static final JAXBContext JAXB_CONTEXT = initializeJaxbContext();
-    
+
     /**
      * Load the JAXBContext version.
      */
@@ -38,5 +38,5 @@ public final class JaxbProtocolUtils {
             throw new RuntimeException("Unable to create JAXBContext.", e);
         }
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/NodeBulletinsAdapter.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/NodeBulletinsAdapter.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/NodeBulletinsAdapter.java
index 1ae41f7..859d8b7 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/NodeBulletinsAdapter.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/NodeBulletinsAdapter.java
@@ -26,17 +26,17 @@ public class NodeBulletinsAdapter extends XmlAdapter<AdaptedNodeBulletins, NodeB
 
     @Override
     public AdaptedNodeBulletins marshal(final NodeBulletins hb) {
-        
+
         final AdaptedNodeBulletins adaptedBulletins = new AdaptedNodeBulletins();
-        
-        if(hb != null) {
+
+        if (hb != null) {
             // set node identifier
             adaptedBulletins.setNodeIdentifier(hb.getNodeIdentifier());
 
             // set payload
             adaptedBulletins.setPayload(hb.getPayload());
         }
-        
+
         return adaptedBulletins;
     }
 
@@ -44,5 +44,5 @@ public class NodeBulletinsAdapter extends XmlAdapter<AdaptedNodeBulletins, NodeB
     public NodeBulletins unmarshal(final AdaptedNodeBulletins adaptedBulletins) {
         return new NodeBulletins(adaptedBulletins.getNodeIdentifier(), adaptedBulletins.getPayload());
     }
- 
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/NodeIdentifierAdapter.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/NodeIdentifierAdapter.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/NodeIdentifierAdapter.java
index fe2d8a4..7594266 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/NodeIdentifierAdapter.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/NodeIdentifierAdapter.java
@@ -26,7 +26,7 @@ public class NodeIdentifierAdapter extends XmlAdapter<AdaptedNodeIdentifier, Nod
 
     @Override
     public AdaptedNodeIdentifier marshal(final NodeIdentifier ni) {
-        if(ni == null) {
+        if (ni == null) {
             return null;
         } else {
             final AdaptedNodeIdentifier aNi = new AdaptedNodeIdentifier();
@@ -41,11 +41,11 @@ public class NodeIdentifierAdapter extends XmlAdapter<AdaptedNodeIdentifier, Nod
 
     @Override
     public NodeIdentifier unmarshal(final AdaptedNodeIdentifier aNi) {
-        if(aNi == null) {
+        if (aNi == null) {
             return null;
         } else {
             return new NodeIdentifier(aNi.getId(), aNi.getApiAddress(), aNi.getApiPort(), aNi.getSocketAddress(), aNi.getSocketPort());
         }
     }
- 
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ObjectFactory.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ObjectFactory.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ObjectFactory.java
index 1613536..89956c1 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ObjectFactory.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/jaxb/message/ObjectFactory.java
@@ -39,65 +39,66 @@ import org.apache.nifi.cluster.protocol.message.ServiceBroadcastMessage;
  */
 @XmlRegistry
 public class ObjectFactory {
-    
-    public ObjectFactory() {}
-    
+
+    public ObjectFactory() {
+    }
+
     public ReconnectionRequestMessage createReconnectionRequestMessage() {
         return new ReconnectionRequestMessage();
     }
-    
+
     public ReconnectionFailureMessage createReconnectionFailureMessage() {
         return new ReconnectionFailureMessage();
     }
-    
+
     public ReconnectionResponseMessage createReconnectionResponseMessage() {
         return new ReconnectionResponseMessage();
     }
-    
+
     public DisconnectMessage createDisconnectionMessage() {
         return new DisconnectMessage();
     }
-    
+
     public ConnectionRequestMessage createConnectionRequestMessage() {
         return new ConnectionRequestMessage();
     }
-    
+
     public ConnectionResponseMessage createConnectionResponseMessage() {
         return new ConnectionResponseMessage();
     }
-    
+
     public ServiceBroadcastMessage createServiceBroadcastMessage() {
         return new ServiceBroadcastMessage();
     }
-    
+
     public HeartbeatMessage createHeartbeatMessage() {
         return new HeartbeatMessage();
     }
-    
+
     public FlowRequestMessage createFlowRequestMessage() {
         return new FlowRequestMessage();
     }
-    
+
     public FlowResponseMessage createFlowResponseMessage() {
         return new FlowResponseMessage();
     }
-    
+
     public PingMessage createPingMessage() {
         return new PingMessage();
     }
-    
+
     public MulticastProtocolMessage createMulticastProtocolMessage() {
         return new MulticastProtocolMessage();
     }
-    
+
     public ControllerStartupFailureMessage createControllerStartupFailureMessage() {
         return new ControllerStartupFailureMessage();
     }
-    
+
     public PrimaryRoleAssignmentMessage createPrimaryRoleAssignmentMessage() {
         return new PrimaryRoleAssignmentMessage();
     }
-    
+
     public NodeBulletinsMessage createBulletinsMessage() {
         return new NodeBulletinsMessage();
     }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ConnectionRequestMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ConnectionRequestMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ConnectionRequestMessage.java
index 344de4e..09c03f1 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ConnectionRequestMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ConnectionRequestMessage.java
@@ -25,11 +25,12 @@ import org.apache.nifi.cluster.protocol.ConnectionRequest;
  */
 @XmlRootElement(name = "connectionRequestMessage")
 public class ConnectionRequestMessage extends ProtocolMessage {
-    
+
     private ConnectionRequest connectionRequest;
-    
-    public ConnectionRequestMessage() {}
-    
+
+    public ConnectionRequestMessage() {
+    }
+
     public ConnectionRequest getConnectionRequest() {
         return connectionRequest;
     }
@@ -37,7 +38,7 @@ public class ConnectionRequestMessage extends ProtocolMessage {
     public void setConnectionRequest(ConnectionRequest connectionRequest) {
         this.connectionRequest = connectionRequest;
     }
-    
+
     @Override
     public MessageType getType() {
         return MessageType.CONNECTION_REQUEST;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ConnectionResponseMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ConnectionResponseMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ConnectionResponseMessage.java
index a262d7a..0f72dd6 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ConnectionResponseMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ConnectionResponseMessage.java
@@ -19,16 +19,14 @@ package org.apache.nifi.cluster.protocol.message;
 import javax.xml.bind.annotation.XmlRootElement;
 import org.apache.nifi.cluster.protocol.ConnectionResponse;
 
-/**
- * @author unattributed
- */
 @XmlRootElement(name = "connectionResponseMessage")
 public class ConnectionResponseMessage extends ProtocolMessage {
-    
+
     private ConnectionResponse connectionResponse;
     private String clusterManagerDN;
-    
-    public ConnectionResponseMessage() {}
+
+    public ConnectionResponseMessage() {
+    }
 
     public ConnectionResponse getConnectionResponse() {
         return connectionResponse;
@@ -36,23 +34,22 @@ public class ConnectionResponseMessage extends ProtocolMessage {
 
     public void setConnectionResponse(final ConnectionResponse connectionResponse) {
         this.connectionResponse = connectionResponse;
-        
-        if ( clusterManagerDN != null ) {
+
+        if (clusterManagerDN != null) {
             this.connectionResponse.setClusterManagerDN(clusterManagerDN);
         }
     }
-    
+
     public void setClusterManagerDN(final String dn) {
-        if ( connectionResponse != null ) {
+        if (connectionResponse != null) {
             connectionResponse.setClusterManagerDN(dn);
         }
         this.clusterManagerDN = dn;
     }
-    
+
     /**
-     * Returns the DN of the NCM, if it is available or <code>null</code> otherwise.
-     * 
-     * @return
+     * @return the DN of the NCM, if it is available or <code>null</code>
+     * otherwise
      */
     public String getClusterManagerDN() {
         return clusterManagerDN;
@@ -62,5 +59,5 @@ public class ConnectionResponseMessage extends ProtocolMessage {
     public MessageType getType() {
         return MessageType.CONNECTION_RESPONSE;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ControllerStartupFailureMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ControllerStartupFailureMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ControllerStartupFailureMessage.java
index ebc1cae..4ac9275 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ControllerStartupFailureMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ControllerStartupFailureMessage.java
@@ -29,9 +29,10 @@ import org.apache.nifi.cluster.protocol.jaxb.message.NodeIdentifierAdapter;
 public class ControllerStartupFailureMessage extends ExceptionMessage {
 
     private NodeIdentifier nodeId;
-    
-    public ControllerStartupFailureMessage() {}
-    
+
+    public ControllerStartupFailureMessage() {
+    }
+
     @Override
     public MessageType getType() {
         return MessageType.CONTROLLER_STARTUP_FAILURE;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/DisconnectMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/DisconnectMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/DisconnectMessage.java
index 8aa7a40..7665274 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/DisconnectMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/DisconnectMessage.java
@@ -26,10 +26,10 @@ import org.apache.nifi.cluster.protocol.jaxb.message.NodeIdentifierAdapter;
  */
 @XmlRootElement(name = "disconnectionMessage")
 public class DisconnectMessage extends ProtocolMessage {
-    
+
     private NodeIdentifier nodeId;
     private String explanation;
- 
+
     @XmlJavaTypeAdapter(NodeIdentifierAdapter.class)
     public NodeIdentifier getNodeId() {
         return nodeId;
@@ -46,10 +46,10 @@ public class DisconnectMessage extends ProtocolMessage {
     public void setExplanation(String explanation) {
         this.explanation = explanation;
     }
-    
+
     @Override
     public MessageType getType() {
         return MessageType.DISCONNECTION_REQUEST;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ExceptionMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ExceptionMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ExceptionMessage.java
index 99a6dee..dbc7bc1 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ExceptionMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ExceptionMessage.java
@@ -23,10 +23,11 @@ import javax.xml.bind.annotation.XmlRootElement;
  */
 @XmlRootElement(name = "exceptionMessage")
 public class ExceptionMessage extends ProtocolMessage {
-    
+
     private String exceptionMessage;
 
-    public ExceptionMessage() {}
+    public ExceptionMessage() {
+    }
 
     public String getExceptionMessage() {
         return exceptionMessage;
@@ -35,10 +36,10 @@ public class ExceptionMessage extends ProtocolMessage {
     public void setExceptionMessage(String exceptionMessage) {
         this.exceptionMessage = exceptionMessage;
     }
-    
+
     @Override
     public MessageType getType() {
         return MessageType.EXCEPTION;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/FlowRequestMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/FlowRequestMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/FlowRequestMessage.java
index 4a10538..f72e270 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/FlowRequestMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/FlowRequestMessage.java
@@ -26,7 +26,7 @@ import org.apache.nifi.cluster.protocol.jaxb.message.NodeIdentifierAdapter;
  */
 @XmlRootElement(name = "flowRequestMessage")
 public class FlowRequestMessage extends ProtocolMessage {
-    
+
     private NodeIdentifier nodeId;
 
     @XmlJavaTypeAdapter(NodeIdentifierAdapter.class)
@@ -37,10 +37,10 @@ public class FlowRequestMessage extends ProtocolMessage {
     public void setNodeId(NodeIdentifier nodeId) {
         this.nodeId = nodeId;
     }
-    
+
     @Override
     public MessageType getType() {
         return MessageType.FLOW_REQUEST;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/FlowResponseMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/FlowResponseMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/FlowResponseMessage.java
index 0d34dae..cc0538c 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/FlowResponseMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/FlowResponseMessage.java
@@ -25,9 +25,9 @@ import org.apache.nifi.cluster.protocol.StandardDataFlow;
  */
 @XmlRootElement(name = "flowResponseMessage")
 public class FlowResponseMessage extends ProtocolMessage {
-    
+
     private StandardDataFlow dataFlow;
-    
+
     @Override
     public MessageType getType() {
         return MessageType.FLOW_RESPONSE;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/HeartbeatMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/HeartbeatMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/HeartbeatMessage.java
index 0064cb6..05f40ac 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/HeartbeatMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/HeartbeatMessage.java
@@ -24,9 +24,9 @@ import javax.xml.bind.annotation.XmlRootElement;
  */
 @XmlRootElement(name = "heartbeatMessage")
 public class HeartbeatMessage extends ProtocolMessage {
-    
+
     private Heartbeat heartbeat;
-    
+
     @Override
     public MessageType getType() {
         return MessageType.HEARTBEAT;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/MulticastProtocolMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/MulticastProtocolMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/MulticastProtocolMessage.java
index c6d2d44..83c284c 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/MulticastProtocolMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/MulticastProtocolMessage.java
@@ -20,28 +20,29 @@ import javax.xml.bind.annotation.XmlRootElement;
 
 /**
  * Wraps a protocol message and an identifier for sending the message by way
- * multicast.  The identifier is necessary for the sender to identify a message
+ * multicast. The identifier is necessary for the sender to identify a message
  * sent by it.
- * 
+ *
  * @author unattributed
  */
 @XmlRootElement(name = "multicastMessage")
 public class MulticastProtocolMessage extends ProtocolMessage {
-    
+
     private ProtocolMessage protocolMessage;
-    
+
     private String id;
-    
-    public MulticastProtocolMessage() {}
+
+    public MulticastProtocolMessage() {
+    }
 
     public MulticastProtocolMessage(final String id, final ProtocolMessage protocolMessage) {
         this.protocolMessage = protocolMessage;
         this.id = id;
     }
-    
+
     @Override
     public MessageType getType() {
-        if(protocolMessage == null) {
+        if (protocolMessage == null) {
             return null;
         }
         return protocolMessage.getType();

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/NodeBulletinsMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/NodeBulletinsMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/NodeBulletinsMessage.java
index 9237a92..45e4dba 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/NodeBulletinsMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/NodeBulletinsMessage.java
@@ -24,9 +24,9 @@ import javax.xml.bind.annotation.XmlRootElement;
  */
 @XmlRootElement(name = "nodeBulletinsMessage")
 public class NodeBulletinsMessage extends ProtocolMessage {
-    
+
     private NodeBulletins bulletins;
-    
+
     @Override
     public MessageType getType() {
         return MessageType.BULLETINS;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/PingMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/PingMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/PingMessage.java
index ee38deb..c9cb39f 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/PingMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/PingMessage.java
@@ -24,13 +24,14 @@ import javax.xml.bind.annotation.XmlRootElement;
  */
 @XmlRootElement(name = "pingMessage")
 public class PingMessage extends ProtocolMessage {
-    
+
     private String id;
-    
+
     private Date date = new Date();
 
-    public PingMessage() {}
-    
+    public PingMessage() {
+    }
+
     public Date getDate() {
         return date;
     }
@@ -46,10 +47,10 @@ public class PingMessage extends ProtocolMessage {
     public void setId(String id) {
         this.id = id;
     }
-    
+
     @Override
     public MessageType getType() {
         return MessageType.PING;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/PrimaryRoleAssignmentMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/PrimaryRoleAssignmentMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/PrimaryRoleAssignmentMessage.java
index a289abc..db11f92 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/PrimaryRoleAssignmentMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/PrimaryRoleAssignmentMessage.java
@@ -30,7 +30,7 @@ public class PrimaryRoleAssignmentMessage extends ProtocolMessage {
     private NodeIdentifier nodeId;
 
     private boolean primary;
-    
+
     @XmlJavaTypeAdapter(NodeIdentifierAdapter.class)
     public NodeIdentifier getNodeId() {
         return nodeId;
@@ -47,7 +47,7 @@ public class PrimaryRoleAssignmentMessage extends ProtocolMessage {
     public void setPrimary(boolean primary) {
         this.primary = primary;
     }
-   
+
     @Override
     public MessageType getType() {
         return MessageType.PRIMARY_ROLE;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ProtocolMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ProtocolMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ProtocolMessage.java
index 6bf2a13..c6f7ce0 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ProtocolMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ProtocolMessage.java
@@ -16,13 +16,12 @@
  */
 package org.apache.nifi.cluster.protocol.message;
 
-/**
- * @author unattributed
- */
 public abstract class ProtocolMessage {
+
     private volatile String requestorDN;
-    
+
     public static enum MessageType {
+
         BULLETINS,
         CONNECTION_REQUEST,
         CONNECTION_RESPONSE,
@@ -39,23 +38,24 @@ public abstract class ProtocolMessage {
         RECONNECTION_RESPONSE,
         SERVICE_BROADCAST,
     }
-    
+
     public abstract MessageType getType();
-    
+
     /**
      * Sets the DN of the entity making the request
-     * @param dn
+     *
+     * @param dn dn of the entity making the request
      */
     public void setRequestorDN(final String dn) {
         this.requestorDN = dn;
     }
-    
+
     /**
-     * Returns the DN of the entity that made the request, if using a secure socket. Otherwise, returns <code>null</code>
-     * @return
+     * @return the DN of the entity that made the request, if using a secure
+     * socket. Otherwise, returns <code>null</code>
      */
     public String getRequestorDN() {
         return requestorDN;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionFailureMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionFailureMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionFailureMessage.java
index ba45e28..ce62c5b 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionFailureMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionFailureMessage.java
@@ -24,10 +24,12 @@ import org.apache.nifi.cluster.protocol.jaxb.message.NodeIdentifierAdapter;
 
 @XmlRootElement(name = "reconnectionFailureMessage")
 public class ReconnectionFailureMessage extends ExceptionMessage {
+
     private NodeIdentifier nodeId;
-    
-    public ReconnectionFailureMessage() {}
-    
+
+    public ReconnectionFailureMessage() {
+    }
+
     @Override
     public MessageType getType() {
         return MessageType.RECONNECTION_FAILURE;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionRequestMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionRequestMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionRequestMessage.java
index eab3d5d..6d67d21 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionRequestMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionRequestMessage.java
@@ -35,8 +35,9 @@ public class ReconnectionRequestMessage extends ProtocolMessage {
     private Integer managerRemoteSiteListeningPort;
     private Boolean managerRemoteSiteCommsSecure;
     private String instanceId;
-    
-    public ReconnectionRequestMessage() {}
+
+    public ReconnectionRequestMessage() {
+    }
 
     @XmlJavaTypeAdapter(NodeIdentifierAdapter.class)
     public NodeIdentifier getNodeId() {
@@ -62,32 +63,32 @@ public class ReconnectionRequestMessage extends ProtocolMessage {
     public void setPrimary(boolean primary) {
         this.primary = primary;
     }
-    
+
     @Override
     public MessageType getType() {
         return MessageType.RECONNECTION_REQUEST;
     }
-    
+
     public void setManagerRemoteSiteListeningPort(final Integer listeningPort) {
         this.managerRemoteSiteListeningPort = listeningPort;
     }
-    
+
     public Integer getManagerRemoteSiteListeningPort() {
         return managerRemoteSiteListeningPort;
     }
-    
+
     public void setManagerRemoteSiteCommsSecure(final Boolean remoteSiteCommsSecure) {
         this.managerRemoteSiteCommsSecure = remoteSiteCommsSecure;
     }
-    
+
     public Boolean isManagerRemoteSiteCommsSecure() {
         return managerRemoteSiteCommsSecure;
     }
-    
+
     public void setInstanceId(final String instanceId) {
         this.instanceId = instanceId;
     }
-    
+
     public String getInstanceId() {
         return instanceId;
     }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionResponseMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionResponseMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionResponseMessage.java
index fd0f921..10ed7f6 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionResponseMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ReconnectionResponseMessage.java
@@ -29,4 +29,4 @@ public class ReconnectionResponseMessage extends ProtocolMessage {
         return MessageType.RECONNECTION_RESPONSE;
     }
 
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ServiceBroadcastMessage.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ServiceBroadcastMessage.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ServiceBroadcastMessage.java
index 92708ba..113b719 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ServiceBroadcastMessage.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/message/ServiceBroadcastMessage.java
@@ -25,12 +25,13 @@ import javax.xml.bind.annotation.XmlRootElement;
 public class ServiceBroadcastMessage extends ProtocolMessage {
 
     private String serviceName;
-    
+
     private String address;
-    
+
     private int port;
-    
-    public ServiceBroadcastMessage() {}
+
+    public ServiceBroadcastMessage() {
+    }
 
     public String getServiceName() {
         return serviceName;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/MulticastConfigurationFactoryBean.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/MulticastConfigurationFactoryBean.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/MulticastConfigurationFactoryBean.java
index fa201bb..460d3bc 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/MulticastConfigurationFactoryBean.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/MulticastConfigurationFactoryBean.java
@@ -24,18 +24,18 @@ import org.apache.nifi.util.NiFiProperties;
 import org.springframework.beans.factory.FactoryBean;
 
 /**
- * Factory bean for creating a singleton MulticastConfiguration instance.  
+ * Factory bean for creating a singleton MulticastConfiguration instance.
  */
 public class MulticastConfigurationFactoryBean implements FactoryBean {
-    
+
     private MulticastConfiguration configuration;
     private NiFiProperties properties;
-    
+
     @Override
     public Object getObject() throws Exception {
-        if(configuration == null) {
+        if (configuration == null) {
             configuration = new MulticastConfiguration();
-            
+
             final int timeout = (int) FormatUtils.getTimeDuration(properties.getClusterProtocolSocketTimeout(), TimeUnit.MILLISECONDS);
             configuration.setSocketTimeout(timeout);
             configuration.setReuseAddress(true);
@@ -53,7 +53,7 @@ public class MulticastConfigurationFactoryBean implements FactoryBean {
     public boolean isSingleton() {
         return true;
     }
-    
+
     public void setProperties(NiFiProperties properties) {
         this.properties = properties;
     }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/ServerSocketConfigurationFactoryBean.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/ServerSocketConfigurationFactoryBean.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/ServerSocketConfigurationFactoryBean.java
index 5b5816d..c41aeff 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/ServerSocketConfigurationFactoryBean.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/ServerSocketConfigurationFactoryBean.java
@@ -26,22 +26,23 @@ import org.apache.nifi.util.NiFiProperties;
 import org.springframework.beans.factory.FactoryBean;
 
 /**
- * Factory bean for creating a singleton ServerSocketConfiguration instance.  
+ * Factory bean for creating a singleton ServerSocketConfiguration instance.
  */
 public class ServerSocketConfigurationFactoryBean implements FactoryBean<ServerSocketConfiguration> {
+
     private ServerSocketConfiguration configuration;
     private NiFiProperties properties;
-    
+
     @Override
     public ServerSocketConfiguration getObject() throws Exception {
-        if(configuration == null) {
+        if (configuration == null) {
             configuration = new ServerSocketConfiguration();
             configuration.setNeedClientAuth(properties.getNeedClientAuth());
-            
+
             final int timeout = (int) FormatUtils.getTimeDuration(properties.getClusterProtocolSocketTimeout(), TimeUnit.MILLISECONDS);
             configuration.setSocketTimeout(timeout);
             configuration.setReuseAddress(true);
-            if(Boolean.valueOf(properties.getProperty(NiFiProperties.CLUSTER_PROTOCOL_IS_SECURE))) {
+            if (Boolean.valueOf(properties.getProperty(NiFiProperties.CLUSTER_PROTOCOL_IS_SECURE))) {
                 configuration.setSSLContextFactory(new SSLContextFactory(properties));
             }
         }
@@ -58,7 +59,7 @@ public class ServerSocketConfigurationFactoryBean implements FactoryBean<ServerS
     public boolean isSingleton() {
         return true;
     }
-    
+
     public void setProperties(NiFiProperties properties) {
         this.properties = properties;
     }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/888254b2/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/SocketConfigurationFactoryBean.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/SocketConfigurationFactoryBean.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/SocketConfigurationFactoryBean.java
index b438e44..d3fe42c 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/SocketConfigurationFactoryBean.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-cluster-protocol/src/main/java/org/apache/nifi/cluster/protocol/spring/SocketConfigurationFactoryBean.java
@@ -26,23 +26,23 @@ import org.apache.nifi.util.NiFiProperties;
 import org.springframework.beans.factory.FactoryBean;
 
 /**
- * Factory bean for creating a singleton SocketConfiguration instance.  
+ * Factory bean for creating a singleton SocketConfiguration instance.
  */
 public class SocketConfigurationFactoryBean implements FactoryBean<SocketConfiguration> {
-    
+
     private SocketConfiguration configuration;
-    
+
     private NiFiProperties properties;
-    
+
     @Override
     public SocketConfiguration getObject() throws Exception {
-        if(configuration == null) {
+        if (configuration == null) {
             configuration = new SocketConfiguration();
-            
+
             final int timeout = (int) FormatUtils.getTimeDuration(properties.getClusterProtocolSocketTimeout(), TimeUnit.MILLISECONDS);
             configuration.setSocketTimeout(timeout);
             configuration.setReuseAddress(true);
-            if(Boolean.valueOf(properties.getProperty(NiFiProperties.CLUSTER_PROTOCOL_IS_SECURE))) {
+            if (Boolean.valueOf(properties.getProperty(NiFiProperties.CLUSTER_PROTOCOL_IS_SECURE))) {
                 configuration.setSSLContextFactory(new SSLContextFactory(properties));
             }
         }
@@ -59,7 +59,7 @@ public class SocketConfigurationFactoryBean implements FactoryBean<SocketConfigu
     public boolean isSingleton() {
         return true;
     }
-    
+
     public void setProperties(NiFiProperties properties) {
         this.properties = properties;
     }