You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@nifi.apache.org by mc...@apache.org on 2015/04/28 16:05:03 UTC

[29/50] [abbrv] incubator-nifi git commit: NIFI-271

NIFI-271


Project: http://git-wip-us.apache.org/repos/asf/incubator-nifi/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-nifi/commit/e811929f
Tree: http://git-wip-us.apache.org/repos/asf/incubator-nifi/tree/e811929f
Diff: http://git-wip-us.apache.org/repos/asf/incubator-nifi/diff/e811929f

Branch: refs/heads/NIFI-292
Commit: e811929f5913586b38f5f95d321623da2f07b64a
Parents: 43b2f04
Author: joewitt <jo...@apache.org>
Authored: Mon Apr 27 14:56:45 2015 -0400
Committer: joewitt <jo...@apache.org>
Committed: Mon Apr 27 14:56:45 2015 -0400

----------------------------------------------------------------------
 .../apache/nifi/cluster/HeartbeatPayload.java   |   3 +-
 .../org/apache/nifi/connectable/LocalPort.java  |   5 +-
 .../nifi/connectable/StandardConnection.java    |  10 +-
 .../nifi/controller/FileSystemSwapManager.java  |   6 +-
 .../apache/nifi/controller/FlowController.java  | 214 ++++++-------------
 .../controller/FlowSerializationException.java  |   3 +-
 .../apache/nifi/controller/FlowSerializer.java  |   3 +-
 .../FlowSynchronizationException.java           |   3 +-
 .../nifi/controller/FlowSynchronizer.java       |  25 +--
 .../nifi/controller/FlowUnmarshaller.java       |   4 +-
 .../controller/StandardFlowSynchronizer.java    |  12 +-
 .../nifi/controller/StandardProcessorNode.java  |  64 ++----
 .../apache/nifi/controller/TemplateManager.java |  19 +-
 .../controller/UninheritableFlowException.java  |   3 +-
 .../repository/FileSystemRepository.java        |   4 +-
 .../controller/repository/ProcessContext.java   |  18 +-
 .../repository/ProvenanceEventEnricher.java     |   3 +-
 .../repository/RepositoryPurgeException.java    |   3 +-
 .../repository/StandardFlowFileRecord.java      |   7 +-
 .../repository/StandardProcessSession.java      |  34 +--
 .../repository/StandardProvenanceReporter.java  |   6 +-
 .../repository/StandardRepositoryRecord.java    |   3 +-
 .../StandardRepositoryStatusReport.java         |  12 +-
 .../repository/VolatileContentRepository.java   |  30 +--
 .../repository/VolatileFlowFileRepository.java  |   4 +-
 .../WriteAheadFlowFileRepository.java           |  25 +--
 .../repository/claim/ContentDirection.java      |   9 +-
 .../repository/claim/StandardContentClaim.java  |   7 +-
 .../io/DisableOnCloseInputStream.java           |   4 +-
 .../io/DisableOnCloseOutputStream.java          |   4 +-
 .../io/FlowFileAccessInputStream.java           |  11 +-
 .../io/FlowFileAccessOutputStream.java          |   9 +-
 .../controller/repository/io/LongHolder.java    |   6 +-
 .../scheduling/ConnectableProcessContext.java   |   3 +-
 .../controller/scheduling/ScheduleState.java    |  12 +-
 .../scheduling/StandardProcessScheduler.java    |  18 +-
 .../StandardControllerServiceProvider.java      |   6 +-
 .../status/history/StandardStatusSnapshot.java  |   2 +-
 .../tasks/ContinuallyRunConnectableTask.java    |   4 +-
 .../tasks/ContinuallyRunProcessorTask.java      |   4 +-
 .../nifi/controller/tasks/ExpireFlowFiles.java  |   4 +-
 .../apache/nifi/encrypt/StringEncryptor.java    |  12 +-
 .../java/org/apache/nifi/engine/FlowEngine.java |  16 +-
 .../nifi/events/VolatileBulletinRepository.java |   5 +-
 .../nifi/fingerprint/FingerprintFactory.java    |  17 +-
 .../nifi/groups/StandardProcessGroup.java       |  13 +-
 .../org/apache/nifi/lifecycle/LifeCycle.java    |  17 +-
 .../nifi/lifecycle/LifeCycleException.java      |   3 +-
 .../nifi/lifecycle/LifeCycleStartException.java |   4 +-
 .../nifi/lifecycle/LifeCycleStopException.java  |   3 +-
 .../nifi/persistence/FlowConfigurationDAO.java  |  33 +--
 .../nifi/processor/StandardProcessContext.java  |   3 +-
 .../nifi/processor/StandardPropertyValue.java   |  12 +-
 .../org/apache/nifi/remote/RemoteNiFiUtils.java |  11 +-
 .../nifi/remote/StandardRemoteProcessGroup.java |  49 ++---
 .../org/apache/nifi/services/FlowService.java   |  55 ++---
 .../nifi/spring/FlowControllerFactoryBean.java  |   4 +-
 .../spring/StandardFlowServiceFactoryBean.java  |   4 +-
 .../apache/nifi/util/ComponentStatusReport.java |   4 +-
 .../org/apache/nifi/util/ReflectionUtils.java   |  71 ++----
 .../java/org/apache/nifi/util/SnippetUtils.java |   6 +-
 61 files changed, 305 insertions(+), 663 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/cluster/HeartbeatPayload.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/cluster/HeartbeatPayload.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/cluster/HeartbeatPayload.java
