You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@nifi.apache.org by ex...@apache.org on 2022/01/22 02:08:41 UTC

[nifi] branch main updated: NIFI-9618 Upgraded Checkstyle to 9.2.1

This is an automated email from the ASF dual-hosted git repository.

exceptionfactory pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/nifi.git


The following commit(s) were added to refs/heads/main by this push:
     new e224350  NIFI-9618 Upgraded Checkstyle to 9.2.1
e224350 is described below

commit e2243500d3c878fbb33b8f642462a7b29c441fa3
Author: exceptionfactory <ex...@apache.org>
AuthorDate: Fri Jan 21 12:49:54 2022 -0600

    NIFI-9618 Upgraded Checkstyle to 9.2.1
    
    - Corrected several missing return statements
    - Increased Maven heap size to 3 GB for ci-workflow
    
    This closes #5700
    
    Signed-off-by: David Handermann <ex...@apache.org>
---
 .github/workflows/ci-workflow.yml                  |  2 +-
 .../nifi/bootstrap/util/SecureNiFiConfigUtil.java  |  2 +-
 .../hashicorp/config/HashiCorpVaultProperties.java | 26 +++++++++++-----------
 .../config/HashiCorpVaultPropertySource.java       |  2 +-
 .../java/org/apache/nifi/util/TestRunners.java     |  2 +-
 .../accumulo/processors/PutAccumuloRecord.java     |  2 +-
 .../apache/nifi/rules/engine/EasyRulesEngine.java  |  4 ++--
 .../nifi/rules/engine/EasyRulesEngineProvider.java |  2 +-
 .../nifi/rules/engine/EasyRulesEngineService.java  |  2 +-
 .../processor/util/list/AbstractListProcessor.java |  2 +-
 .../analytics/StatusAnalyticsModelMapFactory.java  |  2 +-
 .../apache/nifi/web/server/HostHeaderHandler.java  |  2 +-
 .../org/apache/nifi/processors/hadoop/PutHDFS.java |  2 +-
 nifi-registry/pom.xml                              | 12 ----------
 pom.xml                                            |  2 +-
 15 files changed, 27 insertions(+), 39 deletions(-)

diff --git a/.github/workflows/ci-workflow.yml b/.github/workflows/ci-workflow.yml
index 4de3302..942f6f6 100644
--- a/.github/workflows/ci-workflow.yml
+++ b/.github/workflows/ci-workflow.yml
@@ -19,7 +19,7 @@ on: [push, pull_request]
 
 env:
   DEFAULT_MAVEN_OPTS: >-
-    -Xmx2g
+    -Xmx3g
     -XX:ReservedCodeCacheSize=1g
     -XX:+UseG1GC
     -Dorg.slf4j.simpleLogger.defaultLogLevel=WARN
