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/23 05:48:55 UTC

[2/4] incubator-nifi git commit: NIFI-271 more cleanup

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/ReportingTaskResource.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/ReportingTaskResource.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/ReportingTaskResource.java
index 38ddc36..485b8fd 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/ReportingTaskResource.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/ReportingTaskResource.java
@@ -77,15 +77,15 @@ public class ReportingTaskResource extends ApplicationResource {
     private NiFiServiceFacade serviceFacade;
     private WebClusterManager clusterManager;
     private NiFiProperties properties;
-    
+
     @Context
     private ServletContext servletContext;
-    
+
     /**
      * Populates the uri for the specified reporting task.
-     * 
+     *
      * @param reportingTasks
-     * @return 
+     * @return
      */
     private Set<ReportingTaskDTO> populateRemainingReportingTasksContent(final String availability, final Set<ReportingTaskDTO> reportingTasks) {
         for (ReportingTaskDTO reportingTask : reportingTasks) {
@@ -93,7 +93,7 @@ public class ReportingTaskResource extends ApplicationResource {
         }
         return reportingTasks;
     }
-    
+
     /**
      * Populates the uri for the specified reporting task.
      */
@@ -101,7 +101,7 @@ public class ReportingTaskResource extends ApplicationResource {
         // populate the reporting task href
         reportingTask.setUri(generateResourceUri("controller", "reporting-tasks", availability, reportingTask.getId()));
         reportingTask.setAvailability(availability);
-        
+
         // see if this processor has any ui extensions
         final UiExtensionMapping uiExtensionMapping = (UiExtensionMapping) servletContext.getAttribute("nifi-ui-extensions");
         if (uiExtensionMapping.hasUiExtension(reportingTask.getType())) {
@@ -112,16 +112,16 @@ public class ReportingTaskResource extends ApplicationResource {
                 }
             }
         }
-        
+
         return reportingTask;
     }
 
     /**
-     * Parses the availability and ensure that the specified availability makes sense for the
-     * given NiFi instance.
-     * 
+     * Parses the availability and ensure that the specified availability makes
+     * sense for the given NiFi instance.
+     *
      * @param availability
-     * @return 
+     * @return
      */
     private Availability parseAvailability(final String availability) {
         final Availability avail;
@@ -130,23 +130,24 @@ public class ReportingTaskResource extends ApplicationResource {
         } catch (IllegalArgumentException iae) {
             throw new IllegalArgumentException(String.format("Availability: Value must be one of [%s]", StringUtils.join(Availability.values(), ", ")));
         }
-        
+
         // ensure this nifi is an NCM is specifying NCM availability
         if (!properties.isClusterManager() && Availability.NCM.equals(avail)) {
             throw new IllegalArgumentException("Availability of NCM is only applicable when the NiFi instance is the cluster manager.");
         }
-        
+
         return avail;
     }
-    
+
     /**
      * Retrieves all the of reporting tasks in this NiFi.
      *
      * @param clientId Optional client id. If the client id is not specified, a
      * new one will be generated. This value (whether specified or generated) is
      * included in the response.
-     * @param availability Whether the reporting task is available on the NCM only (ncm) or on the 
-     * nodes only (node). If this instance is not clustered all tasks should use the node availability.
+     * @param availability Whether the reporting task is available on the NCM
+     * only (ncm) or on the nodes only (node). If this instance is not clustered
+     * all tasks should use the node availability.
      * @return A reportingTasksEntity.
      */
     @GET
@@ -156,7 +157,7 @@ public class ReportingTaskResource extends ApplicationResource {
     @TypeHint(ReportingTasksEntity.class)
     public Response getReportingTasks(@QueryParam(CLIENT_ID) @DefaultValue(StringUtils.EMPTY) ClientIdParameter clientId, @PathParam("availability") String availability) {
         final Availability avail = parseAvailability(availability);
-        
+
         // replicate if cluster manager
         if (properties.isClusterManager() && Availability.NODE.equals(avail)) {
             return clusterManager.applyRequest(HttpMethod.GET, getAbsolutePath(), getRequestParameters(true), getHeaders()).getResponse();
@@ -164,7 +165,7 @@ public class ReportingTaskResource extends ApplicationResource {
 
         // get all the reporting tasks
         final Set<ReportingTaskDTO> reportingTasks = populateRemainingReportingTasksContent(availability, serviceFacade.getReportingTasks());
-        
+
         // create the revision
         final RevisionDTO revision = new RevisionDTO();
         revision.setClientId(clientId.getClientId());
@@ -187,8 +188,9 @@ public class ReportingTaskResource extends ApplicationResource {
      * @param clientId Optional client id. If the client id is not specified, a
      * new one will be generated. This value (whether specified or generated) is
      * included in the response.
-     * @param availability Whether the reporting task is available on the NCM only (ncm) or on the 
-     * nodes only (node). If this instance is not clustered all tasks should use the node availability.
+     * @param availability Whether the reporting task is available on the NCM
+     * only (ncm) or on the nodes only (node). If this instance is not clustered
+     * all tasks should use the node availability.
      * @param type The type of reporting task to create.
      * @return A reportingTaskEntity.
      */
@@ -202,9 +204,9 @@ public class ReportingTaskResource extends ApplicationResource {
             @Context HttpServletRequest httpServletRequest,
             @FormParam(VERSION) LongParameter version,
             @FormParam(CLIENT_ID) @DefaultValue(StringUtils.EMPTY) ClientIdParameter clientId,
-            @PathParam("availability") String availability, 
+            @PathParam("availability") String availability,
             @FormParam("type") String type) {
-        
+
         // create the reporting task DTO
         final ReportingTaskDTO reportingTaskDTO = new ReportingTaskDTO();
         reportingTaskDTO.setType(type);
@@ -228,8 +230,9 @@ public class ReportingTaskResource extends ApplicationResource {
      * Creates a new Reporting Task.
      *
      * @param httpServletRequest
-     * @param availability Whether the reporting task is available on the NCM only (ncm) or on the 
-     * nodes only (node). If this instance is not clustered all tasks should use the node availability.
+     * @param availability Whether the reporting task is available on the NCM
+     * only (ncm) or on the nodes only (node). If this instance is not clustered
+     * all tasks should use the node availability.
      * @param reportingTaskEntity A reportingTaskEntity.
      * @return A reportingTaskEntity.
      */
@@ -241,27 +244,27 @@ public class ReportingTaskResource extends ApplicationResource {
     @TypeHint(ReportingTaskEntity.class)
     public Response createReportingTask(
             @Context HttpServletRequest httpServletRequest,
-            @PathParam("availability") String availability, 
+            @PathParam("availability") String availability,
             ReportingTaskEntity reportingTaskEntity) {
-        
+
         final Availability avail = parseAvailability(availability);
 
-        if (reportingTaskEntity == null || reportingTaskEntity.getReportingTask()== null) {
+        if (reportingTaskEntity == null || reportingTaskEntity.getReportingTask() == null) {
             throw new IllegalArgumentException("Reporting task details must be specified.");
         }
 
         if (reportingTaskEntity.getRevision() == null) {
             throw new IllegalArgumentException("Revision must be specified.");
         }
-        
+
         if (reportingTaskEntity.getReportingTask().getId() != null) {
             throw new IllegalArgumentException("Reporting task ID cannot be specified.");
         }
-        
+
         if (StringUtils.isBlank(reportingTaskEntity.getReportingTask().getType())) {
             throw new IllegalArgumentException("The type of reporting task to create must be specified.");
         }
-        
+
         // get the revision
         final RevisionDTO revision = reportingTaskEntity.getRevision();
 
@@ -320,8 +323,9 @@ public class ReportingTaskResource extends ApplicationResource {
      * @param clientId Optional client id. If the client id is not specified, a
      * new one will be generated. This value (whether specified or generated) is
      * included in the response.
-     * @param availability Whether the reporting task is available on the NCM only (ncm) or on the 
-     * nodes only (node). If this instance is not clustered all tasks should use the node availability.
+     * @param availability Whether the reporting task is available on the NCM
+     * only (ncm) or on the nodes only (node). If this instance is not clustered
+     * all tasks should use the node availability.
      * @param id The id of the reporting task to retrieve
      * @return A reportingTaskEntity.
      */
@@ -330,11 +334,11 @@ public class ReportingTaskResource extends ApplicationResource {
     @Path("/{availability}/{id}")
     @PreAuthorize("hasAnyRole('ROLE_MONITOR', 'ROLE_DFM', 'ROLE_ADMIN')")
     @TypeHint(ReportingTaskEntity.class)
-    public Response getReportingTask(@QueryParam(CLIENT_ID) @DefaultValue(StringUtils.EMPTY) ClientIdParameter clientId, 
+    public Response getReportingTask(@QueryParam(CLIENT_ID) @DefaultValue(StringUtils.EMPTY) ClientIdParameter clientId,
             @PathParam("availability") String availability, @PathParam("id") String id) {
 
         final Availability avail = parseAvailability(availability);
-        
+
         // replicate if cluster manager
         if (properties.isClusterManager() && Availability.NODE.equals(avail)) {
             return clusterManager.applyRequest(HttpMethod.GET, getAbsolutePath(), getRequestParameters(true), getHeaders()).getResponse();
@@ -354,10 +358,10 @@ public class ReportingTaskResource extends ApplicationResource {
 
         return clusterContext(generateOkResponse(entity)).build();
     }
-    
+
     /**
      * Returns the descriptor for the specified property.
-     * 
+     *
      * @param clientId Optional client id. If the client id is not specified, a
      * new one will be generated. This value (whether specified or generated) is
      * included in the response.
@@ -372,38 +376,38 @@ public class ReportingTaskResource extends ApplicationResource {
     @PreAuthorize("hasAnyRole('ROLE_MONITOR', 'ROLE_DFM', 'ROLE_ADMIN')")
     @TypeHint(PropertyDescriptorEntity.class)
     public Response getPropertyDescriptor(
-            @QueryParam(CLIENT_ID) @DefaultValue(StringUtils.EMPTY) ClientIdParameter clientId, 
-            @PathParam("availability") String availability, @PathParam("id") String id, 
+            @QueryParam(CLIENT_ID) @DefaultValue(StringUtils.EMPTY) ClientIdParameter clientId,
+            @PathParam("availability") String availability, @PathParam("id") String id,
             @QueryParam("propertyName") String propertyName) {
-        
+
         final Availability avail = parseAvailability(availability);
-        
+
         // ensure the property name is specified
         if (propertyName == null) {
             throw new IllegalArgumentException("The property name must be specified.");
         }
-        
+
         // replicate if cluster manager and task is on node
         if (properties.isClusterManager() && Availability.NODE.equals(avail)) {
             return clusterManager.applyRequest(HttpMethod.GET, getAbsolutePath(), getRequestParameters(true), getHeaders()).getResponse();
         }
-        
+
         // get the property descriptor
         final PropertyDescriptorDTO descriptor = serviceFacade.getReportingTaskPropertyDescriptor(id, propertyName);
-        
+
         // create the revision
         final RevisionDTO revision = new RevisionDTO();
         revision.setClientId(clientId.getClientId());
-        
+
         // generate the response entity
         final PropertyDescriptorEntity entity = new PropertyDescriptorEntity();
         entity.setRevision(revision);
         entity.setPropertyDescriptor(descriptor);
-        
+
         // generate the response
         return clusterContext(generateOkResponse(entity)).build();
     }
-    
+
     /**
      * Updates the specified reporting task.
      *
@@ -413,12 +417,14 @@ public class ReportingTaskResource extends ApplicationResource {
      * @param clientId Optional client id. If the client id is not specified, a
      * new one will be generated. This value (whether specified or generated) is
      * included in the response.
-     * @param availability Whether the reporting task is available on the NCM only (ncm) or on the 
-     * nodes only (node). If this instance is not clustered all tasks should use the node availability.
+     * @param availability Whether the reporting task is available on the NCM
+     * only (ncm) or on the nodes only (node). If this instance is not clustered
+     * all tasks should use the node availability.
      * @param id The id of the reporting task to update.
      * @param name The name of the reporting task
      * @param annotationData The annotation data for the reporting task
-     * @param markedForDeletion Array of property names whose value should be removed.
+     * @param markedForDeletion Array of property names whose value should be
+     * removed.
      * @param state The updated scheduled state
      * @param schedulingStrategy The scheduling strategy for this reporting task
      * @param schedulingPeriod The scheduling period for this reporting task
@@ -457,7 +463,7 @@ public class ReportingTaskResource extends ApplicationResource {
 
         // create collections for holding the reporting task properties
         final Map<String, String> updatedProperties = new LinkedHashMap<>();
-        
+
         // go through each parameter and look for processor properties
         for (String parameterName : formParams.keySet()) {
             if (StringUtils.isNotBlank(parameterName)) {
@@ -473,12 +479,12 @@ public class ReportingTaskResource extends ApplicationResource {
                 }
             }
         }
-        
+
         // set the properties to remove
         for (String propertyToDelete : markedForDeletion) {
             updatedProperties.put(propertyToDelete, null);
         }
-        
+
         // create the reporting task DTO
         final ReportingTaskDTO reportingTaskDTO = new ReportingTaskDTO();
         reportingTaskDTO.setId(id);
@@ -493,7 +499,7 @@ public class ReportingTaskResource extends ApplicationResource {
         if (!updatedProperties.isEmpty()) {
             reportingTaskDTO.setProperties(updatedProperties);
         }
-        
+
         // create the revision
         final RevisionDTO revision = new RevisionDTO();
         revision.setClientId(clientId.getClientId());
@@ -514,8 +520,9 @@ public class ReportingTaskResource extends ApplicationResource {
      * Updates the specified a Reporting Task.
      *
      * @param httpServletRequest
-     * @param availability Whether the reporting task is available on the NCM only (ncm) or on the 
-     * nodes only (node). If this instance is not clustered all tasks should use the node availability.
+     * @param availability Whether the reporting task is available on the NCM
+     * only (ncm) or on the nodes only (node). If this instance is not clustered
+     * all tasks should use the node availability.
      * @param id The id of the reporting task to update.
      * @param reportingTaskEntity A reportingTaskEntity.
      * @return A reportingTaskEntity.
@@ -528,12 +535,12 @@ public class ReportingTaskResource extends ApplicationResource {
     @TypeHint(ReportingTaskEntity.class)
     public Response updateReportingTask(
             @Context HttpServletRequest httpServletRequest,
-            @PathParam("availability") String availability, 
+            @PathParam("availability") String availability,
             @PathParam("id") String id,
             ReportingTaskEntity reportingTaskEntity) {
 
         final Availability avail = parseAvailability(availability);
-        
+
         if (reportingTaskEntity == null || reportingTaskEntity.getReportingTask() == null) {
             throw new IllegalArgumentException("Reporting task details must be specified.");
         }
@@ -558,7 +565,7 @@ public class ReportingTaskResource extends ApplicationResource {
             // replicate the request
             return clusterManager.applyRequest(HttpMethod.PUT, getAbsolutePath(), updateClientId(reportingTaskEntity), getHeaders(headersToOverride)).getResponse();
         }
-        
+
         // handle expects request (usually from the cluster manager)
         final String expects = httpServletRequest.getHeader(WebClusterManager.NCM_EXPECTS_HTTP_HEADER);
         if (expects != null) {
@@ -596,8 +603,9 @@ public class ReportingTaskResource extends ApplicationResource {
      * @param clientId Optional client id. If the client id is not specified, a
      * new one will be generated. This value (whether specified or generated) is
      * included in the response.
-     * @param availability Whether the reporting task is available on the NCM only (ncm) or on the 
-     * nodes only (node). If this instance is not clustered all tasks should use the node availability.
+     * @param availability Whether the reporting task is available on the NCM
+     * only (ncm) or on the nodes only (node). If this instance is not clustered
+     * all tasks should use the node availability.
      * @param id The id of the reporting task to remove.
      * @return A entity containing the client id and an updated revision.
      */
@@ -613,7 +621,7 @@ public class ReportingTaskResource extends ApplicationResource {
             @PathParam("availability") String availability, @PathParam("id") String id) {
 
         final Availability avail = parseAvailability(availability);
-        
+
         // replicate if cluster manager
         if (properties.isClusterManager() && Availability.NODE.equals(avail)) {
             return clusterManager.applyRequest(HttpMethod.DELETE, getAbsolutePath(), getRequestParameters(true), getHeaders()).getResponse();
@@ -648,7 +656,6 @@ public class ReportingTaskResource extends ApplicationResource {
     }
 
     // setters
-    
     public void setServiceFacade(NiFiServiceFacade serviceFacade) {
         this.serviceFacade = serviceFacade;
     }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/TemplateResource.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/TemplateResource.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/TemplateResource.java
index 0c1b23f..24292e9 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/TemplateResource.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/TemplateResource.java
@@ -71,8 +71,9 @@ public class TemplateResource extends ApplicationResource {
 
     /**
      * Populates the uri for the specified templates.
+     *
      * @param templates
-     * @return 
+     * @return
      */
     public Set<TemplateDTO> populateRemainingTemplatesContent(Set<TemplateDTO> templates) {
         for (TemplateDTO template : templates) {

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/dto/DtoFactory.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/dto/DtoFactory.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/dto/DtoFactory.java
index 4e83ac5..56ee9ba 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/dto/DtoFactory.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/api/dto/DtoFactory.java
@@ -854,7 +854,7 @@ public final class DtoFactory {
         defaultSchedulingPeriod.put(SchedulingStrategy.TIMER_DRIVEN.name(), SchedulingStrategy.TIMER_DRIVEN.getDefaultSchedulingPeriod());
         defaultSchedulingPeriod.put(SchedulingStrategy.CRON_DRIVEN.name(), SchedulingStrategy.CRON_DRIVEN.getDefaultSchedulingPeriod());
         dto.setDefaultSchedulingPeriod(defaultSchedulingPeriod);
-        
+
         // sort a copy of the properties
         final Map<PropertyDescriptor, String> sortedProperties = new TreeMap<>(new Comparator<PropertyDescriptor>() {
             @Override
@@ -874,7 +874,7 @@ public final class DtoFactory {
             }
         }
         orderedProperties.putAll(sortedProperties);
-        
+
         // build the descriptor and property dtos
         dto.setDescriptors(new LinkedHashMap<String, PropertyDescriptorDTO>());
         dto.setProperties(new LinkedHashMap<String, String>());
@@ -893,7 +893,7 @@ public final class DtoFactory {
             // set the property value
             dto.getProperties().put(descriptor.getName(), propertyValue);
         }
-        
+
         // add the validation errors
         final Collection<ValidationResult> validationErrors = reportingTaskNode.getValidationErrors();
         if (validationErrors != null && !validationErrors.isEmpty()) {
@@ -904,10 +904,10 @@ public final class DtoFactory {
 
             dto.setValidationErrors(errors);
         }
-        
+
         return dto;
     }
-    
+
     public ControllerServiceDTO createControllerServiceDto(final ControllerServiceNode controllerServiceNode) {
         final ControllerServiceDTO dto = new ControllerServiceDTO();
         dto.setId(controllerServiceNode.getIdentifier());
@@ -916,7 +916,7 @@ public final class DtoFactory {
         dto.setState(controllerServiceNode.getState().name());
         dto.setAnnotationData(controllerServiceNode.getAnnotationData());
         dto.setComments(controllerServiceNode.getComments());
-        
+
         // sort a copy of the properties
         final Map<PropertyDescriptor, String> sortedProperties = new TreeMap<>(new Comparator<PropertyDescriptor>() {
             @Override
@@ -936,7 +936,7 @@ public final class DtoFactory {
             }
         }
         orderedProperties.putAll(sortedProperties);
-        
+
         // build the descriptor and property dtos
         dto.setDescriptors(new LinkedHashMap<String, PropertyDescriptorDTO>());
         dto.setProperties(new LinkedHashMap<String, String>());
@@ -955,7 +955,7 @@ public final class DtoFactory {
             // set the property value
             dto.getProperties().put(descriptor.getName(), propertyValue);
         }
-        
+
         // create the reference dto's
         dto.setReferencingComponents(createControllerServiceReferencingComponentsDto(controllerServiceNode.getReferences()));
 
@@ -969,23 +969,23 @@ public final class DtoFactory {
 
             dto.setValidationErrors(errors);
         }
-        
+
         return dto;
     }
-    
+
     public Set<ControllerServiceReferencingComponentDTO> createControllerServiceReferencingComponentsDto(final ControllerServiceReference reference) {
         return createControllerServiceReferencingComponentsDto(reference, new HashSet<ControllerServiceNode>());
     }
-    
+
     private Set<ControllerServiceReferencingComponentDTO> createControllerServiceReferencingComponentsDto(final ControllerServiceReference reference, final Set<ControllerServiceNode> visited) {
         final Set<ControllerServiceReferencingComponentDTO> referencingComponents = new LinkedHashSet<>();
-        
+
         // get all references
         for (final ConfiguredComponent component : reference.getReferencingComponents()) {
             final ControllerServiceReferencingComponentDTO dto = new ControllerServiceReferencingComponentDTO();
             dto.setId(component.getIdentifier());
             dto.setName(component.getName());
-            
+
             List<PropertyDescriptor> propertyDescriptors = null;
             Collection<ValidationResult> validationErrors = null;
             if (component instanceof ProcessorNode) {
@@ -995,7 +995,7 @@ public final class DtoFactory {
                 dto.setActiveThreadCount(node.getActiveThreadCount());
                 dto.setType(node.getProcessor().getClass().getName());
                 dto.setReferenceType(Processor.class.getSimpleName());
-                
+
                 propertyDescriptors = node.getProcessor().getPropertyDescriptors();
                 validationErrors = node.getValidationErrors();
             } else if (component instanceof ControllerServiceNode) {
@@ -1004,12 +1004,12 @@ public final class DtoFactory {
                 dto.setType(node.getControllerServiceImplementation().getClass().getName());
                 dto.setReferenceType(ControllerService.class.getSimpleName());
                 dto.setReferenceCycle(visited.contains(node));
-                
+
                 // if we haven't encountered this service before include it's referencing components
                 if (!dto.getReferenceCycle()) {
                     dto.setReferencingComponents(createControllerServiceReferencingComponentsDto(node.getReferences(), visited));
                 }
-                
+
                 propertyDescriptors = node.getControllerServiceImplementation().getPropertyDescriptors();
                 validationErrors = node.getValidationErrors();
             } else if (component instanceof ReportingTaskNode) {
@@ -1018,11 +1018,11 @@ public final class DtoFactory {
                 dto.setActiveThreadCount(node.getActiveThreadCount());
                 dto.setType(node.getReportingTask().getClass().getName());
                 dto.setReferenceType(ReportingTask.class.getSimpleName());
-                
+
                 propertyDescriptors = node.getReportingTask().getPropertyDescriptors();
                 validationErrors = node.getValidationErrors();
             }
-            
+
             if (propertyDescriptors != null && !propertyDescriptors.isEmpty()) {
                 final Map<PropertyDescriptor, String> sortedProperties = new TreeMap<>(new Comparator<PropertyDescriptor>() {
                     @Override
@@ -1057,7 +1057,7 @@ public final class DtoFactory {
                     dto.getProperties().put(descriptor.getName(), propertyValue);
                 }
             }
-            
+
             if (validationErrors != null && !validationErrors.isEmpty()) {
                 final List<String> errors = new ArrayList<>();
                 for (final ValidationResult validationResult : validationErrors) {
@@ -1066,13 +1066,13 @@ public final class DtoFactory {
 
                 dto.setValidationErrors(errors);
             }
-            
+
             referencingComponents.add(dto);
         }
-        
+
         return referencingComponents;
     }
-    
+
     public RemoteProcessGroupPortDTO createRemoteProcessGroupPortDto(final RemoteGroupPort port) {
         if (port == null) {
             return null;
@@ -1324,13 +1324,13 @@ public final class DtoFactory {
     @SuppressWarnings("deprecation")
     private String getCapabilityDescription(final Class<?> cls) {
         final CapabilityDescription capabilityDesc = cls.getAnnotation(CapabilityDescription.class);
-        if ( capabilityDesc != null ) {
+        if (capabilityDesc != null) {
             return capabilityDesc.value();
         }
-        
-        final org.apache.nifi.processor.annotation.CapabilityDescription deprecatedCapabilityDesc =
-                cls.getAnnotation(org.apache.nifi.processor.annotation.CapabilityDescription.class);
-        
+
+        final org.apache.nifi.processor.annotation.CapabilityDescription deprecatedCapabilityDesc
+                = cls.getAnnotation(org.apache.nifi.processor.annotation.CapabilityDescription.class);
+
         return (deprecatedCapabilityDesc == null) ? null : deprecatedCapabilityDesc.value();
     }
 
@@ -1350,8 +1350,8 @@ public final class DtoFactory {
             }
         } else {
             final org.apache.nifi.processor.annotation.Tags deprecatedTagsAnnotation = cls.getAnnotation(org.apache.nifi.processor.annotation.Tags.class);
-            if ( deprecatedTagsAnnotation != null ) {
-                for ( final String tag : deprecatedTagsAnnotation.value() ) {
+            if (deprecatedTagsAnnotation != null) {
+                for (final String tag : deprecatedTagsAnnotation.value()) {
                     tags.add(tag);
                 }
             }
@@ -1382,7 +1382,7 @@ public final class DtoFactory {
 
         return types;
     }
-    
+
     /**
      * Creates a ProcessorDTO from the specified ProcessorNode.
      *
@@ -1829,7 +1829,7 @@ public final class DtoFactory {
         dto.setDescription(propertyDescriptor.getDescription());
         dto.setDefaultValue(propertyDescriptor.getDefaultValue());
         dto.setSupportsEl(propertyDescriptor.isExpressionLanguageSupported());
-        
+
         // set the identifies controller service is applicable
         if (propertyDescriptor.getControllerServiceDefinition() != null) {
             dto.setIdentifiesControllerService(propertyDescriptor.getControllerServiceDefinition().getName());
@@ -1842,7 +1842,7 @@ public final class DtoFactory {
             } else {
                 final List<AllowableValueDTO> allowableValues = new ArrayList<>();
                 for (final String serviceIdentifier : controllerServiceLookup.getControllerServiceIdentifiers(serviceDefinition)) {
-                	final String displayName = controllerServiceLookup.getControllerServiceName(serviceIdentifier);
+                    final String displayName = controllerServiceLookup.getControllerServiceName(serviceIdentifier);
 
                     final AllowableValueDTO allowableValue = new AllowableValueDTO();
                     allowableValue.setDisplayName(displayName);
@@ -1883,7 +1883,6 @@ public final class DtoFactory {
         return copy;
     }
 
-    
     public ControllerServiceDTO copy(final ControllerServiceDTO original) {
         final ControllerServiceDTO copy = new ControllerServiceDTO();
         copy.setAnnotationData(original.getAnnotationData());
@@ -1901,7 +1900,7 @@ public final class DtoFactory {
         copy.setValidationErrors(copy(original.getValidationErrors()));
         return copy;
     }
-    
+
     public FunnelDTO copy(final FunnelDTO original) {
         final FunnelDTO copy = new FunnelDTO();
         copy.setId(original.getId());
@@ -2294,7 +2293,7 @@ public final class DtoFactory {
      */
     public RevisionDTO createRevisionDTO(FlowModification lastMod) {
         final Revision revision = lastMod.getRevision();
-        
+
         // create the dto
         final RevisionDTO revisionDTO = new RevisionDTO();
         revisionDTO.setVersion(revision.getVersion());
@@ -2409,7 +2408,6 @@ public final class DtoFactory {
     }
 
     /* setters */
-
     public void setControllerServiceLookup(ControllerServiceLookup lookup) {
         this.controllerServiceLookup = lookup;
     }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/contextlistener/ApplicationStartupContextListener.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/contextlistener/ApplicationStartupContextListener.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/contextlistener/ApplicationStartupContextListener.java
index 8b48abf..de54dd2 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/contextlistener/ApplicationStartupContextListener.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/contextlistener/ApplicationStartupContextListener.java
@@ -39,7 +39,6 @@ import org.springframework.web.context.support.WebApplicationContextUtils;
  * clustered environment. In this case, the cluster manager is created and
  * managed.
  *
- * @author unattributed
  */
 public class ApplicationStartupContextListener implements ServletContextListener {
 
@@ -68,14 +67,14 @@ public class ApplicationStartupContextListener implements ServletContextListener
             try {
                 flowService = ctx.getBean("flowService", FlowService.class);
 
-                // start and load the flow if we're not clustered (clustered flow loading should 
-                // happen once the application (wars) is fully loaded and initialized). non clustered 
-                // nifi instance need to load the flow before the application (wars) are fully loaded. 
-                // during the flow loading (below) the flow controller is lazily initialized. when the 
-                // flow is loaded after the application is completely initialized (wars deploy), as  
-                // required with a clustered node, users are able to make web requests before the flow 
-                // is loaded (and the flow controller is initialized) which shouldn't be allowed. moving 
-                // the flow loading here when not clustered resolves this. 
+                // start and load the flow if we're not clustered (clustered flow loading should
+                // happen once the application (wars) is fully loaded and initialized). non clustered
+                // nifi instance need to load the flow before the application (wars) are fully loaded.
+                // during the flow loading (below) the flow controller is lazily initialized. when the
+                // flow is loaded after the application is completely initialized (wars deploy), as
+                // required with a clustered node, users are able to make web requests before the flow
+                // is loaded (and the flow controller is initialized) which shouldn't be allowed. moving
+                // the flow loading here when not clustered resolves this.
                 if (!properties.isNode()) {
                     logger.info("Starting Flow Controller...");
 

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/controller/ControllerFacade.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/controller/ControllerFacade.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/controller/ControllerFacade.java
index b5e6f7e..0f384e3 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/controller/ControllerFacade.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/controller/ControllerFacade.java
@@ -347,10 +347,10 @@ public class ControllerFacade {
     public Set<DocumentedTypeDTO> getFlowFileComparatorTypes() {
         return dtoFactory.fromDocumentedTypes(ExtensionManager.getExtensions(FlowFilePrioritizer.class));
     }
-    
+
     /**
      * Returns whether the specified type implements the specified serviceType.
-     * 
+     *
      * @param baseType
      * @param type
      * @return
@@ -362,24 +362,24 @@ public class ControllerFacade {
                 return true;
             }
         }
-        
+
         return false;
     }
-    
+
     /**
      * Gets the ControllerService types that this controller supports.
-     * 
+     *
      * @param serviceType
-     * @return 
+     * @return
      */
-    public Set<DocumentedTypeDTO> getControllerServiceTypes(final String serviceType) { 
+    public Set<DocumentedTypeDTO> getControllerServiceTypes(final String serviceType) {
         final Set<Class> serviceImplementations = ExtensionManager.getExtensions(ControllerService.class);
-        
+
         // identify the controller services that implement the specified serviceType if applicable
         final Set<Class> matchingServiceImplementions;
         if (serviceType != null) {
             matchingServiceImplementions = new HashSet<>();
-            
+
             // check each type and remove those that aren't in the specified ancestry
             for (final Class type : serviceImplementations) {
                 if (implementsServiceType(serviceType, type)) {
@@ -389,14 +389,14 @@ public class ControllerFacade {
         } else {
             matchingServiceImplementions = serviceImplementations;
         }
-        
+
         return dtoFactory.fromDocumentedTypes(matchingServiceImplementions);
     }
-    
+
     /**
      * Gets the ReportingTask types that this controller supports.
-     * 
-     * @return 
+     *
+     * @return
      */
     public Set<DocumentedTypeDTO> getReportingTaskTypes() {
         return dtoFactory.fromDocumentedTypes(ExtensionManager.getExtensions(ReportingTask.class));
@@ -413,8 +413,9 @@ public class ControllerFacade {
 
     /**
      * Resets the counter with the specified id.
+     *
      * @param id
-     * @return 
+     * @return
      */
     public Counter resetCounter(final String id) {
         final Counter counter = flowController.resetCounter(id);
@@ -425,7 +426,7 @@ public class ControllerFacade {
 
         return counter;
     }
-    
+
     /**
      * Gets the status of this controller.
      *
@@ -831,7 +832,7 @@ public class ControllerFacade {
             if (!downloadAuthorization.isApproved()) {
                 throw new AccessDeniedException(downloadAuthorization.getExplanation());
             }
-            
+
             // get the filename and fall back to the idnetifier (should never happen)
             String filename = event.getAttributes().get(CoreAttributes.FILENAME.key());
             if (filename == null) {
@@ -1193,22 +1194,22 @@ public class ControllerFacade {
 
         for (final Map.Entry<PropertyDescriptor, String> entry : procNode.getProperties().entrySet()) {
             final PropertyDescriptor descriptor = entry.getKey();
-            
+
             addIfAppropriate(searchStr, descriptor.getName(), "Property name", matches);
             addIfAppropriate(searchStr, descriptor.getDescription(), "Property description", matches);
-            
+
             // never include sensitive properties values in search results
             if (descriptor.isSensitive()) {
                 continue;
             }
-            
+
             String value = entry.getValue();
-            
+
             // if unset consider default value
             if (value == null) {
                 value = descriptor.getDefaultValue();
             }
-            
+
             // evaluate if the value matches the search criteria
             if (StringUtils.containsIgnoreCase(value, searchStr)) {
                 matches.add("Property value: " + descriptor.getName() + " - " + value);
@@ -1286,7 +1287,7 @@ public class ControllerFacade {
         for (final FlowFilePrioritizer comparator : queue.getPriorities()) {
             addIfAppropriate(searchStr, comparator.getClass().getName(), "Prioritizer", matches);
         }
-        
+
         // search expiration
         if (StringUtils.containsIgnoreCase("expires", searchStr) || StringUtils.containsIgnoreCase("expiration", searchStr)) {
             final int expirationMillis = connection.getFlowFileQueue().getFlowFileExpiration(TimeUnit.MILLISECONDS);
@@ -1294,7 +1295,7 @@ public class ControllerFacade {
                 matches.add("FlowFile expiration: " + connection.getFlowFileQueue().getFlowFileExpiration());
             }
         }
-        
+
         // search back pressure
         if (StringUtils.containsIgnoreCase("back pressure", searchStr) || StringUtils.containsIgnoreCase("pressure", searchStr)) {
             final String backPressureDataSize = connection.getFlowFileQueue().getBackPressureDataSizeThreshold();

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ConnectionDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ConnectionDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ConnectionDAO.java
index 119a47a..e0fb89e 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ConnectionDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ConnectionDAO.java
@@ -20,15 +20,12 @@ import java.util.Set;
 import org.apache.nifi.connectable.Connection;
 import org.apache.nifi.web.api.dto.ConnectionDTO;
 
-/**
- *
- */
 public interface ConnectionDAO {
 
     /**
      * Gets the specified Connection.
      *
-     * @param groupId
+     * @param groupId group id
      * @param id The connection id
      * @return The connection
      */
@@ -37,25 +34,25 @@ public interface ConnectionDAO {
     /**
      * Gets the connections for the specified source processor.
      *
-     * @param groupId
-     * @param processorId
-     * @return
+     * @param groupId group id
+     * @param processorId processor id
+     * @return connections
      */
     Set<Connection> getConnectionsForSource(String groupId, String processorId);
 
     /**
      * Determines if the specified connection exists.
      *
-     * @param groupId
-     * @param id
-     * @return
+     * @param groupId group id
+     * @param id id
+     * @return true if connection exists
      */
     boolean hasConnection(String groupId, String id);
 
     /**
      * Gets all of the connections.
      *
-     * @param groupId
+     * @param groupId group identifier
      * @return The connections
      */
     Set<Connection> getConnections(String groupId);
@@ -63,7 +60,7 @@ public interface ConnectionDAO {
     /**
      * Creates a new Connection.
      *
-     * @param groupId
+     * @param groupId group id
      * @param connectionDTO The connection DTO
      * @return The connection
      */
@@ -72,23 +69,23 @@ public interface ConnectionDAO {
     /**
      * Verifies the create request can be processed.
      *
-     * @param groupId
-     * @param connectionDTO
+     * @param groupId group id
+     * @param connectionDTO connection
      */
     void verifyCreate(String groupId, ConnectionDTO connectionDTO);
 
     /**
      * Verifies the update request can be processed.
      *
-     * @param groupId
-     * @param connectionDTO
+     * @param groupId group id
+     * @param connectionDTO connection
      */
     void verifyUpdate(String groupId, ConnectionDTO connectionDTO);
 
     /**
      * Updates the specified Connection.
      *
-     * @param groupId
+     * @param groupId group id
      * @param connectionDTO The connection DTO
      * @return The connection
      */
@@ -97,15 +94,15 @@ public interface ConnectionDAO {
     /**
      * Verifies the delete request can be processed.
      *
-     * @param groupId
-     * @param id
+     * @param groupId group id
+     * @param id id
      */
     void verifyDelete(String groupId, String id);
 
     /**
      * Deletes the specified Connection.
      *
-     * @param groupId
+     * @param groupId group id
      * @param id The id of the connection
      */
     void deleteConnection(String groupId, String id);

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ControllerServiceDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ControllerServiceDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ControllerServiceDAO.java
index c1fba0c..52cba66 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ControllerServiceDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ControllerServiceDAO.java
@@ -24,16 +24,11 @@ import org.apache.nifi.controller.service.ControllerServiceReference;
 import org.apache.nifi.controller.service.ControllerServiceState;
 import org.apache.nifi.web.api.dto.ControllerServiceDTO;
 
-/**
- *
- */
 public interface ControllerServiceDAO {
 
     /**
-     * Determines if the specified controller service exists.
-     *
-     * @param controllerServiceId
-     * @return
+     * @param controllerServiceId service id
+     * @return Determines if the specified controller service exists
      */
     boolean hasControllerService(String controllerServiceId);
 
@@ -70,34 +65,35 @@ public interface ControllerServiceDAO {
 
     /**
      * Updates the referencing components for the specified controller service.
-     * 
-     * @param controllerServiceId
-     * @param scheduledState
-     * @param controllerServiceState the value of state 
-     * @return the org.apache.nifi.controller.service.ControllerServiceReference 
+     *
+     * @param controllerServiceId service id
+     * @param scheduledState scheduled state
+     * @param controllerServiceState the value of state
+     * @return the org.apache.nifi.controller.service.ControllerServiceReference
      */
     ControllerServiceReference updateControllerServiceReferencingComponents(String controllerServiceId, ScheduledState scheduledState, ControllerServiceState controllerServiceState);
-    
+
     /**
      * Determines whether this controller service can be updated.
      *
-     * @param controllerServiceDTO
+     * @param controllerServiceDTO service
      */
     void verifyUpdate(ControllerServiceDTO controllerServiceDTO);
-    
+
     /**
-     * Determines whether the referencing component of the specified controller service can be updated.
-     * 
-     * @param controllerServiceId
-     * @param scheduledState
-     * @param controllerServiceState 
+     * Determines whether the referencing component of the specified controller
+     * service can be updated.
+     *
+     * @param controllerServiceId service id
+     * @param scheduledState scheduled state
+     * @param controllerServiceState service state
      */
     void verifyUpdateReferencingComponents(String controllerServiceId, ScheduledState scheduledState, ControllerServiceState controllerServiceState);
-    
+
     /**
      * Determines whether this controller service can be removed.
      *
-     * @param controllerServiceId
+     * @param controllerServiceId service id
      */
     void verifyDelete(String controllerServiceId);
 

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/FunnelDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/FunnelDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/FunnelDAO.java
index 0d8624f..278405a 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/FunnelDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/FunnelDAO.java
@@ -21,24 +21,19 @@ import java.util.Set;
 import org.apache.nifi.connectable.Funnel;
 import org.apache.nifi.web.api.dto.FunnelDTO;
 
-/**
- *
- */
 public interface FunnelDAO {
 
     /**
-     * Determines if the specified funnel exists in the specified group.
-     *
-     * @param groupId
-     * @param funnelId
-     * @return
+     * @param groupId group id
+     * @param funnelId funnel id
+     * @return Determines if the specified funnel exists in the specified group
      */
     boolean hasFunnel(String groupId, String funnelId);
 
     /**
      * Creates a funnel in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param funnelDTO The funnel DTO
      * @return The funnel
      */
@@ -47,7 +42,7 @@ public interface FunnelDAO {
     /**
      * Gets the specified funnel in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param funnelId The funnel id
      * @return The funnel
      */
@@ -56,7 +51,7 @@ public interface FunnelDAO {
     /**
      * Gets all of the funnels in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @return The funnels
      */
     Set<Funnel> getFunnels(String groupId);
@@ -64,7 +59,7 @@ public interface FunnelDAO {
     /**
      * Updates the specified funnel in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param funnelDTO The funnel DTO
      * @return The funnel
      */
@@ -73,15 +68,15 @@ public interface FunnelDAO {
     /**
      * Determines whether this funnel can be removed.
      *
-     * @param groupId
-     * @param funnelId
+     * @param groupId group id
+     * @param funnelId funnel id
      */
     void verifyDelete(String groupId, String funnelId);
 
     /**
      * Deletes the specified Funnel in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param funnelId The funnel id
      */
     void deleteFunnel(String groupId, String funnelId);

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/LabelDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/LabelDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/LabelDAO.java
index edd024c..2a908ac 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/LabelDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/LabelDAO.java
@@ -20,24 +20,19 @@ import java.util.Set;
 import org.apache.nifi.controller.label.Label;
 import org.apache.nifi.web.api.dto.LabelDTO;
 
-/**
- *
- */
 public interface LabelDAO {
 
     /**
-     * Determines if the specified label exists in the specified group.
-     *
-     * @param groupId
-     * @param labelId
-     * @return
+     * @param groupId group id
+     * @param labelId label id
+     * @return Determines if the specified label exists in the specified group
      */
     boolean hasLabel(String groupId, String labelId);
 
     /**
      * Creates a label in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param labelDTO The label DTO
      * @return The label
      */
@@ -46,7 +41,7 @@ public interface LabelDAO {
     /**
      * Gets the specified label in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param labelId The label id
      * @return The label
      */
@@ -55,7 +50,7 @@ public interface LabelDAO {
     /**
      * Gets all of the labels in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @return The labels
      */
     Set<Label> getLabels(String groupId);
@@ -63,7 +58,7 @@ public interface LabelDAO {
     /**
      * Updates the specified label in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param labelDTO The label DTO
      * @return The label
      */
@@ -72,7 +67,7 @@ public interface LabelDAO {
     /**
      * Deletes the specified label in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param labelId The label id
      */
     void deleteLabel(String groupId, String labelId);

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/PortDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/PortDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/PortDAO.java
index 1cb5bf4..33ae2bd 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/PortDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/PortDAO.java
@@ -21,24 +21,19 @@ import java.util.Set;
 import org.apache.nifi.connectable.Port;
 import org.apache.nifi.web.api.dto.PortDTO;
 
-/**
- *
- */
 public interface PortDAO {
 
     /**
-     * Determines if the specified port exists in the specified group.
-     *
-     * @param groupId
-     * @param portId
-     * @return
+     * @param groupId group id
+     * @param portId  port id
+     * @return Determines if the specified port exists in the specified group
      */
     boolean hasPort(String groupId, String portId);
 
     /**
      * Creates a port in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param portDTO The port DTO
      * @return The port
      */
@@ -47,7 +42,7 @@ public interface PortDAO {
     /**
      * Gets the specified port in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param portId The port id
      * @return The port
      */
@@ -56,7 +51,7 @@ public interface PortDAO {
     /**
      * Gets all of the ports in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @return The ports
      */
     Set<Port> getPorts(String groupId);
@@ -64,15 +59,15 @@ public interface PortDAO {
     /**
      * Verifies the specified port can be updated per the specified request.
      *
-     * @param groupId
-     * @param portDTO
+     * @param groupId group id
+     * @param portDTO port
      */
     void verifyUpdate(String groupId, PortDTO portDTO);
 
     /**
      * Updates the specified port in the specified group.
      *
-     * @param groupId
+     * @param groupId group
      * @param portDTO The port DTO
      * @return The port
      */
@@ -81,15 +76,15 @@ public interface PortDAO {
     /**
      * Verifies the specified port can be removed.
      *
-     * @param groupId
-     * @param portId
+     * @param groupId group id
+     * @param portId port id
      */
     void verifyDelete(String groupId, String portId);
 
     /**
      * Deletes the specified label in the specified group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param portId The port id
      */
     void deletePort(String groupId, String portId);

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ProcessorDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ProcessorDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ProcessorDAO.java
index 104a04c..8f2416a 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ProcessorDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ProcessorDAO.java
@@ -20,24 +20,19 @@ import java.util.Set;
 import org.apache.nifi.controller.ProcessorNode;
 import org.apache.nifi.web.api.dto.ProcessorDTO;
 
-/**
- *
- */
 public interface ProcessorDAO {
 
     /**
-     * Determines if the specified processor is loaded.
-     *
-     * @param groupId
-     * @param id
-     * @return
+     * @param groupId group id
+     * @param id id
+     * @return Determines if the specified processor is loaded
      */
     boolean hasProcessor(String groupId, String id);
 
     /**
      * Creates a new Processor.
      *
-     * @param groupId
+     * @param groupId group id
      * @param processorDTO The processor DTO
      * @return The new Processor
      */
@@ -46,7 +41,7 @@ public interface ProcessorDAO {
     /**
      * Gets the Processor transfer object for the specified id.
      *
-     * @param groupId
+     * @param groupId group id
      * @param id Id of the processor to return
      * @return The Processor
      */
@@ -55,7 +50,7 @@ public interface ProcessorDAO {
     /**
      * Gets all the Processor transfer objects for this controller.
      *
-     * @param groupId
+     * @param groupId group id
      * @return List of all the Processors
      */
     Set<ProcessorNode> getProcessors(String groupId);
@@ -63,8 +58,8 @@ public interface ProcessorDAO {
     /**
      * Verifies the specified processor can be updated.
      *
-     * @param groupId
-     * @param processorDTO
+     * @param groupId group id
+     * @param processorDTO processor
      */
     void verifyUpdate(String groupId, ProcessorDTO processorDTO);
 
@@ -72,24 +67,24 @@ public interface ProcessorDAO {
      * Updates the configuration for the processor using the specified
      * processorDTO.
      *
-     * @param groupId
-     * @param processorDTO
-     * @return 
+     * @param groupId group id
+     * @param processorDTO processor
+     * @return updated processor
      */
     ProcessorNode updateProcessor(String groupId, ProcessorDTO processorDTO);
 
     /**
      * Verifies the specified processor can be removed.
      *
-     * @param groupId
-     * @param processorId
+     * @param groupId group id
+     * @param processorId processor id
      */
     void verifyDelete(String groupId, String processorId);
 
     /**
      * Deletes the specified processor.
      *
-     * @param groupId
+     * @param groupId group id
      * @param processorId The processor id to delete
      */
     void deleteProcessor(String groupId, String processorId);

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/RemoteProcessGroupDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/RemoteProcessGroupDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/RemoteProcessGroupDAO.java
index 563d074..cf1ac30 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/RemoteProcessGroupDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/RemoteProcessGroupDAO.java
@@ -22,24 +22,21 @@ import org.apache.nifi.remote.RemoteGroupPort;
 import org.apache.nifi.web.api.dto.RemoteProcessGroupDTO;
 import org.apache.nifi.web.api.dto.RemoteProcessGroupPortDTO;
 
-/**
- *
- */
 public interface RemoteProcessGroupDAO {
 
     /**
      * Determines if the specified remote process group exists.
      *
-     * @param groupId
-     * @param remoteProcessGroupId
-     * @return
+     * @param groupId group id
+     * @param remoteProcessGroupId group id
+     * @return true if the specified remote process group exists
      */
     boolean hasRemoteProcessGroup(String groupId, String remoteProcessGroupId);
 
     /**
      * Creates a remote process group reference.
      *
-     * @param groupId
+     * @param groupId group id
      * @param remoteProcessGroup The remote process group
      * @return The remote process group
      */
@@ -48,7 +45,7 @@ public interface RemoteProcessGroupDAO {
     /**
      * Gets the specified remote process group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param remoteProcessGroupId The remote process group id
      * @return The remote process group
      */
@@ -57,7 +54,7 @@ public interface RemoteProcessGroupDAO {
     /**
      * Gets all of the remote process groups.
      *
-     * @param groupId
+     * @param groupId group id
      * @return The remote process groups
      */
     Set<RemoteProcessGroup> getRemoteProcessGroups(String groupId);
@@ -65,33 +62,33 @@ public interface RemoteProcessGroupDAO {
     /**
      * Verifies the specified remote process group can be updated.
      *
-     * @param groupId
-     * @param remoteProcessGroup
+     * @param groupId group id
+     * @param remoteProcessGroup group
      */
     void verifyUpdate(String groupId, RemoteProcessGroupDTO remoteProcessGroup);
 
     /**
      * Verifies the specified remote process group input port can be updated.
      *
-     * @param groupId
-     * @param remoteProcessGroupId
-     * @param remoteProcessGroupPort
+     * @param groupId group id
+     * @param remoteProcessGroupId process group id
+     * @param remoteProcessGroupPort port
      */
     void verifyUpdateInputPort(String groupId, String remoteProcessGroupId, RemoteProcessGroupPortDTO remoteProcessGroupPort);
 
     /**
      * Verifies the specified remote process group input port can be updated.
      *
-     * @param groupId
-     * @param remoteProcessGroupId
-     * @param remoteProcessGroupPort
+     * @param groupId group id
+     * @param remoteProcessGroupId group id
+     * @param remoteProcessGroupPort group port
      */
     void verifyUpdateOutputPort(String groupId, String remoteProcessGroupId, RemoteProcessGroupPortDTO remoteProcessGroupPort);
 
     /**
      * Updates the specified remote process group.
      *
-     * @param groupId
+     * @param groupId id
      * @param remoteProcessGroup The remote process group
      * @return The remote process group
      */
@@ -100,9 +97,9 @@ public interface RemoteProcessGroupDAO {
     /**
      * Updates the specified remote process group input port.
      *
-     * @param groupId
-     * @param remoteProcessGroupId
-     * @param remoteProcessGroupPort
+     * @param groupId id
+     * @param remoteProcessGroupId id
+     * @param remoteProcessGroupPort port
      * @return
      */
     RemoteGroupPort updateRemoteProcessGroupInputPort(String groupId, String remoteProcessGroupId, RemoteProcessGroupPortDTO remoteProcessGroupPort);
@@ -110,9 +107,9 @@ public interface RemoteProcessGroupDAO {
     /**
      * Updates the specified remote process group output port.
      *
-     * @param groupId
-     * @param remoteProcessGroupId
-     * @param remoteProcessGroupPort
+     * @param groupId group id
+     * @param remoteProcessGroupId group id
+     * @param remoteProcessGroupPort port
      * @return
      */
     RemoteGroupPort updateRemoteProcessGroupOutputPort(String groupId, String remoteProcessGroupId, RemoteProcessGroupPortDTO remoteProcessGroupPort);
@@ -120,15 +117,15 @@ public interface RemoteProcessGroupDAO {
     /**
      * Verifies the specified remote process group can be removed.
      *
-     * @param groupId
-     * @param remoteProcessGroupId
+     * @param groupId group id
+     * @param remoteProcessGroupId group id
      */
     void verifyDelete(String groupId, String remoteProcessGroupId);
 
     /**
      * Deletes the specified remote process group.
      *
-     * @param groupId
+     * @param groupId group id
      * @param remoteProcessGroupId The remote process group id
      */
     void deleteRemoteProcessGroup(String groupId, String remoteProcessGroupId);

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ReportingTaskDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ReportingTaskDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ReportingTaskDAO.java
index 49446d3..cbdd4a1 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ReportingTaskDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/ReportingTaskDAO.java
@@ -71,7 +71,7 @@ public interface ReportingTaskDAO {
      * @param reportingTaskDTO
      */
     void verifyUpdate(ReportingTaskDTO reportingTaskDTO);
-    
+
     /**
      * Determines whether this reporting task can be removed.
      *

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/SnippetDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/SnippetDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/SnippetDAO.java
index c31875f..9ea60cb 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/SnippetDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/SnippetDAO.java
@@ -20,27 +20,24 @@ import org.apache.nifi.controller.Snippet;
 import org.apache.nifi.web.api.dto.FlowSnippetDTO;
 import org.apache.nifi.web.api.dto.SnippetDTO;
 
-/**
- *
- */
 public interface SnippetDAO {
 
     /**
      * Copies the specified snippet and added the copy to the flow in the
      * specified group.
      *
-     * @param groupId
-     * @param snippetId
-     * @param originX
-     * @param originY
-     * @return
+     * @param groupId group id
+     * @param snippetId snippet id
+     * @param originX x
+     * @param originY y
+     * @return snippet
      */
     FlowSnippetDTO copySnippet(String groupId, String snippetId, Double originX, Double originY);
 
     /**
      * Creates a snippet.
      *
-     * @param snippetDTO
+     * @param snippetDTO snippet
      * @return The snippet
      */
     Snippet createSnippet(SnippetDTO snippetDTO);
@@ -48,8 +45,8 @@ public interface SnippetDAO {
     /**
      * Determines if the specified snippet exists.
      *
-     * @param snippetId
-     * @return
+     * @param snippetId snippet id
+     * @return true if the snippet exists
      */
     boolean hasSnippet(String snippetId);
 
@@ -64,14 +61,14 @@ public interface SnippetDAO {
     /**
      * Verifies the specified snippet can be updated.
      *
-     * @param snippetDTO
+     * @param snippetDTO snippet
      */
     void verifyUpdate(SnippetDTO snippetDTO);
 
     /**
      * Updates the specified snippet.
      *
-     * @param snippetDTO
+     * @param snippetDTO snippet
      * @return The snippet
      */
     Snippet updateSnippet(SnippetDTO snippetDTO);
@@ -79,7 +76,7 @@ public interface SnippetDAO {
     /**
      * Verifies the specified snippet can be removed.
      *
-     * @param snippetId
+     * @param snippetId snippet id
      */
     void verifyDelete(String snippetId);
 

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/TemplateDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/TemplateDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/TemplateDAO.java
index 5a55718..5264119 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/TemplateDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/TemplateDAO.java
@@ -49,7 +49,7 @@ public interface TemplateDAO {
      * @param originX
      * @param originY
      * @param templateId
-     * @return 
+     * @return
      */
     FlowSnippetDTO instantiateTemplate(String groupId, Double originX, Double originY, String templateId);
 

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardControllerServiceDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardControllerServiceDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardControllerServiceDAO.java
index 14217c5..dd9fc0d 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardControllerServiceDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardControllerServiceDAO.java
@@ -67,7 +67,7 @@ public class StandardControllerServiceDAO extends ComponentDAO implements Contro
         if (controllerServiceDTO.getType() == null) {
             throw new IllegalArgumentException("The controller service type must be specified.");
         }
-        
+
         try {
             // create the controller service
             final ControllerServiceNode controllerService = serviceProvider.createControllerService(controllerServiceDTO.getType(), controllerServiceDTO.getId(), true);
@@ -126,10 +126,10 @@ public class StandardControllerServiceDAO extends ComponentDAO implements Contro
     public ControllerServiceNode updateControllerService(final ControllerServiceDTO controllerServiceDTO) {
         // get the controller service
         final ControllerServiceNode controllerService = locateControllerService(controllerServiceDTO.getId());
-        
+
         // ensure we can perform the update 
         verifyUpdate(controllerService, controllerServiceDTO);
-        
+
         // perform the update
         configureControllerService(controllerService, controllerServiceDTO);
 
@@ -146,7 +146,7 @@ public class StandardControllerServiceDAO extends ComponentDAO implements Contro
                 }
             }
         }
-        
+
         return controllerService;
     }
 
@@ -154,7 +154,7 @@ public class StandardControllerServiceDAO extends ComponentDAO implements Contro
     public ControllerServiceReference updateControllerServiceReferencingComponents(final String controllerServiceId, final ScheduledState scheduledState, final ControllerServiceState controllerServiceState) {
         // get the controller service
         final ControllerServiceNode controllerService = locateControllerService(controllerServiceId);
-        
+
         // this request is either acting upon referncing services or schedulable components
         if (controllerServiceState != null) {
             if (ControllerServiceState.ENABLED.equals(controllerServiceState)) {
@@ -169,22 +169,23 @@ public class StandardControllerServiceDAO extends ComponentDAO implements Contro
                 serviceProvider.unscheduleReferencingComponents(controllerService);
             }
         }
-        
+
         return controllerService.getReferences();
     }
 
     /**
-     * Validates the specified configuration for the specified controller service.
-     * 
+     * Validates the specified configuration for the specified controller
+     * service.
+     *
      * @param controllerService
      * @param controllerServiceDTO
-     * @return 
+     * @return
      */
     private List<String> validateProposedConfiguration(final ControllerServiceNode controllerService, final ControllerServiceDTO controllerServiceDTO) {
         final List<String> validationErrors = new ArrayList<>();
         return validationErrors;
     }
-    
+
     @Override
     public void verifyDelete(final String controllerServiceId) {
         final ControllerServiceNode controllerService = locateControllerService(controllerServiceId);
@@ -200,7 +201,7 @@ public class StandardControllerServiceDAO extends ComponentDAO implements Contro
     @Override
     public void verifyUpdateReferencingComponents(String controllerServiceId, ScheduledState scheduledState, ControllerServiceState controllerServiceState) {
         final ControllerServiceNode controllerService = locateControllerService(controllerServiceId);
-        
+
         if (controllerServiceState != null) {
             if (ControllerServiceState.ENABLED.equals(controllerServiceState)) {
                 serviceProvider.verifyCanEnableReferencingServices(controllerService);
@@ -215,12 +216,12 @@ public class StandardControllerServiceDAO extends ComponentDAO implements Contro
             }
         }
     }
-    
+
     /**
      * Verifies the controller service can be updated.
-     * 
+     *
      * @param controllerService
-     * @param controllerServiceDTO 
+     * @param controllerServiceDTO
      */
     private void verifyUpdate(final ControllerServiceNode controllerService, final ControllerServiceDTO controllerServiceDTO) {
         // validate the new controller service state if appropriate
@@ -228,12 +229,12 @@ public class StandardControllerServiceDAO extends ComponentDAO implements Contro
             try {
                 // attempt to parse the service state
                 final ControllerServiceState purposedControllerServiceState = ControllerServiceState.valueOf(controllerServiceDTO.getState());
-                
+
                 // ensure the state is valid
                 if (ControllerServiceState.ENABLING.equals(purposedControllerServiceState) || ControllerServiceState.DISABLING.equals(purposedControllerServiceState)) {
                     throw new IllegalArgumentException();
                 }
-                
+
                 // only attempt an action if it is changing
                 if (!purposedControllerServiceState.equals(controllerService.getState())) {
                     if (ControllerServiceState.ENABLED.equals(purposedControllerServiceState)) {
@@ -246,14 +247,14 @@ public class StandardControllerServiceDAO extends ComponentDAO implements Contro
                 throw new IllegalArgumentException("Controller Service state: Value must be one of [ENABLED, DISABLED]");
             }
         }
-        
+
         boolean modificationRequest = false;
         if (isAnyNotNull(controllerServiceDTO.getName(),
                 controllerServiceDTO.getAnnotationData(),
                 controllerServiceDTO.getComments(),
                 controllerServiceDTO.getProperties())) {
             modificationRequest = true;
-            
+
             // validate the request
             final List<String> requestValidation = validateProposedConfiguration(controllerService, controllerServiceDTO);
 
@@ -262,24 +263,24 @@ public class StandardControllerServiceDAO extends ComponentDAO implements Contro
                 throw new ValidationException(requestValidation);
             }
         }
-        
+
         if (modificationRequest) {
             controllerService.verifyCanUpdate();
         }
     }
-    
+
     /**
      * Configures the specified controller service.
-     * 
+     *
      * @param controllerService
-     * @param controllerServiceDTO 
+     * @param controllerServiceDTO
      */
     private void configureControllerService(final ControllerServiceNode controllerService, final ControllerServiceDTO controllerServiceDTO) {
         final String name = controllerServiceDTO.getName();
         final String annotationData = controllerServiceDTO.getAnnotationData();
         final String comments = controllerServiceDTO.getComments();
         final Map<String, String> properties = controllerServiceDTO.getProperties();
-        
+
         if (isNotNull(name)) {
             controllerService.setName(name);
         }
@@ -301,7 +302,7 @@ public class StandardControllerServiceDAO extends ComponentDAO implements Contro
             }
         }
     }
-    
+
     /**
      * Deletes the specified controller service.
      *

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardProcessorDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardProcessorDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardProcessorDAO.java
index b291b4f..be33d5a 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardProcessorDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardProcessorDAO.java
@@ -99,7 +99,7 @@ public class StandardProcessorDAO extends ComponentDAO implements ProcessorDAO {
         if (processorDTO.getParentGroupId() != null && !flowController.areGroupsSame(groupId, processorDTO.getParentGroupId())) {
             throw new IllegalArgumentException("Cannot specify a different Parent Group ID than the Group to which the Processor is being added.");
         }
-        
+
         // ensure the type is specified
         if (processorDTO.getType() == null) {
             throw new IllegalArgumentException("The processor type must be specified.");

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardRemoteProcessGroupDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardRemoteProcessGroupDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardRemoteProcessGroupDAO.java
index 7cb3758..e237b0d 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardRemoteProcessGroupDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardRemoteProcessGroupDAO.java
@@ -16,7 +16,6 @@
  */
 package org.apache.nifi.web.dao.impl;
 
-
 import java.util.ArrayList;
 import java.util.List;
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardReportingTaskDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardReportingTaskDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardReportingTaskDAO.java
index 46b7070..4c85b04 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardReportingTaskDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardReportingTaskDAO.java
@@ -73,7 +73,7 @@ public class StandardReportingTaskDAO extends ComponentDAO implements ReportingT
         if (reportingTaskDTO.getType() == null) {
             throw new IllegalArgumentException("The reporting task type must be specified.");
         }
-        
+
         try {
             // create the reporting task
             final ReportingTaskNode reportingTask = reportingTaskProvider.createReportingTask(reportingTaskDTO.getType(), reportingTaskDTO.getId(), true);
@@ -321,7 +321,7 @@ public class StandardReportingTaskDAO extends ComponentDAO implements ReportingT
         if (isNotNull(schedulingStrategy)) {
             reportingTask.setSchedulingStrategy(SchedulingStrategy.valueOf(schedulingStrategy));
         }
-        
+
         if (isNotNull(name)) {
             reportingTask.setName(name);
         }

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardSnippetDAO.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardSnippetDAO.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardSnippetDAO.java
index 6447464..0d75c30 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardSnippetDAO.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/dao/impl/StandardSnippetDAO.java
@@ -289,10 +289,10 @@ public class StandardSnippetDAO implements SnippetDAO {
                 lookupSensitiveProcessorProperties(snippet.getProcessors());
             }
 
-            if ( snippet.getControllerServices() != null ) {
+            if (snippet.getControllerServices() != null) {
                 lookupSensitiveControllerServiceProperties(snippet.getControllerServices());
             }
-            
+
             // go through each process group if specified
             if (snippet.getProcessGroups() != null) {
                 for (final ProcessGroupDTO group : snippet.getProcessGroups()) {
@@ -336,11 +336,11 @@ public class StandardSnippetDAO implements SnippetDAO {
             }
         }
     }
-    
+
     private void lookupSensitiveControllerServiceProperties(final Set<ControllerServiceDTO> controllerServices) {
         // go through each service
         for (final ControllerServiceDTO serviceDTO : controllerServices) {
-            
+
             // ensure that some property configuration have been specified
             final Map<String, String> serviceProperties = serviceDTO.getProperties();
             if (serviceProperties != null) {

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/spring/ReportingTaskProviderFactoryBean.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/spring/ReportingTaskProviderFactoryBean.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/spring/ReportingTaskProviderFactoryBean.java
index d344fa6..bfa6e3e 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/spring/ReportingTaskProviderFactoryBean.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/spring/ReportingTaskProviderFactoryBean.java
@@ -20,7 +20,6 @@ import org.apache.nifi.cluster.manager.impl.WebClusterManager;
 import org.apache.nifi.controller.FlowController;
 import org.apache.nifi.controller.reporting.ReportingTaskProvider;
 import org.apache.nifi.util.NiFiProperties;
-import org.apache.nifi.web.dao.ControllerServiceDAO;
 import org.springframework.beans.BeansException;
 import org.springframework.beans.factory.FactoryBean;
 import org.springframework.context.ApplicationContext;

http://git-wip-us.apache.org/repos/asf/incubator-nifi/blob/a53cc3d7/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/util/Availability.java
----------------------------------------------------------------------
diff --git a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/util/Availability.java b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/util/Availability.java
index 29ba4f8..7f51e0f 100644
--- a/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/util/Availability.java
+++ b/nifi/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-web-api/src/main/java/org/apache/nifi/web/util/Availability.java
@@ -25,7 +25,6 @@ public enum Availability {
      * Service or reporting task will run only on the NiFi Cluster Manager (NCM)
      */
     NCM,
-    
     /**
      * Service or reporting task will run only on NiFi Nodes (or standalone
      * instance, if not clustered)