index 093b238..668c5e0 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/cluster/HeartbeatPayload.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/cluster/HeartbeatPayload.java
@@ -34,8 +34,7 @@ import org.apache.nifi.diagnostics.SystemDiagnostics;
 import org.apache.nifi.jaxb.CounterAdapter;
 
 /**
- * The payload of the heartbeat. The payload contains status to inform the
- * cluster manager the current workload of this node.
+ * The payload of the heartbeat. The payload contains status to inform the cluster manager the current workload of this node.
  *
  * @author unattributed
  */

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/connectable/LocalPort.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/connectable/LocalPort.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/connectable/LocalPort.java
index f0739c2..ceb85f2 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/connectable/LocalPort.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/connectable/LocalPort.java
@@ -37,9 +37,8 @@ import org.apache.nifi.processor.Relationship;
 import org.apache.nifi.scheduling.SchedulingStrategy;
 
 /**
- * Provides a mechanism by which <code>FlowFile</code>s can be transferred into
- * and out of a <code>ProcessGroup</code> to and/or from another
- * <code>ProcessGroup</code> within the same instance of NiFi.
+ * Provides a mechanism by which <code>FlowFile</code>s can be transferred into and out of a <code>ProcessGroup</code> to and/or from another <code>ProcessGroup</code> within the same instance of
+ * NiFi.
  */
 public class LocalPort extends AbstractPort {
 

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/connectable/StandardConnection.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/connectable/StandardConnection.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/connectable/StandardConnection.java
index b2feab5..86c9320 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/connectable/StandardConnection.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/connectable/StandardConnection.java
@@ -39,9 +39,7 @@ import org.apache.commons.lang3.builder.EqualsBuilder;
 import org.apache.commons.lang3.builder.HashCodeBuilder;
 
 /**
- * Models a connection between connectable components. A connection may contain
- * one or more relationships that map the source component to the destination
- * component.
+ * Models a connection between connectable components. A connection may contain one or more relationships that map the source component to the destination component.
  */
 public final class StandardConnection implements Connection {
 
@@ -231,10 +229,8 @@ public final class StandardConnection implements Connection {
     }
 
     /**
-     * Gives this Connection ownership of the given FlowFile and allows the
-     * Connection to hold on to the FlowFile but NOT provide the FlowFile to
-     * consumers. This allows us to ensure that the Connection is not deleted
-     * during the middle of a Session commit.
+     * Gives this Connection ownership of the given FlowFile and allows the Connection to hold on to the FlowFile but NOT provide the FlowFile to consumers. This allows us to ensure that the
+     * Connection is not deleted during the middle of a Session commit.
      *
      * @param flowFile to add
      */

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FileSystemSwapManager.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FileSystemSwapManager.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FileSystemSwapManager.java
index 3041ada..604dba9 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FileSystemSwapManager.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FileSystemSwapManager.java
@@ -74,8 +74,7 @@ import org.slf4j.LoggerFactory;
 
 /**
  * <p>
- * An implementation of the {@link FlowFileSwapManager} that swaps FlowFiles
- * to/from local disk
+ * An implementation of the {@link FlowFileSwapManager} that swaps FlowFiles to/from local disk
  * </p>
  */
 public class FileSystemSwapManager implements FlowFileSwapManager {
@@ -562,8 +561,7 @@ public class FileSystemSwapManager implements FlowFileSwapManager {
     }
 
     /**
-     * Recovers FlowFiles from all Swap Files, returning the largest FlowFile ID
-     * that was recovered.
+     * Recovers FlowFiles from all Swap Files, returning the largest FlowFile ID that was recovered.
      *
      * @param queueProvider provider
      * @return the largest FlowFile ID that was recovered

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowController.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowController.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowController.java
index 0d7699a..e241112 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowController.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowController.java
@@ -582,8 +582,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
 
     /**
      * <p>
-     * Causes any processors that were added to the flow with a 'delayStart'
-     * flag of true to now start
+     * Causes any processors that were added to the flow with a 'delayStart' flag of true to now start
      * </p>
      *
      * @param startDelayedComponents true if start
@@ -697,17 +696,14 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
      * Creates a connection between two Connectable objects.
      *
      * @param id required ID of the connection
-     * @param name the name of the connection, or <code>null</code> to leave the
-     * connection unnamed
+     * @param name the name of the connection, or <code>null</code> to leave the connection unnamed
      * @param source required source
      * @param destination required destination
      * @param relationshipNames required collection of relationship names
      * @return
      *
-     * @throws NullPointerException if the ID, source, destination, or set of
-     * relationships is null.
-     * @throws IllegalArgumentException if <code>relationships</code> is an
-     * empty collection
+     * @throws NullPointerException if the ID, source, destination, or set of relationships is null.
+     * @throws IllegalArgumentException if <code>relationships</code> is an empty collection
      */
     public Connection createConnection(final String id, final String name, final Connectable source, final Connectable destination, final Collection<String> relationshipNames) {
         final StandardConnection.Builder builder = new StandardConnection.Builder(processScheduler);
@@ -749,8 +745,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
      * @param name port name
      * @return new port
      * @throws NullPointerException if the ID or name is not unique
-     * @throws IllegalStateException if an Input Port already exists with the
-     * same name or id.
+     * @throws IllegalStateException if an Input Port already exists with the same name or id.
      */
     public Port createLocalInputPort(String id, String name) {
         id = requireNonNull(id).intern();
@@ -766,8 +761,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
      * @param name port name
      * @return new port
      * @throws NullPointerException if the ID or name is not unique
-     * @throws IllegalStateException if an Input Port already exists with the
-     * same name or id.
+     * @throws IllegalStateException if an Input Port already exists with the same name or id.
      */
     public Port createLocalOutputPort(String id, String name) {
         id = requireNonNull(id).intern();
@@ -789,16 +783,14 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
 
     /**
      * <p>
-     * Creates a new ProcessorNode with the given type and identifier and
-     * initializes it invoking the methods annotated with {@link OnAdded}.
+     * Creates a new ProcessorNode with the given type and identifier and initializes it invoking the methods annotated with {@link OnAdded}.
      * </p>
      *
      * @param type processor type
      * @param id processor id
      * @return new processor
      * @throws NullPointerException if either arg is null
-     * @throws ProcessorInstantiationException if the processor cannot be
-     * instantiated for any reason
+     * @throws ProcessorInstantiationException if the processor cannot be instantiated for any reason
      */
     public ProcessorNode createProcessor(final String type, String id) throws ProcessorInstantiationException {
         return createProcessor(type, id, true);
@@ -806,19 +798,15 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
 
     /**
      * <p>
-     * Creates a new ProcessorNode with the given type and identifier and
-     * optionally initializes it.
+     * Creates a new ProcessorNode with the given type and identifier and optionally initializes it.
      * </p>
      *
      * @param type the fully qualified Processor class name
      * @param id the unique ID of the Processor
-     * @param firstTimeAdded whether or not this is the first time this
-     * Processor is added to the graph. If {@code true}, will invoke methods
-     * annotated with the {@link OnAdded} annotation.
+     * @param firstTimeAdded whether or not this is the first time this Processor is added to the graph. If {@code true}, will invoke methods annotated with the {@link OnAdded} annotation.
      * @return new processor node
      * @throws NullPointerException if either arg is null
-     * @throws ProcessorInstantiationException if the processor cannot be
-     * instantiated for any reason
+     * @throws ProcessorInstantiationException if the processor cannot be instantiated for any reason
      */
     @SuppressWarnings("deprecation")
     public ProcessorNode createProcessor(final String type, String id, final boolean firstTimeAdded) throws ProcessorInstantiationException {
@@ -874,8 +862,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * @return the ExtensionManager used for instantiating Processors,
-     * Prioritizers, etc.
+     * @return the ExtensionManager used for instantiating Processors, Prioritizers, etc.
      */
     public ExtensionManager getExtensionManager() {
         return extensionManager;
@@ -902,15 +889,13 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * Creates a Port to use as an Input Port for the root Process Group, which
-     * is used for Site-to-Site communications
+     * Creates a Port to use as an Input Port for the root Process Group, which is used for Site-to-Site communications
      *
      * @param id port id
      * @param name port name
      * @return new port
      * @throws NullPointerException if the ID or name is not unique
-     * @throws IllegalStateException if an Input Port already exists with the
-     * same name or id.
+     * @throws IllegalStateException if an Input Port already exists with the same name or id.
      */
     public Port createRemoteInputPort(String id, String name) {
         id = requireNonNull(id).intern();
@@ -921,16 +906,13 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * Creates a Port to use as an Output Port for the root Process Group, which
-     * is used for Site-to-Site communications and will queue flow files waiting
-     * to be delivered to remote instances
+     * Creates a Port to use as an Output Port for the root Process Group, which is used for Site-to-Site communications and will queue flow files waiting to be delivered to remote instances
      *
      * @param id port id
      * @param name port name
      * @return new port
      * @throws NullPointerException if the ID or name is not unique
-     * @throws IllegalStateException if an Input Port already exists with the
-     * same name or id.
+     * @throws IllegalStateException if an Input Port already exists with the same name or id.
      */
     public Port createRemoteOutputPort(String id, String name) {
         id = requireNonNull(id).intern();
@@ -941,8 +923,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * Creates a new Remote Process Group with the given ID that points to the
-     * given URI
+     * Creates a new Remote Process Group with the given ID that points to the given URI
      *
      * @param id group id
      * @param uri group uri
@@ -955,8 +936,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * Verifies that no output port exists with the given id or name. If this
-     * does not hold true, throws an IllegalStateException
+     * Verifies that no output port exists with the given id or name. If this does not hold true, throws an IllegalStateException
      *
      * @param id port identifier
      * @throws IllegalStateException port already exists
@@ -973,8 +953,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * @return the name of this controller, which is also the name of the Root
-     * Group.
+     * @return the name of this controller, which is also the name of the Root Group.
      */
     public String getName() {
         readLock.lock();
@@ -986,8 +965,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * Sets the name for the Root Group, which also changes the name for the
-     * controller.
+     * Sets the name for the Root Group, which also changes the name for the controller.
      *
      * @param name of root group
      */
@@ -1001,8 +979,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * @return the comments of this controller, which is also the comment of the
-     * Root Group
+     * @return the comments of this controller, which is also the comment of the Root Group
      */
     public String getComments() {
         readLock.lock();
@@ -1016,8 +993,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     /**
      * Sets the comments
      *
-     * @param comments for the Root Group, which also changes the comment for
-     * the controller
+     * @param comments for the Root Group, which also changes the comment for the controller
      */
     public void setComments(final String comments) {
         readLock.lock();
@@ -1029,8 +1005,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * @return <code>true</code> if the scheduling engine for this controller
-     * has been terminated.
+     * @return <code>true</code> if the scheduling engine for this controller has been terminated.
      */
     public boolean isTerminated() {
         this.readLock.lock();
@@ -1042,16 +1017,12 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * Triggers the controller to begin shutdown, stopping all processors and
-     * terminating the scheduling engine. After calling this method, the
-     * {@link #isTerminated()} method will indicate whether or not the shutdown
-     * has finished.
+     * Triggers the controller to begin shutdown, stopping all processors and terminating the scheduling engine. After calling this method, the {@link #isTerminated()} method will indicate whether or
+     * not the shutdown has finished.
      *
-     * @param kill if <code>true</code>, attempts to stop all active threads,
-     * but makes no guarantee that this will happen
+     * @param kill if <code>true</code>, attempts to stop all active threads, but makes no guarantee that this will happen
      *
-     * @throws IllegalStateException if the controller is already stopped or
-     * currently in the processor of stopping
+     * @throws IllegalStateException if the controller is already stopped or currently in the processor of stopping
      */
     public void shutdown(final boolean kill) {
         this.shutdown = true;
@@ -1150,8 +1121,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
      *
      * @param serializer serializer
      * @param os stream
-     * @throws FlowSerializationException if serialization of the flow fails for
-     * any reason
+     * @throws FlowSerializationException if serialization of the flow fails for any reason
      */
     public void serialize(final FlowSerializer serializer, final OutputStream os) throws FlowSerializationException {
         readLock.lock();
@@ -1165,21 +1135,14 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     /**
      * Synchronizes this controller with the proposed flow.
      *
-     * For more details, see
-     * {@link FlowSynchronizer#sync(FlowController, DataFlow)}.
+     * For more details, see {@link FlowSynchronizer#sync(FlowController, DataFlow)}.
      *
      * @param synchronizer synchronizer
-     * @param dataFlow the flow to load the controller with. If the flow is null
-     * or zero length, then the controller must not have a flow or else an
-     * UninheritableFlowException will be thrown.
+     * @param dataFlow the flow to load the controller with. If the flow is null or zero length, then the controller must not have a flow or else an UninheritableFlowException will be thrown.
      *
-     * @throws FlowSerializationException if proposed flow is not a valid flow
-     * configuration file
-     * @throws UninheritableFlowException if the proposed flow cannot be loaded
-     * by the controller because in doing so would risk orphaning flow files
-     * @throws FlowSynchronizationException if updates to the controller failed.
-     * If this exception is thrown, then the controller should be considered
-     * unsafe to be used
+     * @throws FlowSerializationException if proposed flow is not a valid flow configuration file
+     * @throws UninheritableFlowException if the proposed flow cannot be loaded by the controller because in doing so would risk orphaning flow files
+     * @throws FlowSynchronizationException if updates to the controller failed. If this exception is thrown, then the controller should be considered unsafe to be used
      */
     public void synchronize(final FlowSynchronizer synchronizer, final DataFlow dataFlow)
             throws FlowSerializationException, FlowSynchronizationException, UninheritableFlowException {
@@ -1194,8 +1157,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * @return the currently configured maximum number of threads that can be
-     * used for executing processors at any given time.
+     * @return the currently configured maximum number of threads that can be used for executing processors at any given time.
      */
     public int getMaxTimerDrivenThreadCount() {
         return maxTimerDrivenThreads.get();
@@ -1225,8 +1187,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * Updates the number of threads that can be simultaneously used for
-     * executing processors.
+     * Updates the number of threads that can be simultaneously used for executing processors.
      *
      * @param maxThreadCount
      *
@@ -1261,8 +1222,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
      * @param group the ProcessGroup that is to become the new Root Group
      *
      * @throws IllegalArgumentException if the ProcessGroup has a parent
-     * @throws IllegalStateException if the FlowController does not know about
-     * the given process group
+     * @throws IllegalStateException if the FlowController does not know about the given process group
      */
     void setRootGroup(final ProcessGroup group) {
         if (requireNonNull(group).getParent() != null) {
@@ -1293,17 +1253,13 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     // ProcessGroup access
     //
     /**
-     * Updates the process group corresponding to the specified DTO. Any field
-     * in DTO that is <code>null</code> (with the exception of the required ID)
-     * will be ignored.
+     * Updates the process group corresponding to the specified DTO. Any field in DTO that is <code>null</code> (with the exception of the required ID) will be ignored.
      *
      * @param dto group
      * @throws ProcessorInstantiationException
      *
-     * @throws IllegalStateException if no process group can be found with the
-     * ID of DTO or with the ID of the DTO's parentGroupId, if the template ID
-     * specified is invalid, or if the DTO's Parent Group ID changes but the
-     * parent group has incoming or outgoing connections
+     * @throws IllegalStateException if no process group can be found with the ID of DTO or with the ID of the DTO's parentGroupId, if the template ID specified is invalid, or if the DTO's Parent
+     * Group ID changes but the parent group has incoming or outgoing connections
      *
      * @throws NullPointerException if the DTO or its ID is null
      */
@@ -1329,17 +1285,13 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     // Template access
     //
     /**
-     * Adds a template to this controller. The contents of this template must be
-     * part of the current flow. This is going create a template based on a
-     * snippet of this flow.
+     * Adds a template to this controller. The contents of this template must be part of the current flow. This is going create a template based on a snippet of this flow.
      *
      * @param dto template
      * @return a copy of the given DTO
      * @throws IOException if an I/O error occurs when persisting the Template
      * @throws NullPointerException if the DTO is null
-     * @throws IllegalArgumentException if does not contain all required
-     * information, such as the template name or a processor's configuration
-     * element
+     * @throws IllegalArgumentException if does not contain all required information, such as the template name or a processor's configuration element
      */
     public Template addTemplate(final TemplateDTO dto) throws IOException {
         return templateManager.addTemplate(dto);
@@ -1355,8 +1307,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * Imports the specified template into this controller. The contents of this
-     * template may have come from another NiFi instance.
+     * Imports the specified template into this controller. The contents of this template may have come from another NiFi instance.
      *
      * @param dto dto
      * @return template
@@ -1368,8 +1319,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
 
     /**
      * @param id identifier
-     * @return the template with the given ID, or <code>null</code> if no
-     * template exists with the given ID
+     * @return the template with the given ID, or <code>null</code> if no template exists with the given ID
      */
     public Template getTemplate(final String id) {
         return templateManager.getTemplate(id);
@@ -1406,21 +1356,15 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     // Snippet
     //
     /**
-     * Creates an instance of the given snippet and adds the components to the
-     * given group
+     * Creates an instance of the given snippet and adds the components to the given group
      *
      * @param group group
      * @param dto dto
      *
      * @throws NullPointerException if either argument is null
-     * @throws IllegalStateException if the snippet is not valid because a
-     * component in the snippet has an ID that is not unique to this flow, or
-     * because it shares an Input Port or Output Port at the root level whose
-     * name already exists in the given ProcessGroup, or because the Template
-     * contains a Processor or a Prioritizer whose class is not valid within
-     * this instance of NiFi.
-     * @throws ProcessorInstantiationException if unable to instantiate a
-     * processor
+     * @throws IllegalStateException if the snippet is not valid because a component in the snippet has an ID that is not unique to this flow, or because it shares an Input Port or Output Port at the
+     * root level whose name already exists in the given ProcessGroup, or because the Template contains a Processor or a Prioritizer whose class is not valid within this instance of NiFi.
+     * @throws ProcessorInstantiationException if unable to instantiate a processor
      */
     public void instantiateSnippet(final ProcessGroup group, final FlowSnippetDTO dto) throws ProcessorInstantiationException {
         writeLock.lock();
@@ -1732,8 +1676,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * Returns the parent of the specified Connectable. This only considers this
-     * group and any direct child sub groups.
+     * Returns the parent of the specified Connectable. This only considers this group and any direct child sub groups.
      *
      * @param parentGroupId group id
      * @return parent group
@@ -1751,20 +1694,16 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
      * Verifies that the given DTO is valid, according to the following:
      *
      * <ul>
-     * <li>None of the ID's in any component of the DTO can be used in this
-     * flow.</li>
-     * <li>The ProcessGroup to which the template's contents will be added must
-     * not contain any InputPort or OutputPort with the same name as one of the
-     * corresponding components in the root level of the template.</li>
+     * <li>None of the ID's in any component of the DTO can be used in this flow.</li>
+     * <li>The ProcessGroup to which the template's contents will be added must not contain any InputPort or OutputPort with the same name as one of the corresponding components in the root level of
+     * the template.</li>
      * <li>All Processors' classes must exist in this instance.</li>
      * <li>All Flow File Prioritizers' classes must exist in this instance.</li>
      * </ul>
      * </p>
      *
      * <p>
-     * If any of the above statements does not hold true, an
-     * {@link IllegalStateException} or a
-     * {@link ProcessorInstantiationException} will be thrown.
+     * If any of the above statements does not hold true, an {@link IllegalStateException} or a {@link ProcessorInstantiationException} will be thrown.
      * </p>
      *
      * @param group group
@@ -1875,8 +1814,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     // Processor access
     //
     /**
-     * Indicates whether or not the two ID's point to the same ProcessGroup. If
-     * either id is null, will return <code>false</code>.
+     * Indicates whether or not the two ID's point to the same ProcessGroup. If either id is null, will return <code>false</code>.
      *
      * @param id1 group id
      * @param id2 other group id
@@ -2846,8 +2784,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     // Clustering methods
     //
     /**
-     * Starts heartbeating to the cluster. May only be called if the instance
-     * was constructed for a clustered environment.
+     * Starts heartbeating to the cluster. May only be called if the instance was constructed for a clustered environment.
      *
      * @throws IllegalStateException if not configured for clustering
      */
@@ -2874,31 +2811,23 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * Notifies controller that the sending of heartbeats should be temporarily
-     * suspended. This method does not cancel any background tasks as does
-     * {@link #stopHeartbeating()} and does not require any lock on the
-     * FlowController. Background tasks will still generate heartbeat messages
-     * and any background task currently in the process of sending a Heartbeat
-     * to the cluster will continue.
+     * Notifies controller that the sending of heartbeats should be temporarily suspended. This method does not cancel any background tasks as does {@link #stopHeartbeating()} and does not require any
+     * lock on the FlowController. Background tasks will still generate heartbeat messages and any background task currently in the process of sending a Heartbeat to the cluster will continue.
      */
     public void suspendHeartbeats() {
         heartbeatsSuspended.set(true);
     }
 
     /**
-     * Notifies controller that the sending of heartbeats should be re-enabled.
-     * This method does not submit any background tasks to take affect as does
-     * {@link #startHeartbeating()} and does not require any lock on the
-     * FlowController.
+     * Notifies controller that the sending of heartbeats should be re-enabled. This method does not submit any background tasks to take affect as does {@link #startHeartbeating()} and does not
+     * require any lock on the FlowController.
      */
     public void resumeHeartbeats() {
         heartbeatsSuspended.set(false);
     }
 
     /**
-     * Stops heartbeating to the cluster. May only be called if the instance was
-     * constructed for a clustered environment. If the controller was not
-     * heartbeating, then this method has no effect.
+     * Stops heartbeating to the cluster. May only be called if the instance was constructed for a clustered environment. If the controller was not heartbeating, then this method has no effect.
      *
      * @throws IllegalStateException if not clustered
      */
@@ -2985,9 +2914,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * @return true if this instance is clustered; false otherwise. Clustered
-     * means that a node is either connected or trying to connect to the
-     * cluster.
+     * @return true if this instance is clustered; false otherwise. Clustered means that a node is either connected or trying to connect to the cluster.
      */
     public boolean isClustered() {
         readLock.lock();
@@ -2999,10 +2926,8 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * @return the DN of the Cluster Manager that we are currently connected to,
-     * if available. This will return null if the instance is not clustered or
-     * if the instance is clustered but the NCM's DN is not available - for
-     * instance, if cluster communications are not secure
+     * @return the DN of the Cluster Manager that we are currently connected to, if available. This will return null if the instance is not clustered or if the instance is clustered but the NCM's DN
+     * is not available - for instance, if cluster communications are not secure
      */
     public String getClusterManagerDN() {
         readLock.lock();
@@ -3014,24 +2939,20 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * Sets whether this instance is clustered. Clustered means that a node is
-     * either connected or trying to connect to the cluster.
+     * Sets whether this instance is clustered. Clustered means that a node is either connected or trying to connect to the cluster.
      *
      * @param clustered true if clustered
-     * @param clusterInstanceId if clustered is true, indicates the InstanceID
-     * of the Cluster Manager
+     * @param clusterInstanceId if clustered is true, indicates the InstanceID of the Cluster Manager
      */
     public void setClustered(final boolean clustered, final String clusterInstanceId) {
         setClustered(clustered, clusterInstanceId, null);
     }
 
     /**
-     * Sets whether this instance is clustered. Clustered means that a node is
-     * either connected or trying to connect to the cluster.
+     * Sets whether this instance is clustered. Clustered means that a node is either connected or trying to connect to the cluster.
      *
      * @param clustered true if clustered
-     * @param clusterInstanceId if clustered is true, indicates the InstanceID
-     * of the Cluster Manager
+     * @param clusterInstanceId if clustered is true, indicates the InstanceID of the Cluster Manager
      * @param clusterManagerDn the DN of the NCM
      */
     public void setClustered(final boolean clustered, final String clusterInstanceId, final String clusterManagerDn) {
@@ -3077,8 +2998,7 @@ public class FlowController implements EventAccess, ControllerServiceProvider, R
     }
 
     /**
-     * @return true if this instance is the primary node in the cluster; false
-     * otherwise
+     * @return true if this instance is the primary node in the cluster; false otherwise
      */
     public boolean isPrimary() {
         rwLock.readLock().lock();

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSerializationException.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSerializationException.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSerializationException.java
index f1ee760..444b9e5 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSerializationException.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSerializationException.java
@@ -17,8 +17,7 @@
 package org.apache.nifi.controller;
 
 /**
- * Represents the exceptional case when flow configuration is malformed and
- * therefore, cannot be serialized or deserialized.
+ * Represents the exceptional case when flow configuration is malformed and therefore, cannot be serialized or deserialized.
  *
  * @author unattributed
  */

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSerializer.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSerializer.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSerializer.java
index 331b26c..0528674 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSerializer.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSerializer.java
@@ -19,8 +19,7 @@ package org.apache.nifi.controller;
 import java.io.OutputStream;
 
 /**
- * Serializes the flow configuration of a controller instance to an output
- * stream.
+ * Serializes the flow configuration of a controller instance to an output stream.
  *
  * @author unattributed
  */

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSynchronizationException.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSynchronizationException.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSynchronizationException.java
index 706ac46..68673b4 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSynchronizationException.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSynchronizationException.java
@@ -17,8 +17,7 @@
 package org.apache.nifi.controller;
 
 /**
- * Represents the exceptional case when a controller managing an existing flow
- * fails to fully load a different flow.
+ * Represents the exceptional case when a controller managing an existing flow fails to fully load a different flow.
  *
  * @author unattributed
  */

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSynchronizer.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSynchronizer.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSynchronizer.java
index f6889fe..275f816 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSynchronizer.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowSynchronizer.java
@@ -25,27 +25,18 @@ import org.apache.nifi.encrypt.StringEncryptor;
 public interface FlowSynchronizer {
 
     /**
-     * Synchronizes the given controller with the given flow configuration. If
-     * loading the proposed flow configuration would cause the controller to
-     * orphan flow files, then an UninheritableFlowException is thrown.
+     * Synchronizes the given controller with the given flow configuration. If loading the proposed flow configuration would cause the controller to orphan flow files, then an
+     * UninheritableFlowException is thrown.
      *
-     * If the FlowSynchronizationException is thrown, then the controller may
-     * have changed some of its state and should no longer be used.
+     * If the FlowSynchronizationException is thrown, then the controller may have changed some of its state and should no longer be used.
      *
      * @param controller the flow controller
-     * @param dataFlow the flow to load the controller with. If the flow is null
-     * or zero length, then the controller must not have a flow or else an
-     * UninheritableFlowException will be thrown.
-     * @param encryptor used for the encryption/decryption of sensitive property
-     * values
+     * @param dataFlow the flow to load the controller with. If the flow is null or zero length, then the controller must not have a flow or else an UninheritableFlowException will be thrown.
+     * @param encryptor used for the encryption/decryption of sensitive property values
      *
-     * @throws FlowSerializationException if proposed flow is not a valid flow
-     * configuration file
-     * @throws UninheritableFlowException if the proposed flow cannot be loaded
-     * by the controller because in doing so would risk orphaning flow files
-     * @throws FlowSynchronizationException if updates to the controller failed.
-     * If this exception is thrown, then the controller should be considered
-     * unsafe to be used
+     * @throws FlowSerializationException if proposed flow is not a valid flow configuration file
+     * @throws UninheritableFlowException if the proposed flow cannot be loaded by the controller because in doing so would risk orphaning flow files
+     * @throws FlowSynchronizationException if updates to the controller failed. If this exception is thrown, then the controller should be considered unsafe to be used
      */
     void sync(FlowController controller, DataFlow dataFlow, StringEncryptor encryptor)
             throws FlowSerializationException, UninheritableFlowException, FlowSynchronizationException;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowUnmarshaller.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowUnmarshaller.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowUnmarshaller.java
index 7cc3039..cddb798 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowUnmarshaller.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/FlowUnmarshaller.java
@@ -38,9 +38,7 @@ import org.xml.sax.SAXException;
 public class FlowUnmarshaller {
 
     /**
-     * Interprets the given byte array as an XML document that conforms to the
-     * Flow Configuration schema and returns a FlowSnippetDTO representing the
-     * flow
+     * Interprets the given byte array as an XML document that conforms to the Flow Configuration schema and returns a FlowSnippetDTO representing the flow
      *
      * @param flowContents contents
      * @param encryptor encryptor

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/StandardFlowSynchronizer.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/StandardFlowSynchronizer.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/StandardFlowSynchronizer.java
index b66bedc..5448174 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/StandardFlowSynchronizer.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/StandardFlowSynchronizer.java
@@ -1030,15 +1030,13 @@ public class StandardFlowSynchronizer implements FlowSynchronizer {
     }
 
     /**
-     * Returns true if the given controller can inherit the proposed flow
-     * without orphaning flow files.
+     * Returns true if the given controller can inherit the proposed flow without orphaning flow files.
      *
      * @param existingFlow flow
      * @param controller the running controller
      * @param proposedFlow the flow to inherit
      *
-     * @return null if the controller can inherit the specified flow, an
-     * explanation of why it cannot be inherited otherwise
+     * @return null if the controller can inherit the specified flow, an explanation of why it cannot be inherited otherwise
      *
      * @throws FingerprintException if flow fingerprints could not be generated
      */
@@ -1080,14 +1078,12 @@ public class StandardFlowSynchronizer implements FlowSynchronizer {
     }
 
     /**
-     * Returns true if the given controller can inherit the proposed flow
-     * without orphaning flow files.
+     * Returns true if the given controller can inherit the proposed flow without orphaning flow files.
      *
      * @param existingFlow flow
      * @param proposedFlow the flow to inherit
      *
-     * @return null if the controller can inherit the specified flow, an
-     * explanation of why it cannot be inherited otherwise
+     * @return null if the controller can inherit the specified flow, an explanation of why it cannot be inherited otherwise
      *
      * @throws FingerprintException if flow fingerprints could not be generated
      */

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/StandardProcessorNode.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/StandardProcessorNode.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/StandardProcessorNode.java
index eb7ec83..7820b7b 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/StandardProcessorNode.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/StandardProcessorNode.java
@@ -67,10 +67,8 @@ import org.quartz.CronExpression;
 import org.slf4j.LoggerFactory;
 
 /**
- * ProcessorNode provides thread-safe access to a FlowFileProcessor as it exists
- * within a controlled flow. This node keeps track of the processor, its
- * scheduling information and its relationships to other processors and whatever
- * scheduled futures exist for it. Must be thread safe.
+ * ProcessorNode provides thread-safe access to a FlowFileProcessor as it exists within a controlled flow. This node keeps track of the processor, its scheduling information and its relationships to
+ * other processors and whatever scheduled futures exist for it. Must be thread safe.
  *
  * @author none
  */
@@ -171,8 +169,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * Provides and opportunity to retain information about this particular
-     * processor instance
+     * Provides and opportunity to retain information about this particular processor instance
      *
      * @param comments new comments
      */
@@ -222,8 +219,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * @return if true flow file content generated by this processor is
-     * considered loss tolerant
+     * @return if true flow file content generated by this processor is considered loss tolerant
      */
     @Override
     public boolean isLossTolerant() {
@@ -236,8 +232,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * @return true if the processor has the {@link TriggerWhenEmpty}
-     * annotation, false otherwise.
+     * @return true if the processor has the {@link TriggerWhenEmpty} annotation, false otherwise.
      */
     @Override
     public boolean isTriggerWhenEmpty() {
@@ -245,8 +240,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * @return true if the processor has the {@link SideEffectFree} annotation,
-     * false otherwise.
+     * @return true if the processor has the {@link SideEffectFree} annotation, false otherwise.
      */
     @Override
     public boolean isSideEffectFree() {
@@ -259,8 +253,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * @return true if the processor has the
-     * {@link TriggerWhenAnyDestinationAvailable} annotation, false otherwise.
+     * @return true if the processor has the {@link TriggerWhenAnyDestinationAvailable} annotation, false otherwise.
      */
     @Override
     public boolean isTriggerWhenAnyDestinationAvailable() {
@@ -268,8 +261,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * Indicates whether flow file content made by this processor must be
-     * persisted
+     * Indicates whether flow file content made by this processor must be persisted
      *
      * @param lossTolerant tolerant
      */
@@ -332,8 +324,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * @return an unmodifiable Set that contains all of the
-     * ProcessorRelationship objects that are configured to be auto-terminated
+     * @return an unmodifiable Set that contains all of the ProcessorRelationship objects that are configured to be auto-terminated
      */
     @Override
     public Set<Relationship> getAutoTerminatedRelationships() {
@@ -350,8 +341,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * @return the value of the processor's {@link CapabilityDescription}
-     * annotation, if one exists, else <code>null</code>.
+     * @return the value of the processor's {@link CapabilityDescription} annotation, if one exists, else <code>null</code>.
      */
     @SuppressWarnings("deprecation")
     public String getProcessorDescription() {
@@ -384,11 +374,8 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * @param timeUnit determines the unit of time to represent the scheduling
-     * period. If null will be reported in units of
-     * {@link #DEFAULT_SCHEDULING_TIME_UNIT}
-     * @return the schedule period that should elapse before subsequent cycles
-     * of this processor's tasks
+     * @param timeUnit determines the unit of time to represent the scheduling period. If null will be reported in units of {@link #DEFAULT_SCHEDULING_TIME_UNIT}
+     * @return the schedule period that should elapse before subsequent cycles of this processor's tasks
      */
     @Override
     public long getSchedulingPeriod(final TimeUnit timeUnit) {
@@ -410,8 +397,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
      *
      * @param schedulingStrategy strategy
      *
-     * @throws IllegalArgumentException if the SchedulingStrategy is not not
-     * applicable for this Processor
+     * @throws IllegalArgumentException if the SchedulingStrategy is not not applicable for this Processor
      */
     @Override
     public void setSchedulingStrategy(final SchedulingStrategy schedulingStrategy) {
@@ -538,10 +524,8 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * Causes the processor not to be scheduled for some period of time. This
-     * duration can be obtained and set via the
-     * {@link #getYieldPeriod(TimeUnit)} and
-     * {@link #setYieldPeriod(long, TimeUnit)} methods.
+     * Causes the processor not to be scheduled for some period of time. This duration can be obtained and set via the {@link #getYieldPeriod(TimeUnit)} and {@link #setYieldPeriod(long, TimeUnit)}
+     * methods.
      */
     @Override
     public void yield() {
@@ -561,8 +545,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * @return the number of milliseconds since Epoch at which time this
-     * processor is to once again be scheduled.
+     * @return the number of milliseconds since Epoch at which time this processor is to once again be scheduled.
      */
     @Override
     public long getYieldExpiration() {
@@ -597,11 +580,9 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * Determines the number of concurrent tasks that may be running for this
-     * processor.
+     * Determines the number of concurrent tasks that may be running for this processor.
      *
-     * @param taskCount a number of concurrent tasks this processor may have
-     * running
+     * @param taskCount a number of concurrent tasks this processor may have running
      * @throws IllegalArgumentException if the given value is less than 1
      */
     @Override
@@ -628,8 +609,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * @return the number of tasks that may execute concurrently for this
-     * processor
+     * @return the number of tasks that may execute concurrently for this processor
      */
     @Override
     public int getMaxConcurrentTasks() {
@@ -857,8 +837,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
 
     /**
      * @param relationshipName name
-     * @return the relationship for this nodes processor for the given name or
-     * creates a new relationship for the given name
+     * @return the relationship for this nodes processor for the given name or creates a new relationship for the given name
      */
     @Override
     public Relationship getRelationship(final String relationshipName) {
@@ -885,8 +864,7 @@ public class StandardProcessorNode extends ProcessorNode implements Connectable
     }
 
     /**
-     * @return the Set of destination processors for all relationships excluding
-     * any destinations that are this processor itself (self-loops)
+     * @return the Set of destination processors for all relationships excluding any destinations that are this processor itself (self-loops)
      */
     public Set<Connectable> getDestinations() {
         final Set<Connectable> nonSelfDestinations = new HashSet<>();

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/TemplateManager.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/TemplateManager.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/TemplateManager.java
index 6a11a33..7b8e173 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/TemplateManager.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/TemplateManager.java
@@ -98,18 +98,14 @@ public class TemplateManager {
     }
 
     /**
-     * Adds a template to this manager. The contents of this template must be
-     * part of the current flow. This is going create a template based on a
-     * snippet of this flow. Any sensitive properties in the TemplateDTO will be
-     * removed.
+     * Adds a template to this manager. The contents of this template must be part of the current flow. This is going create a template based on a snippet of this flow. Any sensitive properties in the
+     * TemplateDTO will be removed.
      *
      * @param dto dto
      * @return a copy of the given DTO
      * @throws IOException if an I/O error occurs when persisting the Template
      * @throws NullPointerException if the DTO is null
-     * @throws IllegalArgumentException if does not contain all required
-     * information, such as the template name or a processor's configuration
-     * element
+     * @throws IllegalArgumentException if does not contain all required information, such as the template name or a processor's configuration element
      */
     public Template addTemplate(final TemplateDTO dto) throws IOException {
         scrubTemplate(dto.getSnippet());
@@ -246,8 +242,7 @@ public class TemplateManager {
     }
 
     /**
-     * Scrubs the template prior to persisting in order to remove fields that
-     * shouldn't be included or are unnecessary.
+     * Scrubs the template prior to persisting in order to remove fields that shouldn't be included or are unnecessary.
      *
      * @param snippet snippet
      */
@@ -294,8 +289,7 @@ public class TemplateManager {
     }
 
     /**
-     * Scrubs processors prior to saving. This includes removing sensitive
-     * properties, validation errors, property descriptors, etc.
+     * Scrubs processors prior to saving. This includes removing sensitive properties, validation errors, property descriptors, etc.
      *
      * @param processors procs
      */
@@ -348,8 +342,7 @@ public class TemplateManager {
     }
 
     /**
-     * Scrubs connections prior to saving. This includes removing available
-     * relationships.
+     * Scrubs connections prior to saving. This includes removing available relationships.
      *
      * @param connections conns
      */

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/UninheritableFlowException.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/UninheritableFlowException.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/UninheritableFlowException.java
index ac6fc5f..2f9f0f8 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/UninheritableFlowException.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/UninheritableFlowException.java
@@ -17,8 +17,7 @@
 package org.apache.nifi.controller;
 
 /**
- * Represents the exceptional case when a controller is to be loaded with a flow
- * that is fundamentally different than its existing flow.
+ * Represents the exceptional case when a controller is to be loaded with a flow that is fundamentally different than its existing flow.
  *
  * @author unattributed
  */

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/FileSystemRepository.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/FileSystemRepository.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/FileSystemRepository.java
index d69b417..e212bdb 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/FileSystemRepository.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/FileSystemRepository.java
@@ -1280,9 +1280,7 @@ public class FileSystemRepository implements ContentRepository {
         }
 
         /**
-         * @return {@code true} if wait is required to create claims against
-         * this Container, based on whether or not the container has reached its
-         * back pressure threshold
+         * @return {@code true} if wait is required to create claims against this Container, based on whether or not the container has reached its back pressure threshold
          */
         public boolean isWaitRequired() {
             if (!archiveEnabled) {

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/ProcessContext.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/ProcessContext.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/ProcessContext.java
index 7502641..1937d0d 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/ProcessContext.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/ProcessContext.java
@@ -77,9 +77,7 @@ public class ProcessContext {
     }
 
     /**
-     * @return an unmodifiable list containing a copy of all incoming
-     * connections for the processor from which FlowFiles are allowed to be
-     * pulled
+     * @return an unmodifiable list containing a copy of all incoming connections for the processor from which FlowFiles are allowed to be pulled
      */
     List<Connection> getPollableConnections() {
         if (pollFromSelfLoopsOnly()) {
@@ -106,9 +104,7 @@ public class ProcessContext {
     }
 
     /**
-     * @return true if we are allowed to take FlowFiles only from self-loops.
-     * This is the case when no Relationships are available except for
-     * self-looping Connections
+     * @return true if we are allowed to take FlowFiles only from self-loops. This is the case when no Relationships are available except for self-looping Connections
      */
     private boolean pollFromSelfLoopsOnly() {
         if (isTriggerWhenAnyDestinationAvailable()) {
@@ -217,14 +213,10 @@ public class ProcessContext {
     }
 
     /**
-     * A Relationship is said to be Available if and only if all Connections for
-     * that Relationship are either self-loops or have non-full queues.
+     * A Relationship is said to be Available if and only if all Connections for that Relationship are either self-loops or have non-full queues.
      *
-     * @param requiredNumber minimum number of relationships that must have
-     * availability
-     * @return Checks if at least <code>requiredNumber</code> of
-     * Relationationships are "available." If so, returns <code>true</code>,
-     * otherwise returns <code>false</code>
+     * @param requiredNumber minimum number of relationships that must have availability
+     * @return Checks if at least <code>requiredNumber</code> of Relationationships are "available." If so, returns <code>true</code>, otherwise returns <code>false</code>
      */
     public boolean isRelationshipAvailabilitySatisfied(final int requiredNumber) {
         int unavailable = 0;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/ProvenanceEventEnricher.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/ProvenanceEventEnricher.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/ProvenanceEventEnricher.java
index db098fc..323bfb0 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/ProvenanceEventEnricher.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/ProvenanceEventEnricher.java
@@ -22,8 +22,7 @@ import org.apache.nifi.provenance.ProvenanceEventRecord;
 public interface ProvenanceEventEnricher {
 
     /**
-     * Returns a new Provenance event that has been updated to contain the
-     * original and updated FlowFile attributes and content claim information.
+     * Returns a new Provenance event that has been updated to contain the original and updated FlowFile attributes and content claim information.
      *
      * @param record record
      * @param flowFile flowfile

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/RepositoryPurgeException.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/RepositoryPurgeException.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/RepositoryPurgeException.java
index e668be3..710bb79 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/RepositoryPurgeException.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/RepositoryPurgeException.java
@@ -17,8 +17,7 @@
 package org.apache.nifi.controller.repository;
 
 /**
- * This exception is thrown when a flow file repository was unable to be
- * properly purged.
+ * This exception is thrown when a flow file repository was unable to be properly purged.
  *
  *
  */

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardFlowFileRecord.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardFlowFileRecord.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardFlowFileRecord.java
index 433c3d2..6bb5e35 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardFlowFileRecord.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardFlowFileRecord.java
@@ -37,9 +37,7 @@ import org.apache.commons.lang3.builder.ToStringStyle;
 
 /**
  * <p>
- * A flow file is a logical notion of an item in a flow with its associated
- * attributes and identity which can be used as a reference for its actual
- * content.</p>
+ * A flow file is a logical notion of an item in a flow with its associated attributes and identity which can be used as a reference for its actual content.</p>
  *
  * <b>Immutable - Thread Safe</b>
  *
@@ -127,8 +125,7 @@ public final class StandardFlowFileRecord implements FlowFile, FlowFileRecord {
     }
 
     /**
-     * Provides the natural ordering for FlowFile objects which is based on
-     * their identifier.
+     * Provides the natural ordering for FlowFile objects which is based on their identifier.
      *
      * @param other other
      * @return standard compare contract

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardProcessSession.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardProcessSession.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardProcessSession.java
index 4827ab7..d3b0690 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardProcessSession.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardProcessSession.java
@@ -81,9 +81,7 @@ import org.slf4j.LoggerFactory;
 
 /**
  * <p>
- * Provides a ProcessSession that ensures all accesses, changes and transfers
- * occur in an atomic manner for all FlowFiles including their contents and
- * attributes</p>
+ * Provides a ProcessSession that ensures all accesses, changes and transfers occur in an atomic manner for all FlowFiles including their contents and attributes</p>
  * <p>
  * NOT THREAD SAFE</p>
  * <p/>
@@ -770,10 +768,8 @@ public final class StandardProcessSession implements ProcessSession, ProvenanceE
     }
 
     /**
-     * Checks if the given event is a spurious FORK, meaning that the FORK has a
-     * single child and that child was removed in this session. This happens
-     * when a Processor calls #create(FlowFile) and then removes the created
-     * FlowFile.
+     * Checks if the given event is a spurious FORK, meaning that the FORK has a single child and that child was removed in this session. This happens when a Processor calls #create(FlowFile) and then
+     * removes the created FlowFile.
      *
      * @param event event
      * @return true if spurious fork
@@ -790,10 +786,8 @@ public final class StandardProcessSession implements ProcessSession, ProvenanceE
     }
 
     /**
-     * Checks if the given event is a spurious ROUTE, meaning that the ROUTE
-     * indicates that a FlowFile was routed to a relationship with only 1
-     * connection and that Connection is the Connection from which the FlowFile
-     * was pulled. I.e., the FlowFile was really routed nowhere.
+     * Checks if the given event is a spurious ROUTE, meaning that the ROUTE indicates that a FlowFile was routed to a relationship with only 1 connection and that Connection is the Connection from
+     * which the FlowFile was pulled. I.e., the FlowFile was really routed nowhere.
      *
      * @param event event
      * @param records records
@@ -2085,13 +2079,10 @@ public final class StandardProcessSession implements ProcessSession, ProvenanceE
     }
 
     /**
-     * Checks if the ContentClaim associated with this record should be removed,
-     * since the record is about to be updated to point to a new content claim.
-     * If so, removes the working claim.
+     * Checks if the ContentClaim associated with this record should be removed, since the record is about to be updated to point to a new content claim. If so, removes the working claim.
      *
-     * This happens if & only if the content of this FlowFile has been modified
-     * since it was last committed to the FlowFile repository, because this
-     * indicates that the content is no longer needed and should be cleaned up.
+     * This happens if & only if the content of this FlowFile has been modified since it was last committed to the FlowFile repository, because this indicates that the content is no longer needed and
+     * should be cleaned up.
      *
      * @param record record
      */
@@ -2155,8 +2146,7 @@ public final class StandardProcessSession implements ProcessSession, ProvenanceE
     }
 
     /**
-     * @return Indicates whether or not multiple FlowFiles should be merged into
-     * a single ContentClaim
+     * @return Indicates whether or not multiple FlowFiles should be merged into a single ContentClaim
      */
     private boolean isMergeContent() {
         if (writeRecursionLevel > 0) {
@@ -2573,8 +2563,7 @@ public final class StandardProcessSession implements ProcessSession, ProvenanceE
     }
 
     /**
-     * Returns the attributes that are common to every FlowFile given. The key
-     * and value must match exactly.
+     * Returns the attributes that are common to every FlowFile given. The key and value must match exactly.
      *
      * @param flowFileList a list of FlowFiles
      *
@@ -2629,8 +2618,7 @@ public final class StandardProcessSession implements ProcessSession, ProvenanceE
     }
 
     /**
-     * Callback interface used to poll a FlowFileQueue, in order to perform
-     * functional programming-type of polling a queue
+     * Callback interface used to poll a FlowFileQueue, in order to perform functional programming-type of polling a queue
      */
     private static interface QueuePoller {
 

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardProvenanceReporter.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardProvenanceReporter.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardProvenanceReporter.java
index 5e8bb3e..a55fb25 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardProvenanceReporter.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardProvenanceReporter.java
@@ -67,10 +67,8 @@ public class StandardProvenanceReporter implements ProvenanceReporter {
     }
 
     /**
-     * Generates a Fork event for the given child and parents but does not
-     * register the event. This is useful so that a ProcessSession has the
-     * ability to de-dupe events, since one or more events may be created by the
-     * session itself, as well as by the Processor
+     * Generates a Fork event for the given child and parents but does not register the event. This is useful so that a ProcessSession has the ability to de-dupe events, since one or more events may
+     * be created by the session itself, as well as by the Processor
      *
      * @param parents parents
      * @param child child

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardRepositoryRecord.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardRepositoryRecord.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardRepositoryRecord.java
index c965ed8..5fcb35a 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardRepositoryRecord.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardRepositoryRecord.java
@@ -37,8 +37,7 @@ public class StandardRepositoryRecord implements RepositoryRecord {
     private final Map<String, String> originalAttributes;
 
     /**
-     * Creates a new record which has no original claim or flow file - it is
-     * entirely new
+     * Creates a new record which has no original claim or flow file - it is entirely new
      *
      * @param originalQueue queue
      */

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardRepositoryStatusReport.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardRepositoryStatusReport.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardRepositoryStatusReport.java
index 4e41de1..3e30059 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardRepositoryStatusReport.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/StandardRepositoryStatusReport.java
@@ -21,8 +21,7 @@ import java.util.HashMap;
 import java.util.Map;
 
 /**
- * Encapsulates the status of the processor data transfers as stored in the
- * repository.
+ * Encapsulates the status of the processor data transfers as stored in the repository.
  */
 public class StandardRepositoryStatusReport implements RepositoryStatusReport {
 
@@ -30,8 +29,7 @@ public class StandardRepositoryStatusReport implements RepositoryStatusReport {
     }
 
     /**
-     * Returns a map where the key is the processor ID and the value is the
-     * status entry for the processor.
+     * Returns a map where the key is the processor ID and the value is the status entry for the processor.
      *
      * @return a map of report entries
      */
@@ -41,11 +39,9 @@ public class StandardRepositoryStatusReport implements RepositoryStatusReport {
     }
 
     /**
-     * Returns a particular entry for a given processor ID. If the processor ID
-     * does not exist, then null is returned.
+     * Returns a particular entry for a given processor ID. If the processor ID does not exist, then null is returned.
      *
-     * @param componentId the ID of a component; that component may be a
-     * Processor, a Connection, a ProcessGroup, etc.
+     * @param componentId the ID of a component; that component may be a Processor, a Connection, a ProcessGroup, etc.
      *
      * @return a status entry
      */

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/e811929f/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/VolatileContentRepository.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/VolatileContentRepository.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/VolatileContentRepository.java
index 65756f4..5971865 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/VolatileContentRepository.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/repository/VolatileContentRepository.java
@@ -54,33 +54,24 @@ import org.slf4j.LoggerFactory;
 
 /**
  * <p>
- * An in-memory implementation of the {@link ContentRepository} interface. This
- * implementation stores FlowFile content in the Java heap and keeps track of
- * the number of bytes used. If the number of bytes used by FlowFile content
- * exceeds some threshold (configured via the
- * <code>nifi.volatile.content.repository.max.size</code> property in the NiFi
- * properties with a default of 100 MB), one of two situations will occur:
+ * An in-memory implementation of the {@link ContentRepository} interface. This implementation stores FlowFile content in the Java heap and keeps track of the number of bytes used. If the number of
+ * bytes used by FlowFile content exceeds some threshold (configured via the <code>nifi.volatile.content.repository.max.size</code> property in the NiFi properties with a default of 100 MB), one of
+ * two situations will occur:
  * </p>
  *
  * <ul>
- * <li><b>Backup Repository:</b> If a Backup Repository has been specified (via
- * the {@link #setBackupRepository(ContentRepository)} method), the content will
- * be stored in the backup repository and all access to the FlowFile content
- * will automatically and transparently be proxied to the backup repository.
+ * <li><b>Backup Repository:</b> If a Backup Repository has been specified (via the {@link #setBackupRepository(ContentRepository)} method), the content will be stored in the backup repository and all
+ * access to the FlowFile content will automatically and transparently be proxied to the backup repository.
  * </li>
  * <li>
- * <b>Without Backup Repository:</b> If no Backup Repository has been specified,
- * when the threshold is exceeded, an IOException will be thrown.
+ * <b>Without Backup Repository:</b> If no Backup Repository has been specified, when the threshold is exceeded, an IOException will be thrown.
  * </li>
  * </ul>
  *
  * <p>
- * When a Content Claim is created via the {@link #create(boolean)} method, if
- * the <code>lossTolerant</code> flag is set to <code>false</code>, the Backup
- * Repository will be used to create the Content Claim and any accesses to the
- * ContentClaim will be proxied to the Backup Repository. If the Backup
- * Repository has not been specified, attempting to create a non-loss-tolerant
- * ContentClaim will result in an {@link IllegalStateException} being thrown.
+ * When a Content Claim is created via the {@link #create(boolean)} method, if the <code>lossTolerant</code> flag is set to <code>false</code>, the Backup Repository will be used to create the Content
+ * Claim and any accesses to the ContentClaim will be proxied to the Backup Repository. If the Backup Repository has not been specified, attempting to create a non-loss-tolerant ContentClaim will
+ * result in an {@link IllegalStateException} being thrown.
  * </p>
  */
 public class VolatileContentRepository implements ContentRepository {
@@ -144,8 +135,7 @@ public class VolatileContentRepository implements ContentRepository {
     }
 
     /**
-     * Specifies a Backup Repository where data should be written if this
-     * Repository fills up
+     * Specifies a Backup Repository where data should be written if this Repository fills up
      *
      * @param backup repo backup
      */