diff --git a/nifi-bootstrap/src/main/java/org/apache/nifi/bootstrap/util/SecureNiFiConfigUtil.java b/nifi-bootstrap/src/main/java/org/apache/nifi/bootstrap/util/SecureNiFiConfigUtil.java
index 60d1f7e..2eb06ce 100644
--- a/nifi-bootstrap/src/main/java/org/apache/nifi/bootstrap/util/SecureNiFiConfigUtil.java
+++ b/nifi-bootstrap/src/main/java/org/apache/nifi/bootstrap/util/SecureNiFiConfigUtil.java
@@ -69,7 +69,7 @@ public class SecureNiFiConfigUtil {
      * This would indicate that the user intends to auto-generate a keystore and truststore, rather than
      * using their existing kestore and truststore.
      * @param nifiProperties The nifi properties
-     * @return
+     * @return HTTPS Security Configured status
      */
     private static boolean isHttpsSecurityConfiguredWithEmptyPasswords(final Properties nifiProperties) {
         if (StringUtils.isEmpty(nifiProperties.getProperty(NiFiProperties.WEB_HTTPS_PORT, StringUtils.EMPTY))) {
diff --git a/nifi-commons/nifi-vault-utils/src/main/java/org/apache/nifi/vault/hashicorp/config/HashiCorpVaultProperties.java b/nifi-commons/nifi-vault-utils/src/main/java/org/apache/nifi/vault/hashicorp/config/HashiCorpVaultProperties.java
index 3a84bc9..99b6ff1 100644
--- a/nifi-commons/nifi-vault-utils/src/main/java/org/apache/nifi/vault/hashicorp/config/HashiCorpVaultProperties.java
+++ b/nifi-commons/nifi-vault-utils/src/main/java/org/apache/nifi/vault/hashicorp/config/HashiCorpVaultProperties.java
@@ -113,7 +113,7 @@ public class HashiCorpVaultProperties {
          * Set the Vault URI (e.g., http://localhost:8200).  If using https protocol, the KeyStore and TrustStore
          * properties are expected to also be set.
          * @param uri Vault's URI
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setUri(String uri) {
             this.uri = uri;
@@ -123,7 +123,7 @@ public class HashiCorpVaultProperties {
         /**
          * Sets the path to the keyStore.
          * @param keyStore Path to the keyStore
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setKeyStore(String keyStore) {
             this.keyStore = keyStore;
@@ -133,7 +133,7 @@ public class HashiCorpVaultProperties {
         /**
          * Sets keyStore type (e.g., JKS, PKCS12).
          * @param keyStoreType KeyStore type
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setKeyStoreType(String keyStoreType) {
             this.keyStoreType = keyStoreType;
@@ -143,7 +143,7 @@ public class HashiCorpVaultProperties {
         /**
          * Sets the keyStore password.
          * @param keyStorePassword KeyStore password
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setKeyStorePassword(String keyStorePassword) {
             this.keyStorePassword = keyStorePassword;
@@ -153,7 +153,7 @@ public class HashiCorpVaultProperties {
         /**
          * Sets the path to the trustStore.
          * @param trustStore Path to the trustStore
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setTrustStore(String trustStore) {
             this.trustStore = trustStore;
@@ -163,7 +163,7 @@ public class HashiCorpVaultProperties {
         /**
          * Sets the trustStore type (e.g., JKS, PKCS12).
          * @param trustStoreType TrustStore type
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setTrustStoreType(String trustStoreType) {
             this.trustStoreType = trustStoreType;
@@ -173,7 +173,7 @@ public class HashiCorpVaultProperties {
         /**
          * Sets the trustStore passsword.
          * @param trustStorePassword TrustStore password
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setTrustStorePassword(String trustStorePassword) {
             this.trustStorePassword = trustStorePassword;
@@ -188,7 +188,7 @@ public class HashiCorpVaultProperties {
          *     https://docs.spring.io/spring-vault/docs/2.3.1/reference/html/#vault.core.environment-vault-configuration</a>
          * @param authPropertiesFilename The filename of a properties file containing Spring Vault authentication
          *                               properties
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setAuthPropertiesFilename(String authPropertiesFilename) {
             this.authPropertiesFilename = authPropertiesFilename;
@@ -198,7 +198,7 @@ public class HashiCorpVaultProperties {
         /**
          * Sets an optional comma-separated list of enabled TLS cipher suites.
          * @param enabledTlsCipherSuites Enabled TLS cipher suites (only these will be enabled)
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setEnabledTlsCipherSuites(String enabledTlsCipherSuites) {
             this.enabledTlsCipherSuites = enabledTlsCipherSuites;
@@ -208,7 +208,7 @@ public class HashiCorpVaultProperties {
         /**
          * Sets an optional comma-separated list of enabled TLS protocols.
          * @param enabledTlsProtocols Enabled TLS protocols (only these will be enabled)
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setEnabledTlsProtocols(String enabledTlsProtocols) {
             this.enabledTlsProtocols = enabledTlsProtocols;
@@ -218,7 +218,7 @@ public class HashiCorpVaultProperties {
         /**
          * Sets the connection timeout for the HTTP client, using the standard NiFi duration format (e.g., 5 secs)
          * @param connectionTimeout Connection timeout (default is 5 secs)
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setConnectionTimeout(String connectionTimeout) {
             this.connectionTimeout = connectionTimeout;
@@ -228,7 +228,7 @@ public class HashiCorpVaultProperties {
         /**
          * Sets the read timeout for the HTTP client, using the standard NiFi duration format (e.g., 15 secs).
          * @param readTimeout Read timeout (default is 15 secs)
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultPropertiesBuilder setReadTimeout(String readTimeout) {
             this.readTimeout = readTimeout;
@@ -237,7 +237,7 @@ public class HashiCorpVaultProperties {
 
         /**
          * Build the VaultProperties.
-         * @return
+         * @return Builder
          */
         public HashiCorpVaultProperties build() {
             return new HashiCorpVaultProperties(uri, keyStore, keyStoreType, keyStorePassword, trustStore, trustStoreType,
diff --git a/nifi-commons/nifi-vault-utils/src/main/java/org/apache/nifi/vault/hashicorp/config/HashiCorpVaultPropertySource.java b/nifi-commons/nifi-vault-utils/src/main/java/org/apache/nifi/vault/hashicorp/config/HashiCorpVaultPropertySource.java
index 8e64d08..b2c63c9 100644
--- a/nifi-commons/nifi-vault-utils/src/main/java/org/apache/nifi/vault/hashicorp/config/HashiCorpVaultPropertySource.java
+++ b/nifi-commons/nifi-vault-utils/src/main/java/org/apache/nifi/vault/hashicorp/config/HashiCorpVaultPropertySource.java
@@ -46,7 +46,7 @@ public class HashiCorpVaultPropertySource extends PropertySource<HashiCorpVaultP
     /**
      * Converts key names from format test-value to testValue
      * @param springPropertyKey A Spring Vault property key
-     * @return
+     * @return Property Key
      */
     private String getPropertyKey(String springPropertyKey) {
         final Matcher m = DASH_LETTER_PATTERN.matcher(springPropertyKey);
diff --git a/nifi-mock/src/main/java/org/apache/nifi/util/TestRunners.java b/nifi-mock/src/main/java/org/apache/nifi/util/TestRunners.java
index 8370e88..29c3253 100644
--- a/nifi-mock/src/main/java/org/apache/nifi/util/TestRunners.java
+++ b/nifi-mock/src/main/java/org/apache/nifi/util/TestRunners.java
@@ -35,7 +35,7 @@ public class TestRunners {
      * Returns a {@code TestRunner} for the given {@code Processor} which uses the given {@code KerberosContext}.
      * @param processor the {@code Processor} under test
      * @param kerberosContext the {@code KerberosContext} used during the test
-     * @return
+     * @return a {@code TestRunner}
      */
     public static TestRunner newTestRunner(final Processor processor, KerberosContext kerberosContext) {
         return newTestRunner(processor,processor.getClass().getName(), kerberosContext);
diff --git a/nifi-nar-bundles/nifi-accumulo-bundle/nifi-accumulo-processors/src/main/java/org/apache/nifi/accumulo/processors/PutAccumuloRecord.java b/nifi-nar-bundles/nifi-accumulo-bundle/nifi-accumulo-processors/src/main/java/org/apache/nifi/accumulo/processors/PutAccumuloRecord.java
index 7808b82..97062e4 100644
--- a/nifi-nar-bundles/nifi-accumulo-bundle/nifi-accumulo-processors/src/main/java/org/apache/nifi/accumulo/processors/PutAccumuloRecord.java
+++ b/nifi-nar-bundles/nifi-accumulo-bundle/nifi-accumulo-processors/src/main/java/org/apache/nifi/accumulo/processors/PutAccumuloRecord.java
@@ -432,7 +432,7 @@ public class PutAccumuloRecord extends BaseAccumuloProcessor {
      * @param columnQualifier column qualifier from which to extract the visibility or to execute an expression against
      * @param flowFile flow file being written
      * @param context process context
-     * @return
+     * @return Visibility
      */
     public static String produceVisibility(String columnFamily, String columnQualifier, FlowFile flowFile, ProcessContext context) {
         if (org.apache.commons.lang3.StringUtils.isNotEmpty(columnFamily)) {
diff --git a/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngine.java b/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngine.java
index 1c6ac17..0b64e02 100644
--- a/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngine.java
+++ b/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngine.java
@@ -63,7 +63,7 @@ public class EasyRulesEngine implements RulesEngine {
      * Return the list of actions what should be executed for a given set of facts
      *
      * @param facts a Map of key and facts values, as objects, that should be evaluated by the rules engine
-     * @return
+     * @return List of Actions
      */
     @Override
     public List<Action> fireRules(Map<String, Object> facts) {
@@ -81,7 +81,7 @@ public class EasyRulesEngine implements RulesEngine {
      * Return a Map with Rule as a key and Boolean as a value indicating that the rule's conditions were met
      *
      * @param facts Map of keys and values contains facts to evaluate against rules
-     * @return
+     * @return Map of Rules
      */
     @Override
     public Map<Rule, Boolean> checkRules(Map<String, Object> facts) {
diff --git a/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngineProvider.java b/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngineProvider.java
index 83b897a..941a4e1 100644
--- a/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngineProvider.java
+++ b/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngineProvider.java
@@ -27,7 +27,7 @@ public class EasyRulesEngineProvider extends AbstractEasyRulesEngineController i
 
     /**
      * Returns a rules engine instance
-     * @return
+     * @return Rules Engine
      */
     @Override
     public RulesEngine getRulesEngine() {
diff --git a/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngineService.java b/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngineService.java
index 520a0e0..8f1cba5 100644
--- a/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngineService.java
+++ b/nifi-nar-bundles/nifi-easyrules-bundle/nifi-easyrules-service/src/main/java/org/apache/nifi/rules/engine/EasyRulesEngineService.java
@@ -57,7 +57,7 @@ public class EasyRulesEngineService  extends EasyRulesEngineProvider implements
     /**
      * Return the list of actions what should be executed for a given set of facts
      * @param facts a Map of key and facts values, as objects, that should be evaluated by the rules engine
-     * @return
+     * @return List of Actions
      */
     @Override
     public List<Action> fireRules(Map<String, Object> facts) {
diff --git a/nifi-nar-bundles/nifi-extension-utils/nifi-processor-utils/src/main/java/org/apache/nifi/processor/util/list/AbstractListProcessor.java b/nifi-nar-bundles/nifi-extension-utils/nifi-processor-utils/src/main/java/org/apache/nifi/processor/util/list/AbstractListProcessor.java
index dce4c24..094ba8b 100644
--- a/nifi-nar-bundles/nifi-extension-utils/nifi-processor-utils/src/main/java/org/apache/nifi/processor/util/list/AbstractListProcessor.java
+++ b/nifi-nar-bundles/nifi-extension-utils/nifi-processor-utils/src/main/java/org/apache/nifi/processor/util/list/AbstractListProcessor.java
@@ -969,7 +969,7 @@ public abstract class AbstractListProcessor<T extends ListableEntity> extends Ab
      * If TARGET_SYSTEM_TIMESTAMP_PRECISION is supported as a valid Processor property,
      * then PRECISION_AUTO_DETECT will be the default value when not specified by a user.
      *
-     * @return
+     * @return Default Time Precision
      */
     protected String getDefaultTimePrecision() {
         return TARGET_SYSTEM_TIMESTAMP_PRECISION.getDefaultValue();
diff --git a/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/status/analytics/StatusAnalyticsModelMapFactory.java b/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/status/analytics/StatusAnalyticsModelMapFactory.java
index 1a5d351..f869053 100644
--- a/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/status/analytics/StatusAnalyticsModelMapFactory.java
+++ b/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/status/analytics/StatusAnalyticsModelMapFactory.java
@@ -54,7 +54,7 @@ public class StatusAnalyticsModelMapFactory {
 
     /**
      * Return mapping of models and extraction functions for connection status analytics prediction instances
-     * @return
+     * @return Connection Status Model Map
      */
     public Map<String, Tuple<StatusAnalyticsModel, StatusMetricExtractFunction>> getConnectionStatusModelMap(){
         Map<String, Tuple<StatusAnalyticsModel, StatusMetricExtractFunction>> modelMap = new HashMap<>();
diff --git a/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-jetty/src/main/java/org/apache/nifi/web/server/HostHeaderHandler.java b/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-jetty/src/main/java/org/apache/nifi/web/server/HostHeaderHandler.java
index 9a411fa..47ef195 100644
--- a/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-jetty/src/main/java/org/apache/nifi/web/server/HostHeaderHandler.java
+++ b/nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-web/nifi-jetty/src/main/java/org/apache/nifi/web/server/HostHeaderHandler.java
@@ -351,7 +351,7 @@ public class HostHeaderHandler extends ScopedHandler {
      *
      * @param networkInterfaces the map of properties to bindings
      *                          ({@code ["nifi.web.http.network.interface.first":"eth0"]})
-     * @return
+     * @return Not Defined status
      */
     static boolean isNotDefined(Map<String, String> networkInterfaces) {
         return networkInterfaces == null || networkInterfaces.isEmpty() || networkInterfaces.values().stream().filter(value -> !Strings.isNullOrEmpty(value)).collect(Collectors.toList()).isEmpty();
diff --git a/nifi-nar-bundles/nifi-hadoop-bundle/nifi-hdfs-processors/src/main/java/org/apache/nifi/processors/hadoop/PutHDFS.java b/nifi-nar-bundles/nifi-hadoop-bundle/nifi-hdfs-processors/src/main/java/org/apache/nifi/processors/hadoop/PutHDFS.java
index 9b669ae..eb7dfb5 100644
--- a/nifi-nar-bundles/nifi-hadoop-bundle/nifi-hdfs-processors/src/main/java/org/apache/nifi/processors/hadoop/PutHDFS.java
+++ b/nifi-nar-bundles/nifi-hadoop-bundle/nifi-hdfs-processors/src/main/java/org/apache/nifi/processors/hadoop/PutHDFS.java
@@ -550,7 +550,7 @@ public class PutHDFS extends AbstractHadoopProcessor {
      * Returns an optional with the first throwable in the causal chain that is assignable to the provided cause type,
      * and satisfies the provided cause predicate, {@link Optional#empty()} otherwise.
      * @param t The throwable to inspect for the cause.
-     * @return
+     * @return Throwable Cause
      */
     private <T extends Throwable> Optional<T> findCause(Throwable t, Class<T> expectedCauseType, Predicate<T> causePredicate) {
         Stream<Throwable> causalChain = Throwables.getCausalChain(t).stream();
diff --git a/nifi-registry/pom.xml b/nifi-registry/pom.xml
index fc15338..e240bc8 100644
--- a/nifi-registry/pom.xml
+++ b/nifi-registry/pom.xml
@@ -328,18 +328,6 @@
                         <additionalJOption>-J-Xmx512m</additionalJOption>
                     </configuration>
                 </plugin>
-                <plugin>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-checkstyle-plugin</artifactId>
-                    <version>3.1.1</version>
-                    <dependencies>
-                        <dependency>
-                            <groupId>com.puppycrawl.tools</groupId>
-                            <artifactId>checkstyle</artifactId>
-                            <version>8.31</version>
-                        </dependency>
-                    </dependencies>
-                </plugin>
             </plugins>
         </pluginManagement>
 
diff --git a/pom.xml b/pom.xml
index 844f483..0120bf5 100644
--- a/pom.xml
+++ b/pom.xml
@@ -711,7 +711,7 @@
                         <dependency>
                             <groupId>com.puppycrawl.tools</groupId>
                             <artifactId>checkstyle</artifactId>
-                            <version>8.29</version>
+                            <version>9.2.1</version>
                         </dependency>
                     </dependencies>
                 </plugin>