You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hop.apache.org by ha...@apache.org on 2021/12/27 15:20:38 UTC

[incubator-hop] branch master updated: [SONAR] cleanup

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

hansva pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-hop.git


The following commit(s) were added to refs/heads/master by this push:
     new 335cfb0  [SONAR] cleanup
     new 5a07cf5  Merge pull request #1247 from hansva/master
335cfb0 is described below

commit 335cfb07e54d9f3ee8f44c7e67362031b821dee1
Author: Hans Van Akelyen <ha...@gmail.com>
AuthorDate: Mon Dec 27 14:50:08 2021 +0100

    [SONAR] cleanup
---
 core/src/main/java/org/apache/hop/core/Const.java  |  12 +-
 .../org/apache/hop/core/database/Database.java     |   7 +-
 .../org/apache/hop/core/database/DatabaseMeta.java |   4 +-
 .../main/java/org/apache/hop/core/util/Utils.java  |   2 +-
 .../java/org/apache/hop/base/AbstractMeta.java     |   9 +-
 .../main/java/org/apache/hop/base/BaseHopMeta.java |   3 +-
 .../main/java/org/apache/hop/core/NotePadMeta.java |   3 +-
 .../apache/hop/core/file/TextFileInputField.java   |  15 +-
 .../java/org/apache/hop/core/gui/BasePainter.java  |   3 +-
 .../hop/core/injection/bean/BeanInjector.java      |   3 +-
 .../hop/core/injection/bean/BeanLevelInfo.java     |   4 +-
 .../org/apache/hop/pipeline/PipelinePainter.java   |   7 +-
 .../hop/pipeline/PipelinePainterExtension.java     |   7 +-
 .../hop/pipeline/transform/BaseTransform.java      |   3 +-
 .../hop/pipeline/transform/TransformStatus.java    |  14 +-
 .../pipeline/transforms/file/BaseFileField.java    |  73 +++--
 .../java/org/apache/hop/workflow/WorkflowMeta.java |  21 +-
 .../org/apache/hop/workflow/WorkflowPainter.java   |  11 +-
 .../hop/workflow/WorkflowPainterExtension.java     |   7 +-
 .../engines/local/LocalWorkflowEngine.java         |   2 +-
 .../org/apache/hop/www/RegisterPackageServlet.java |   4 +-
 .../ActionAddResultFilenamesDialog.java            |   3 +-
 .../ActionCheckFilesLockedDialog.java              |   3 +-
 .../actions/copyfiles/ActionCopyFiles.java         |  12 +-
 .../hop/workflow/actions/delay/ActionDelay.java    |  26 +-
 .../actions/dostounix/ActionDosToUnixDialog.java   |   6 +-
 .../evalfilesmetrics/ActionEvalFilesMetrics.java   |  54 ++--
 .../ActionEvalFilesMetricsDialog.java              |   3 +-
 .../ActionEvalTableContentDialog.java              |  19 +-
 .../actions/filecompare/ActionFileCompare.java     |   3 +-
 .../folderscompare/ActionFoldersCompare.java       |  13 +-
 .../hop/workflow/actions/ftp/ActionFtpDialog.java  |  64 ++---
 .../actions/ftpdelete/ActionFtpDeleteDialog.java   |  53 ++--
 .../actions/ftpput/ActionFtpPutDialog.java         |  61 +++--
 .../hop/workflow/actions/sftp/ActionSftp.java      |  22 +-
 .../workflow/actions/sftp/ActionSftpDialog.java    |  36 +--
 .../actions/sftpput/ActionSftpPutDialog.java       |  28 +-
 .../hop/workflow/actions/getpop/ActionGetPOP.java  |   4 +-
 .../actions/getpop/ActionGetPOPDialog.java         |  64 ++---
 .../workflow/actions/getpop/MailConnection.java    |  23 +-
 .../hop/workflow/actions/http/ActionHttp.java      |   4 +-
 .../workflow/actions/http/ActionHttpDialog.java    |  32 +--
 .../hop/workflow/actions/mail/ActionMail.java      |   8 +-
 .../workflow/actions/mail/ActionMailDialog.java    |  22 +-
 .../actions/movefiles/ActionMoveFiles.java         | 111 ++++----
 .../actions/movefiles/ActionMoveFilesDialog.java   |  24 +-
 .../actions/mssqlbulkload/ActionMssqlBulkLoad.java |  88 +++---
 .../mssqlbulkload/ActionMssqlBulkLoadDialog.java   |  24 +-
 .../actions/mysqlbulkfile/ActionMysqlBulkFile.java |  62 ++---
 .../actions/mysqlbulkload/ActionMysqlBulkLoad.java |  70 ++---
 .../pgpdecryptfiles/ActionPGPDecryptFiles.java     |  73 ++---
 .../ActionPGPDecryptFilesDialog.java               |  29 +-
 .../pgpencryptfiles/ActionPGPEncryptFiles.java     |  77 +++---
 .../ActionPGPEncryptFilesDialog.java               |  24 +-
 .../actions/pgpverify/ActionPGPVerifyDialog.java   |   8 +-
 .../hop/workflow/actions/ping/ActionPing.java      |  14 +-
 .../workflow/actions/pipeline/ActionPipeline.java  |   6 +-
 .../workflow/actions/repeat/EndRepeatDialog.java   |   2 +-
 .../hop/workflow/actions/repeat/RepeatDialog.java  |  15 +-
 .../ActionSendNagiosPassiveCheckDialog.java        |  24 +-
 .../hop/workflow/actions/shell/ActionShell.java    |   6 +-
 .../workflow/actions/shell/ActionShellDialog.java  |  16 +-
 .../actions/simpleeval/ActionSimpleEvalDialog.java |   4 +-
 .../workflow/actions/snmptrap/ActionSNMPTrap.java  |  14 +-
 .../actions/snmptrap/ActionSNMPTrapDialog.java     |  24 +-
 .../apache/hop/workflow/actions/sql/ActionSql.java |   9 +-
 .../workflow/actions/unzip/ActionUnZipDialog.java  |   3 +-
 .../actions/waitforsql/ActionWaitForSqlDialog.java |  19 +-
 .../workflow/actions/workflow/ActionWorkflow.java  |   6 +-
 .../writetofile/ActionWriteToFileDialog.java       |  24 +-
 .../actions/xml/dtdvalidator/DtdValidatorUtil.java |   8 +-
 .../actions/xml/xmlwellformed/XmlWellFormed.java   |  91 ++++---
 .../xml/xmlwellformed/XmlWellFormedDialog.java     |  12 +-
 .../actions/xml/xsdvalidator/XsdValidator.java     |  14 +-
 .../workflow/actions/zipfile/ActionZipFile.java    |  26 +-
 .../actions/zipfile/ActionZipFileDialog.java       |   3 +-
 .../org/apache/hop/beam/core/fn/HopKeyValueFn.java |   3 +-
 .../org/apache/hop/beam/core/fn/HopToStringFn.java |   3 +-
 .../core/transform/BeamKafkaInputTransform.java    |   2 +-
 .../org/apache/hop/www/AsyncWebServiceEditor.java  |  18 +-
 .../hop/debug/action/ActionDebugLevelDialog.java   |  11 +-
 .../debug/transform/TransformDebugLevelDialog.java |  18 +-
 .../environment/LifecycleEnvironmentDialog.java    |  13 +-
 .../pipeline/meta/PipelineLogEditor.java           |  25 +-
 .../reflection/probe/meta/PipelineProbeEditor.java |  18 +-
 .../reflection/probe/xp/PipelineDataProbeXp.java   |   5 +-
 .../workflow/meta/WorkflowLogEditor.java           |  25 +-
 .../actions/runtests/RunPipelineTestsDialog.java   |  10 +-
 .../testing/xp/WriteToDataSetExtensionPoint.java   |   9 +-
 .../org/apache/hop/ui/testing/EditRowsDialog.java  |   9 +-
 .../testing/PipelineUnitTestSetLocationDialog.java |   8 +-
 .../transforms/avrodecode/AvroDecodeDialog.java    |   3 +-
 .../transforms/eventhubs/listen/AzureListener.java |  29 +-
 .../eventhubs/listen/AzureListenerDialog.java      |   2 +-
 .../listen/AzureListenerEventProcessor.java        |   4 +-
 .../eventhubs/listen/AzureListenerMeta.java        |   4 +-
 .../transforms/eventhubs/write/AzureWrite.java     |   4 +-
 .../eventhubs/write/AzureWriterDialog.java         |   2 +-
 .../cassandra/datastax/DriverConnection.java       |   3 +-
 .../cassandra/datastax/DriverCqlRowHandler.java    |   4 +-
 .../cassandra/datastax/TableMetaData.java          |   5 +-
 .../cassandraoutput/CassandraOutputDialog.java     |   7 +-
 .../writer/SSTableWriterBuilder.java               |   5 +-
 .../workflow/actions/execcql/ExecCqlDialog.java    |   2 +-
 .../hop/vfs/googledrive/GoogleDriveFileObject.java |   6 +-
 .../googledrive/ui/GoogleAuthorizationDialog.java  |   4 +-
 .../googledrive/util/CustomDataStoreFactory.java   |   6 +-
 .../util/CustomLocalServerReceiver.java            |   8 +-
 .../actions/check/CheckConnectionsDialog.java      |  11 +-
 .../actions/constraint/Neo4jConstraintDialog.java  |   6 +-
 .../actions/cypherscript/CypherScriptDialog.java   |  10 +-
 .../hop/neo4j/actions/index/Neo4jIndexDialog.java  |   6 +-
 .../apache/hop/neo4j/model/GraphModelEditor.java   |  25 +-
 .../hop/neo4j/perspective/HopNeo4jPerspective.java |  10 +-
 .../hop/neo4j/shared/NeoConnectionEditor.java      |  35 +--
 .../hop/neo4j/transforms/cypher/CypherDialog.java  |   7 +-
 .../neo4j/transforms/gencsv/GenerateCsvDialog.java |   3 +-
 .../neo4j/transforms/graph/GraphOutputDialog.java  |  19 +-
 .../neo4j/transforms/importer/ImporterDialog.java  |   6 +-
 .../transforms/loginfo/GetLoggingInfoDialog.java   |  19 +-
 .../transforms/loginfo/GetLoggingInfoMeta.java     |   2 +-
 .../hop/neo4j/transforms/output/Neo4JOutput.java   |   3 +-
 .../neo4j/transforms/output/Neo4JOutputDialog.java |  43 +--
 .../neo4j/transforms/split/SplitGraphDialog.java   |   3 +-
 .../transforms/calculator/CalculatorDialog.java    |   7 +-
 .../combinationlookup/CombinationLookupDialog.java |   6 +-
 .../combinationlookup/CombinationLookupMeta.java   |  17 +-
 .../transforms/concatfields/ConcatFieldsMeta.java  |   3 +-
 .../CreditCardValidatorDialog.java                 |  15 +-
 .../creditcardvalidator/CreditCardVerifier.java    |  12 +-
 .../databaselookup/DatabaseLookupDialog.java       |  23 +-
 .../databaselookup/readallcache/GtIndex.java       |   3 +-
 .../databaselookup/readallcache/IsNullIndex.java   |   3 +-
 .../databaselookup/readallcache/LtIndex.java       |   3 +-
 .../denormaliser/DenormaliserDialog.java           |   4 +-
 .../dimensionlookup/DimensionLookupMeta.java       |  18 +-
 .../transforms/excelinput/ExcelInputDialog.java    |  14 +-
 .../excelwriter/ExcelWriterTransformMeta.java      |   2 +-
 .../transforms/execprocess/ExecProcessDialog.java  |   5 +-
 .../transforms/execsqlrow/ExecSqlRowDialog.java    |   8 +-
 .../transforms/filemetadata/FileMetadata.java      |  15 +-
 .../transforms/fuzzymatch/FuzzyMatchDialog.java    |  56 ++--
 .../getfilesrowcount/GetFilesRowsCountDialog.java  |  25 +-
 .../getfilesrowcount/GetFilesRowsCountMeta.java    |  35 ++-
 .../transforms/gettablenames/GetTableNames.java    |  30 +-
 .../gettablenames/GetTableNamesDialog.java         |  20 +-
 .../hop/pipeline/transforms/http/HttpDialog.java   |  16 +-
 .../hop/pipeline/transforms/ifnull/IfNull.java     |   6 +-
 .../pipeline/transforms/ifnull/IfNullDialog.java   |  21 +-
 .../insertupdate/InsertUpdateDialog.java           |  14 +-
 .../pipeline/transforms/janino/JaninoDialog.java   |   7 +-
 .../UserDefinedJavaClassDialog.java                |  30 +-
 .../javascript/ScriptValuesAddedFunctions.java     |   3 +-
 .../transforms/javascript/ScriptValuesDialog.java  |   9 +-
 .../jsonoutputenhanced/JsonOutputField.java        |   4 +-
 .../jsonoutputenhanced/JsonOutputMeta.java         |   2 +-
 .../transforms/ldapinput/LdapConnection.java       |  22 +-
 .../transforms/ldapinput/LdapInputDialog.java      |  32 +--
 .../transforms/ldapinput/LdapInputField.java       |  12 +-
 .../transforms/ldapinput/LdapInputMeta.java        |  18 +-
 .../transforms/ldapoutput/LdapOutputDialog.java    |  40 +--
 .../transforms/ldapoutput/LdapOutputMeta.java      |   2 +-
 .../loadfileinput/LoadFileInputData.java           |   4 +-
 .../loadfileinput/LoadFileInputDialog.java         |  27 +-
 .../loadfileinput/LoadFileInputField.java          |  16 +-
 .../loadfileinput/LoadFileInputMeta.java           |  26 +-
 .../transforms/mailinput/MailInputDialog.java      |   3 +-
 .../transforms/mapping/SimpleMappingDialog.java    |  14 +-
 .../transforms/memgroupby/MemoryGroupByDialog.java |   8 +-
 .../transforms/mergejoin/MergeJoinData.java        |  18 +-
 .../transforms/mergerows/MergeRowsData.java        |   3 +-
 .../transforms/metainject/MetaInjectDialog.java    |  20 +-
 .../TransformMetaStructureDialog.java              |   2 +-
 .../metastructure/TransformMetaStructureMeta.java  |   2 +-
 .../org/apache/hop/mongo/MongoPropToOption.java    |   2 +-
 .../mongo/wrapper/NoAuthMongoClientWrapper.java    |   2 +-
 .../transforms/mongodbinput/MongoDbInput.java      |   2 +-
 .../mongodbinput/MongoDbInputDialog.java           |   2 +-
 .../transforms/mongodbinput/MongoDbInputMeta.java  |  10 +-
 .../transforms/mongodboutput/MongoDbOutput.java    |   2 +-
 .../wrapper/NoAuthMongoClientWrapperTest.java      |   2 +-
 .../multimerge/MultiMergeJoinDialog.java           |   3 +-
 .../pipeline/transforms/normaliser/Normaliser.java |   7 +-
 .../transforms/normaliser/NormaliserMeta.java      |  20 +-
 .../pgpdecryptstream/PGPDecryptStreamDialog.java   |   8 +-
 .../pgpencryptstream/PGPEncryptStreamDialog.java   |  14 +-
 .../pipelineexecutor/PipelineExecutorDialog.java   |  53 ++--
 .../propertyinput/PropertyInputDialog.java         |  16 +-
 .../propertyinput/PropertyInputField.java          |  12 +-
 .../propertyoutput/PropertyOutputMeta.java         |   6 +-
 .../regexeval/RegexEvalHelperDialog.java           |  12 +-
 .../hop/pipeline/transforms/rest/RestDialog.java   |  33 ++-
 .../salesforce/SalesforceConnection.java           |   7 +-
 .../salesforce/SalesforceConnectionUtils.java      |   2 +-
 .../salesforce/SalesforceTransformMeta.java        |   2 +-
 .../salesforcedelete/SalesforceDeleteDialog.java   |   6 +-
 .../salesforcedelete/SalesforceDeleteMeta.java     |  12 +-
 .../salesforceinput/SalesforceInputField.java      |   2 +-
 .../salesforceinput/SalesforceInputMeta.java       |   2 +-
 .../salesforceinsert/SalesforceInsertMeta.java     |   2 +-
 .../salesforceupdate/SalesforceUpdateMeta.java     |   2 +-
 .../salesforceupsert/SalesforceUpsertMeta.java     |   2 +-
 .../salesforceutils/SalesforceUtils.java           |   2 +-
 .../transforms/samplerows/SampleRowsDialog.java    |   5 +-
 .../transforms/sasinput/SasInputDialog.java        |   2 +-
 .../pipeline/transforms/sasinput/SasInputMeta.java |   2 +-
 .../serverstatus/GetServerStatusDialog.java        |   2 +-
 .../setvalueconstant/SetValueConstantDialog.java   |   4 +-
 .../transforms/setvaluefield/SetValueField.java    |  23 +-
 .../transforms/splunkinput/SplunkInputDialog.java  |   2 +-
 .../apache/hop/splunk/SplunkConnectionEditor.java  |   2 +-
 .../sqlfileoutput/SQLFileOutputMeta.java           |  45 +--
 .../hop/pipeline/transforms/ssh/SSHDialog.java     |  23 +-
 .../streamlookup/StreamLookupDialog.java           |   8 +-
 .../transforms/streamschemamerge/SchemaMapper.java |   4 +-
 .../streamschemamerge/StreamSchemaData.java        |   7 +-
 .../streamschemamerge/StreamSchemaMeta.java        |   4 +-
 .../stringoperations/StringOperations.java         |  10 +-
 .../SynchronizeAfterMergeMeta.java                 |  41 +--
 .../transforms/tablecompare/TableCompare.java      |   3 +-
 .../hop/pipeline/transforms/terafast/TeraFast.java |  14 +-
 .../transforms/terafast/TeraFastDialog.java        |   8 +-
 .../fileinput/text/TextFileInputDialog.java        |  19 +-
 .../transforms/textfileoutput/TextFileField.java   |  20 +-
 .../textfileoutput/TextFileOutputMeta.java         |  11 +-
 .../apache/hop/pipeline/transforms/tika/Tika.java  |  21 +-
 .../hop/pipeline/transforms/tika/TikaDialog.java   |   2 +-
 .../hop/pipeline/transforms/tika/TikaMeta.java     |   2 +-
 .../tokenreplacement/TokenReplacement.java         |   2 +-
 .../tokenreplacement/TokenReplacementDialog.java   | 302 ++++++++-------------
 .../tokenreplacement/TokenReplacementMeta.java     |  18 +-
 .../UniqueRowsByHashSetDialog.java                 |   8 +-
 .../pipeline/transforms/update/UpdateDialog.java   |   6 +-
 .../pipeline/transforms/xml/addxml/XmlField.java   |  12 +-
 .../transforms/xml/getxmldata/GetXmlData.java      |   8 +-
 .../transforms/xml/getxmldata/GetXmlDataData.java  |   4 +-
 .../xml/getxmldata/GetXmlDataDialog.java           | 243 ++++++++++-------
 .../transforms/xml/getxmldata/GetXmlDataField.java |  12 +-
 .../getxmldata/LoopNodesImportProgressDialog.java  |  12 +-
 .../pipeline/transforms/xml/xmljoin/XmlJoin.java   |  10 +-
 .../xml/xsdvalidator/XsdValidatorDialog.java       |  14 +-
 .../hop/pipeline/transforms/xml/xslt/XsltMeta.java |  10 +-
 .../transforms/yamlinput/YamlInputDialog.java      | 173 +++++-------
 .../transforms/yamlinput/YamlInputField.java       |  12 +-
 .../main/java/org/apache/hop/ui/hopgui/HopWeb.java |  20 +-
 .../java/org/apache/hop/ui/core/PrintSpool.java    |   2 +-
 .../database/dialog/DatabaseExplorerDialog.java    |  15 +-
 .../org/apache/hop/ui/core/dialog/BaseDialog.java  |   6 +-
 .../hop/ui/core/dialog/BaseMessageDialog.java      |   6 +-
 .../hop/ui/core/dialog/CheckResultDialog.java      |   4 +-
 .../hop/ui/core/dialog/ConfigurationDialog.java    |   9 +-
 .../hop/ui/core/dialog/EnterConditionDialog.java   |   7 +-
 .../apache/hop/ui/core/dialog/EnterListDialog.java |   3 +-
 .../hop/ui/core/dialog/EnterMappingDialog.java     |   6 +-
 .../hop/ui/core/dialog/EnterNumberDialog.java      |  20 +-
 .../hop/ui/core/dialog/EnterOptionsDialog.java     |  22 +-
 .../hop/ui/core/dialog/EnterPrintDialog.java       |  12 +-
 .../hop/ui/core/dialog/EnterSearchDialog.java      |  12 +-
 .../apache/hop/ui/core/dialog/EnterTextDialog.java |  11 +-
 .../core/dialog/HopDescribedVariablesDialog.java   |   4 +-
 .../hop/ui/core/dialog/ProgressMonitorDialog.java  |  52 ++--
 .../apache/hop/ui/core/dialog/SelectRowDialog.java |   4 +-
 .../apache/hop/ui/core/dialog/ShowHelpDialog.java  |  13 +-
 .../hop/ui/core/dialog/ShowMessageDialog.java      |   7 +-
 .../apache/hop/ui/core/vfs/HopVfsFileDialog.java   |   3 +-
 .../apache/hop/ui/core/widget/ColumnsResizer.java  |   3 +-
 .../hop/ui/core/widget/MetaSelectionLine.java      |   2 +-
 .../hop/ui/core/widget/TabFolderReorder.java       |   2 +-
 .../main/java/org/apache/hop/ui/hopgui/HopGui.java |   2 +-
 .../ui/hopgui/dialog/EnterPreviewRowsDialog.java   |  22 +-
 .../ui/hopgui/dialog/MetadataExplorerDialog.java   |   7 +-
 .../hopgui/file/pipeline/HopGuiPipelineGraph.java  |   4 +-
 .../pipeline/context/HopGuiPipelineContext.java    |  19 +-
 .../workflow/context/HopGuiWorkflowContext.java    |  15 +-
 .../dataorch/HopDataOrchestrationPerspective.java  |  21 +-
 .../perspective/dataorch/HopGuiAbstractGraph.java  |   4 +-
 .../ui/hopgui/search/HopGuiMetadataSearchable.java |  11 +-
 .../hop/ui/pipeline/debug/PipelineDebugDialog.java |  15 +-
 .../ui/pipeline/dialog/ModPartitionerDialog.java   |   8 +-
 .../hop/ui/pipeline/dialog/PipelineDialog.java     |  10 +-
 .../ui/pipeline/transform/BaseTransformDialog.java |  31 ++-
 .../transform/TransformErrorMetaDialog.java        |  28 +-
 .../transform/common/FieldSelectionDialog.java     |  12 +-
 .../transform/common/TextFileLineUtil.java         |  62 ++---
 .../transforms/injector/InjectorDialog.java        |   9 +-
 .../transforms/missing/MissingPipelineDialog.java  |   6 +-
 .../org/apache/hop/ui/server/HopServerEditor.java  |   8 +-
 .../actions/missing/MissingActionDialog.java       |   3 +-
 .../workflow/actions/start/ActionStartDialog.java  |   4 +-
 .../hop/ui/workflow/dialog/WorkflowDialog.java     |  11 +-
 .../WorkflowExecutionConfigurationDialog.java      |  21 +-
 .../hop/ui/www/service/WebServiceEditor.java       |  26 +-
 292 files changed, 2372 insertions(+), 2504 deletions(-)

diff --git a/core/src/main/java/org/apache/hop/core/Const.java b/core/src/main/java/org/apache/hop/core/Const.java
index 076d117..ba14319 100644
--- a/core/src/main/java/org/apache/hop/core/Const.java
+++ b/core/src/main/java/org/apache/hop/core/Const.java
@@ -2466,7 +2466,8 @@ public class Const {
    */
   public static String removeCRLF(String in) {
     if ((in != null) && (in.length() > 0)) {
-      int inLen = in.length(), posn = 0;
+      int inLen = in.length();
+      int posn = 0;
       char[] tmp = new char[inLen];
       char ch;
       for (int i = 0; i < inLen; i++) {
@@ -2492,7 +2493,8 @@ public class Const {
    */
   public static String removeChar(String in, char badChar) {
     if ((in != null) && (in.length() > 0)) {
-      int inLen = in.length(), posn = 0;
+      int inLen = in.length();
+      int posn = 0;
       char[] tmp = new char[inLen];
       char ch;
       for (int i = 0; i < inLen; i++) {
@@ -2598,11 +2600,11 @@ public class Const {
   public static String[] GetAvailableFontNames() {
     GraphicsEnvironment ge = GraphicsEnvironment.getLocalGraphicsEnvironment();
     Font[] fonts = ge.getAllFonts();
-    String[] FontName = new String[fonts.length];
+    String[] fontName = new String[fonts.length];
     for (int i = 0; i < fonts.length; i++) {
-      FontName[i] = fonts[i].getFontName();
+      fontName[i] = fonts[i].getFontName();
     }
-    return FontName;
+    return fontName;
   }
 
   /**
diff --git a/core/src/main/java/org/apache/hop/core/database/Database.java b/core/src/main/java/org/apache/hop/core/database/Database.java
index 0be2bff..0beadb0 100644
--- a/core/src/main/java/org/apache/hop/core/database/Database.java
+++ b/core/src/main/java/org/apache/hop/core/database/Database.java
@@ -114,10 +114,9 @@ public class Database implements IVariables, ILoggingObject {
       valueMetaPluginClasses = ValueMetaFactory.getValueMetaPluginClasses();
       Collections.sort(
           valueMetaPluginClasses,
-          (o1, o2) -> {
-            // Reverse the sort list
-            return (Integer.valueOf(o1.getType()).compareTo(Integer.valueOf(o2.getType()))) * -1;
-          });
+          (o1, o2) ->
+              // Reverse the sort list
+              (Integer.valueOf(o1.getType()).compareTo(Integer.valueOf(o2.getType()))) * -1);
     } catch (Exception e) {
       throw new RuntimeException("Unable to get list of instantiated value meta plugin classes", e);
     }
diff --git a/core/src/main/java/org/apache/hop/core/database/DatabaseMeta.java b/core/src/main/java/org/apache/hop/core/database/DatabaseMeta.java
index 0415429..07824e6 100644
--- a/core/src/main/java/org/apache/hop/core/database/DatabaseMeta.java
+++ b/core/src/main/java/org/apache/hop/core/database/DatabaseMeta.java
@@ -61,9 +61,7 @@ public class DatabaseMeta extends HopMetadataBase implements Cloneable, IHopMeta
 
   // Comparator for sorting databases alphabetically by name
   public static final Comparator<DatabaseMeta> comparator =
-      (DatabaseMeta dbm1, DatabaseMeta dbm2) -> {
-        return dbm1.getName().compareToIgnoreCase(dbm2.getName());
-      };
+      (DatabaseMeta dbm1, DatabaseMeta dbm2) -> dbm1.getName().compareToIgnoreCase(dbm2.getName());
 
   @HopMetadataProperty(key = "rdbms")
   private IDatabase iDatabase;
diff --git a/core/src/main/java/org/apache/hop/core/util/Utils.java b/core/src/main/java/org/apache/hop/core/util/Utils.java
index 033e2b0..27b9939 100644
--- a/core/src/main/java/org/apache/hop/core/util/Utils.java
+++ b/core/src/main/java/org/apache/hop/core/util/Utils.java
@@ -55,7 +55,7 @@ public class Utils {
     // A distancesMatrix to keep track of distances between characters.
     // It explores all valid distances in the loop below
     //
-    int distancesMatrix[][] = new int[oneLength + 2][twoLength + 2];
+    int[][] distancesMatrix = new int[oneLength + 2][twoLength + 2];
 
     // Initialize the matrix
     // The maximum possible length is the sum of both String lengths
diff --git a/engine/src/main/java/org/apache/hop/base/AbstractMeta.java b/engine/src/main/java/org/apache/hop/base/AbstractMeta.java
index 2014750..87a926e 100644
--- a/engine/src/main/java/org/apache/hop/base/AbstractMeta.java
+++ b/engine/src/main/java/org/apache/hop/base/AbstractMeta.java
@@ -93,8 +93,10 @@ public abstract class AbstractMeta
 
   protected IHopMetadataProvider metadataProvider;
 
-  protected String createdUser, modifiedUser;
-  protected Date createdDate, modifiedDate;
+  protected String createdUser;
+  protected String modifiedUser;
+  protected Date createdDate;
+  protected Date modifiedDate;
 
   protected final ChangedFlag changedFlag = new ChangedFlag();
 
@@ -752,7 +754,8 @@ public abstract class AbstractMeta
    *     found: null.
    */
   public NotePadMeta getNote(int x, int y) {
-    int i, s;
+    int i;
+    int s;
     s = notes.size();
     for (i = s - 1; i >= 0; i--) {
       // Back to front because drawing goes from start to end
diff --git a/engine/src/main/java/org/apache/hop/base/BaseHopMeta.java b/engine/src/main/java/org/apache/hop/base/BaseHopMeta.java
index 9cbef6b..8572930 100644
--- a/engine/src/main/java/org/apache/hop/base/BaseHopMeta.java
+++ b/engine/src/main/java/org/apache/hop/base/BaseHopMeta.java
@@ -23,7 +23,8 @@ public abstract class BaseHopMeta<T> {
   public static final String XML_TAG = "hop";
 
   public boolean split = false;
-  protected T from, to;
+  protected T from;
+  protected T to;
   protected boolean enabled;
   protected boolean changed;
   private boolean errorHop;
diff --git a/engine/src/main/java/org/apache/hop/core/NotePadMeta.java b/engine/src/main/java/org/apache/hop/core/NotePadMeta.java
index 963a9e9..7d8bda8 100644
--- a/engine/src/main/java/org/apache/hop/core/NotePadMeta.java
+++ b/engine/src/main/java/org/apache/hop/core/NotePadMeta.java
@@ -59,7 +59,8 @@ public class NotePadMeta implements Cloneable, IGuiPosition, IGuiSize {
   private int borderColorBlue;
 
   private Point location;
-  public int width, height;
+  public int width;
+  public int height;
   private boolean selected;
 
   private boolean changed;
diff --git a/engine/src/main/java/org/apache/hop/core/file/TextFileInputField.java b/engine/src/main/java/org/apache/hop/core/file/TextFileInputField.java
index 610ae7b..440152d 100644
--- a/engine/src/main/java/org/apache/hop/core/file/TextFileInputField.java
+++ b/engine/src/main/java/org/apache/hop/core/file/TextFileInputField.java
@@ -77,12 +77,6 @@ public class TextFileInputField implements Cloneable, ITextFileInputField {
 
   private String[] samples;
 
-  // Guess fields...
-  private NumberFormat nf;
-  private DecimalFormat df;
-  private DecimalFormatSymbols dfs;
-  private SimpleDateFormat daf;
-
   private static final String[] dateFormats =
       new String[] {
         "yyyy/MM/dd HH:mm:ss.SSS", "yyyy/MM/dd HH:mm:ss", "dd/MM/yyyy", "dd-MM-yyyy", "yyyy/MM/dd",
@@ -336,10 +330,11 @@ public class TextFileInputField implements Cloneable, ITextFileInputField {
   }
 
   public void guessType() {
-    nf = NumberFormat.getInstance();
-    df = (DecimalFormat) nf;
-    dfs = new DecimalFormatSymbols();
-    daf = new SimpleDateFormat();
+    // Guess fields...
+    NumberFormat nf = NumberFormat.getInstance();
+    DecimalFormat df = (DecimalFormat) nf;
+    DecimalFormatSymbols dfs = new DecimalFormatSymbols();
+    SimpleDateFormat daf = new SimpleDateFormat();
 
     daf.setLenient(false);
 
diff --git a/engine/src/main/java/org/apache/hop/core/gui/BasePainter.java b/engine/src/main/java/org/apache/hop/core/gui/BasePainter.java
index f6d9308..009a1f2 100644
--- a/engine/src/main/java/org/apache/hop/core/gui/BasePainter.java
+++ b/engine/src/main/java/org/apache/hop/core/gui/BasePainter.java
@@ -54,7 +54,8 @@ public abstract class BasePainter<Hop extends BaseHopMeta<?>, Part extends IBase
 
   protected Point area;
 
-  protected IScrollBar hori, vert;
+  protected IScrollBar hori;
+  protected IScrollBar vert;
 
   protected List<AreaOwner> areaOwners;
 
diff --git a/engine/src/main/java/org/apache/hop/core/injection/bean/BeanInjector.java b/engine/src/main/java/org/apache/hop/core/injection/bean/BeanInjector.java
index f25fd75..b13f7f0 100644
--- a/engine/src/main/java/org/apache/hop/core/injection/bean/BeanInjector.java
+++ b/engine/src/main/java/org/apache/hop/core/injection/bean/BeanInjector.java
@@ -159,7 +159,8 @@ public class BeanInjector<Meta extends Object> {
           "Property '" + propName + "' not found for injection to " + root.getClass());
     }
 
-    String dataName, dataValue;
+    String dataName;
+    String dataValue;
     if (data != null) {
       dataName = dataN;
       dataValue = null;
diff --git a/engine/src/main/java/org/apache/hop/core/injection/bean/BeanLevelInfo.java b/engine/src/main/java/org/apache/hop/core/injection/bean/BeanLevelInfo.java
index d9116f9..6b8575e 100644
--- a/engine/src/main/java/org/apache/hop/core/injection/bean/BeanLevelInfo.java
+++ b/engine/src/main/java/org/apache/hop/core/injection/bean/BeanLevelInfo.java
@@ -40,7 +40,9 @@ public class BeanLevelInfo<Meta extends Object> {
   /** Field of transform, or null if bean has getter/setter. */
   public Field field;
   /** Getter and setter. */
-  public Method getter, setter;
+  public Method getter;
+
+  public Method setter;
   /** Dimension of level. */
   public DIMENSION dim = DIMENSION.NONE;
   /** Values converter. */
diff --git a/engine/src/main/java/org/apache/hop/pipeline/PipelinePainter.java b/engine/src/main/java/org/apache/hop/pipeline/PipelinePainter.java
index d835967..56c403f 100644
--- a/engine/src/main/java/org/apache/hop/pipeline/PipelinePainter.java
+++ b/engine/src/main/java/org/apache/hop/pipeline/PipelinePainter.java
@@ -1009,8 +1009,11 @@ public class PipelinePainter extends BasePainter<PipelineHopMeta, TransformMeta>
       Object startObject,
       Object endObject)
       throws HopException {
-    int mx, my;
-    int a, b, dist;
+    int mx;
+    int my;
+    int a;
+    int b;
+    int dist;
     double angle;
 
     gc.drawLine(x1, y1, x2, y2);
diff --git a/engine/src/main/java/org/apache/hop/pipeline/PipelinePainterExtension.java b/engine/src/main/java/org/apache/hop/pipeline/PipelinePainterExtension.java
index 47093fb..c322e08 100644
--- a/engine/src/main/java/org/apache/hop/pipeline/PipelinePainterExtension.java
+++ b/engine/src/main/java/org/apache/hop/pipeline/PipelinePainterExtension.java
@@ -32,7 +32,12 @@ public class PipelinePainterExtension {
   public PipelineMeta pipelineMeta;
   public TransformMeta transformMeta;
   public PipelineHopMeta pipelineHop;
-  public int x1, y1, x2, y2, mx, my;
+  public int x1;
+  public int y1;
+  public int x2;
+  public int y2;
+  public int mx;
+  public int my;
   public Point offset;
   public int iconSize;
   public Map<String, Object> stateMap;
diff --git a/engine/src/main/java/org/apache/hop/pipeline/transform/BaseTransform.java b/engine/src/main/java/org/apache/hop/pipeline/transform/BaseTransform.java
index f0eea8a..4e8d944 100644
--- a/engine/src/main/java/org/apache/hop/pipeline/transform/BaseTransform.java
+++ b/engine/src/main/java/org/apache/hop/pipeline/transform/BaseTransform.java
@@ -175,7 +175,8 @@ public class BaseTransform<Meta extends ITransformMeta, Data extends ITransformD
 
   private TransformMeta[] prevTransforms;
 
-  private int currentInputRowSetNr, currentOutputRowSetNr;
+  private int currentInputRowSetNr;
+  private int currentOutputRowSetNr;
 
   /** The rowsets on the input, size() == nr of source transforms */
   private List<IRowSet> inputRowSets;
diff --git a/engine/src/main/java/org/apache/hop/pipeline/transform/TransformStatus.java b/engine/src/main/java/org/apache/hop/pipeline/transform/TransformStatus.java
index eb3e1ac..a03e7ea 100644
--- a/engine/src/main/java/org/apache/hop/pipeline/transform/TransformStatus.java
+++ b/engine/src/main/java/org/apache/hop/pipeline/transform/TransformStatus.java
@@ -82,19 +82,19 @@ public class TransformStatus {
     this.accumulatedRuntime = accumulatedRuntime + component.getExecutionDuration();
     this.statusDescription = component.getStatusDescription();
 
-    long in_proc = Math.max(linesInput, linesRead);
-    long out_proc = Math.max(linesOutput + linesUpdated, linesWritten + linesRejected);
+    long inProc = Math.max(linesInput, linesRead);
+    long outProc = Math.max(linesOutput + linesUpdated, linesWritten + linesRejected);
 
     float lapsed = ((float) accumulatedRuntime) / 1000;
-    double in_speed = 0;
-    double out_speed = 0;
+    double inSpeed = 0;
+    double outSpeed = 0;
 
     if (lapsed != 0) {
-      in_speed = Math.floor(10 * (in_proc / lapsed)) / 10;
-      out_speed = Math.floor(10 * (out_proc / lapsed)) / 10;
+      inSpeed = Math.floor(10 * (inProc / lapsed)) / 10;
+      outSpeed = Math.floor(10 * (outProc / lapsed)) / 10;
     }
 
-    double speedNumber = (in_speed > out_speed ? in_speed : out_speed);
+    double speedNumber = (inSpeed > outSpeed ? inSpeed : outSpeed);
 
     this.seconds = Math.floor((lapsed * 10) + 0.5) / 10;
     this.speed = lapsed == 0 ? "-" : " " + speedDf.format(speedNumber);
diff --git a/engine/src/main/java/org/apache/hop/pipeline/transforms/file/BaseFileField.java b/engine/src/main/java/org/apache/hop/pipeline/transforms/file/BaseFileField.java
index af36a79..e06f7c5 100644
--- a/engine/src/main/java/org/apache/hop/pipeline/transforms/file/BaseFileField.java
+++ b/engine/src/main/java/org/apache/hop/pipeline/transforms/file/BaseFileField.java
@@ -75,12 +75,6 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
 
   private String[] samples;
 
-  // Guess fields...
-  private NumberFormat nf;
-  private DecimalFormat df;
-  private DecimalFormatSymbols dfs;
-  private SimpleDateFormat daf;
-
   private static final String[] dateFormats =
       new String[] {
         "yyyy/MM/dd HH:mm:ss.SSS",
@@ -250,24 +244,24 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
     return groupSymbol;
   }
 
-  public void setGroupSymbol(String group_symbol) {
-    this.groupSymbol = group_symbol;
+  public void setGroupSymbol(String groupSymbol) {
+    this.groupSymbol = groupSymbol;
   }
 
   public String getDecimalSymbol() {
     return decimalSymbol;
   }
 
-  public void setDecimalSymbol(String decimal_symbol) {
-    this.decimalSymbol = decimal_symbol;
+  public void setDecimalSymbol(String decimalSymbol) {
+    this.decimalSymbol = decimalSymbol;
   }
 
   public String getCurrencySymbol() {
     return currencySymbol;
   }
 
-  public void setCurrencySymbol(String currency_symbol) {
-    this.currencySymbol = currency_symbol;
+  public void setCurrencySymbol(String currencySymbol) {
+    this.currencySymbol = currencySymbol;
   }
 
   public int getPrecision() {
@@ -318,30 +312,31 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
   }
 
   public void guessTrimType() {
-    boolean spaces_before = false;
-    boolean spaces_after = false;
+    boolean spacesBefore = false;
+    boolean spacesAfter = false;
 
     for (int i = 0; i < samples.length; i++) {
-      spaces_before |= Const.nrSpacesBefore(samples[i]) > 0;
-      spaces_after |= Const.nrSpacesAfter(samples[i]) > 0;
+      spacesBefore |= Const.nrSpacesBefore(samples[i]) > 0;
+      spacesAfter |= Const.nrSpacesAfter(samples[i]) > 0;
       samples[i] = Const.trim(samples[i]);
     }
 
     trimtype = IValueMeta.TRIM_TYPE_NONE;
 
-    if (spaces_before) {
+    if (spacesBefore) {
       trimtype |= IValueMeta.TRIM_TYPE_LEFT;
     }
-    if (spaces_after) {
+    if (spacesAfter) {
       trimtype |= IValueMeta.TRIM_TYPE_RIGHT;
     }
   }
 
   public void guessType() {
-    nf = NumberFormat.getInstance();
-    df = (DecimalFormat) nf;
-    dfs = new DecimalFormatSymbols();
-    daf = new SimpleDateFormat();
+    // Guess fields...
+    NumberFormat nf = NumberFormat.getInstance();
+    DecimalFormat df = (DecimalFormat) nf;
+    DecimalFormatSymbols dfs = new DecimalFormatSymbols();
+    SimpleDateFormat daf = new SimpleDateFormat();
 
     daf.setLenient(false);
 
@@ -358,7 +353,7 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
     // ////////////////////////////
 
     // See if all samples can be transformed into a date...
-    int datefmt_cnt = dateFormats.length;
+    int datefmtCnt = dateFormats.length;
     boolean[] datefmt = new boolean[dateFormats.length];
     for (int i = 0; i < dateFormats.length; i++) {
       datefmt[i] = true;
@@ -372,7 +367,7 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
         for (int x = 0; x < dateFormats.length; x++) {
           if (samples[i] == null || Const.onlySpaces(samples[i]) || samples[i].length() == 0) {
             datefmt[x] = false;
-            datefmt_cnt--;
+            datefmtCnt--;
           }
 
           if (datefmt[x]) {
@@ -386,11 +381,11 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
 
               if (year < 1800 || year > 2200) {
                 datefmt[x] = false; // Don't try it again in the future.
-                datefmt_cnt--; // One less that works..
+                datefmtCnt--; // One less that works..
               }
             } catch (Exception e) {
               datefmt[x] = false; // Don't try it again in the future.
-              datefmt_cnt--; // One less that works..
+              datefmtCnt--; // One less that works..
             }
           }
         }
@@ -400,7 +395,7 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
     // If it is a date, copy info over to the format etc. Then return with the info.
     // If all samples where NULL values, we can't really decide what the type is.
     // So we're certainly not going to take a date, just take a string in that case.
-    if (datefmt_cnt > 0 && datenul != samples.length) {
+    if (datefmtCnt > 0 && datenul != samples.length) {
       int first = -1;
       for (int i = 0; i < dateFormats.length && first < 0; i++) {
         if (datefmt[i]) {
@@ -430,11 +425,11 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
       numfmt[i] = true;
       maxprecision[i] = -1;
     }
-    int numfmt_cnt = numberFormats.length;
+    int numfmtCnt = numberFormats.length;
     int numnul = 0;
 
     for (int i = 0; i < samples.length && isnumber; i++) {
-      boolean contains_dot = false;
+      boolean containsDot = false;
       boolean containsComma = false;
 
       String field = samples[i];
@@ -452,10 +447,10 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
               && ch != 'e' // exponential
           ) {
             isnumber = false;
-            numfmt_cnt = 0;
+            numfmtCnt = 0;
           } else {
             if (ch == '.') {
-              contains_dot = true;
+              containsDot = true;
             }
             if (ch == ',') {
               containsComma = true;
@@ -464,24 +459,24 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
         }
         // If it's still a number, try to parse it as a double
         if (isnumber) {
-          if (contains_dot && !containsComma) { // American style 174.5
+          if (containsDot && !containsComma) { // American style 174.5
 
             dfs.setDecimalSeparator('.');
             decimalSymbol = ".";
             dfs.setGroupingSeparator(',');
             groupSymbol = ",";
-          } else if (!contains_dot && containsComma) { // European style 174,5
+          } else if (!containsDot && containsComma) { // European style 174,5
 
             dfs.setDecimalSeparator(',');
             decimalSymbol = ",";
             dfs.setGroupingSeparator('.');
             groupSymbol = ".";
-          } else if (contains_dot && containsComma) { // Both appear!
+          } else if (containsDot && containsComma) { // Both appear!
 
             // What's the last occurance: decimal point!
-            int idx_dot = field.indexOf('.');
+            int idxDot = field.indexOf('.');
             int idxCom = field.indexOf(',');
-            if (idx_dot > idxCom) {
+            if (idxDot > idxCom) {
               dfs.setDecimalSeparator('.');
               decimalSymbol = ".";
               dfs.setGroupingSeparator(',');
@@ -502,7 +497,7 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
               try {
                 int prec = -1;
                 // Try long integers first....
-                if (!contains_dot && !containsComma) {
+                if (!containsDot && !containsComma) {
                   try {
                     Long.parseLong(field);
                     prec = 0;
@@ -524,7 +519,7 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
                 }
               } catch (Exception e) {
                 numfmt[x] = false; // Don't try it again in the future.
-                numfmt_cnt--; // One less that works..
+                numfmtCnt--; // One less that works..
               }
             }
           }
@@ -534,7 +529,7 @@ public class BaseFileField implements Cloneable, ITextFileInputField {
 
     // Still a number? Grab the result and return.
     // If all sample strings are empty or represent NULL values we can't take a number as type.
-    if (numfmt_cnt > 0 && numnul != samples.length) {
+    if (numfmtCnt > 0 && numnul != samples.length) {
       int first = -1;
       for (int i = 0; i < numberFormats.length && first < 0; i++) {
         if (numfmt[i]) {
diff --git a/engine/src/main/java/org/apache/hop/workflow/WorkflowMeta.java b/engine/src/main/java/org/apache/hop/workflow/WorkflowMeta.java
index d25b66a..6ca204e 100644
--- a/engine/src/main/java/org/apache/hop/workflow/WorkflowMeta.java
+++ b/engine/src/main/java/org/apache/hop/workflow/WorkflowMeta.java
@@ -87,7 +87,8 @@ public class WorkflowMeta extends AbstractMeta
 
   protected String[] arguments;
 
-  protected boolean changedActions, changedHops;
+  protected boolean changedActions;
+  protected boolean changedHops;
 
   protected String startActionName;
 
@@ -595,7 +596,8 @@ public class WorkflowMeta extends AbstractMeta
    * @return the action copy
    */
   public ActionMeta getAction(int x, int y, int iconsize) {
-    int i, s;
+    int i;
+    int s;
     s = nrActions();
     for (i = s - 1; i >= 0; i--) {
       // Back to front because drawing goes from start to end
@@ -1191,7 +1193,8 @@ public class WorkflowMeta extends AbstractMeta
    * @return the maximum
    */
   public Point getMaximum() {
-    int maxx = 0, maxy = 0;
+    int maxx = 0;
+    int maxy = 0;
     for (int i = 0; i < nrActions(); i++) {
       ActionMeta action = getAction(i);
       Point loc = action.getLocation();
@@ -1697,12 +1700,12 @@ public class WorkflowMeta extends AbstractMeta
    * own settings.
    *
    * @param remarks List of CheckResult remarks inserted into by each Action
-   * @param only_selected true if you only want to check the selected workflows
+   * @param onlySelected true if you only want to check the selected workflows
    * @param monitor Progress monitor (not presently in use)
    */
   public void checkActions(
       List<ICheckResult> remarks,
-      boolean only_selected,
+      boolean onlySelected,
       IProgressMonitor monitor,
       IVariables variables,
       IHopMetadataProvider metadataProvider) {
@@ -1712,10 +1715,10 @@ public class WorkflowMeta extends AbstractMeta
           BaseMessages.getString(PKG, "WorkflowMeta.Monitor.VerifyingThisActionTask.Title"),
           workflowActions.size() + 2);
     }
-    boolean stop_checking = false;
-    for (int i = 0; i < workflowActions.size() && !stop_checking; i++) {
+    boolean stopChecking = false;
+    for (int i = 0; i < workflowActions.size() && !stopChecking; i++) {
       ActionMeta copy = workflowActions.get(i); // get the action copy
-      if ((!only_selected) || (only_selected && copy.isSelected())) {
+      if ((!onlySelected) || (onlySelected && copy.isSelected())) {
         IAction action = copy.getAction();
         if (action != null) {
           if (monitor != null) {
@@ -1727,7 +1730,7 @@ public class WorkflowMeta extends AbstractMeta
           if (monitor != null) {
             monitor.worked(1); // progress bar...
             if (monitor.isCanceled()) {
-              stop_checking = true;
+              stopChecking = true;
             }
           }
         }
diff --git a/engine/src/main/java/org/apache/hop/workflow/WorkflowPainter.java b/engine/src/main/java/org/apache/hop/workflow/WorkflowPainter.java
index 66aed26..4eac4be 100644
--- a/engine/src/main/java/org/apache/hop/workflow/WorkflowPainter.java
+++ b/engine/src/main/java/org/apache/hop/workflow/WorkflowPainter.java
@@ -416,7 +416,7 @@ public class WorkflowPainter extends BasePainter<WorkflowHopMeta, ActionMeta> {
   }
 
   /** Calculates line coordinates from center to center. */
-  protected void drawLine(WorkflowHopMeta workflowHop, boolean is_candidate) throws HopException {
+  protected void drawLine(WorkflowHopMeta workflowHop, boolean isCandidate) throws HopException {
     int[] line = getLine(workflowHop.getFromAction(), workflowHop.getToAction());
 
     gc.setLineWidth(lineWidth);
@@ -429,7 +429,7 @@ public class WorkflowPainter extends BasePainter<WorkflowHopMeta, ActionMeta> {
     }
 
     EImage arrow;
-    if (is_candidate) {
+    if (isCandidate) {
       color = EColor.BLUE;
       arrow = EImage.ARROW_CANDIDATE;
     } else if (workflowHop.isEnabled()) {
@@ -484,8 +484,11 @@ public class WorkflowPainter extends BasePainter<WorkflowHopMeta, ActionMeta> {
       Object startObject,
       Object endObject)
       throws HopException {
-    int mx, my;
-    int a, b, dist;
+    int mx;
+    int my;
+    int a;
+    int b;
+    int dist;
     double angle;
 
     gc.drawLine(x1, y1, x2, y2);
diff --git a/engine/src/main/java/org/apache/hop/workflow/WorkflowPainterExtension.java b/engine/src/main/java/org/apache/hop/workflow/WorkflowPainterExtension.java
index d8b5cc3..2c42d73 100644
--- a/engine/src/main/java/org/apache/hop/workflow/WorkflowPainterExtension.java
+++ b/engine/src/main/java/org/apache/hop/workflow/WorkflowPainterExtension.java
@@ -31,7 +31,12 @@ public class WorkflowPainterExtension {
   public WorkflowMeta workflowMeta;
   public WorkflowHopMeta workflowHop;
   public final ActionMeta actionMeta;
-  public int x1, y1, x2, y2, mx, my;
+  public int x1;
+  public int y1;
+  public int x2;
+  public int y2;
+  public int mx;
+  public int my;
   public Point offset;
   public int iconSize;
 
diff --git a/engine/src/main/java/org/apache/hop/workflow/engines/local/LocalWorkflowEngine.java b/engine/src/main/java/org/apache/hop/workflow/engines/local/LocalWorkflowEngine.java
index 45683fb..c2f93ce 100644
--- a/engine/src/main/java/org/apache/hop/workflow/engines/local/LocalWorkflowEngine.java
+++ b/engine/src/main/java/org/apache/hop/workflow/engines/local/LocalWorkflowEngine.java
@@ -109,7 +109,7 @@ public class LocalWorkflowEngine extends Workflow implements IWorkflowEngine<Wor
       // We also need to commit/rollback at the end of this workflow...
       //
       addWorkflowFinishedListener(
-          (workflow) -> {
+          workflow -> {
             String group = (String) workflow.getExtensionDataMap().get(Const.CONNECTION_GROUP);
             List<Database> databases = DatabaseConnectionMap.getInstance().getDatabases(group);
             Result result = workflow.getResult();
diff --git a/engine/src/main/java/org/apache/hop/www/RegisterPackageServlet.java b/engine/src/main/java/org/apache/hop/www/RegisterPackageServlet.java
index 6f2b020..7f14588 100644
--- a/engine/src/main/java/org/apache/hop/www/RegisterPackageServlet.java
+++ b/engine/src/main/java/org/apache/hop/www/RegisterPackageServlet.java
@@ -143,11 +143,11 @@ public class RegisterPackageServlet extends BaseWorkflowServlet {
     return true;
   }
 
-  protected Node getConfigNodeFromZIP(Object archiveUrl, Object fileName, String xml_tag)
+  protected Node getConfigNodeFromZIP(Object archiveUrl, Object fileName, String xmlTag)
       throws HopXmlException {
     String configUrl = MessageFormat.format(ZIP_CONT, archiveUrl, fileName);
     Document configDoc = XmlHandler.loadXmlFile(configUrl);
-    return XmlHandler.getSubNode(configDoc, xml_tag);
+    return XmlHandler.getSubNode(configDoc, xmlTag);
   }
 
   public static final String getMetaStoreJsonFromZIP(Object archiveUrl)
diff --git a/plugins/actions/addresultfilenames/src/main/java/org/apache/hop/workflow/actions/addresultfilenames/ActionAddResultFilenamesDialog.java b/plugins/actions/addresultfilenames/src/main/java/org/apache/hop/workflow/actions/addresultfilenames/ActionAddResultFilenamesDialog.java
index e9b0465..b4b2dea 100644
--- a/plugins/actions/addresultfilenames/src/main/java/org/apache/hop/workflow/actions/addresultfilenames/ActionAddResultFilenamesDialog.java
+++ b/plugins/actions/addresultfilenames/src/main/java/org/apache/hop/workflow/actions/addresultfilenames/ActionAddResultFilenamesDialog.java
@@ -52,7 +52,8 @@ public class ActionAddResultFilenamesDialog extends ActionDialog implements IAct
   private Text wName;
 
   private Label wlFilename;
-  private Button wbFilename, wbDirectory;
+  private Button wbFilename;
+  private Button wbDirectory;
   private TextVar wFilename;
 
   private Button wIncludeSubfolders;
diff --git a/plugins/actions/checkfilelocked/src/main/java/org/apache/hop/workflow/actions/checkfilelocked/ActionCheckFilesLockedDialog.java b/plugins/actions/checkfilelocked/src/main/java/org/apache/hop/workflow/actions/checkfilelocked/ActionCheckFilesLockedDialog.java
index 7d2ce79..0600a35 100644
--- a/plugins/actions/checkfilelocked/src/main/java/org/apache/hop/workflow/actions/checkfilelocked/ActionCheckFilesLockedDialog.java
+++ b/plugins/actions/checkfilelocked/src/main/java/org/apache/hop/workflow/actions/checkfilelocked/ActionCheckFilesLockedDialog.java
@@ -51,7 +51,8 @@ public class ActionCheckFilesLockedDialog extends ActionDialog implements IActio
   private Text wName;
 
   private Label wlFilename;
-  private Button wbFilename, wbDirectory;
+  private Button wbFilename;
+  private Button wbDirectory;
   private TextVar wFilename;
 
   private Button wIncludeSubfolders;
diff --git a/plugins/actions/copyfiles/src/main/java/org/apache/hop/workflow/actions/copyfiles/ActionCopyFiles.java b/plugins/actions/copyfiles/src/main/java/org/apache/hop/workflow/actions/copyfiles/ActionCopyFiles.java
index 32fcb0a..acb9959 100644
--- a/plugins/actions/copyfiles/src/main/java/org/apache/hop/workflow/actions/copyfiles/ActionCopyFiles.java
+++ b/plugins/actions/copyfiles/src/main/java/org/apache/hop/workflow/actions/copyfiles/ActionCopyFiles.java
@@ -253,9 +253,9 @@ public class ActionCopyFiles extends ActionBase implements Cloneable, IAction {
     List<RowMetaAndData> rows = result.getRows();
     RowMetaAndData resultRow = null;
 
-    int NbrFail = 0;
+    int nbrFail = 0;
 
-    NbrFail = 0;
+    nbrFail = 0;
 
     if (isBasic()) {
       logBasic(BaseMessages.getString(PKG, "ActionCopyFiles.Log.Starting"));
@@ -310,7 +310,7 @@ public class ActionCopyFiles extends ActionBase implements Cloneable, IAction {
                 parentWorkflow,
                 result)) {
               // The copy process fail
-              NbrFail++;
+              nbrFail++;
             }
           } else {
             if (isDetailed()) {
@@ -347,7 +347,7 @@ public class ActionCopyFiles extends ActionBase implements Cloneable, IAction {
                 parentWorkflow,
                 result)) {
               // The copy process fail
-              NbrFail++;
+              nbrFail++;
             }
           } else {
             if (isDetailed()) {
@@ -368,11 +368,11 @@ public class ActionCopyFiles extends ActionBase implements Cloneable, IAction {
     }
 
     // Check if all files was process with success
-    if (NbrFail == 0) {
+    if (nbrFail == 0) {
       result.setResult(true);
       result.setNrErrors(0);
     } else {
-      result.setNrErrors(NbrFail);
+      result.setNrErrors(nbrFail);
     }
 
     return result;
diff --git a/plugins/actions/delay/src/main/java/org/apache/hop/workflow/actions/delay/ActionDelay.java b/plugins/actions/delay/src/main/java/org/apache/hop/workflow/actions/delay/ActionDelay.java
index afaacb7..cbfaf5d 100644
--- a/plugins/actions/delay/src/main/java/org/apache/hop/workflow/actions/delay/ActionDelay.java
+++ b/plugins/actions/delay/src/main/java/org/apache/hop/workflow/actions/delay/ActionDelay.java
@@ -47,7 +47,7 @@ import java.util.List;
 public class ActionDelay extends ActionBase implements Cloneable, IAction {
   private static final Class<?> PKG = ActionDelay.class; // For Translator
 
-  private static String DEFAULT_MAXIMUM_TIMEOUT = "0";
+  private static final String DEFAULT_MAXIMUM_TIMEOUT = "0";
 
   private String maximumTimeout; // maximum timeout in seconds
 
@@ -102,31 +102,31 @@ public class ActionDelay extends ActionBase implements Cloneable, IAction {
   public Result execute(Result previousResult, int nr) {
     Result result = previousResult;
     result.setResult(false);
-    int Multiple;
-    String Waitscale;
+    int multiple;
+    String waitscale;
 
     // Scale time
     switch (scaleTime) {
       case 0:
         // Second
-        Multiple = 1000;
-        Waitscale = BaseMessages.getString(PKG, "ActionDelay.SScaleTime.Label");
+        multiple = 1000;
+        waitscale = BaseMessages.getString(PKG, "ActionDelay.SScaleTime.Label");
         break;
       case 1:
         // Minute
-        Multiple = 60000;
-        Waitscale = BaseMessages.getString(PKG, "ActionDelay.MnScaleTime.Label");
+        multiple = 60000;
+        waitscale = BaseMessages.getString(PKG, "ActionDelay.MnScaleTime.Label");
         break;
       default:
         // Hour
-        Multiple = 3600000;
-        Waitscale = BaseMessages.getString(PKG, "ActionDelay.HrScaleTime.Label");
+        multiple = 3600000;
+        waitscale = BaseMessages.getString(PKG, "ActionDelay.HrScaleTime.Label");
         break;
     }
 
     try {
       // starttime (in seconds ,Minutes or Hours)
-      double timeStart = (double) System.currentTimeMillis() / (double) Multiple;
+      double timeStart = (double) System.currentTimeMillis() / (double) multiple;
 
       double iMaximumTimeout =
           Const.toInt(getRealMaximumTimeout(), Const.toInt(DEFAULT_MAXIMUM_TIMEOUT, 0));
@@ -134,7 +134,7 @@ public class ActionDelay extends ActionBase implements Cloneable, IAction {
       if (isDetailed()) {
         logDetailed(
             BaseMessages.getString(
-                PKG, "ActionDelay.LetsWaitFor.Label", iMaximumTimeout, Waitscale));
+                PKG, "ActionDelay.LetsWaitFor.Label", iMaximumTimeout, waitscale));
       }
 
       boolean continueLoop = true;
@@ -148,14 +148,14 @@ public class ActionDelay extends ActionBase implements Cloneable, IAction {
                 PKG,
                 "ActionDelay.MaximumTimeReset.Label",
                 String.valueOf(iMaximumTimeout),
-                String.valueOf(Waitscale)));
+                String.valueOf(waitscale)));
       }
 
       // Loop until the delay time has expired.
       //
       while (continueLoop && !parentWorkflow.isStopped()) {
         // Update Time value
-        double now = (double) System.currentTimeMillis() / (double) Multiple;
+        double now = (double) System.currentTimeMillis() / (double) multiple;
 
         // Let's check the limit time
         if ((iMaximumTimeout >= 0) && (now >= (timeStart + iMaximumTimeout))) {
diff --git a/plugins/actions/dostounix/src/main/java/org/apache/hop/workflow/actions/dostounix/ActionDosToUnixDialog.java b/plugins/actions/dostounix/src/main/java/org/apache/hop/workflow/actions/dostounix/ActionDosToUnixDialog.java
index fcd7a4a..45c8ec1 100644
--- a/plugins/actions/dostounix/src/main/java/org/apache/hop/workflow/actions/dostounix/ActionDosToUnixDialog.java
+++ b/plugins/actions/dostounix/src/main/java/org/apache/hop/workflow/actions/dostounix/ActionDosToUnixDialog.java
@@ -58,7 +58,8 @@ public class ActionDosToUnixDialog extends ActionDialog implements IActionDialog
   private Text wName;
 
   private Label wlSourceFileFolder;
-  private Button wbSourceFileFolder, wbSourceDirectory;
+  private Button wbSourceFileFolder;
+  private Button wbSourceDirectory;
 
   private TextVar wSourceFileFolder;
 
@@ -84,7 +85,8 @@ public class ActionDosToUnixDialog extends ActionDialog implements IActionDialog
 
   // Add File to result
 
-  private CCombo wSuccessCondition, wAddFilenameToResult;
+  private CCombo wSuccessCondition;
+  private CCombo wAddFilenameToResult;
 
   private Label wlNrErrorsLessThan;
   private TextVar wNrErrorsLessThan;
diff --git a/plugins/actions/evalfilesmetrics/src/main/java/org/apache/hop/workflow/actions/evalfilesmetrics/ActionEvalFilesMetrics.java b/plugins/actions/evalfilesmetrics/src/main/java/org/apache/hop/workflow/actions/evalfilesmetrics/ActionEvalFilesMetrics.java
index 635f537..dd49801 100644
--- a/plugins/actions/evalfilesmetrics/src/main/java/org/apache/hop/workflow/actions/evalfilesmetrics/ActionEvalFilesMetrics.java
+++ b/plugins/actions/evalfilesmetrics/src/main/java/org/apache/hop/workflow/actions/evalfilesmetrics/ActionEvalFilesMetrics.java
@@ -167,9 +167,9 @@ public class ActionEvalFilesMetrics extends ActionBase implements Cloneable, IAc
   private BigDecimal filesCount;
   private long nrErrors;
 
-  private String ResultFieldFile;
-  private String ResultFieldWildcard;
-  private String ResultFieldIncludesubFolders;
+  private String resultFieldFile;
+  private String resultFieldWildcard;
+  private String resultFieldIncludesubFolders;
 
   private BigDecimal compareValue;
   private BigDecimal minValue;
@@ -185,9 +185,9 @@ public class ActionEvalFilesMetrics extends ActionBase implements Cloneable, IAc
     evaluationType = EVALUATE_TYPE_SIZE;
     successConditionType = SUCCESS_NUMBER_CONDITION_GREATER;
     resultFilenamesWildcard = null;
-    ResultFieldFile = null;
-    ResultFieldWildcard = null;
-    ResultFieldIncludesubFolders = null;
+    resultFieldFile = null;
+    resultFieldWildcard = null;
+    resultFieldIncludesubFolders = null;
   }
 
   public ActionEvalFilesMetrics() {
@@ -221,14 +221,14 @@ public class ActionEvalFilesMetrics extends ActionBase implements Cloneable, IAc
     retval
         .append("      ")
         .append(XmlHandler.addTagValue("result_filenames_wildcard", resultFilenamesWildcard));
-    retval.append("      ").append(XmlHandler.addTagValue("Result_field_file", ResultFieldFile));
+    retval.append("      ").append(XmlHandler.addTagValue("Result_field_file", resultFieldFile));
     retval
         .append("      ")
-        .append(XmlHandler.addTagValue("Result_field_wildcard", ResultFieldWildcard));
+        .append(XmlHandler.addTagValue("Result_field_wildcard", resultFieldWildcard));
     retval
         .append("      ")
         .append(
-            XmlHandler.addTagValue("Result_field_includesubfolders", ResultFieldIncludesubFolders));
+            XmlHandler.addTagValue("Result_field_includesubfolders", resultFieldIncludesubFolders));
 
     retval.append("      <fields>").append(Const.CR);
     if (sourceFileFolder != null) {
@@ -307,9 +307,9 @@ public class ActionEvalFilesMetrics extends ActionBase implements Cloneable, IAc
       }
 
       resultFilenamesWildcard = XmlHandler.getTagValue(entrynode, "result_filenames_wildcard");
-      ResultFieldFile = XmlHandler.getTagValue(entrynode, "result_field_file");
-      ResultFieldWildcard = XmlHandler.getTagValue(entrynode, "result_field_wildcard");
-      ResultFieldIncludesubFolders =
+      resultFieldFile = XmlHandler.getTagValue(entrynode, "result_field_file");
+      resultFieldWildcard = XmlHandler.getTagValue(entrynode, "result_field_wildcard");
+      resultFieldIncludesubFolders =
           XmlHandler.getTagValue(entrynode, "result_field_includesubfolders");
       comparevalue = XmlHandler.getTagValue(entrynode, "comparevalue");
       minvalue = XmlHandler.getTagValue(entrynode, "minvalue");
@@ -744,27 +744,27 @@ public class ActionEvalFilesMetrics extends ActionBase implements Cloneable, IAc
   }
 
   public String getResultFieldFile() {
-    return this.ResultFieldFile;
+    return this.resultFieldFile;
   }
 
   public void setResultFieldFile(String field) {
-    this.ResultFieldFile = field;
+    this.resultFieldFile = field;
   }
 
   public String getResultFieldWildcard() {
-    return this.ResultFieldWildcard;
+    return this.resultFieldWildcard;
   }
 
   public void setResultFieldWildcard(String field) {
-    this.ResultFieldWildcard = field;
+    this.resultFieldWildcard = field;
   }
 
   public String getResultFieldIncludeSubfolders() {
-    return this.ResultFieldIncludesubFolders;
+    return this.resultFieldIncludesubFolders;
   }
 
   public void setResultFieldIncludeSubfolders(String field) {
-    this.ResultFieldIncludesubFolders = field;
+    this.resultFieldIncludesubFolders = field;
   }
 
   private void ProcessFileFolder(
@@ -775,7 +775,7 @@ public class ActionEvalFilesMetrics extends ActionBase implements Cloneable, IAc
       Result result) {
 
     FileObject sourcefilefolder = null;
-    FileObject CurrentFile = null;
+    FileObject currentFile = null;
 
     // Get real source file and wildcard
     String realSourceFilefoldername = resolve(sourcefilefoldername);
@@ -844,19 +844,19 @@ public class ActionEvalFilesMetrics extends ActionBase implements Cloneable, IAc
           if (fileObjects != null) {
             for (int j = 0; j < fileObjects.length && !parentWorkflow.isStopped(); j++) {
               // Fetch files in list one after one ...
-              CurrentFile = fileObjects[j];
+              currentFile = fileObjects[j];
 
-              if (!CurrentFile.getParent().toString().equals(sourcefilefolder.toString())) {
+              if (!currentFile.getParent().toString().equals(sourcefilefolder.toString())) {
                 // Not in the Base Folder..Only if include sub folders
                 if (includeSubFolders) {
-                  if (GetFileWildcard(CurrentFile.getName().getBaseName(), realWildcard)) {
-                    getFileSize(CurrentFile, result, parentWorkflow);
+                  if (GetFileWildcard(currentFile.getName().getBaseName(), realWildcard)) {
+                    getFileSize(currentFile, result, parentWorkflow);
                   }
                 }
               } else {
                 // In the base folder
-                if (GetFileWildcard(CurrentFile.getName().getBaseName(), realWildcard)) {
-                  getFileSize(CurrentFile, result, parentWorkflow);
+                if (GetFileWildcard(currentFile.getName().getBaseName(), realWildcard)) {
+                  getFileSize(currentFile, result, parentWorkflow);
                 }
               }
             }
@@ -892,9 +892,9 @@ public class ActionEvalFilesMetrics extends ActionBase implements Cloneable, IAc
           /* Ignore */
         }
       }
-      if (CurrentFile != null) {
+      if (currentFile != null) {
         try {
-          CurrentFile.close();
+          currentFile.close();
         } catch (IOException ex) {
           /* Ignore */
         }
diff --git a/plugins/actions/evalfilesmetrics/src/main/java/org/apache/hop/workflow/actions/evalfilesmetrics/ActionEvalFilesMetricsDialog.java b/plugins/actions/evalfilesmetrics/src/main/java/org/apache/hop/workflow/actions/evalfilesmetrics/ActionEvalFilesMetricsDialog.java
index 235e274..dc8a52c 100644
--- a/plugins/actions/evalfilesmetrics/src/main/java/org/apache/hop/workflow/actions/evalfilesmetrics/ActionEvalFilesMetricsDialog.java
+++ b/plugins/actions/evalfilesmetrics/src/main/java/org/apache/hop/workflow/actions/evalfilesmetrics/ActionEvalFilesMetricsDialog.java
@@ -55,7 +55,8 @@ public class ActionEvalFilesMetricsDialog extends ActionDialog implements IActio
   private Text wName;
 
   private Label wlSourceFileFolder;
-  private Button wbSourceFileFolder, wbSourceDirectory;
+  private Button wbSourceFileFolder;
+  private Button wbSourceDirectory;
 
   private TextVar wSourceFileFolder;
 
diff --git a/plugins/actions/evaluatetablecontent/src/main/java/org/apache/hop/workflow/actions/evaluatetablecontent/ActionEvalTableContentDialog.java b/plugins/actions/evaluatetablecontent/src/main/java/org/apache/hop/workflow/actions/evaluatetablecontent/ActionEvalTableContentDialog.java
index 1baff60..d5d1180 100644
--- a/plugins/actions/evaluatetablecontent/src/main/java/org/apache/hop/workflow/actions/evaluatetablecontent/ActionEvalTableContentDialog.java
+++ b/plugins/actions/evaluatetablecontent/src/main/java/org/apache/hop/workflow/actions/evaluatetablecontent/ActionEvalTableContentDialog.java
@@ -55,7 +55,8 @@ import org.eclipse.swt.widgets.*;
 public class ActionEvalTableContentDialog extends ActionDialog implements IActionDialog {
   private static final Class<?> PKG = ActionEvalTableContent.class; // For Translator
 
-  private Button wbTable, wbSqlTable;
+  private Button wbTable;
+  private Button wbSqlTable;
 
   private Text wName;
 
@@ -224,10 +225,10 @@ public class ActionEvalTableContentDialog extends ActionDialog implements IActio
     wSuccessGroup.setText(
         BaseMessages.getString(PKG, "ActionEvalTableContent.SuccessGroup.Group.Label"));
 
-    FormLayout SuccessGroupLayout = new FormLayout();
-    SuccessGroupLayout.marginWidth = 10;
-    SuccessGroupLayout.marginHeight = 10;
-    wSuccessGroup.setLayout(SuccessGroupLayout);
+    FormLayout successGroupLayout = new FormLayout();
+    successGroupLayout.marginWidth = 10;
+    successGroupLayout.marginHeight = 10;
+    wSuccessGroup.setLayout(successGroupLayout);
 
     // Success Condition
     Label wlSuccessCondition = new Label(wSuccessGroup, SWT.RIGHT);
@@ -298,10 +299,10 @@ public class ActionEvalTableContentDialog extends ActionDialog implements IActio
     wCustomGroup.setText(
         BaseMessages.getString(PKG, "ActionEvalTableContent.CustomGroup.Group.Label"));
 
-    FormLayout CustomGroupLayout = new FormLayout();
-    CustomGroupLayout.marginWidth = 10;
-    CustomGroupLayout.marginHeight = 10;
-    wCustomGroup.setLayout(CustomGroupLayout);
+    FormLayout customGroupLayout = new FormLayout();
+    customGroupLayout.marginWidth = 10;
+    customGroupLayout.marginHeight = 10;
+    wCustomGroup.setLayout(customGroupLayout);
 
     // custom Sql?
     Label wlCustomSql = new Label(wCustomGroup, SWT.RIGHT);
diff --git a/plugins/actions/filecompare/src/main/java/org/apache/hop/workflow/actions/filecompare/ActionFileCompare.java b/plugins/actions/filecompare/src/main/java/org/apache/hop/workflow/actions/filecompare/ActionFileCompare.java
index 721bede..450d824 100644
--- a/plugins/actions/filecompare/src/main/java/org/apache/hop/workflow/actions/filecompare/ActionFileCompare.java
+++ b/plugins/actions/filecompare/src/main/java/org/apache/hop/workflow/actions/filecompare/ActionFileCompare.java
@@ -143,7 +143,8 @@ public class ActionFileCompare extends ActionBase implements Cloneable, IAction
           new DataInputStream(
               new BufferedInputStream(HopVfs.getInputStream(HopVfs.getFilename(file2))));
 
-      char ch1, ch2;
+      char ch1;
+      char ch2;
       while (in1.available() != 0 && in2.available() != 0) {
         ch1 = (char) in1.readByte();
         ch2 = (char) in2.readByte();
diff --git a/plugins/actions/folderscompare/src/main/java/org/apache/hop/workflow/actions/folderscompare/ActionFoldersCompare.java b/plugins/actions/folderscompare/src/main/java/org/apache/hop/workflow/actions/folderscompare/ActionFoldersCompare.java
index 39e6faf..1aca482 100644
--- a/plugins/actions/folderscompare/src/main/java/org/apache/hop/workflow/actions/folderscompare/ActionFoldersCompare.java
+++ b/plugins/actions/folderscompare/src/main/java/org/apache/hop/workflow/actions/folderscompare/ActionFoldersCompare.java
@@ -199,7 +199,8 @@ public class ActionFoldersCompare extends ActionBase implements Cloneable, IActi
           new DataInputStream(
               new BufferedInputStream(HopVfs.getInputStream(HopVfs.getFilename(file2))));
 
-      char ch1, ch2;
+      char ch1;
+      char ch2;
       while (in1.available() != 0 && in2.available() != 0) {
         ch1 = (char) in1.readByte();
         ch2 = (char) in2.readByte();
@@ -409,9 +410,9 @@ public class ActionFoldersCompare extends ActionBase implements Cloneable, IActi
                       if (filefolder2.getType() == FileType.FILE) {
                         // Let's compare file size
                         if (comparefilesize) {
-                          long filefolder1_size = filefolder1.getContent().getSize();
-                          long filefolder2_size = filefolder2.getContent().getSize();
-                          if (filefolder1_size != filefolder2_size) {
+                          long filefolder1Size = filefolder1.getContent().getSize();
+                          long filefolder2Size = filefolder2.getContent().getSize();
+                          if (filefolder1Size != filefolder2Size) {
                             ok = false;
                             if (log.isDetailed()) {
                               logDetailed(
@@ -425,13 +426,13 @@ public class ActionFoldersCompare extends ActionBase implements Cloneable, IActi
                                       PKG,
                                       "ActionFoldersCompare.Log.SizeFileIs",
                                       filefolder1.toString(),
-                                      "" + filefolder1_size));
+                                      "" + filefolder1Size));
                               logDetailed(
                                   BaseMessages.getString(
                                       PKG,
                                       "ActionFoldersCompare.Log.SizeFileIs",
                                       filefolder2.toString(),
-                                      "" + filefolder2_size));
+                                      "" + filefolder2Size));
                             }
                           }
                         }
diff --git a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftp/ActionFtpDialog.java b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftp/ActionFtpDialog.java
index fcc9881..47f4963 100644
--- a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftp/ActionFtpDialog.java
+++ b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftp/ActionFtpDialog.java
@@ -56,7 +56,10 @@ public class ActionFtpDialog extends ActionDialog implements IActionDialog {
 
   private LabelTextVar wServerName;
 
-  private LabelTextVar wSocksProxyHost, wSocksProxyPort, wSocksProxyUsername, wSocksProxyPassword;
+  private LabelTextVar wSocksProxyHost;
+  private LabelTextVar wSocksProxyPort;
+  private LabelTextVar wSocksProxyUsername;
+  private LabelTextVar wSocksProxyPassword;
 
   private LabelTextVar wUserName;
 
@@ -132,7 +135,6 @@ public class ActionFtpDialog extends ActionDialog implements IActionDialog {
   private CCombo wSuccessCondition;
 
   private FTPClient ftpclient = null;
-  private String pwdFolder = null;
 
   // These should not be translated, they are required to exist on all
   // platforms according to the documentation of "Charset".
@@ -159,7 +161,6 @@ public class ActionFtpDialog extends ActionDialog implements IActionDialog {
 
     ModifyListener lsMod =
         e -> {
-          pwdFolder = null;
           ftpclient = null;
           action.setChanged();
         };
@@ -401,10 +402,10 @@ public class ActionFtpDialog extends ActionDialog implements IActionDialog {
     props.setLook(wAdvancedSettings);
     wAdvancedSettings.setText(
         BaseMessages.getString(PKG, "ActionFtp.AdvancedSettings.Group.Label"));
-    FormLayout AdvancedSettingsgroupLayout = new FormLayout();
-    AdvancedSettingsgroupLayout.marginWidth = 10;
-    AdvancedSettingsgroupLayout.marginHeight = 10;
-    wAdvancedSettings.setLayout(AdvancedSettingsgroupLayout);
+    FormLayout advancedSettingsgroupLayout = new FormLayout();
+    advancedSettingsgroupLayout.marginWidth = 10;
+    advancedSettingsgroupLayout.marginHeight = 10;
+    wAdvancedSettings.setLayout(advancedSettingsgroupLayout);
 
     // Binary mode selection...
     Label wlBinaryMode = new Label(wAdvancedSettings, SWT.RIGHT);
@@ -518,10 +519,10 @@ public class ActionFtpDialog extends ActionDialog implements IActionDialog {
     Composite wFilesComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wFilesComp);
 
-    FormLayout FilesLayout = new FormLayout();
-    FilesLayout.marginWidth = 3;
-    FilesLayout.marginHeight = 3;
-    wFilesComp.setLayout(FilesLayout);
+    FormLayout filesLayout = new FormLayout();
+    filesLayout.marginWidth = 3;
+    filesLayout.marginHeight = 3;
+    wFilesComp.setLayout(filesLayout);
 
     // ////////////////////////
     // START OF Remote SETTINGS GROUP///
@@ -993,10 +994,10 @@ public class ActionFtpDialog extends ActionDialog implements IActionDialog {
     Composite wAdvancedComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wAdvancedComp);
 
-    FormLayout AdvancedLayout = new FormLayout();
-    AdvancedLayout.marginWidth = 3;
-    AdvancedLayout.marginHeight = 3;
-    wAdvancedComp.setLayout(AdvancedLayout);
+    FormLayout advancedLayout = new FormLayout();
+    advancedLayout.marginWidth = 3;
+    advancedLayout.marginHeight = 3;
+    wAdvancedComp.setLayout(advancedLayout);
 
     // SuccessOngrouping?
     // ////////////////////////
@@ -1101,10 +1102,10 @@ public class ActionFtpDialog extends ActionDialog implements IActionDialog {
     Composite wSocksProxyComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wSocksProxyComp);
 
-    FormLayout SoxProxyLayout = new FormLayout();
-    SoxProxyLayout.marginWidth = 3;
-    SoxProxyLayout.marginHeight = 3;
-    wSocksProxyComp.setLayout(SoxProxyLayout);
+    FormLayout soxProxyLayout = new FormLayout();
+    soxProxyLayout.marginWidth = 3;
+    soxProxyLayout.marginHeight = 3;
+    wSocksProxyComp.setLayout(soxProxyLayout);
 
     // ////////////////////////////////////////////////////////
     // Start of Proxy Group
@@ -1113,10 +1114,10 @@ public class ActionFtpDialog extends ActionDialog implements IActionDialog {
     props.setLook(wSocksProxy);
     wSocksProxy.setText(BaseMessages.getString(PKG, "ActionFtp.SocksProxy.Group.Label"));
 
-    FormLayout SocksProxyGroupLayout = new FormLayout();
-    SocksProxyGroupLayout.marginWidth = 10;
-    SocksProxyGroupLayout.marginHeight = 10;
-    wSocksProxy.setLayout(SocksProxyGroupLayout);
+    FormLayout socksProxyGroupLayout = new FormLayout();
+    socksProxyGroupLayout.marginWidth = 10;
+    socksProxyGroupLayout.marginHeight = 10;
+    wSocksProxy.setLayout(socksProxyGroupLayout);
 
     // host line
     wSocksProxyHost =
@@ -1252,15 +1253,14 @@ public class ActionFtpDialog extends ActionDialog implements IActionDialog {
     closeFtpConnection();
   }
 
-  private void checkRemoteFolder(boolean FtpFolfer, boolean checkMoveFolder, String foldername) {
-    if (!Utils.isEmpty(foldername)) {
-      if (connectToFtp(FtpFolfer, checkMoveFolder)) {
-        MessageBox mb = new MessageBox(shell, SWT.OK | SWT.ICON_INFORMATION);
-        mb.setMessage(
-            BaseMessages.getString(PKG, "ActionFtp.FolderExists.OK", foldername) + Const.CR);
-        mb.setText(BaseMessages.getString(PKG, "ActionFtp.FolderExists.Title.Ok"));
-        mb.open();
-      }
+  private void checkRemoteFolder(boolean ftpFolfer, boolean checkMoveFolder, String foldername) {
+    if (!Utils.isEmpty(foldername) && connectToFtp(ftpFolfer, checkMoveFolder)) {
+
+      MessageBox mb = new MessageBox(shell, SWT.OK | SWT.ICON_INFORMATION);
+      mb.setMessage(
+          BaseMessages.getString(PKG, "ActionFtp.FolderExists.OK", foldername) + Const.CR);
+      mb.setText(BaseMessages.getString(PKG, "ActionFtp.FolderExists.Title.Ok"));
+      mb.open();
     }
   }
 
diff --git a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftpdelete/ActionFtpDeleteDialog.java b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftpdelete/ActionFtpDeleteDialog.java
index c86c39d..42561d8 100644
--- a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftpdelete/ActionFtpDeleteDialog.java
+++ b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftpdelete/ActionFtpDeleteDialog.java
@@ -87,7 +87,10 @@ public class ActionFtpDeleteDialog extends ActionDialog implements IActionDialog
   private boolean changed;
 
   private Group wSocksProxy;
-  private LabelTextVar wSocksProxyHost, wSocksProxyPort, wSocksProxyUsername, wSocksProxyPassword;
+  private LabelTextVar wSocksProxyHost;
+  private LabelTextVar wSocksProxyPort;
+  private LabelTextVar wSocksProxyUsername;
+  private LabelTextVar wSocksProxyPassword;
 
   private LabelTextVar wPort;
 
@@ -215,11 +218,11 @@ public class ActionFtpDeleteDialog extends ActionDialog implements IActionDialog
     wServerSettings.setText(
         BaseMessages.getString(PKG, "ActionFtpDelete.ServerSettings.Group.Label"));
 
-    FormLayout ServerSettingsgroupLayout = new FormLayout();
-    ServerSettingsgroupLayout.marginWidth = 10;
-    ServerSettingsgroupLayout.marginHeight = 10;
+    FormLayout serverSettingsgroupLayout = new FormLayout();
+    serverSettingsgroupLayout.marginWidth = 10;
+    serverSettingsgroupLayout.marginHeight = 10;
 
-    wServerSettings.setLayout(ServerSettingsgroupLayout);
+    wServerSettings.setLayout(serverSettingsgroupLayout);
 
     // Protocol
     Label wlProtocol = new Label(wServerSettings, SWT.RIGHT);
@@ -545,10 +548,10 @@ public class ActionFtpDeleteDialog extends ActionDialog implements IActionDialog
     Composite wFilesComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wFilesComp);
 
-    FormLayout AdvancedLayout = new FormLayout();
-    AdvancedLayout.marginWidth = 3;
-    AdvancedLayout.marginHeight = 3;
-    wFilesComp.setLayout(AdvancedLayout);
+    FormLayout advancedLayout = new FormLayout();
+    advancedLayout.marginWidth = 3;
+    advancedLayout.marginHeight = 3;
+    wFilesComp.setLayout(advancedLayout);
 
     // ////////////////////////
     // START OF Advanced SETTINGS GROUP///
@@ -558,11 +561,11 @@ public class ActionFtpDeleteDialog extends ActionDialog implements IActionDialog
     wAdvancedSettings.setText(
         BaseMessages.getString(PKG, "ActionFtpDelete.AdvancedSettings.Group.Label"));
 
-    FormLayout AdvancedSettingsgroupLayout = new FormLayout();
-    AdvancedSettingsgroupLayout.marginWidth = 10;
-    AdvancedSettingsgroupLayout.marginHeight = 10;
+    FormLayout advancedSettingsgroupLayout = new FormLayout();
+    advancedSettingsgroupLayout.marginWidth = 10;
+    advancedSettingsgroupLayout.marginHeight = 10;
 
-    wAdvancedSettings.setLayout(AdvancedSettingsgroupLayout);
+    wAdvancedSettings.setLayout(advancedSettingsgroupLayout);
 
     // Timeout line
     wTimeout =
@@ -617,11 +620,11 @@ public class ActionFtpDeleteDialog extends ActionDialog implements IActionDialog
     wRemoteSettings.setText(
         BaseMessages.getString(PKG, "ActionFtpDelete.RemoteSettings.Group.Label"));
 
-    FormLayout RemoteSettinsgroupLayout = new FormLayout();
-    RemoteSettinsgroupLayout.marginWidth = 10;
-    RemoteSettinsgroupLayout.marginHeight = 10;
+    FormLayout remoteSettinsgroupLayout = new FormLayout();
+    remoteSettinsgroupLayout.marginWidth = 10;
+    remoteSettinsgroupLayout.marginHeight = 10;
 
-    wRemoteSettings.setLayout(RemoteSettinsgroupLayout);
+    wRemoteSettings.setLayout(remoteSettinsgroupLayout);
 
     // Get arguments from previous result...
     Label wlGetPrevious = new Label(wRemoteSettings, SWT.RIGHT);
@@ -815,10 +818,10 @@ public class ActionFtpDeleteDialog extends ActionDialog implements IActionDialog
     Composite wSocksProxyComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wSocksProxyComp);
 
-    FormLayout SoxProxyLayout = new FormLayout();
-    SoxProxyLayout.marginWidth = 3;
-    SoxProxyLayout.marginHeight = 3;
-    wSocksProxyComp.setLayout(SoxProxyLayout);
+    FormLayout soxProxyLayout = new FormLayout();
+    soxProxyLayout.marginWidth = 3;
+    soxProxyLayout.marginHeight = 3;
+    wSocksProxyComp.setLayout(soxProxyLayout);
 
     // ////////////////////////////////////////////////////////
     // Start of Proxy Group
@@ -827,10 +830,10 @@ public class ActionFtpDeleteDialog extends ActionDialog implements IActionDialog
     props.setLook(wSocksProxy);
     wSocksProxy.setText(BaseMessages.getString(PKG, "ActionFtpDelete.SocksProxy.Group.Label"));
 
-    FormLayout SocksProxyGroupLayout = new FormLayout();
-    SocksProxyGroupLayout.marginWidth = 10;
-    SocksProxyGroupLayout.marginHeight = 10;
-    wSocksProxy.setLayout(SocksProxyGroupLayout);
+    FormLayout socksProxyGroupLayout = new FormLayout();
+    socksProxyGroupLayout.marginWidth = 10;
+    socksProxyGroupLayout.marginHeight = 10;
+    wSocksProxy.setLayout(socksProxyGroupLayout);
 
     // host line
     wSocksProxyHost =
diff --git a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftpput/ActionFtpPutDialog.java b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftpput/ActionFtpPutDialog.java
index 16cfc1b..227e510 100644
--- a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftpput/ActionFtpPutDialog.java
+++ b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/ftpput/ActionFtpPutDialog.java
@@ -91,7 +91,10 @@ public class ActionFtpPutDialog extends ActionDialog implements IActionDialog {
 
   private LabelTextVar wProxyHost;
 
-  private LabelTextVar wSocksProxyHost, wSocksProxyPort, wSocksProxyUsername, wSocksProxyPassword;
+  private LabelTextVar wSocksProxyHost;
+  private LabelTextVar wSocksProxyPort;
+  private LabelTextVar wSocksProxyUsername;
+  private LabelTextVar wSocksProxyPassword;
 
   // These should not be translated, they are required to exist on all
   // platforms according to the documentation of "Charset".
@@ -194,11 +197,11 @@ public class ActionFtpPutDialog extends ActionDialog implements IActionDialog {
     props.setLook(wServerSettings);
     wServerSettings.setText(BaseMessages.getString(PKG, "ActionFtpPut.ServerSettings.Group.Label"));
 
-    FormLayout ServerSettingsgroupLayout = new FormLayout();
-    ServerSettingsgroupLayout.marginWidth = 10;
-    ServerSettingsgroupLayout.marginHeight = 10;
+    FormLayout serverSettingsgroupLayout = new FormLayout();
+    serverSettingsgroupLayout.marginWidth = 10;
+    serverSettingsgroupLayout.marginHeight = 10;
 
-    wServerSettings.setLayout(ServerSettingsgroupLayout);
+    wServerSettings.setLayout(serverSettingsgroupLayout);
 
     // ServerName line
     Label wlServerName = new Label(wServerSettings, SWT.RIGHT);
@@ -372,10 +375,10 @@ public class ActionFtpPutDialog extends ActionDialog implements IActionDialog {
     props.setLook(wAdvancedSettings);
     wAdvancedSettings.setText(
         BaseMessages.getString(PKG, "ActionFtpPut.AdvancedSettings.Group.Label"));
-    FormLayout AdvancedSettingsgroupLayout = new FormLayout();
-    AdvancedSettingsgroupLayout.marginWidth = 10;
-    AdvancedSettingsgroupLayout.marginHeight = 10;
-    wAdvancedSettings.setLayout(AdvancedSettingsgroupLayout);
+    FormLayout advancedSettingsgroupLayout = new FormLayout();
+    advancedSettingsgroupLayout.marginWidth = 10;
+    advancedSettingsgroupLayout.marginHeight = 10;
+    wAdvancedSettings.setLayout(advancedSettingsgroupLayout);
 
     // Binary mode selection...
     Label wlBinaryMode = new Label(wAdvancedSettings, SWT.RIGHT);
@@ -493,10 +496,10 @@ public class ActionFtpPutDialog extends ActionDialog implements IActionDialog {
     Composite wFilesComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wFilesComp);
 
-    FormLayout FilesLayout = new FormLayout();
-    FilesLayout.marginWidth = 3;
-    FilesLayout.marginHeight = 3;
-    wFilesComp.setLayout(FilesLayout);
+    FormLayout filesLayout = new FormLayout();
+    filesLayout.marginWidth = 3;
+    filesLayout.marginHeight = 3;
+    wFilesComp.setLayout(filesLayout);
 
     // ////////////////////////
     // START OF Source SETTINGS GROUP///
@@ -504,10 +507,10 @@ public class ActionFtpPutDialog extends ActionDialog implements IActionDialog {
     Group wSourceSettings = new Group(wFilesComp, SWT.SHADOW_NONE);
     props.setLook(wSourceSettings);
     wSourceSettings.setText(BaseMessages.getString(PKG, "ActionFtpPut.SourceSettings.Group.Label"));
-    FormLayout SourceSettinsgroupLayout = new FormLayout();
-    SourceSettinsgroupLayout.marginWidth = 10;
-    SourceSettinsgroupLayout.marginHeight = 10;
-    wSourceSettings.setLayout(SourceSettinsgroupLayout);
+    FormLayout sourceSettinsgroupLayout = new FormLayout();
+    sourceSettinsgroupLayout.marginWidth = 10;
+    sourceSettinsgroupLayout.marginHeight = 10;
+    wSourceSettings.setLayout(sourceSettinsgroupLayout);
 
     // Local (source) directory line
     Label wlLocalDirectory = new Label(wSourceSettings, SWT.RIGHT);
@@ -618,10 +621,10 @@ public class ActionFtpPutDialog extends ActionDialog implements IActionDialog {
     Group wTargetSettings = new Group(wFilesComp, SWT.SHADOW_NONE);
     props.setLook(wTargetSettings);
     wTargetSettings.setText(BaseMessages.getString(PKG, "ActionFtpPut.TargetSettings.Group.Label"));
-    FormLayout TargetSettinsgroupLayout = new FormLayout();
-    TargetSettinsgroupLayout.marginWidth = 10;
-    TargetSettinsgroupLayout.marginHeight = 10;
-    wTargetSettings.setLayout(TargetSettinsgroupLayout);
+    FormLayout targetSettinsgroupLayout = new FormLayout();
+    targetSettinsgroupLayout.marginWidth = 10;
+    targetSettinsgroupLayout.marginHeight = 10;
+    wTargetSettings.setLayout(targetSettinsgroupLayout);
 
     // Remote Directory line
     Label wlRemoteDirectory = new Label(wTargetSettings, SWT.RIGHT);
@@ -692,10 +695,10 @@ public class ActionFtpPutDialog extends ActionDialog implements IActionDialog {
     Composite wSocksProxyComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wSocksProxyComp);
 
-    FormLayout SoxProxyLayout = new FormLayout();
-    SoxProxyLayout.marginWidth = 3;
-    SoxProxyLayout.marginHeight = 3;
-    wSocksProxyComp.setLayout(SoxProxyLayout);
+    FormLayout soxProxyLayout = new FormLayout();
+    soxProxyLayout.marginWidth = 3;
+    soxProxyLayout.marginHeight = 3;
+    wSocksProxyComp.setLayout(soxProxyLayout);
 
     // ////////////////////////////////////////////////////////
     // Start of Proxy Group
@@ -704,10 +707,10 @@ public class ActionFtpPutDialog extends ActionDialog implements IActionDialog {
     props.setLook(wSocksProxy);
     wSocksProxy.setText(BaseMessages.getString(PKG, "ActionFtpPut.SocksProxy.Group.Label"));
 
-    FormLayout SocksProxyGroupLayout = new FormLayout();
-    SocksProxyGroupLayout.marginWidth = 10;
-    SocksProxyGroupLayout.marginHeight = 10;
-    wSocksProxy.setLayout(SocksProxyGroupLayout);
+    FormLayout socksProxyGroupLayout = new FormLayout();
+    socksProxyGroupLayout.marginWidth = 10;
+    socksProxyGroupLayout.marginHeight = 10;
+    wSocksProxy.setLayout(socksProxyGroupLayout);
 
     // host line
     wSocksProxyHost =
diff --git a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftp/ActionSftp.java b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftp/ActionSftp.java
index 3dd1b4f..32c51c3 100644
--- a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftp/ActionSftp.java
+++ b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftp/ActionSftp.java
@@ -433,7 +433,7 @@ public class ActionSftp extends ActionBase implements Cloneable, IAction {
     String realTargetDirectory = resolve(targetDirectory);
     String realKeyFilename = null;
     String realPassPhrase = null;
-    FileObject TargetFolder = null;
+    FileObject targetFolder = null;
 
     try {
       // Let's perform some checks before starting
@@ -457,9 +457,9 @@ public class ActionSftp extends ActionBase implements Cloneable, IAction {
       }
 
       if (!Utils.isEmpty(realTargetDirectory)) {
-        TargetFolder = HopVfs.getFileObject(realTargetDirectory);
-        boolean TargetFolderExists = TargetFolder.exists();
-        if (TargetFolderExists) {
+        targetFolder = HopVfs.getFileObject(realTargetDirectory);
+        boolean targetFolderExists = targetFolder.exists();
+        if (targetFolderExists) {
           if (log.isDetailed()) {
             logDetailed(
                 BaseMessages.getString(
@@ -475,7 +475,7 @@ public class ActionSftp extends ActionBase implements Cloneable, IAction {
             return result;
           } else {
             // create target folder
-            TargetFolder.createFolder();
+            targetFolder.createFolder();
             if (log.isDetailed()) {
               logDetailed(
                   BaseMessages.getString(
@@ -485,9 +485,9 @@ public class ActionSftp extends ActionBase implements Cloneable, IAction {
         }
       }
 
-      if (TargetFolder != null) {
-        TargetFolder.close();
-        TargetFolder = null;
+      if (targetFolder != null) {
+        targetFolder.close();
+        targetFolder = null;
       }
 
       // Create sftp client to host ...
@@ -641,9 +641,9 @@ public class ActionSftp extends ActionBase implements Cloneable, IAction {
       }
 
       try {
-        if (TargetFolder != null) {
-          TargetFolder.close();
-          TargetFolder = null;
+        if (targetFolder != null) {
+          targetFolder.close();
+          targetFolder = null;
         }
         if (listPreviousFilenames != null) {
           listPreviousFilenames = null;
diff --git a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftp/ActionSftpDialog.java b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftp/ActionSftpDialog.java
index 7f1690e..612287d 100644
--- a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftp/ActionSftpDialog.java
+++ b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftp/ActionSftpDialog.java
@@ -197,10 +197,10 @@ public class ActionSftpDialog extends ActionDialog implements IActionDialog {
     Group wServerSettings = new Group(wGeneralComp, SWT.SHADOW_NONE);
     props.setLook(wServerSettings);
     wServerSettings.setText(BaseMessages.getString(PKG, "ActionSftp.ServerSettings.Group.Label"));
-    FormLayout ServerSettingsgroupLayout = new FormLayout();
-    ServerSettingsgroupLayout.marginWidth = 10;
-    ServerSettingsgroupLayout.marginHeight = 10;
-    wServerSettings.setLayout(ServerSettingsgroupLayout);
+    FormLayout serverSettingsgroupLayout = new FormLayout();
+    serverSettingsgroupLayout.marginWidth = 10;
+    serverSettingsgroupLayout.marginHeight = 10;
+    wServerSettings.setLayout(serverSettingsgroupLayout);
 
     // ServerName line
     Label wlServerName = new Label(wServerSettings, SWT.RIGHT);
@@ -518,10 +518,10 @@ public class ActionSftpDialog extends ActionDialog implements IActionDialog {
     Composite wFilesComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wFilesComp);
 
-    FormLayout FilesLayout = new FormLayout();
-    FilesLayout.marginWidth = 3;
-    FilesLayout.marginHeight = 3;
-    wFilesComp.setLayout(FilesLayout);
+    FormLayout filesLayout = new FormLayout();
+    filesLayout.marginWidth = 3;
+    filesLayout.marginHeight = 3;
+    wFilesComp.setLayout(filesLayout);
 
     // ////////////////////////
     // START OF Source files GROUP///
@@ -529,10 +529,10 @@ public class ActionSftpDialog extends ActionDialog implements IActionDialog {
     Group wSourceFiles = new Group(wFilesComp, SWT.SHADOW_NONE);
     props.setLook(wSourceFiles);
     wSourceFiles.setText(BaseMessages.getString(PKG, "ActionSftp.SourceFiles.Group.Label"));
-    FormLayout SourceFilesgroupLayout = new FormLayout();
-    SourceFilesgroupLayout.marginWidth = 10;
-    SourceFilesgroupLayout.marginHeight = 10;
-    wSourceFiles.setLayout(SourceFilesgroupLayout);
+    FormLayout sourceFilesgroupLayout = new FormLayout();
+    sourceFilesgroupLayout.marginWidth = 10;
+    sourceFilesgroupLayout.marginHeight = 10;
+    wSourceFiles.setLayout(sourceFilesgroupLayout);
 
     // Get arguments from previous result...
     Label wlGetPrevious = new Label(wSourceFiles, SWT.RIGHT);
@@ -651,10 +651,10 @@ public class ActionSftpDialog extends ActionDialog implements IActionDialog {
     Group wTargetFiles = new Group(wFilesComp, SWT.SHADOW_NONE);
     props.setLook(wTargetFiles);
     wTargetFiles.setText(BaseMessages.getString(PKG, "ActionSftp.TargetFiles.Group.Label"));
-    FormLayout TargetFilesgroupLayout = new FormLayout();
-    TargetFilesgroupLayout.marginWidth = 10;
-    TargetFilesgroupLayout.marginHeight = 10;
-    wTargetFiles.setLayout(TargetFilesgroupLayout);
+    FormLayout targetFilesgroupLayout = new FormLayout();
+    targetFilesgroupLayout.marginWidth = 10;
+    targetFilesgroupLayout.marginHeight = 10;
+    wTargetFiles.setLayout(targetFilesgroupLayout);
 
     // TargetDirectory line
     Label wlTargetDirectory = new Label(wTargetFiles, SWT.RIGHT);
@@ -800,7 +800,7 @@ public class ActionSftpDialog extends ActionDialog implements IActionDialog {
     }
   }
 
-  private boolean connectToSftp(boolean checkFolder, String Remotefoldername) {
+  private boolean connectToSftp(boolean checkFolder, String remotefoldername) {
     boolean retval = false;
     try {
       WorkflowMeta workflowMeta = getWorkflowMeta();
@@ -832,7 +832,7 @@ public class ActionSftpDialog extends ActionDialog implements IActionDialog {
         retval = true;
       }
       if (checkFolder) {
-        retval = sftpclient.folderExists(Remotefoldername);
+        retval = sftpclient.folderExists(remotefoldername);
       }
     } catch (Exception e) {
       if (sftpclient != null) {
diff --git a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftpput/ActionSftpPutDialog.java b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftpput/ActionSftpPutDialog.java
index 633bf29..99f2c3d 100644
--- a/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftpput/ActionSftpPutDialog.java
+++ b/plugins/actions/ftp/src/main/java/org/apache/hop/workflow/actions/sftpput/ActionSftpPutDialog.java
@@ -216,10 +216,10 @@ public class ActionSftpPutDialog extends ActionDialog implements IActionDialog {
     props.setLook(wServerSettings);
     wServerSettings.setText(
         BaseMessages.getString(PKG, "ActionSftpPut.ServerSettings.Group.Label"));
-    FormLayout ServerSettingsgroupLayout = new FormLayout();
-    ServerSettingsgroupLayout.marginWidth = 10;
-    ServerSettingsgroupLayout.marginHeight = 10;
-    wServerSettings.setLayout(ServerSettingsgroupLayout);
+    FormLayout serverSettingsgroupLayout = new FormLayout();
+    serverSettingsgroupLayout.marginWidth = 10;
+    serverSettingsgroupLayout.marginHeight = 10;
+    wServerSettings.setLayout(serverSettingsgroupLayout);
 
     // ServerName line
     Label wlServerName = new Label(wServerSettings, SWT.RIGHT);
@@ -538,10 +538,10 @@ public class ActionSftpPutDialog extends ActionDialog implements IActionDialog {
     Composite wFilesComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wFilesComp);
 
-    FormLayout FilesLayout = new FormLayout();
-    FilesLayout.marginWidth = 3;
-    FilesLayout.marginHeight = 3;
-    wFilesComp.setLayout(FilesLayout);
+    FormLayout filesLayout = new FormLayout();
+    filesLayout.marginWidth = 3;
+    filesLayout.marginHeight = 3;
+    wFilesComp.setLayout(filesLayout);
 
     // ////////////////////////
     // START OF Source files GROUP///
@@ -815,10 +815,10 @@ public class ActionSftpPutDialog extends ActionDialog implements IActionDialog {
     Group wTargetFiles = new Group(wFilesComp, SWT.SHADOW_NONE);
     props.setLook(wTargetFiles);
     wTargetFiles.setText(BaseMessages.getString(PKG, "ActionSftpPut.TargetFiles.Group.Label"));
-    FormLayout TargetFilesgroupLayout = new FormLayout();
-    TargetFilesgroupLayout.marginWidth = 10;
-    TargetFilesgroupLayout.marginHeight = 10;
-    wTargetFiles.setLayout(TargetFilesgroupLayout);
+    FormLayout targetFilesgroupLayout = new FormLayout();
+    targetFilesgroupLayout.marginWidth = 10;
+    targetFilesgroupLayout.marginHeight = 10;
+    wTargetFiles.setLayout(targetFilesgroupLayout);
 
     // FtpDirectory line
     Label wlScpDirectory = new Label(wTargetFiles, SWT.RIGHT);
@@ -967,7 +967,7 @@ public class ActionSftpPutDialog extends ActionDialog implements IActionDialog {
     }
   }
 
-  private boolean connectToSftp(boolean checkFolder, String Remotefoldername) {
+  private boolean connectToSftp(boolean checkFolder, String remotefoldername) {
     boolean retval = false;
     try {
       WorkflowMeta workflowMeta = getWorkflowMeta();
@@ -998,7 +998,7 @@ public class ActionSftpPutDialog extends ActionDialog implements IActionDialog {
         retval = true;
       }
       if (checkFolder) {
-        retval = sftpclient.folderExists(Remotefoldername);
+        retval = sftpclient.folderExists(remotefoldername);
       }
 
     } catch (Exception e) {
diff --git a/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/ActionGetPOP.java b/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/ActionGetPOP.java
index c321786..4701070 100644
--- a/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/ActionGetPOP.java
+++ b/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/ActionGetPOP.java
@@ -1227,10 +1227,10 @@ public class ActionGetPOP extends ActionBase implements Cloneable, IAction {
       if (j > -1) {
         String varName = rest.substring(i + open.length(), j);
         DateFormat dateFormat = new SimpleDateFormat(varName);
-        Object Value = dateFormat.format(datetime);
+        Object value = dateFormat.format(datetime);
 
         buffer.append(rest.substring(0, i));
-        buffer.append(Value);
+        buffer.append(value);
         rest = rest.substring(j + close.length());
       } else {
         // no closing tag found; end the search
diff --git a/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/ActionGetPOPDialog.java b/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/ActionGetPOPDialog.java
index ddf2212..3704506 100644
--- a/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/ActionGetPOPDialog.java
+++ b/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/ActionGetPOPDialog.java
@@ -299,10 +299,10 @@ public class ActionGetPOPDialog extends ActionDialog implements IActionDialog {
     props.setLook(wServerSettings);
     wServerSettings.setText(BaseMessages.getString(PKG, "ActionGetPOP.ServerSettings.Group.Label"));
 
-    FormLayout ServerSettingsgroupLayout = new FormLayout();
-    ServerSettingsgroupLayout.marginWidth = 10;
-    ServerSettingsgroupLayout.marginHeight = 10;
-    wServerSettings.setLayout(ServerSettingsgroupLayout);
+    FormLayout serverSettingsgroupLayout = new FormLayout();
+    serverSettingsgroupLayout.marginWidth = 10;
+    serverSettingsgroupLayout.marginHeight = 10;
+    wServerSettings.setLayout(serverSettingsgroupLayout);
 
     // ServerName line
     Label wlServerName = new Label(wServerSettings, SWT.RIGHT);
@@ -505,10 +505,10 @@ public class ActionGetPOPDialog extends ActionDialog implements IActionDialog {
     props.setLook(wTargetFolder);
     wTargetFolder.setText(BaseMessages.getString(PKG, "ActionGetPOP.TargetFolder.Group.Label"));
 
-    FormLayout TargetFoldergroupLayout = new FormLayout();
-    TargetFoldergroupLayout.marginWidth = 10;
-    TargetFoldergroupLayout.marginHeight = 10;
-    wTargetFolder.setLayout(TargetFoldergroupLayout);
+    FormLayout targetFoldergroupLayout = new FormLayout();
+    targetFoldergroupLayout.marginWidth = 10;
+    targetFoldergroupLayout.marginHeight = 10;
+    wTargetFolder.setLayout(targetFoldergroupLayout);
 
     // OutputDirectory line
     wlOutputDirectory = new Label(wTargetFolder, SWT.RIGHT);
@@ -759,10 +759,10 @@ public class ActionGetPOPDialog extends ActionDialog implements IActionDialog {
     wSettingsTab.setText(BaseMessages.getString(PKG, "ActionGetPOP.Tab.Pop.Label"));
     Composite wSettingsComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wSettingsComp);
-    FormLayout PopLayout = new FormLayout();
-    PopLayout.marginWidth = 3;
-    PopLayout.marginHeight = 3;
-    wSettingsComp.setLayout(PopLayout);
+    FormLayout popLayout = new FormLayout();
+    popLayout.marginWidth = 3;
+    popLayout.marginHeight = 3;
+    wSettingsComp.setLayout(popLayout);
 
     // Action type
     Label wlActionType = new Label(wSettingsComp, SWT.RIGHT);
@@ -810,10 +810,10 @@ public class ActionGetPOPDialog extends ActionDialog implements IActionDialog {
     props.setLook(wPOP3Settings);
     wPOP3Settings.setText(BaseMessages.getString(PKG, "ActionGetPOP.POP3Settings.Group.Label"));
 
-    FormLayout POP3SettingsgroupLayout = new FormLayout();
-    POP3SettingsgroupLayout.marginWidth = 10;
-    POP3SettingsgroupLayout.marginHeight = 10;
-    wPOP3Settings.setLayout(POP3SettingsgroupLayout);
+    FormLayout pop3Settingsgrouplayout = new FormLayout();
+    pop3Settingsgrouplayout.marginWidth = 10;
+    pop3Settingsgrouplayout.marginHeight = 10;
+    wPOP3Settings.setLayout(pop3Settingsgrouplayout);
 
     // List of mails of retrieve
     wlListmails = new Label(wPOP3Settings, SWT.RIGHT);
@@ -898,10 +898,10 @@ public class ActionGetPOPDialog extends ActionDialog implements IActionDialog {
     props.setLook(wIMAPSettings);
     wIMAPSettings.setText(BaseMessages.getString(PKG, "ActionGetPOP.IMAPSettings.Groupp.Label"));
 
-    FormLayout IMAPSettingsgroupLayout = new FormLayout();
-    IMAPSettingsgroupLayout.marginWidth = 10;
-    IMAPSettingsgroupLayout.marginHeight = 10;
-    wIMAPSettings.setLayout(IMAPSettingsgroupLayout);
+    FormLayout imapSettingsgroupLayout = new FormLayout();
+    imapSettingsgroupLayout.marginWidth = 10;
+    imapSettingsgroupLayout.marginHeight = 10;
+    wIMAPSettings.setLayout(imapSettingsgroupLayout);
 
     // SelectFolder button
     wSelectFolder = new Button(wIMAPSettings, SWT.PUSH);
@@ -1156,10 +1156,10 @@ public class ActionGetPOPDialog extends ActionDialog implements IActionDialog {
     props.setLook(wHeader);
     wHeader.setText(BaseMessages.getString(PKG, "ActionGetPOP.Header.Group.Label"));
 
-    FormLayout HeadergroupLayout = new FormLayout();
-    HeadergroupLayout.marginWidth = 10;
-    HeadergroupLayout.marginHeight = 10;
-    wHeader.setLayout(HeadergroupLayout);
+    FormLayout headergroupLayout = new FormLayout();
+    headergroupLayout.marginWidth = 10;
+    headergroupLayout.marginHeight = 10;
+    wHeader.setLayout(headergroupLayout);
 
     // Sender line: label, text, negate checkbox
     //
@@ -1263,10 +1263,10 @@ public class ActionGetPOPDialog extends ActionDialog implements IActionDialog {
     props.setLook(wContent);
     wContent.setText(BaseMessages.getString(PKG, "ActionGetPOP.Content.Group.Label"));
 
-    FormLayout ContentgroupLayout = new FormLayout();
-    ContentgroupLayout.marginWidth = 10;
-    ContentgroupLayout.marginHeight = 10;
-    wContent.setLayout(ContentgroupLayout);
+    FormLayout contentgroupLayout = new FormLayout();
+    contentgroupLayout.marginWidth = 10;
+    contentgroupLayout.marginHeight = 10;
+    wContent.setLayout(contentgroupLayout);
 
     // Body: label, text, negate checkbox
     //
@@ -1312,10 +1312,10 @@ public class ActionGetPOPDialog extends ActionDialog implements IActionDialog {
     props.setLook(wReceivedDate);
     wReceivedDate.setText(BaseMessages.getString(PKG, "ActionGetPOP.ReceivedDate.Group.Label"));
 
-    FormLayout ReceivedDategroupLayout = new FormLayout();
-    ReceivedDategroupLayout.marginWidth = 10;
-    ReceivedDategroupLayout.marginHeight = 10;
-    wReceivedDate.setLayout(ReceivedDategroupLayout);
+    FormLayout receivedDategroupLayout = new FormLayout();
+    receivedDategroupLayout.marginWidth = 10;
+    receivedDategroupLayout.marginHeight = 10;
+    wReceivedDate.setLayout(receivedDategroupLayout);
 
     // Received Date Condition line: label, text, negate checkbox
     //
diff --git a/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/MailConnection.java b/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/MailConnection.java
index 5b543e3..253fad7 100644
--- a/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/MailConnection.java
+++ b/plugins/actions/getpop/src/main/java/org/apache/hop/workflow/actions/getpop/MailConnection.java
@@ -51,7 +51,6 @@ public class MailConnection {
   private String username;
   private String password;
   private boolean usessl;
-  private boolean write;
   private boolean useproxy;
   private String proxyusername;
   /** Protocol used. Should be PROTOCOL_POP3 (0) for POP3 and PROTOCOL_IMAP (1) to IMAP */
@@ -306,7 +305,6 @@ public class MailConnection {
    */
   public void openFolder(String folderName, boolean defaultFolder, boolean write)
       throws HopException {
-    this.write = write;
     try {
       if (getFolder() != null) {
         // A folder is already opened
@@ -342,7 +340,7 @@ public class MailConnection {
               BaseMessages.getString(PKG, "ActionGetMailsFromPOP.InvalidFolder.Label"));
         }
       }
-      if (this.write) {
+      if (write) {
         if (log.isDebug()) {
           log.logDebug(
               BaseMessages.getString(
@@ -759,13 +757,13 @@ public class MailConnection {
 
       if (disposition.equalsIgnoreCase(Part.ATTACHMENT)
           || disposition.equalsIgnoreCase(Part.INLINE)) {
-        String MimeText = null;
+        String mimeText = null;
         try {
-          MimeText = MimeUtility.decodeText(part.getFileName());
+          mimeText = MimeUtility.decodeText(part.getFileName());
         } catch (Exception e) {
           // Ignore errors
         }
-        if (MimeText != null) {
+        if (mimeText != null) {
           String filename = MimeUtility.decodeText(part.getFileName());
           if (isWildcardMatch(filename, pattern)) {
             // Save file
@@ -793,12 +791,13 @@ public class MailConnection {
     if (fileName == null || folderName == null) {
       throw new IllegalArgumentException("Cannot have null arguments to findValidTarget");
     }
-    String fileNameRoot = FilenameUtils.getBaseName(fileName),
-        ext = "." + FilenameUtils.getExtension(fileName);
+    String fileNameRoot = FilenameUtils.getBaseName(fileName);
+    String ext = "." + FilenameUtils.getExtension(fileName);
     if ((ext.length() == 1)) { // only a "."
       ext = "";
     }
-    String rtn = "", base = FilenameUtils.concat(folderName, fileNameRoot);
+    String rtn = "";
+    String base = FilenameUtils.concat(folderName, fileNameRoot);
     int baseSz = base.length();
     StringBuilder build = new StringBuilder(baseSz).append(base);
     int i = -1;
@@ -1356,13 +1355,13 @@ public class MailConnection {
           if ((disposition != null)
               && (disposition.equalsIgnoreCase(Part.ATTACHMENT)
                   || disposition.equalsIgnoreCase(Part.INLINE))) {
-            String MimeText = null;
+            String mimeText = null;
             try {
-              MimeText = MimeUtility.decodeText(part.getFileName());
+              mimeText = MimeUtility.decodeText(part.getFileName());
             } catch (Exception e) {
               // Ignore errors
             }
-            if (MimeText != null) {
+            if (mimeText != null) {
               String filename = MimeUtility.decodeText(part.getFileName());
               if (isWildcardMatch(filename, pattern)) {
                 retval++;
diff --git a/plugins/actions/http/src/main/java/org/apache/hop/workflow/actions/http/ActionHttp.java b/plugins/actions/http/src/main/java/org/apache/hop/workflow/actions/http/ActionHttp.java
index 1980809..a70d144 100644
--- a/plugins/actions/http/src/main/java/org/apache/hop/workflow/actions/http/ActionHttp.java
+++ b/plugins/actions/http/src/main/java/org/apache/hop/workflow/actions/http/ActionHttp.java
@@ -316,7 +316,9 @@ public class ActionHttp extends ActionBase implements Cloneable, IAction {
 
     // Get previous result rows...
     List<RowMetaAndData> resultRows;
-    String urlFieldnameToUse, uploadFieldnameToUse, destinationFieldnameToUse;
+    String urlFieldnameToUse;
+    String uploadFieldnameToUse;
+    String destinationFieldnameToUse;
 
     if (Utils.isEmpty(urlFieldname)) {
       urlFieldnameToUse = URL_FIELDNAME;
diff --git a/plugins/actions/http/src/main/java/org/apache/hop/workflow/actions/http/ActionHttpDialog.java b/plugins/actions/http/src/main/java/org/apache/hop/workflow/actions/http/ActionHttpDialog.java
index 5ab1e07..1649d88 100644
--- a/plugins/actions/http/src/main/java/org/apache/hop/workflow/actions/http/ActionHttpDialog.java
+++ b/plugins/actions/http/src/main/java/org/apache/hop/workflow/actions/http/ActionHttpDialog.java
@@ -307,10 +307,10 @@ public class ActionHttpDialog extends ActionDialog implements IActionDialog {
     props.setLook(wAuthentication);
     wAuthentication.setText(BaseMessages.getString(PKG, "ActionHTTP.Authentication.Group.Label"));
 
-    FormLayout AuthenticationgroupLayout = new FormLayout();
-    AuthenticationgroupLayout.marginWidth = 10;
-    AuthenticationgroupLayout.marginHeight = 10;
-    wAuthentication.setLayout(AuthenticationgroupLayout);
+    FormLayout authenticationgroupLayout = new FormLayout();
+    authenticationgroupLayout.marginWidth = 10;
+    authenticationgroupLayout.marginHeight = 10;
+    wAuthentication.setLayout(authenticationgroupLayout);
 
     // UserName line
     Label wlUserName = new Label(wAuthentication, SWT.RIGHT);
@@ -424,10 +424,10 @@ public class ActionHttpDialog extends ActionDialog implements IActionDialog {
     props.setLook(wUpLoadFile);
     wUpLoadFile.setText(BaseMessages.getString(PKG, "ActionHTTP.UpLoadFile.Group.Label"));
 
-    FormLayout UpLoadFilegroupLayout = new FormLayout();
-    UpLoadFilegroupLayout.marginWidth = 10;
-    UpLoadFilegroupLayout.marginHeight = 10;
-    wUpLoadFile.setLayout(UpLoadFilegroupLayout);
+    FormLayout upLoadFilegroupLayout = new FormLayout();
+    upLoadFilegroupLayout.marginWidth = 10;
+    upLoadFilegroupLayout.marginHeight = 10;
+    wUpLoadFile.setLayout(upLoadFilegroupLayout);
 
     // UploadFile line
     wlUploadFile = new Label(wUpLoadFile, SWT.RIGHT);
@@ -483,10 +483,10 @@ public class ActionHttpDialog extends ActionDialog implements IActionDialog {
     props.setLook(wTargetFileGroup);
     wTargetFileGroup.setText(BaseMessages.getString(PKG, "ActionHTTP.TargetFileGroup.Group.Label"));
 
-    FormLayout TargetFileGroupgroupLayout = new FormLayout();
-    TargetFileGroupgroupLayout.marginWidth = 10;
-    TargetFileGroupgroupLayout.marginHeight = 10;
-    wTargetFileGroup.setLayout(TargetFileGroupgroupLayout);
+    FormLayout targetFileGroupgroupLayout = new FormLayout();
+    targetFileGroupgroupLayout.marginWidth = 10;
+    targetFileGroupgroupLayout.marginHeight = 10;
+    wTargetFileGroup.setLayout(targetFileGroupgroupLayout);
 
     // TargetFile line
     wlTargetFile = new Label(wTargetFileGroup, SWT.RIGHT);
@@ -636,10 +636,10 @@ public class ActionHttpDialog extends ActionDialog implements IActionDialog {
     wHeadersTab.setText(BaseMessages.getString(PKG, "ActionHTTP.Tab.Headers.Label"));
     Composite wHeadersComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wHeadersComp);
-    FormLayout HeadersLayout = new FormLayout();
-    HeadersLayout.marginWidth = 3;
-    HeadersLayout.marginHeight = 3;
-    wHeadersComp.setLayout(HeadersLayout);
+    FormLayout headersLayout = new FormLayout();
+    headersLayout.marginWidth = 3;
+    headersLayout.marginHeight = 3;
+    wHeadersComp.setLayout(headersLayout);
 
     int rows =
         action.getHeaderName() == null
diff --git a/plugins/actions/mail/src/main/java/org/apache/hop/workflow/actions/mail/ActionMail.java b/plugins/actions/mail/src/main/java/org/apache/hop/workflow/actions/mail/ActionMail.java
index 568c590..753829a 100644
--- a/plugins/actions/mail/src/main/java/org/apache/hop/workflow/actions/mail/ActionMail.java
+++ b/plugins/actions/mail/src/main/java/org/apache/hop/workflow/actions/mail/ActionMail.java
@@ -658,10 +658,10 @@ public class ActionMail extends ActionBase implements Cloneable, IAction {
       String replyToAddress = resolve(replyToAddresses);
       if (!Utils.isEmpty(replyToAddress)) {
         // Split the mail-address: variables separated
-        String[] reply_Address_List = resolve(replyToAddress).split(" ");
-        InternetAddress[] address = new InternetAddress[reply_Address_List.length];
-        for (int i = 0; i < reply_Address_List.length; i++) {
-          address[i] = new InternetAddress(reply_Address_List[i]);
+        String[] replyAddressList = resolve(replyToAddress).split(" ");
+        InternetAddress[] address = new InternetAddress[replyAddressList.length];
+        for (int i = 0; i < replyAddressList.length; i++) {
+          address[i] = new InternetAddress(replyAddressList[i]);
         }
         msg.setReplyTo(address);
       }
diff --git a/plugins/actions/mail/src/main/java/org/apache/hop/workflow/actions/mail/ActionMailDialog.java b/plugins/actions/mail/src/main/java/org/apache/hop/workflow/actions/mail/ActionMailDialog.java
index f443170..904cc6a 100644
--- a/plugins/actions/mail/src/main/java/org/apache/hop/workflow/actions/mail/ActionMailDialog.java
+++ b/plugins/actions/mail/src/main/java/org/apache/hop/workflow/actions/mail/ActionMailDialog.java
@@ -81,7 +81,8 @@ public class ActionMailDialog extends ActionDialog implements IActionDialog {
 
   private LabelTextVar wAuthPass;
 
-  private LabelTextVar wReply, wReplyName;
+  private LabelTextVar wReply;
+  private LabelTextVar wReplyName;
 
   private LabelTextVar wSubject;
 
@@ -105,7 +106,9 @@ public class ActionMailDialog extends ActionDialog implements IActionDialog {
 
   private TextVar wComment;
 
-  private Button wOnlyComment, wUseHTML, wUsePriority;
+  private Button wOnlyComment;
+  private Button wUseHTML;
+  private Button wUsePriority;
 
   private Label wlEncoding;
   private CCombo wEncoding;
@@ -126,15 +129,22 @@ public class ActionMailDialog extends ActionDialog implements IActionDialog {
 
   private ActionMail action;
 
-  private boolean backupDate, backupChanged;
+  private boolean backupDate;
+  private boolean backupChanged;
 
   private boolean gotEncodings = false;
 
   private LabelTextVar wReplyToAddress;
 
-  private Label wlImageFilename, wlContentID, wlFields;
-  private Button wbImageFilename, wbaImageFilename, wbdImageFilename, wbeImageFilename;
-  private TextVar wImageFilename, wContentID;
+  private Label wlImageFilename;
+  private Label wlContentID;
+  private Label wlFields;
+  private Button wbImageFilename;
+  private Button wbaImageFilename;
+  private Button wbdImageFilename;
+  private Button wbeImageFilename;
+  private TextVar wImageFilename;
+  private TextVar wContentID;
   private TableView wFields;
 
   public ActionMailDialog(
diff --git a/plugins/actions/movefiles/src/main/java/org/apache/hop/workflow/actions/movefiles/ActionMoveFiles.java b/plugins/actions/movefiles/src/main/java/org/apache/hop/workflow/actions/movefiles/ActionMoveFiles.java
index 1aaa1c0..463f3a9 100644
--- a/plugins/actions/movefiles/src/main/java/org/apache/hop/workflow/actions/movefiles/ActionMoveFiles.java
+++ b/plugins/actions/movefiles/src/main/java/org/apache/hop/workflow/actions/movefiles/ActionMoveFiles.java
@@ -81,15 +81,15 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
   private boolean specifyFormat;
   private String dateTimeFormat;
   private boolean addDateBeforeExtension;
-  private boolean DoNotKeepFolderStructure;
+  private boolean doNotKeepFolderStructure;
   private String ifFileExists;
   private String destinationFolder;
   private String ifMovedFileExists;
   private String movedDateTimeFormat;
-  private boolean AddMovedDateBeforeExtension;
+  private boolean addMovedDateBeforeExtension;
   private boolean addMovedDate;
   private boolean addMovedTime;
-  private boolean SpecifyMoveFormat;
+  private boolean specifyMoveFormat;
   public boolean createMoveToFolder;
   public boolean simulate;
 
@@ -103,14 +103,14 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
     super(n, "");
     simulate = false;
     createMoveToFolder = false;
-    SpecifyMoveFormat = false;
+    specifyMoveFormat = false;
     addMovedDate = false;
     addMovedTime = false;
-    AddMovedDateBeforeExtension = false;
+    addMovedDateBeforeExtension = false;
     movedDateTimeFormat = null;
     ifMovedFileExists = "do_nothing";
     destinationFolder = null;
-    DoNotKeepFolderStructure = false;
+    doNotKeepFolderStructure = false;
     moveEmptyFolders = true;
     argFromPrevious = false;
     sourceFileFolder = null;
@@ -181,7 +181,7 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
         .append(XmlHandler.addTagValue("AddDateBeforeExtension", addDateBeforeExtension));
     retval
         .append("      ")
-        .append(XmlHandler.addTagValue("DoNotKeepFolderStructure", DoNotKeepFolderStructure));
+        .append(XmlHandler.addTagValue("DoNotKeepFolderStructure", doNotKeepFolderStructure));
     retval.append("      ").append(XmlHandler.addTagValue("iffileexists", ifFileExists));
     retval.append("      ").append(XmlHandler.addTagValue("destinationFolder", destinationFolder));
     retval.append("      ").append(XmlHandler.addTagValue("ifmovedfileexists", ifMovedFileExists));
@@ -193,10 +193,10 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
         .append(XmlHandler.addTagValue("create_move_to_folder", createMoveToFolder));
     retval.append("      ").append(XmlHandler.addTagValue("add_moved_date", addMovedDate));
     retval.append("      ").append(XmlHandler.addTagValue("add_moved_time", addMovedTime));
-    retval.append("      ").append(XmlHandler.addTagValue("SpecifyMoveFormat", SpecifyMoveFormat));
+    retval.append("      ").append(XmlHandler.addTagValue("SpecifyMoveFormat", specifyMoveFormat));
     retval
         .append("      ")
-        .append(XmlHandler.addTagValue("AddMovedDateBeforeExtension", AddMovedDateBeforeExtension));
+        .append(XmlHandler.addTagValue("AddMovedDateBeforeExtension", addMovedDateBeforeExtension));
     retval.append("      ").append(XmlHandler.addTagValue("simulate", simulate));
 
     retval.append("      <fields>").append(Const.CR);
@@ -240,7 +240,7 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
       specifyFormat = "Y".equalsIgnoreCase(XmlHandler.getTagValue(entrynode, "SpecifyFormat"));
       addDateBeforeExtension =
           "Y".equalsIgnoreCase(XmlHandler.getTagValue(entrynode, "AddDateBeforeExtension"));
-      DoNotKeepFolderStructure =
+      doNotKeepFolderStructure =
           "Y".equalsIgnoreCase(XmlHandler.getTagValue(entrynode, "DoNotKeepFolderStructure"));
       dateTimeFormat = XmlHandler.getTagValue(entrynode, "date_time_format");
       nrErrorsLessThan = XmlHandler.getTagValue(entrynode, "nr_errors_less_than");
@@ -249,13 +249,13 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
       destinationFolder = XmlHandler.getTagValue(entrynode, "destinationFolder");
       ifMovedFileExists = XmlHandler.getTagValue(entrynode, "ifmovedfileexists");
       movedDateTimeFormat = XmlHandler.getTagValue(entrynode, "moved_date_time_format");
-      AddMovedDateBeforeExtension =
+      addMovedDateBeforeExtension =
           "Y".equalsIgnoreCase(XmlHandler.getTagValue(entrynode, "AddMovedDateBeforeExtension"));
       createMoveToFolder =
           "Y".equalsIgnoreCase(XmlHandler.getTagValue(entrynode, "create_move_to_folder"));
       addMovedDate = "Y".equalsIgnoreCase(XmlHandler.getTagValue(entrynode, "add_moved_date"));
       addMovedTime = "Y".equalsIgnoreCase(XmlHandler.getTagValue(entrynode, "add_moved_time"));
-      SpecifyMoveFormat =
+      specifyMoveFormat =
           "Y".equalsIgnoreCase(XmlHandler.getTagValue(entrynode, "SpecifyMoveFormat"));
       simulate = "Y".equalsIgnoreCase(XmlHandler.getTagValue(entrynode, "simulate"));
 
@@ -303,38 +303,38 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
       }
     }
 
-    String MoveToFolder = resolve(destinationFolder);
+    String moveToFolder = resolve(destinationFolder);
     // Get source and destination files, also wildcard
     String[] vSourceFileFolder = sourceFileFolder;
     String[] vDestinationFileFolder = destinationFileFolder;
     String[] vwildcard = wildcard;
 
     if (ifFileExists.equals("move_file")) {
-      if (Utils.isEmpty(MoveToFolder)) {
+      if (Utils.isEmpty(moveToFolder)) {
         logError(BaseMessages.getString(PKG, "ActionMoveFiles.Log.Error.MoveToFolderMissing"));
         return result;
       }
       FileObject folder = null;
       try {
-        folder = HopVfs.getFileObject(MoveToFolder);
+        folder = HopVfs.getFileObject(moveToFolder);
         if (!folder.exists()) {
           if (log.isDetailed()) {
             logDetailed(
                 BaseMessages.getString(
-                    PKG, "ActionMoveFiles.Log.Error.FolderMissing", MoveToFolder));
+                    PKG, "ActionMoveFiles.Log.Error.FolderMissing", moveToFolder));
           }
           if (createMoveToFolder) {
             folder.createFolder();
           } else {
             logError(
                 BaseMessages.getString(
-                    PKG, "ActionMoveFiles.Log.Error.FolderMissing", MoveToFolder));
+                    PKG, "ActionMoveFiles.Log.Error.FolderMissing", moveToFolder));
             return result;
           }
         }
         if (!folder.getType().equals(FileType.FOLDER)) {
           logError(
-              BaseMessages.getString(PKG, "ActionMoveFiles.Log.Error.NotFolder", MoveToFolder));
+              BaseMessages.getString(PKG, "ActionMoveFiles.Log.Error.NotFolder", moveToFolder));
           return result;
         }
       } catch (Exception e) {
@@ -342,7 +342,7 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
             BaseMessages.getString(
                 PKG,
                 "ActionMoveFiles.Log.Error.GettingMoveToFolder",
-                MoveToFolder,
+                moveToFolder,
                 e.getMessage()));
         return result;
       } finally {
@@ -405,7 +405,7 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
               vWildcardPrevious,
               parentWorkflow,
               result,
-              MoveToFolder)) {
+              moveToFolder)) {
             // The move process fail
             // Update Errors
             updateErrors();
@@ -455,7 +455,7 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
               vwildcard[i],
               parentWorkflow,
               result,
-              MoveToFolder)) {
+              moveToFolder)) {
             // Update Errors
             updateErrors();
           }
@@ -515,12 +515,12 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
       String wildcard,
       IWorkflowEngine<WorkflowMeta> parentWorkflow,
       Result result,
-      String MoveToFolder) {
+      String moveToFolder) {
     boolean entrystatus = false;
     FileObject sourcefilefolder = null;
     FileObject destinationfilefolder = null;
     FileObject movetofolderfolder = null;
-    FileObject Currentfile = null;
+    FileObject currentfile = null;
 
     // Get real source, destination file and wildcard
     String realSourceFilefoldername = resolve(sourcefilefoldername);
@@ -530,8 +530,8 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
     try {
       sourcefilefolder = HopVfs.getFileObject(realSourceFilefoldername);
       destinationfilefolder = HopVfs.getFileObject(realDestinationFilefoldername);
-      if (!Utils.isEmpty(MoveToFolder)) {
-        movetofolderfolder = HopVfs.getFileObject(MoveToFolder);
+      if (!Utils.isEmpty(moveToFolder)) {
+        movetofolderfolder = HopVfs.getFileObject(moveToFolder);
       }
 
       if (sourcefilefolder.exists()) {
@@ -680,10 +680,10 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
                     return false;
                   }
                   // Fetch files in list one after one ...
-                  Currentfile = fileObjects[j];
+                  currentfile = fileObjects[j];
 
                   if (!MoveOneFile(
-                      Currentfile,
+                      currentfile,
                       sourcefilefolder,
                       realDestinationFilefoldername,
                       realWildcard,
@@ -716,7 +716,7 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
           BaseMessages.getString(
               PKG,
               "ActionMoveFiles.Error.Exception.MoveProcess",
-              realSourceFilefoldername.toString(),
+              realSourceFilefoldername,
               destinationfilefolder.toString(),
               e.getMessage()));
     } finally {
@@ -734,9 +734,9 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
           /* Ignore */
         }
       }
-      if (Currentfile != null) {
+      if (currentfile != null) {
         try {
-          Currentfile.close();
+          currentfile.close();
         } catch (IOException ex) {
           /* Ignore */
         }
@@ -992,7 +992,7 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
   }
 
   private boolean MoveOneFile(
-      FileObject Currentfile,
+      FileObject currentfile,
       FileObject sourcefilefolder,
       String realDestinationFilefoldername,
       String realWildcard,
@@ -1003,11 +1003,11 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
     FileObject filename = null;
 
     try {
-      if (!Currentfile.toString().equals(sourcefilefolder.toString())) {
+      if (!currentfile.toString().equals(sourcefilefolder.toString())) {
         // Pass over the Base folder itself
 
         // return destination short filename
-        String sourceshortfilename = Currentfile.getName().getBaseName();
+        String sourceshortfilename = currentfile.getName().getBaseName();
         String shortfilename = sourceshortfilename;
         try {
           shortfilename = getDestinationFilename(sourceshortfilename);
@@ -1018,7 +1018,7 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
                   BaseMessages.getString(
                       PKG,
                       "ActionMoveFiles.Error.GettingFilename",
-                      Currentfile.getName().getBaseName(),
+                      currentfile.getName().getBaseName(),
                       e.toString())));
           return entrystatus;
         }
@@ -1027,8 +1027,9 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
         String shortFilenameFromBaseFolder = shortfilename;
         if (!isDoNotKeepFolderStructure()) {
           shortFilenameFromBaseFolder =
-              Currentfile.toString()
-                  .substring(sourcefilefolder.toString().length(), Currentfile.toString().length());
+              currentfile
+                  .toString()
+                  .substring(sourcefilefolder.toString().length(), currentfile.toString().length());
         }
         shortFilenameFromBaseFolder =
             shortFilenameFromBaseFolder.substring(
@@ -1040,17 +1041,17 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
             HopVfs.getFileObject(
                 realDestinationFilefoldername + Const.FILE_SEPARATOR + shortFilenameFromBaseFolder);
 
-        if (!Currentfile.getParent().toString().equals(sourcefilefolder.toString())) {
+        if (!currentfile.getParent().toString().equals(sourcefilefolder.toString())) {
 
           // Not in the Base Folder..Only if include sub folders
           if (includeSubfolders) {
             // Folders..only if include subfolders
-            if (Currentfile.getType() == FileType.FOLDER) {
+            if (currentfile.getType() == FileType.FOLDER) {
               if (includeSubfolders && moveEmptyFolders && Utils.isEmpty(wildcard)) {
                 entrystatus =
                     MoveFile(
                         shortfilename,
-                        Currentfile,
+                        currentfile,
                         filename,
                         movetofolderfolder,
                         parentWorkflow,
@@ -1062,7 +1063,7 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
                 entrystatus =
                     MoveFile(
                         shortfilename,
-                        Currentfile,
+                        currentfile,
                         filename,
                         movetofolderfolder,
                         parentWorkflow,
@@ -1073,12 +1074,12 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
         } else {
           // In the Base Folder...
           // Folders..only if include subfolders
-          if (Currentfile.getType() == FileType.FOLDER) {
+          if (currentfile.getType() == FileType.FOLDER) {
             if (includeSubfolders && moveEmptyFolders && Utils.isEmpty(wildcard)) {
               entrystatus =
                   MoveFile(
                       shortfilename,
-                      Currentfile,
+                      currentfile,
                       filename,
                       movetofolderfolder,
                       parentWorkflow,
@@ -1091,7 +1092,7 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
               entrystatus =
                   MoveFile(
                       shortfilename,
-                      Currentfile,
+                      currentfile,
                       filename,
                       movetofolderfolder,
                       parentWorkflow,
@@ -1271,7 +1272,7 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
     return shortfilename;
   }
 
-  private String getMoveDestinationFilename(String shortsourcefilename, String DateFormat)
+  private String getMoveDestinationFilename(String shortsourcefilename, String dateFormat)
       throws Exception {
     String shortfilename = shortsourcefilename;
     int lenstring = shortsourcefilename.length();
@@ -1287,8 +1288,8 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
     SimpleDateFormat daf = new SimpleDateFormat();
     Date now = new Date();
 
-    if (DateFormat != null) {
-      daf.applyPattern(DateFormat);
+    if (dateFormat != null) {
+      daf.applyPattern(dateFormat);
       String dt = daf.format(now);
       shortfilename += dt;
     } else {
@@ -1369,8 +1370,8 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
     this.addDateBeforeExtension = addDateBeforeExtension;
   }
 
-  public void setAddMovedDateBeforeExtension(boolean AddMovedDateBeforeExtension) {
-    this.AddMovedDateBeforeExtension = AddMovedDateBeforeExtension;
+  public void setAddMovedDateBeforeExtension(boolean addMovedDateBeforeExtension) {
+    this.addMovedDateBeforeExtension = addMovedDateBeforeExtension;
   }
 
   public boolean isSpecifyFormat() {
@@ -1381,12 +1382,12 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
     this.specifyFormat = specifyFormat;
   }
 
-  public void setSpecifyMoveFormat(boolean SpecifyMoveFormat) {
-    this.SpecifyMoveFormat = SpecifyMoveFormat;
+  public void setSpecifyMoveFormat(boolean specifyMoveFormat) {
+    this.specifyMoveFormat = specifyMoveFormat;
   }
 
   public boolean isSpecifyMoveFormat() {
-    return SpecifyMoveFormat;
+    return specifyMoveFormat;
   }
 
   public String getDateTimeFormat() {
@@ -1410,11 +1411,11 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
   }
 
   public boolean isAddMovedDateBeforeExtension() {
-    return AddMovedDateBeforeExtension;
+    return addMovedDateBeforeExtension;
   }
 
   public boolean isDoNotKeepFolderStructure() {
-    return DoNotKeepFolderStructure;
+    return doNotKeepFolderStructure;
   }
 
   public void setDestinationFolder(String destinationFolder) {
@@ -1425,8 +1426,8 @@ public class ActionMoveFiles extends ActionBase implements Cloneable, IAction {
     return destinationFolder;
   }
 
-  public void setDoNotKeepFolderStructure(boolean DoNotKeepFolderStructure) {
-    this.DoNotKeepFolderStructure = DoNotKeepFolderStructure;
+  public void setDoNotKeepFolderStructure(boolean doNotKeepFolderStructure) {
+    this.doNotKeepFolderStructure = doNotKeepFolderStructure;
   }
 
   public void setMoveEmptyFolders(boolean moveEmptyFolders) {
diff --git a/plugins/actions/movefiles/src/main/java/org/apache/hop/workflow/actions/movefiles/ActionMoveFilesDialog.java b/plugins/actions/movefiles/src/main/java/org/apache/hop/workflow/actions/movefiles/ActionMoveFilesDialog.java
index 1f86c91..94248aa 100644
--- a/plugins/actions/movefiles/src/main/java/org/apache/hop/workflow/actions/movefiles/ActionMoveFilesDialog.java
+++ b/plugins/actions/movefiles/src/main/java/org/apache/hop/workflow/actions/movefiles/ActionMoveFilesDialog.java
@@ -55,10 +55,10 @@ public class ActionMoveFilesDialog extends ActionDialog implements IActionDialog
   private Text wName;
 
   private Label wlSourceFileFolder;
-  private Button wbSourceFileFolder,
-      wbDestinationFileFolder,
-      wbSourceDirectory,
-      wbDestinationDirectory;
+  private Button wbSourceFileFolder;
+  private Button wbDestinationFileFolder;
+  private Button wbSourceDirectory;
+  private Button wbDestinationDirectory;
 
   private TextVar wSourceFileFolder;
 
@@ -642,13 +642,13 @@ public class ActionMoveFilesDialog extends ActionDialog implements IActionDialog
     wDestinationFileTab.setText(
         BaseMessages.getString(PKG, "ActionMoveFiles.DestinationFileTab.Label"));
 
-    FormLayout DestcontentLayout = new FormLayout();
-    DestcontentLayout.marginWidth = 3;
-    DestcontentLayout.marginHeight = 3;
+    FormLayout destcontentLayout = new FormLayout();
+    destcontentLayout.marginWidth = 3;
+    destcontentLayout.marginHeight = 3;
 
     Composite wDestinationFileComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wDestinationFileComp);
-    wDestinationFileComp.setLayout(DestcontentLayout);
+    wDestinationFileComp.setLayout(destcontentLayout);
 
     // DestinationFile grouping?
     // ////////////////////////
@@ -935,10 +935,10 @@ public class ActionMoveFilesDialog extends ActionDialog implements IActionDialog
     props.setLook(wMoveToGroup);
     wMoveToGroup.setText(BaseMessages.getString(PKG, "ActionMoveFiles.GroupMoveToGroup.Label"));
 
-    FormLayout MovetoLayoutFile = new FormLayout();
-    MovetoLayoutFile.marginWidth = 10;
-    MovetoLayoutFile.marginHeight = 10;
-    wMoveToGroup.setLayout(MovetoLayoutFile);
+    FormLayout movetoLayoutFile = new FormLayout();
+    movetoLayoutFile.marginWidth = 10;
+    movetoLayoutFile.marginHeight = 10;
+    wMoveToGroup.setLayout(movetoLayoutFile);
 
     // DestinationFolder line
     wlDestinationFolder = new Label(wMoveToGroup, SWT.RIGHT);
diff --git a/plugins/actions/mssqlbulkload/src/main/java/org/apache/hop/workflow/actions/mssqlbulkload/ActionMssqlBulkLoad.java b/plugins/actions/mssqlbulkload/src/main/java/org/apache/hop/workflow/actions/mssqlbulkload/ActionMssqlBulkLoad.java
index d84baf6..0bad3d8 100644
--- a/plugins/actions/mssqlbulkload/src/main/java/org/apache/hop/workflow/actions/mssqlbulkload/ActionMssqlBulkLoad.java
+++ b/plugins/actions/mssqlbulkload/src/main/java/org/apache/hop/workflow/actions/mssqlbulkload/ActionMssqlBulkLoad.java
@@ -281,12 +281,12 @@ public class ActionMssqlBulkLoad extends ActionBase implements Cloneable, IActio
 
   @Override
   public Result execute(Result previousResult, int nr) {
-    String TakeFirstNbrLines = "";
-    String LineTerminatedby = "";
-    String FieldTerminatedby = "";
+    String takeFirstNbrLines = "";
+    String lineTerminatedby = "";
+    String fieldTerminatedby = "";
     boolean useFieldSeparator = false;
-    String UseCodepage = "";
-    String ErrorfileName = "";
+    String useCodepage = "";
+    String errorfileName = "";
 
     Result result = previousResult;
     result.setResult(false);
@@ -352,8 +352,8 @@ public class ActionMssqlBulkLoad extends ActionBase implements Cloneable, IActio
                 }
 
                 // FIELDTERMINATOR
-                String Fieldterminator = getRealFieldTerminator();
-                if (Utils.isEmpty(Fieldterminator)
+                String fieldTerminator = getRealFieldTerminator();
+                if (Utils.isEmpty(fieldTerminator)
                     && (datafiletype.equals("char") || datafiletype.equals("widechar"))) {
                   logError(
                       BaseMessages.getString(
@@ -362,7 +362,7 @@ public class ActionMssqlBulkLoad extends ActionBase implements Cloneable, IActio
                 } else {
                   if (datafiletype.equals("char") || datafiletype.equals("widechar")) {
                     useFieldSeparator = true;
-                    FieldTerminatedby = "FIELDTERMINATOR='" + Fieldterminator + "'";
+                    fieldTerminatedby = "FIELDTERMINATOR='" + fieldTerminator + "'";
                   }
                 }
                 // Check Specific Code page
@@ -375,10 +375,10 @@ public class ActionMssqlBulkLoad extends ActionBase implements Cloneable, IActio
                     return result;
 
                   } else {
-                    UseCodepage = "CODEPAGE = '" + realCodePage + "'";
+                    useCodepage = "CODEPAGE = '" + realCodePage + "'";
                   }
                 } else {
-                  UseCodepage = "CODEPAGE = '" + codepage + "'";
+                  useCodepage = "CODEPAGE = '" + codepage + "'";
                 }
 
                 // Check Error file
@@ -400,99 +400,99 @@ public class ActionMssqlBulkLoad extends ActionBase implements Cloneable, IActio
                     daf.applyPattern("yyyMMdd_HHmmss");
                     String d = daf.format(now);
 
-                    ErrorfileName = "ERRORFILE ='" + realErrorFile + "_" + d + "'";
+                    errorfileName = "ERRORFILE ='" + realErrorFile + "_" + d + "'";
                   } else {
-                    ErrorfileName = "ERRORFILE ='" + realErrorFile + "'";
+                    errorfileName = "ERRORFILE ='" + realErrorFile + "'";
                   }
                 }
 
                 // ROWTERMINATOR
-                String Rowterminator = getRealLineterminated();
-                if (!Utils.isEmpty(Rowterminator)) {
-                  LineTerminatedby = "ROWTERMINATOR='" + Rowterminator + "'";
+                String rowterminator = getRealLineterminated();
+                if (!Utils.isEmpty(rowterminator)) {
+                  lineTerminatedby = "ROWTERMINATOR='" + rowterminator + "'";
                 }
 
                 // Start file at
                 if (startfile > 0) {
-                  TakeFirstNbrLines = "FIRSTROW=" + startfile;
+                  takeFirstNbrLines = "FIRSTROW=" + startfile;
                 }
 
                 // End file at
                 if (endfile > 0) {
-                  TakeFirstNbrLines = "LASTROW=" + endfile;
+                  takeFirstNbrLines = "LASTROW=" + endfile;
                 }
 
                 // Truncate table?
-                String SqlBulkLoad = "";
+                String sqlBulkLoad = "";
                 if (truncate) {
-                  SqlBulkLoad = "TRUNCATE TABLE " + realTablename + ";";
+                  sqlBulkLoad = "TRUNCATE TABLE " + realTablename + ";";
                 }
 
                 // Build BULK Command
-                SqlBulkLoad =
-                    SqlBulkLoad
+                sqlBulkLoad =
+                    sqlBulkLoad
                         + "BULK INSERT "
                         + realTablename
                         + " FROM "
                         + "'"
                         + realFilename.replace('\\', '/')
                         + "'";
-                SqlBulkLoad = SqlBulkLoad + " WITH (";
+                sqlBulkLoad = sqlBulkLoad + " WITH (";
                 if (useFieldSeparator) {
-                  SqlBulkLoad = SqlBulkLoad + FieldTerminatedby;
+                  sqlBulkLoad = sqlBulkLoad + fieldTerminatedby;
                 } else {
-                  SqlBulkLoad = SqlBulkLoad + "DATAFILETYPE ='" + datafiletype + "'";
+                  sqlBulkLoad = sqlBulkLoad + "DATAFILETYPE ='" + datafiletype + "'";
                 }
 
-                if (LineTerminatedby.length() > 0) {
-                  SqlBulkLoad = SqlBulkLoad + "," + LineTerminatedby;
+                if (lineTerminatedby.length() > 0) {
+                  sqlBulkLoad = sqlBulkLoad + "," + lineTerminatedby;
                 }
-                if (TakeFirstNbrLines.length() > 0) {
-                  SqlBulkLoad = SqlBulkLoad + "," + TakeFirstNbrLines;
+                if (takeFirstNbrLines.length() > 0) {
+                  sqlBulkLoad = sqlBulkLoad + "," + takeFirstNbrLines;
                 }
-                if (UseCodepage.length() > 0) {
-                  SqlBulkLoad = SqlBulkLoad + "," + UseCodepage;
+                if (useCodepage.length() > 0) {
+                  sqlBulkLoad = sqlBulkLoad + "," + useCodepage;
                 }
                 String realFormatFile = resolve(formatfilename);
                 if (realFormatFile != null) {
-                  SqlBulkLoad = SqlBulkLoad + ", FORMATFILE='" + realFormatFile + "'";
+                  sqlBulkLoad = sqlBulkLoad + ", FORMATFILE='" + realFormatFile + "'";
                 }
                 if (firetriggers) {
-                  SqlBulkLoad = SqlBulkLoad + ",FIRE_TRIGGERS";
+                  sqlBulkLoad = sqlBulkLoad + ",FIRE_TRIGGERS";
                 }
                 if (keepnulls) {
-                  SqlBulkLoad = SqlBulkLoad + ",KEEPNULLS";
+                  sqlBulkLoad = sqlBulkLoad + ",KEEPNULLS";
                 }
                 if (keepidentity) {
-                  SqlBulkLoad = SqlBulkLoad + ",KEEPIDENTITY";
+                  sqlBulkLoad = sqlBulkLoad + ",KEEPIDENTITY";
                 }
                 if (checkconstraints) {
-                  SqlBulkLoad = SqlBulkLoad + ",CHECK_CONSTRAINTS";
+                  sqlBulkLoad = sqlBulkLoad + ",CHECK_CONSTRAINTS";
                 }
                 if (tablock) {
-                  SqlBulkLoad = SqlBulkLoad + ",TABLOCK";
+                  sqlBulkLoad = sqlBulkLoad + ",TABLOCK";
                 }
                 if (orderby != null) {
-                  SqlBulkLoad = SqlBulkLoad + ",ORDER ( " + orderby + " " + orderdirection + ")";
+                  sqlBulkLoad = sqlBulkLoad + ",ORDER ( " + orderby + " " + orderdirection + ")";
                 }
-                if (ErrorfileName.length() > 0) {
-                  SqlBulkLoad = SqlBulkLoad + ", " + ErrorfileName;
+                if (errorfileName.length() > 0) {
+                  sqlBulkLoad = sqlBulkLoad + ", " + errorfileName;
                 }
                 if (maxerrors > 0) {
-                  SqlBulkLoad = SqlBulkLoad + ", MAXERRORS=" + maxerrors;
+                  sqlBulkLoad = sqlBulkLoad + ", MAXERRORS=" + maxerrors;
                 }
                 if (batchsize > 0) {
-                  SqlBulkLoad = SqlBulkLoad + ", BATCHSIZE=" + batchsize;
+                  sqlBulkLoad = sqlBulkLoad + ", BATCHSIZE=" + batchsize;
                 }
                 if (rowsperbatch > 0) {
-                  SqlBulkLoad = SqlBulkLoad + ", ROWS_PER_BATCH=" + rowsperbatch;
+                  sqlBulkLoad = sqlBulkLoad + ", ROWS_PER_BATCH=" + rowsperbatch;
                 }
                 // End of Bulk command
-                SqlBulkLoad = SqlBulkLoad + ")";
+                sqlBulkLoad = sqlBulkLoad + ")";
 
                 try {
                   // Run the SQL
-                  db.execStatement(SqlBulkLoad);
+                  db.execStatement(sqlBulkLoad);
 
                   // Everything is OK...we can disconnect now
                   db.disconnect();
diff --git a/plugins/actions/mssqlbulkload/src/main/java/org/apache/hop/workflow/actions/mssqlbulkload/ActionMssqlBulkLoadDialog.java b/plugins/actions/mssqlbulkload/src/main/java/org/apache/hop/workflow/actions/mssqlbulkload/ActionMssqlBulkLoadDialog.java
index 7860b41..bac05f4 100644
--- a/plugins/actions/mssqlbulkload/src/main/java/org/apache/hop/workflow/actions/mssqlbulkload/ActionMssqlBulkLoadDialog.java
+++ b/plugins/actions/mssqlbulkload/src/main/java/org/apache/hop/workflow/actions/mssqlbulkload/ActionMssqlBulkLoadDialog.java
@@ -210,11 +210,11 @@ public class ActionMssqlBulkLoadDialog extends ActionDialog implements IActionDi
     wConnectionGroup.setText(
         BaseMessages.getString(PKG, "ActionMssqlBulkLoad.ConnectionGroup.Group.Label"));
 
-    FormLayout ConnectionGroupLayout = new FormLayout();
-    ConnectionGroupLayout.marginWidth = 10;
-    ConnectionGroupLayout.marginHeight = 10;
+    FormLayout connectionGroupLayout = new FormLayout();
+    connectionGroupLayout.marginWidth = 10;
+    connectionGroupLayout.marginHeight = 10;
 
-    wConnectionGroup.setLayout(ConnectionGroupLayout);
+    wConnectionGroup.setLayout(connectionGroupLayout);
 
     // Connection line
     wConnection = addConnectionLine(wConnectionGroup, wName, action.getDatabase(), lsMod);
@@ -319,10 +319,10 @@ public class ActionMssqlBulkLoadDialog extends ActionDialog implements IActionDi
     wDataFileGroup.setText(
         BaseMessages.getString(PKG, "ActionMssqlBulkLoad.DataFileGroup.Group.Label"));
 
-    FormLayout DataFileGroupLayout = new FormLayout();
-    DataFileGroupLayout.marginWidth = 10;
-    DataFileGroupLayout.marginHeight = 10;
-    wDataFileGroup.setLayout(DataFileGroupLayout);
+    FormLayout dataFileGroupLayout = new FormLayout();
+    dataFileGroupLayout.marginWidth = 10;
+    dataFileGroupLayout.marginHeight = 10;
+    wDataFileGroup.setLayout(dataFileGroupLayout);
 
     // Filename line
     // File
@@ -475,13 +475,13 @@ public class ActionMssqlBulkLoadDialog extends ActionDialog implements IActionDi
     CTabItem wAdvancedTab = new CTabItem(wTabFolder, SWT.NONE);
     wAdvancedTab.setText(BaseMessages.getString(PKG, "ActionMssqlBulkLoad.Tab.Advanced.Label"));
 
-    FormLayout AdvancedLayout = new FormLayout();
-    AdvancedLayout.marginWidth = 3;
-    AdvancedLayout.marginHeight = 3;
+    FormLayout advancedLayout = new FormLayout();
+    advancedLayout.marginWidth = 3;
+    advancedLayout.marginHeight = 3;
 
     Composite wAdvancedComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wAdvancedComp);
-    wAdvancedComp.setLayout(AdvancedLayout);
+    wAdvancedComp.setLayout(advancedLayout);
 
     // CodePage
     // CodePage
diff --git a/plugins/actions/mysqlbulkfile/src/main/java/org/apache/hop/workflow/actions/mysqlbulkfile/ActionMysqlBulkFile.java b/plugins/actions/mysqlbulkfile/src/main/java/org/apache/hop/workflow/actions/mysqlbulkfile/ActionMysqlBulkFile.java
index 58f180f..b3f5407 100644
--- a/plugins/actions/mysqlbulkfile/src/main/java/org/apache/hop/workflow/actions/mysqlbulkfile/ActionMysqlBulkFile.java
+++ b/plugins/actions/mysqlbulkfile/src/main/java/org/apache/hop/workflow/actions/mysqlbulkfile/ActionMysqlBulkFile.java
@@ -192,13 +192,13 @@ public class ActionMysqlBulkFile extends ActionBase implements Cloneable, IActio
   @Override
   public Result execute(Result previousResult, int nr) {
 
-    String LimitNbrLignes = "";
-    String ListOfColumn = "*";
+    String limitNbrLignes = "";
+    String listOfColumn = "*";
     String strHighPriority = "";
-    String OutDumpText = "";
-    String OptionEnclosed = "";
-    String FieldSeparator = "";
-    String LinesTerminated = "";
+    String outDumpText = "";
+    String optionEnclosed = "";
+    String fieldSeparator = "";
+    String linesTerminated = "";
 
     Result result = previousResult;
     result.setResult(false);
@@ -290,23 +290,23 @@ public class ActionMysqlBulkFile extends ActionBase implements Cloneable, IActio
 
               // Set the Limit lines
               if (Const.toInt(getRealLimitlines(), 0) > 0) {
-                LimitNbrLignes = "LIMIT " + getRealLimitlines();
+                limitNbrLignes = "LIMIT " + getRealLimitlines();
               }
 
               // Set list of Column, if null get all columns (*)
               if (getRealListColumn() != null) {
-                ListOfColumn = MysqlString(getRealListColumn());
+                listOfColumn = MysqlString(getRealListColumn());
               }
 
               // Fields separator
               if (getRealSeparator() != null && outDumpValue == 0) {
-                FieldSeparator =
+                fieldSeparator =
                     "FIELDS TERMINATED BY '" + Const.replace(getRealSeparator(), "'", "''") + "'";
               }
 
               // Lines Terminated by
               if (getRealLineterminated() != null && outDumpValue == 0) {
-                LinesTerminated =
+                linesTerminated =
                     "LINES TERMINATED BY '"
                         + Const.replace(getRealLineterminated(), "'", "''")
                         + "'";
@@ -319,10 +319,10 @@ public class ActionMysqlBulkFile extends ActionBase implements Cloneable, IActio
 
               if (getRealEnclosed() != null && outDumpValue == 0) {
                 if (isOptionEnclosed()) {
-                  OptionEnclosed = "OPTIONALLY ";
+                  optionEnclosed = "OPTIONALLY ";
                 }
-                OptionEnclosed =
-                    OptionEnclosed
+                optionEnclosed =
+                    optionEnclosed
                         + "ENCLOSED BY '"
                         + Const.replace(getRealEnclosed(), "'", "''")
                         + "'";
@@ -330,38 +330,38 @@ public class ActionMysqlBulkFile extends ActionBase implements Cloneable, IActio
 
               // OutFile or Dumpfile
               if (outDumpValue == 0) {
-                OutDumpText = "INTO OUTFILE";
+                outDumpText = "INTO OUTFILE";
               } else {
-                OutDumpText = "INTO DUMPFILE";
+                outDumpText = "INTO DUMPFILE";
               }
 
-              String FILEBulkFile =
+              String fileBulkFile =
                   "SELECT "
                       + strHighPriority
                       + " "
-                      + ListOfColumn
+                      + listOfColumn
                       + " "
-                      + OutDumpText
+                      + outDumpText
                       + " '"
                       + realFilename
                       + "' "
-                      + FieldSeparator
+                      + fieldSeparator
                       + " "
-                      + OptionEnclosed
+                      + optionEnclosed
                       + " "
-                      + LinesTerminated
+                      + linesTerminated
                       + " FROM "
                       + realTablename
                       + " "
-                      + LimitNbrLignes
+                      + limitNbrLignes
                       + " LOCK IN SHARE MODE";
 
               try {
                 if (log.isDetailed()) {
-                  logDetailed(FILEBulkFile);
+                  logDetailed(fileBulkFile);
                 }
                 // Run the SQL
-                PreparedStatement ps = db.prepareSql(FILEBulkFile);
+                PreparedStatement ps = db.prepareSql(fileBulkFile);
                 ps.execute();
 
                 // Everything is OK...we can disconnect now
@@ -466,8 +466,8 @@ public class ActionMysqlBulkFile extends ActionBase implements Cloneable, IActio
 
   @Override
   public String getRealFilename() {
-    String RealFile = resolve(getFilename());
-    return RealFile.replace('\\', '/');
+    String realFile = resolve(getFilename());
+    return realFile.replace('\\', '/');
   }
 
   public void setSeparator(String separator) {
@@ -542,18 +542,18 @@ public class ActionMysqlBulkFile extends ActionBase implements Cloneable, IActio
     /*
      * handle forbiden char like '
      */
-    String ReturnString = "";
+    String returnString = "";
     String[] split = listcolumns.split(",");
 
     for (int i = 0; i < split.length; i++) {
-      if (ReturnString.equals("")) {
-        ReturnString = "`" + Const.trim(split[i]) + "`";
+      if (returnString.equals("")) {
+        returnString = "`" + Const.trim(split[i]) + "`";
       } else {
-        ReturnString = ReturnString + ", `" + Const.trim(split[i]) + "`";
+        returnString = returnString + ", `" + Const.trim(split[i]) + "`";
       }
     }
 
-    return ReturnString;
+    return returnString;
   }
 
   @Override
diff --git a/plugins/actions/mysqlbulkload/src/main/java/org/apache/hop/workflow/actions/mysqlbulkload/ActionMysqlBulkLoad.java b/plugins/actions/mysqlbulkload/src/main/java/org/apache/hop/workflow/actions/mysqlbulkload/ActionMysqlBulkLoad.java
index cc2764d..c419a1a 100644
--- a/plugins/actions/mysqlbulkload/src/main/java/org/apache/hop/workflow/actions/mysqlbulkload/ActionMysqlBulkLoad.java
+++ b/plugins/actions/mysqlbulkload/src/main/java/org/apache/hop/workflow/actions/mysqlbulkload/ActionMysqlBulkLoad.java
@@ -203,13 +203,13 @@ public class ActionMysqlBulkLoad extends ActionBase implements Cloneable, IActio
 
   @Override
   public Result execute(Result previousResult, int nr) {
-    String ReplaceIgnore;
-    String IgnoreNbrLignes = "";
-    String ListOfColumn = "";
-    String LocalExec = "";
-    String PriorityText = "";
-    String LineTerminatedby = "";
-    String FieldTerminatedby = "";
+    String replaceIgnore;
+    String ignoreNbrLignes = "";
+    String listOfColumn = "";
+    String localExec = "";
+    String priorityText = "";
+    String lineTerminatedby = "";
+    String fieldTerminatedby = "";
 
     Result result = previousResult;
     result.setResult(false);
@@ -272,59 +272,59 @@ public class ActionMysqlBulkLoad extends ActionBase implements Cloneable, IActio
 
                 // Set the REPLACE or IGNORE
                 if (isReplacedata()) {
-                  ReplaceIgnore = "REPLACE";
+                  replaceIgnore = "REPLACE";
                 } else {
-                  ReplaceIgnore = "IGNORE";
+                  replaceIgnore = "IGNORE";
                 }
 
                 // Set the IGNORE LINES
                 if (Const.toInt(getRealIgnorelines(), 0) > 0) {
-                  IgnoreNbrLignes = "IGNORE " + getRealIgnorelines() + " LINES";
+                  ignoreNbrLignes = "IGNORE " + getRealIgnorelines() + " LINES";
                 }
 
                 // Set list of Column
                 if (getRealListattribut() != null) {
-                  ListOfColumn = "(" + MysqlString(getRealListattribut()) + ")";
+                  listOfColumn = "(" + MysqlString(getRealListattribut()) + ")";
                 }
 
                 // Local File execution
                 if (isLocalInfile()) {
-                  LocalExec = "LOCAL";
+                  localExec = "LOCAL";
                 }
 
                 // Prority
                 if (prorityvalue == 1) {
                   // LOW
-                  PriorityText = "LOW_PRIORITY";
+                  priorityText = "LOW_PRIORITY";
                 } else if (prorityvalue == 2) {
                   // CONCURRENT
-                  PriorityText = "CONCURRENT";
+                  priorityText = "CONCURRENT";
                 }
 
                 // Fields ....
                 if (getRealSeparator() != null
                     || getRealEnclosed() != null
                     || getRealEscaped() != null) {
-                  FieldTerminatedby = "FIELDS ";
+                  fieldTerminatedby = "FIELDS ";
 
                   if (getRealSeparator() != null) {
-                    FieldTerminatedby =
-                        FieldTerminatedby
+                    fieldTerminatedby =
+                        fieldTerminatedby
                             + "TERMINATED BY '"
                             + Const.replace(getRealSeparator(), "'", "''")
                             + "'";
                   }
                   if (getRealEnclosed() != null) {
-                    FieldTerminatedby =
-                        FieldTerminatedby
+                    fieldTerminatedby =
+                        fieldTerminatedby
                             + " ENCLOSED BY '"
                             + Const.replace(getRealEnclosed(), "'", "''")
                             + "'";
                   }
                   if (getRealEscaped() != null) {
 
-                    FieldTerminatedby =
-                        FieldTerminatedby
+                    fieldTerminatedby =
+                        fieldTerminatedby
                             + " ESCAPED BY '"
                             + Const.replace(getRealEscaped(), "'", "''")
                             + "'";
@@ -333,12 +333,12 @@ public class ActionMysqlBulkLoad extends ActionBase implements Cloneable, IActio
 
                 // LINES ...
                 if (getRealLinestarted() != null || getRealLineterminated() != null) {
-                  LineTerminatedby = "LINES ";
+                  lineTerminatedby = "LINES ";
 
                   // Line starting By
                   if (getRealLinestarted() != null) {
-                    LineTerminatedby =
-                        LineTerminatedby
+                    lineTerminatedby =
+                        lineTerminatedby
                             + "STARTING BY '"
                             + Const.replace(getRealLinestarted(), "'", "''")
                             + "'";
@@ -346,38 +346,38 @@ public class ActionMysqlBulkLoad extends ActionBase implements Cloneable, IActio
 
                   // Line terminating By
                   if (getRealLineterminated() != null) {
-                    LineTerminatedby =
-                        LineTerminatedby
+                    lineTerminatedby =
+                        lineTerminatedby
                             + " TERMINATED BY '"
                             + Const.replace(getRealLineterminated(), "'", "''")
                             + "'";
                   }
                 }
 
-                String SqlBulkLoad =
+                String sqlBulkLoad =
                     "LOAD DATA "
-                        + PriorityText
+                        + priorityText
                         + " "
-                        + LocalExec
+                        + localExec
                         + " INFILE '"
                         + realFilename.replace('\\', '/')
                         + "' "
-                        + ReplaceIgnore
+                        + replaceIgnore
                         + " INTO TABLE "
                         + realTablename
                         + " "
-                        + FieldTerminatedby
+                        + fieldTerminatedby
                         + " "
-                        + LineTerminatedby
+                        + lineTerminatedby
                         + " "
-                        + IgnoreNbrLignes
+                        + ignoreNbrLignes
                         + " "
-                        + ListOfColumn
+                        + listOfColumn
                         + ";";
 
                 try {
                   // Run the SQL
-                  db.execStatement(SqlBulkLoad);
+                  db.execStatement(sqlBulkLoad);
 
                   // Everything is OK...we can deconnect now
                   db.disconnect();
diff --git a/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpdecryptfiles/ActionPGPDecryptFiles.java b/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpdecryptfiles/ActionPGPDecryptFiles.java
index 425dced..3130907 100644
--- a/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpdecryptfiles/ActionPGPDecryptFiles.java
+++ b/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpdecryptfiles/ActionPGPDecryptFiles.java
@@ -312,7 +312,7 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
         }
       }
 
-      String MoveToFolder = resolve(destinationFolder);
+      String moveToFolder = resolve(destinationFolder);
       // Get source and destination files, also wildcard
       String[] vSourceFileFolder = sourceFileFolder;
       String[] vpassphrase = passphrase;
@@ -320,33 +320,33 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
       String[] vwildcard = wildcard;
 
       if (ifFileExists.equals("move_file")) {
-        if (Utils.isEmpty(MoveToFolder)) {
+        if (Utils.isEmpty(moveToFolder)) {
           logError(
               BaseMessages.getString(PKG, "ActionPGPDecryptFiles.Log.Error.MoveToFolderMissing"));
           return result;
         }
         FileObject folder = null;
         try {
-          folder = HopVfs.getFileObject(MoveToFolder);
+          folder = HopVfs.getFileObject(moveToFolder);
           if (!folder.exists()) {
             if (isDetailed()) {
               logDetailed(
                   BaseMessages.getString(
-                      PKG, "ActionPGPDecryptFiles.Log.Error.FolderMissing", MoveToFolder));
+                      PKG, "ActionPGPDecryptFiles.Log.Error.FolderMissing", moveToFolder));
             }
             if (createMoveToFolder) {
               folder.createFolder();
             } else {
               logError(
                   BaseMessages.getString(
-                      PKG, "ActionPGPDecryptFiles.Log.Error.FolderMissing", MoveToFolder));
+                      PKG, "ActionPGPDecryptFiles.Log.Error.FolderMissing", moveToFolder));
               return result;
             }
           }
           if (!folder.getType().equals(FileType.FOLDER)) {
             logError(
                 BaseMessages.getString(
-                    PKG, "ActionPGPDecryptFiles.Log.Error.NotFolder", MoveToFolder));
+                    PKG, "ActionPGPDecryptFiles.Log.Error.NotFolder", moveToFolder));
             return result;
           }
         } catch (Exception e) {
@@ -354,7 +354,7 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
               BaseMessages.getString(
                   PKG,
                   "ActionPGPDecryptFiles.Log.Error.GettingMoveToFolder",
-                  MoveToFolder,
+                  moveToFolder,
                   e.getMessage()));
           return result;
         } finally {
@@ -422,7 +422,7 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
                 vWildcardPrevious,
                 parentWorkflow,
                 result,
-                MoveToFolder)) {
+                moveToFolder)) {
               // The move process fail
               // Update Errors
               updateErrors();
@@ -473,7 +473,7 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
                 vwildcard[i],
                 parentWorkflow,
                 result,
-                MoveToFolder)) {
+                moveToFolder)) {
               // Update Errors
               updateErrors();
             }
@@ -544,12 +544,12 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
       String wildcard,
       IWorkflowEngine<WorkflowMeta> parentWorkflow,
       Result result,
-      String MoveToFolder) {
+      String moveToFolder) {
     boolean entrystatus = false;
     FileObject sourcefilefolder = null;
     FileObject destinationfilefolder = null;
     FileObject movetofolderfolder = null;
-    FileObject Currentfile = null;
+    FileObject currentfile = null;
 
     // Get real source, destination file and wildcard
     String realSourceFilefoldername = resolve(sourcefilefoldername);
@@ -560,8 +560,8 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
 
       sourcefilefolder = HopVfs.getFileObject(realSourceFilefoldername);
       destinationfilefolder = HopVfs.getFileObject(realDestinationFilefoldername);
-      if (!Utils.isEmpty(MoveToFolder)) {
-        movetofolderfolder = HopVfs.getFileObject(MoveToFolder);
+      if (!Utils.isEmpty(moveToFolder)) {
+        movetofolderfolder = HopVfs.getFileObject(moveToFolder);
       }
 
       if (sourcefilefolder.exists()) {
@@ -711,10 +711,10 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
                     return false;
                   }
                   // Fetch files in list one after one ...
-                  Currentfile = fileObjects[j];
+                  currentfile = fileObjects[j];
 
                   if (!DecryptOneFile(
-                      Currentfile,
+                      currentfile,
                       sourcefilefolder,
                       passPhrase,
                       realDestinationFilefoldername,
@@ -748,7 +748,7 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
           BaseMessages.getString(
               PKG,
               "ActionPGPDecryptFiles.Error.Exception.MoveProcess",
-              realSourceFilefoldername.toString(),
+              realSourceFilefoldername,
               destinationfilefolder.toString(),
               e.getMessage()));
       // Update Errors
@@ -768,9 +768,9 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
           /* Ignore */
         }
       }
-      if (Currentfile != null) {
+      if (currentfile != null) {
         try {
-          Currentfile.close();
+          currentfile.close();
         } catch (IOException ex) {
           /* Ignore */
         }
@@ -1005,7 +1005,7 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
   }
 
   private boolean DecryptOneFile(
-      FileObject Currentfile,
+      FileObject currentfile,
       FileObject sourcefilefolder,
       String passPhrase,
       String realDestinationFilefoldername,
@@ -1017,11 +1017,11 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
     FileObject filename = null;
 
     try {
-      if (!Currentfile.toString().equals(sourcefilefolder.toString())) {
+      if (!currentfile.toString().equals(sourcefilefolder.toString())) {
         // Pass over the Base folder itself
 
         // return destination short filename
-        String sourceshortfilename = Currentfile.getName().getBaseName();
+        String sourceshortfilename = currentfile.getName().getBaseName();
         String shortfilename = sourceshortfilename;
         try {
           shortfilename = getDestinationFilename(sourceshortfilename);
@@ -1030,7 +1030,7 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
               BaseMessages.getString(
                   PKG,
                   "ActionPGPDecryptFiles.Error.GettingFilename",
-                  Currentfile.getName().getBaseName(),
+                  currentfile.getName().getBaseName(),
                   e.toString()));
           return entrystatus;
         }
@@ -1039,8 +1039,9 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
         String shortFilenameFromBaseFolder = shortfilename;
         if (!isDoNotKeepFolderStructure()) {
           shortFilenameFromBaseFolder =
-              Currentfile.toString()
-                  .substring(sourcefilefolder.toString().length(), Currentfile.toString().length());
+              currentfile
+                  .toString()
+                  .substring(sourcefilefolder.toString().length(), currentfile.toString().length());
         }
         shortFilenameFromBaseFolder =
             shortFilenameFromBaseFolder.substring(
@@ -1052,17 +1053,17 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
             HopVfs.getFileObject(
                 realDestinationFilefoldername + Const.FILE_SEPARATOR + shortFilenameFromBaseFolder);
 
-        if (!Currentfile.getParent().toString().equals(sourcefilefolder.toString())) {
+        if (!currentfile.getParent().toString().equals(sourcefilefolder.toString())) {
 
           // Not in the Base Folder..Only if include sub folders
           if (includeSubFolders) {
             // Folders..only if include subfolders
-            if (Currentfile.getType() != FileType.FOLDER) {
+            if (currentfile.getType() != FileType.FOLDER) {
               if (GetFileWildcard(sourceshortfilename, realWildcard)) {
                 entrystatus =
                     DecryptFile(
                         shortfilename,
-                        Currentfile,
+                        currentfile,
                         passPhrase,
                         filename,
                         movetofolderfolder,
@@ -1074,13 +1075,13 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
         } else {
           // In the Base Folder...
           // Folders..only if include subfolders
-          if (Currentfile.getType() != FileType.FOLDER) {
+          if (currentfile.getType() != FileType.FOLDER) {
             // file...Check if exists
             if (GetFileWildcard(sourceshortfilename, realWildcard)) {
               entrystatus =
                   DecryptFile(
                       shortfilename,
-                      Currentfile,
+                      currentfile,
                       passPhrase,
                       filename,
                       movetofolderfolder,
@@ -1267,7 +1268,7 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
     return shortfilename;
   }
 
-  private String getMoveDestinationFilename(String shortsourcefilename, String DateFormat)
+  private String getMoveDestinationFilename(String shortsourcefilename, String dateFormat)
       throws Exception {
     String shortfilename = shortsourcefilename;
     int lenstring = shortsourcefilename.length();
@@ -1283,8 +1284,8 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
     SimpleDateFormat daf = new SimpleDateFormat();
     Date now = new Date();
 
-    if (DateFormat != null) {
-      daf.applyPattern(DateFormat);
+    if (dateFormat != null) {
+      daf.applyPattern(dateFormat);
       String dt = daf.format(now);
       shortfilename += dt;
     } else {
@@ -1365,8 +1366,8 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
     this.addDateBeforeExtension = addDateBeforeExtension;
   }
 
-  public void setAddMovedDateBeforeExtension(boolean AddMovedDateBeforeExtension) {
-    this.addMovedDateBeforeExtension = AddMovedDateBeforeExtension;
+  public void setAddMovedDateBeforeExtension(boolean addMovedDateBeforeExtension) {
+    this.addMovedDateBeforeExtension = addMovedDateBeforeExtension;
   }
 
   public boolean isSpecifyFormat() {
@@ -1377,8 +1378,8 @@ public class ActionPGPDecryptFiles extends ActionBase implements Cloneable, IAct
     this.specifyFormat = specifyFormat;
   }
 
-  public void setSpecifyMoveFormat(boolean SpecifyMoveFormat) {
-    this.specifyMoveFormat = SpecifyMoveFormat;
+  public void setSpecifyMoveFormat(boolean specifyMoveFormat) {
+    this.specifyMoveFormat = specifyMoveFormat;
   }
 
   public boolean isSpecifyMoveFormat() {
diff --git a/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpdecryptfiles/ActionPGPDecryptFilesDialog.java b/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpdecryptfiles/ActionPGPDecryptFilesDialog.java
index 6594dc7..0e96c58 100644
--- a/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpdecryptfiles/ActionPGPDecryptFilesDialog.java
+++ b/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpdecryptfiles/ActionPGPDecryptFilesDialog.java
@@ -45,9 +45,7 @@ import org.eclipse.swt.layout.FormData;
 import org.eclipse.swt.layout.FormLayout;
 import org.eclipse.swt.widgets.*;
 
-/**
- * This dialog allows you to edit the Move Files action settings.
- */
+/** This dialog allows you to edit the Move Files action settings. */
 public class ActionPGPDecryptFilesDialog extends ActionDialog implements IActionDialog {
   private static final Class<?> PKG = ActionPGPDecryptFiles.class; // For Translator
 
@@ -57,10 +55,10 @@ public class ActionPGPDecryptFilesDialog extends ActionDialog implements IAction
   private Text wName;
 
   private Label wlSourceFileFolder;
-  private Button wbSourceFileFolder,
-      wbDestinationFileFolder,
-      wbSourceDirectory,
-      wbDestinationDirectory;
+  private Button wbSourceFileFolder;
+  private Button wbDestinationFileFolder;
+  private Button wbSourceDirectory;
+  private Button wbDestinationDirectory;
 
   private TextVar wSourceFileFolder;
 
@@ -642,13 +640,13 @@ public class ActionPGPDecryptFilesDialog extends ActionDialog implements IAction
     wDestinationFileTab.setText(
         BaseMessages.getString(PKG, "ActionPGPDecryptFiles.DestinationFileTab.Label"));
 
-    FormLayout DestcontentLayout = new FormLayout();
-    DestcontentLayout.marginWidth = 3;
-    DestcontentLayout.marginHeight = 3;
+    FormLayout destcontentLayout = new FormLayout();
+    destcontentLayout.marginWidth = 3;
+    destcontentLayout.marginHeight = 3;
 
     Composite wDestinationFileComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wDestinationFileComp);
-    wDestinationFileComp.setLayout(DestcontentLayout);
+    wDestinationFileComp.setLayout(destcontentLayout);
 
     // DestinationFile grouping?
     // ////////////////////////
@@ -940,10 +938,10 @@ public class ActionPGPDecryptFilesDialog extends ActionDialog implements IAction
     wMoveToGroup.setText(
         BaseMessages.getString(PKG, "ActionPGPDecryptFiles.GroupMoveToGroup.Label"));
 
-    FormLayout MovetoLayoutFile = new FormLayout();
-    MovetoLayoutFile.marginWidth = 10;
-    MovetoLayoutFile.marginHeight = 10;
-    wMoveToGroup.setLayout(MovetoLayoutFile);
+    FormLayout movetoLayoutFile = new FormLayout();
+    movetoLayoutFile.marginWidth = 10;
+    movetoLayoutFile.marginHeight = 10;
+    wMoveToGroup.setLayout(movetoLayoutFile);
 
     // DestinationFolder line
     wlDestinationFolder = new Label(wMoveToGroup, SWT.RIGHT);
@@ -1454,7 +1452,6 @@ public class ActionPGPDecryptFilesDialog extends ActionDialog implements IAction
 
     wlMovedDateTimeFormat.setEnabled(wSpecifyMoveFormat.getSelection());
     wMovedDateTimeFormat.setEnabled(wSpecifyMoveFormat.getSelection());
-
   }
 
   private void RefreshArgFromPrevious() {
diff --git a/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpencryptfiles/ActionPGPEncryptFiles.java b/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpencryptfiles/ActionPGPEncryptFiles.java
index b609fc7..1444f5a 100644
--- a/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpencryptfiles/ActionPGPEncryptFiles.java
+++ b/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpencryptfiles/ActionPGPEncryptFiles.java
@@ -350,7 +350,7 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
         }
       }
 
-      String MoveToFolder = resolve(destinationFolder);
+      String moveToFolder = resolve(destinationFolder);
       // Get source and destination files, also wildcard
       String[] vSourceFileFolder = sourceFileFolder;
       String[] vuserid = userId;
@@ -358,7 +358,7 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
       String[] vwildcard = wildcard;
 
       if (ifFileExists.equals("move_file")) {
-        if (Utils.isEmpty(MoveToFolder)) {
+        if (Utils.isEmpty(moveToFolder)) {
           logError(
               toString(),
               BaseMessages.getString(PKG, "ActionPGPEncryptFiles.Log.Error.MoveToFolderMissing"));
@@ -366,26 +366,26 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
         }
         FileObject folder = null;
         try {
-          folder = HopVfs.getFileObject(MoveToFolder);
+          folder = HopVfs.getFileObject(moveToFolder);
           if (!folder.exists()) {
             if (isDetailed()) {
               logDetailed(
                   BaseMessages.getString(
-                      PKG, "ActionPGPEncryptFiles.Log.Error.FolderMissing", MoveToFolder));
+                      PKG, "ActionPGPEncryptFiles.Log.Error.FolderMissing", moveToFolder));
             }
             if (createMoveToFolder) {
               folder.createFolder();
             } else {
               logError(
                   BaseMessages.getString(
-                      PKG, "ActionPGPEncryptFiles.Log.Error.FolderMissing", MoveToFolder));
+                      PKG, "ActionPGPEncryptFiles.Log.Error.FolderMissing", moveToFolder));
               return result;
             }
           }
           if (!folder.getType().equals(FileType.FOLDER)) {
             logError(
                 BaseMessages.getString(
-                    PKG, "ActionPGPEncryptFiles.Log.Error.NotFolder", MoveToFolder));
+                    PKG, "ActionPGPEncryptFiles.Log.Error.NotFolder", moveToFolder));
             return result;
           }
         } catch (Exception e) {
@@ -393,7 +393,7 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
               BaseMessages.getString(
                   PKG,
                   "ActionPGPEncryptFiles.Log.Error.GettingMoveToFolder",
-                  MoveToFolder,
+                  moveToFolder,
                   e.getMessage()));
           return result;
         } finally {
@@ -462,7 +462,7 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
                 vWildcardPrevious,
                 parentWorkflow,
                 result,
-                MoveToFolder)) {
+                moveToFolder)) {
               // The process fail
               // Update Errors
               updateErrors();
@@ -514,7 +514,7 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
                 vwildcard[i],
                 parentWorkflow,
                 result,
-                MoveToFolder)) {
+                moveToFolder)) {
               // Update Errors
               updateErrors();
             }
@@ -611,12 +611,12 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
       String wildcard,
       IWorkflowEngine<WorkflowMeta> parentWorkflow,
       Result result,
-      String MoveToFolder) {
+      String moveToFolder) {
     boolean entrystatus = false;
     FileObject sourcefilefolder = null;
     FileObject destinationfilefolder = null;
     FileObject movetofolderfolder = null;
-    FileObject Currentfile = null;
+    FileObject currentfile = null;
 
     // Get real source, destination file and wildcard
     String realSourceFilefoldername = resolve(sourcefilefoldername);
@@ -628,8 +628,8 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
 
       sourcefilefolder = HopVfs.getFileObject(realSourceFilefoldername);
       destinationfilefolder = HopVfs.getFileObject(realDestinationFilefoldername);
-      if (!Utils.isEmpty(MoveToFolder)) {
-        movetofolderfolder = HopVfs.getFileObject(MoveToFolder);
+      if (!Utils.isEmpty(moveToFolder)) {
+        movetofolderfolder = HopVfs.getFileObject(moveToFolder);
       }
 
       if (sourcefilefolder.exists()) {
@@ -782,11 +782,11 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
                     return false;
                   }
                   // Fetch files in list one after one ...
-                  Currentfile = fileObjects[j];
+                  currentfile = fileObjects[j];
 
                   if (!EncryptOneFile(
                       actionType,
-                      Currentfile,
+                      currentfile,
                       sourcefilefolder,
                       realuserID,
                       realDestinationFilefoldername,
@@ -820,7 +820,7 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
           BaseMessages.getString(
               PKG,
               "ActionPGPEncryptFiles.Error.Exception.MoveProcess",
-              realSourceFilefoldername.toString(),
+              realSourceFilefoldername,
               destinationfilefolder.toString(),
               e.getMessage()));
       // Update Errors
@@ -840,9 +840,9 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
           /* Ignore */
         }
       }
-      if (Currentfile != null) {
+      if (currentfile != null) {
         try {
-          Currentfile.close();
+          currentfile.close();
         } catch (IOException ex) {
           /* Ignore */
         }
@@ -1078,7 +1078,7 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
 
   private boolean EncryptOneFile(
       int actionType,
-      FileObject Currentfile,
+      FileObject currentfile,
       FileObject sourcefilefolder,
       String userID,
       String realDestinationFilefoldername,
@@ -1090,11 +1090,11 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
     FileObject filename = null;
 
     try {
-      if (!Currentfile.toString().equals(sourcefilefolder.toString())) {
+      if (!currentfile.toString().equals(sourcefilefolder.toString())) {
         // Pass over the Base folder itself
 
         // return destination short filename
-        String sourceshortfilename = Currentfile.getName().getBaseName();
+        String sourceshortfilename = currentfile.getName().getBaseName();
         String shortfilename = sourceshortfilename;
         try {
           shortfilename = getDestinationFilename(sourceshortfilename);
@@ -1103,7 +1103,7 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
               BaseMessages.getString(
                   PKG,
                   "ActionPGPEncryptFiles.Error.GettingFilename",
-                  Currentfile.getName().getBaseName(),
+                  currentfile.getName().getBaseName(),
                   e.toString()));
           return entrystatus;
         }
@@ -1112,8 +1112,9 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
         String shortFilenameFromBaseFolder = shortfilename;
         if (!isDoNotKeepFolderStructure()) {
           shortFilenameFromBaseFolder =
-              Currentfile.toString()
-                  .substring(sourcefilefolder.toString().length(), Currentfile.toString().length());
+              currentfile
+                  .toString()
+                  .substring(sourcefilefolder.toString().length(), currentfile.toString().length());
         }
         shortFilenameFromBaseFolder =
             shortFilenameFromBaseFolder.substring(
@@ -1125,19 +1126,19 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
             HopVfs.getFileObject(
                 realDestinationFilefoldername + Const.FILE_SEPARATOR + shortFilenameFromBaseFolder);
 
-        if (!Currentfile.getParent().toString().equals(sourcefilefolder.toString())) {
+        if (!currentfile.getParent().toString().equals(sourcefilefolder.toString())) {
 
           // Not in the Base Folder..Only if include sub folders
           if (includeSubFolders) {
             // Folders..only if include subfolders
-            if (Currentfile.getType() != FileType.FOLDER) {
+            if (currentfile.getType() != FileType.FOLDER) {
 
               if (GetFileWildcard(sourceshortfilename, realWildcard)) {
                 entrystatus =
                     EncryptFile(
                         actionType,
                         shortfilename,
-                        Currentfile,
+                        currentfile,
                         userID,
                         filename,
                         movetofolderfolder,
@@ -1149,14 +1150,14 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
         } else {
           // In the Base Folder...
           // Folders..only if include subfolders
-          if (Currentfile.getType() != FileType.FOLDER) {
+          if (currentfile.getType() != FileType.FOLDER) {
             // file...Check if exists
             if (GetFileWildcard(sourceshortfilename, realWildcard)) {
               entrystatus =
                   EncryptFile(
                       actionType,
                       shortfilename,
-                      Currentfile,
+                      currentfile,
                       userID,
                       filename,
                       movetofolderfolder,
@@ -1343,7 +1344,7 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
     return shortfilename;
   }
 
-  private String getMoveDestinationFilename(String shortsourcefilename, String DateFormat)
+  private String getMoveDestinationFilename(String shortsourcefilename, String dateFormat)
       throws Exception {
     String shortfilename = shortsourcefilename;
     int lenstring = shortsourcefilename.length();
@@ -1359,8 +1360,8 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
     SimpleDateFormat daf = new SimpleDateFormat();
     Date now = new Date();
 
-    if (DateFormat != null) {
-      daf.applyPattern(DateFormat);
+    if (dateFormat != null) {
+      daf.applyPattern(dateFormat);
       String dt = daf.format(now);
       shortfilename += dt;
     } else {
@@ -1449,8 +1450,8 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
     this.addDateBeforeExtension = addDateBeforeExtension;
   }
 
-  public void setAddMovedDateBeforeExtension(boolean AddMovedDateBeforeExtension) {
-    this.addMovedDateBeforeExtension = AddMovedDateBeforeExtension;
+  public void setAddMovedDateBeforeExtension(boolean addMovedDateBeforeExtension) {
+    this.addMovedDateBeforeExtension = addMovedDateBeforeExtension;
   }
 
   public boolean isSpecifyFormat() {
@@ -1461,8 +1462,8 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
     this.specifyFormat = specifyFormat;
   }
 
-  public void setSpecifyMoveFormat(boolean SpecifyMoveFormat) {
-    this.specifyMoveFormat = SpecifyMoveFormat;
+  public void setSpecifyMoveFormat(boolean specifyMoveFormat) {
+    this.specifyMoveFormat = specifyMoveFormat;
   }
 
   public boolean isSpecifyMoveFormat() {
@@ -1513,8 +1514,8 @@ public class ActionPGPEncryptFiles extends ActionBase implements Cloneable, IAct
     return gpgLocation;
   }
 
-  public void setDoNotKeepFolderStructure(boolean DoNotKeepFolderStructure) {
-    this.doNotKeepFolderStructure = DoNotKeepFolderStructure;
+  public void setDoNotKeepFolderStructure(boolean doNotKeepFolderStructure) {
+    this.doNotKeepFolderStructure = doNotKeepFolderStructure;
   }
 
   public void setIncludeSubFolders(boolean includeSubFolders) {
diff --git a/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpencryptfiles/ActionPGPEncryptFilesDialog.java b/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpencryptfiles/ActionPGPEncryptFilesDialog.java
index 96791db..ef8b31d 100644
--- a/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpencryptfiles/ActionPGPEncryptFilesDialog.java
+++ b/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpencryptfiles/ActionPGPEncryptFilesDialog.java
@@ -55,10 +55,10 @@ public class ActionPGPEncryptFilesDialog extends ActionDialog implements IAction
   private Text wName;
 
   private Label wlSourceFileFolder;
-  private Button wbSourceFileFolder,
-      wbDestinationFileFolder,
-      wbSourceDirectory,
-      wbDestinationDirectory;
+  private Button wbSourceFileFolder;
+  private Button wbDestinationFileFolder;
+  private Button wbSourceDirectory;
+  private Button wbDestinationDirectory;
 
   private TextVar wSourceFileFolder;
 
@@ -669,13 +669,13 @@ public class ActionPGPEncryptFilesDialog extends ActionDialog implements IAction
     wDestinationFileTab.setText(
         BaseMessages.getString(PKG, "ActionPGPEncryptFiles.DestinationFileTab.Label"));
 
-    FormLayout DestcontentLayout = new FormLayout();
-    DestcontentLayout.marginWidth = 3;
-    DestcontentLayout.marginHeight = 3;
+    FormLayout destcontentLayout = new FormLayout();
+    destcontentLayout.marginWidth = 3;
+    destcontentLayout.marginHeight = 3;
 
     Composite wDestinationFileComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wDestinationFileComp);
-    wDestinationFileComp.setLayout(DestcontentLayout);
+    wDestinationFileComp.setLayout(destcontentLayout);
 
     // DestinationFile grouping?
     // ////////////////////////
@@ -966,10 +966,10 @@ public class ActionPGPEncryptFilesDialog extends ActionDialog implements IAction
     wMoveToGroup.setText(
         BaseMessages.getString(PKG, "ActionPGPEncryptFiles.GroupMoveToGroup.Label"));
 
-    FormLayout MovetoLayoutFile = new FormLayout();
-    MovetoLayoutFile.marginWidth = 10;
-    MovetoLayoutFile.marginHeight = 10;
-    wMoveToGroup.setLayout(MovetoLayoutFile);
+    FormLayout movetoLayoutFile = new FormLayout();
+    movetoLayoutFile.marginWidth = 10;
+    movetoLayoutFile.marginHeight = 10;
+    wMoveToGroup.setLayout(movetoLayoutFile);
 
     // DestinationFolder line
     wlDestinationFolder = new Label(wMoveToGroup, SWT.RIGHT);
diff --git a/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpverify/ActionPGPVerifyDialog.java b/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpverify/ActionPGPVerifyDialog.java
index 92aaaa4..601e4cc 100644
--- a/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpverify/ActionPGPVerifyDialog.java
+++ b/plugins/actions/pgpfiles/src/main/java/org/apache/hop/workflow/actions/pgpverify/ActionPGPVerifyDialog.java
@@ -132,11 +132,11 @@ public class ActionPGPVerifyDialog extends ActionDialog implements IActionDialog
     props.setLook(wSettings);
     wSettings.setText(BaseMessages.getString(PKG, "ActionPGPVerify.Settings.Group.Label"));
 
-    FormLayout SettingsgroupLayout = new FormLayout();
-    SettingsgroupLayout.marginWidth = 10;
-    SettingsgroupLayout.marginHeight = 10;
+    FormLayout settingsgroupLayout = new FormLayout();
+    settingsgroupLayout.marginWidth = 10;
+    settingsgroupLayout.marginHeight = 10;
 
-    wSettings.setLayout(SettingsgroupLayout);
+    wSettings.setLayout(settingsgroupLayout);
 
     // GPGLocation line
     Label wlGPGLocation = new Label(wSettings, SWT.RIGHT);
diff --git a/plugins/actions/ping/src/main/java/org/apache/hop/workflow/actions/ping/ActionPing.java b/plugins/actions/ping/src/main/java/org/apache/hop/workflow/actions/ping/ActionPing.java
index 46b32c0..029cc24 100644
--- a/plugins/actions/ping/src/main/java/org/apache/hop/workflow/actions/ping/ActionPing.java
+++ b/plugins/actions/ping/src/main/java/org/apache/hop/workflow/actions/ping/ActionPing.java
@@ -59,8 +59,8 @@ public class ActionPing extends ActionBase implements Cloneable, IAction {
   private String timeout;
   public String defaultTimeOut = "3000";
   private String nbrPackets;
-  private String Windows_CHAR = "-n";
-  private String NIX_CHAR = "-c";
+  private static final String WINDOWS_CHAR = "-n";
+  private static final String NIX_CHAR = "-c";
 
   public String classicPing = "classicPing";
   public int iclassicPing = 0;
@@ -275,18 +275,18 @@ public class ActionPing extends ActionBase implements Cloneable, IAction {
     boolean retval = false;
     try {
       String lignePing = "";
-      String CmdPing = "ping ";
+      String cmdPing = "ping ";
       if (Const.isWindows()) {
-        CmdPing += hostname + " " + Windows_CHAR + " " + nrpackets;
+        cmdPing += hostname + " " + WINDOWS_CHAR + " " + nrpackets;
       } else {
-        CmdPing += hostname + " " + NIX_CHAR + " " + nrpackets;
+        cmdPing += hostname + " " + NIX_CHAR + " " + nrpackets;
       }
 
       if (log.isDetailed()) {
         logDetailed(BaseMessages.getString(PKG, "ActionPing.NbrPackets.Label", "" + nrpackets));
-        logDetailed(BaseMessages.getString(PKG, "ActionPing.ExecClassicPing.Label", CmdPing));
+        logDetailed(BaseMessages.getString(PKG, "ActionPing.ExecClassicPing.Label", cmdPing));
       }
-      Process processPing = Runtime.getRuntime().exec(CmdPing);
+      Process processPing = Runtime.getRuntime().exec(cmdPing);
       try {
         processPing.waitFor();
       } catch (InterruptedException e) {
diff --git a/plugins/actions/pipeline/src/main/java/org/apache/hop/workflow/actions/pipeline/ActionPipeline.java b/plugins/actions/pipeline/src/main/java/org/apache/hop/workflow/actions/pipeline/ActionPipeline.java
index a4d4ce3..d0cde75 100644
--- a/plugins/actions/pipeline/src/main/java/org/apache/hop/workflow/actions/pipeline/ActionPipeline.java
+++ b/plugins/actions/pipeline/src/main/java/org/apache/hop/workflow/actions/pipeline/ActionPipeline.java
@@ -95,8 +95,10 @@ public class ActionPipeline extends ActionBase implements Cloneable, IAction {
 
   public boolean setAppendLogfile;
 
-  public String logfile, logext;
-  public boolean addDate, addTime;
+  public String logfile;
+  public String logext;
+  public boolean addDate;
+  public boolean addTime;
 
   public LogLevel logFileLevel;
 
diff --git a/plugins/actions/repeat/src/main/java/org/apache/hop/workflow/actions/repeat/EndRepeatDialog.java b/plugins/actions/repeat/src/main/java/org/apache/hop/workflow/actions/repeat/EndRepeatDialog.java
index e2770f8..5233b2a 100644
--- a/plugins/actions/repeat/src/main/java/org/apache/hop/workflow/actions/repeat/EndRepeatDialog.java
+++ b/plugins/actions/repeat/src/main/java/org/apache/hop/workflow/actions/repeat/EndRepeatDialog.java
@@ -37,7 +37,7 @@ import org.eclipse.swt.widgets.*;
 
 public class EndRepeatDialog extends ActionDialog implements IActionDialog {
 
-  private static Class<?> PKG = EndRepeatDialog.class; // For Translator
+  private static final Class<?> PKG = EndRepeatDialog.class; // For Translator
 
   private Shell shell;
 
diff --git a/plugins/actions/repeat/src/main/java/org/apache/hop/workflow/actions/repeat/RepeatDialog.java b/plugins/actions/repeat/src/main/java/org/apache/hop/workflow/actions/repeat/RepeatDialog.java
index c1d356f..4a096be 100644
--- a/plugins/actions/repeat/src/main/java/org/apache/hop/workflow/actions/repeat/RepeatDialog.java
+++ b/plugins/actions/repeat/src/main/java/org/apache/hop/workflow/actions/repeat/RepeatDialog.java
@@ -51,7 +51,7 @@ import java.util.List;
 
 public class RepeatDialog extends ActionDialog implements IActionDialog {
 
-  private static Class<?> PKG = RepeatDialog.class; // For Translator
+  private static final Class<?> PKG = RepeatDialog.class; // For Translator
 
   private static final String COLON_SEPARATOR = " : ";
 
@@ -61,14 +61,12 @@ public class RepeatDialog extends ActionDialog implements IActionDialog {
 
   private Text wName;
   private TextVar wFilename;
-  private Button wbbFilename; // Browse for a file
   private TextVar wVariableName;
   private TextVar wVariableValue;
   private TextVar wDelay;
   private Button wKeepValues;
   private TableView wParameters;
 
-  private Group wLogFileGroup;
   private Button wLogFileEnabled;
   private Label wlLogFileBase;
   private TextVar wLogFileBase;
@@ -86,8 +84,6 @@ public class RepeatDialog extends ActionDialog implements IActionDialog {
   private TextVar wLogFileUpdateInterval;
   private ComboVar wRunConfiguration;
 
-  private Button wOK, wCancel;
-
   public RepeatDialog(
       Shell parent, IAction action, WorkflowMeta workflowMeta, IVariables variables) {
     super(parent, workflowMeta, variables);
@@ -145,7 +141,8 @@ public class RepeatDialog extends ActionDialog implements IActionDialog {
 
     // The filename browse button
     //
-    wbbFilename = new Button(shell, SWT.PUSH | SWT.CENTER);
+    // Browse for a file
+    Button wbbFilename = new Button(shell, SWT.PUSH | SWT.CENTER);
     props.setLook(wbbFilename);
     wbbFilename.setText(BaseMessages.getString(PKG, "System.Button.Browse"));
     wbbFilename.setToolTipText(
@@ -251,7 +248,7 @@ public class RepeatDialog extends ActionDialog implements IActionDialog {
     wKeepValues.setLayoutData(fdKeepValues);
     lastControl = wlKeepValues;
 
-    wLogFileGroup = new Group(shell, SWT.SHADOW_NONE);
+    Group wLogFileGroup = new Group(shell, SWT.SHADOW_NONE);
     props.setLook(wLogFileGroup);
     wLogFileGroup.setText("Logging file");
     FormLayout logFileGroupLayout = new FormLayout();
@@ -421,10 +418,10 @@ public class RepeatDialog extends ActionDialog implements IActionDialog {
 
     // Add buttons first, then the script field can use dynamic sizing
     //
-    wOK = new Button(shell, SWT.PUSH);
+    Button wOK = new Button(shell, SWT.PUSH);
     wOK.setText(BaseMessages.getString(PKG, "System.Button.OK"));
     wOK.addListener(SWT.Selection, e -> ok());
-    wCancel = new Button(shell, SWT.PUSH);
+    Button wCancel = new Button(shell, SWT.PUSH);
     wCancel.setText(BaseMessages.getString(PKG, "System.Button.Cancel"));
     wCancel.addListener(SWT.Selection, e -> cancel());
 
diff --git a/plugins/actions/sendnagiospassivecheck/src/main/java/org/apache/hop/workflow/actions/sendnagiospassivecheck/ActionSendNagiosPassiveCheckDialog.java b/plugins/actions/sendnagiospassivecheck/src/main/java/org/apache/hop/workflow/actions/sendnagiospassivecheck/ActionSendNagiosPassiveCheckDialog.java
index dbb1e13..a294c79 100644
--- a/plugins/actions/sendnagiospassivecheck/src/main/java/org/apache/hop/workflow/actions/sendnagiospassivecheck/ActionSendNagiosPassiveCheckDialog.java
+++ b/plugins/actions/sendnagiospassivecheck/src/main/java/org/apache/hop/workflow/actions/sendnagiospassivecheck/ActionSendNagiosPassiveCheckDialog.java
@@ -158,11 +158,11 @@ public class ActionSendNagiosPassiveCheckDialog extends ActionDialog implements
     wServerSettings.setText(
         BaseMessages.getString(PKG, "ActionSendNagiosPassiveCheck.ServerSettings.Group.Label"));
 
-    FormLayout ServerSettingsgroupLayout = new FormLayout();
-    ServerSettingsgroupLayout.marginWidth = 10;
-    ServerSettingsgroupLayout.marginHeight = 10;
+    FormLayout serverSettingsgroupLayout = new FormLayout();
+    serverSettingsgroupLayout.marginWidth = 10;
+    serverSettingsgroupLayout.marginHeight = 10;
 
-    wServerSettings.setLayout(ServerSettingsgroupLayout);
+    wServerSettings.setLayout(serverSettingsgroupLayout);
 
     // ServerName line
     wServerName =
@@ -268,10 +268,10 @@ public class ActionSendNagiosPassiveCheckDialog extends ActionDialog implements
     props.setLook(wSenderSettings);
     wSenderSettings.setText(
         BaseMessages.getString(PKG, "ActionSendNagiosPassiveCheck.SenderSettings.Group.Label"));
-    FormLayout SenderSettingsgroupLayout = new FormLayout();
-    SenderSettingsgroupLayout.marginWidth = 10;
-    SenderSettingsgroupLayout.marginHeight = 10;
-    wSenderSettings.setLayout(SenderSettingsgroupLayout);
+    FormLayout senderSettingsgroupLayout = new FormLayout();
+    senderSettingsgroupLayout.marginWidth = 10;
+    senderSettingsgroupLayout.marginHeight = 10;
+    wSenderSettings.setLayout(senderSettingsgroupLayout);
 
     // SenderServerName line
     wSenderServerName =
@@ -369,10 +369,10 @@ public class ActionSendNagiosPassiveCheckDialog extends ActionDialog implements
     props.setLook(wMessageGroup);
     wMessageGroup.setText(
         BaseMessages.getString(PKG, "ActionSendNagiosPassiveCheck.MessageGroup.Group.Label"));
-    FormLayout MessageGroupgroupLayout = new FormLayout();
-    MessageGroupgroupLayout.marginWidth = 10;
-    MessageGroupgroupLayout.marginHeight = 10;
-    wMessageGroup.setLayout(MessageGroupgroupLayout);
+    FormLayout messageGroupgroupLayout = new FormLayout();
+    messageGroupgroupLayout.marginWidth = 10;
+    messageGroupgroupLayout.marginHeight = 10;
+    wMessageGroup.setLayout(messageGroupgroupLayout);
 
     // Message line
     Label wlMessage = new Label(wMessageGroup, SWT.RIGHT);
diff --git a/plugins/actions/shell/src/main/java/org/apache/hop/workflow/actions/shell/ActionShell.java b/plugins/actions/shell/src/main/java/org/apache/hop/workflow/actions/shell/ActionShell.java
index 71a9dec..5fb811e 100644
--- a/plugins/actions/shell/src/main/java/org/apache/hop/workflow/actions/shell/ActionShell.java
+++ b/plugins/actions/shell/src/main/java/org/apache/hop/workflow/actions/shell/ActionShell.java
@@ -74,8 +74,10 @@ public class ActionShell extends ActionBase implements Cloneable, IAction {
 
   public boolean setLogfile;
 
-  public String logfile, logext;
-  public boolean addDate, addTime;
+  public String logfile;
+  public String logext;
+  public boolean addDate;
+  public boolean addTime;
 
   public LogLevel logFileLevel;
 
diff --git a/plugins/actions/shell/src/main/java/org/apache/hop/workflow/actions/shell/ActionShellDialog.java b/plugins/actions/shell/src/main/java/org/apache/hop/workflow/actions/shell/ActionShellDialog.java
index 1b86c92..71a780b 100644
--- a/plugins/actions/shell/src/main/java/org/apache/hop/workflow/actions/shell/ActionShellDialog.java
+++ b/plugins/actions/shell/src/main/java/org/apache/hop/workflow/actions/shell/ActionShellDialog.java
@@ -104,11 +104,15 @@ public class ActionShellDialog extends ActionDialog implements IActionDialog {
 
   private ActionShell action;
 
-  private boolean backupChanged, backupLogfile, backupDate, backupTime;
+  private boolean backupChanged;
+  private boolean backupLogfile;
+  private boolean backupDate;
+  private boolean backupTime;
 
   private Label wlAppendLogfile;
 
-  private Button wAppendLogfile, wInsertScript;
+  private Button wAppendLogfile;
+  private Button wInsertScript;
 
   private Display display;
 
@@ -573,13 +577,13 @@ public class ActionShellDialog extends ActionDialog implements IActionDialog {
     CTabItem wScriptTab = new CTabItem(wTabFolder, SWT.NONE);
     wScriptTab.setText(BaseMessages.getString(PKG, "ActionShell.Tab.Script.Label"));
 
-    FormLayout ScriptLayout = new FormLayout();
-    ScriptLayout.marginWidth = 3;
-    ScriptLayout.marginHeight = 3;
+    FormLayout scriptLayout = new FormLayout();
+    scriptLayout.marginWidth = 3;
+    scriptLayout.marginHeight = 3;
 
     Composite wScriptComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wScriptComp);
-    wScriptComp.setLayout(ScriptLayout);
+    wScriptComp.setLayout(scriptLayout);
 
     // Script line
 
diff --git a/plugins/actions/simpleeval/src/main/java/org/apache/hop/workflow/actions/simpleeval/ActionSimpleEvalDialog.java b/plugins/actions/simpleeval/src/main/java/org/apache/hop/workflow/actions/simpleeval/ActionSimpleEvalDialog.java
index 0eef7fc..2f01cd0 100644
--- a/plugins/actions/simpleeval/src/main/java/org/apache/hop/workflow/actions/simpleeval/ActionSimpleEvalDialog.java
+++ b/plugins/actions/simpleeval/src/main/java/org/apache/hop/workflow/actions/simpleeval/ActionSimpleEvalDialog.java
@@ -61,7 +61,9 @@ public class ActionSimpleEvalDialog extends ActionDialog implements IActionDialo
   private Label wlSuccessCondition;
   private Label wlFieldType;
   private Label wlMask;
-  private CCombo wSuccessCondition, wValueType, wFieldType;
+  private CCombo wSuccessCondition;
+  private CCombo wValueType;
+  private CCombo wFieldType;
   private ComboVar wMask;
 
   private Label wlSuccessNumberCondition;
diff --git a/plugins/actions/snmptrap/src/main/java/org/apache/hop/workflow/actions/snmptrap/ActionSNMPTrap.java b/plugins/actions/snmptrap/src/main/java/org/apache/hop/workflow/actions/snmptrap/ActionSNMPTrap.java
index 27751d3..7e50f5b 100644
--- a/plugins/actions/snmptrap/src/main/java/org/apache/hop/workflow/actions/snmptrap/ActionSNMPTrap.java
+++ b/plugins/actions/snmptrap/src/main/java/org/apache/hop/workflow/actions/snmptrap/ActionSNMPTrap.java
@@ -69,13 +69,13 @@ public class ActionSNMPTrap extends ActionBase implements Cloneable, IAction {
   private String engineid;
 
   /** Default retries */
-  private static int DEFAULT_RETRIES = 1;
+  private static final int DEFAULT_RETRIES = 1;
 
   /** Default timeout to 500 milliseconds */
-  private static int DEFAULT_TIME_OUT = 5000;
+  private static final int DEFAULT_TIME_OUT = 5000;
 
   /** Default port */
-  public static int DEFAULT_PORT = 162;
+  public static final int DEFAULT_PORT = 162;
 
   public static final String[] targetTypeDesc =
       new String[] {
@@ -293,7 +293,7 @@ public class ActionSNMPTrap extends ActionBase implements Cloneable, IAction {
 
     String servername = resolve(serverName);
     int nrPort = Const.toInt(resolve("" + port), DEFAULT_PORT);
-    String Oid = resolve(oid);
+    String oid = resolve(this.oid);
     int timeOut = Const.toInt(resolve("" + timeout), DEFAULT_TIME_OUT);
     int retry = Const.toInt(resolve("" + nrretry), 1);
     String messageString = resolve(message);
@@ -330,8 +330,8 @@ public class ActionSNMPTrap extends ActionBase implements Cloneable, IAction {
         // create the PDU
         pdu1.setGenericTrap(6);
         pdu1.setSpecificTrap(PDUv1.ENTERPRISE_SPECIFIC);
-        pdu1.setEnterprise(new OID(Oid));
-        pdu1.add(new VariableBinding(new OID(Oid), new OctetString(messageString)));
+        pdu1.setEnterprise(new OID(oid));
+        pdu1.add(new VariableBinding(new OID(oid), new OctetString(messageString)));
 
         response = snmp.send(pdu1, target);
 
@@ -385,7 +385,7 @@ public class ActionSNMPTrap extends ActionBase implements Cloneable, IAction {
 
         // create the PDU
         ScopedPDU pdu = new ScopedPDU();
-        pdu.add(new VariableBinding(new OID(Oid), new OctetString(messageString)));
+        pdu.add(new VariableBinding(new OID(oid), new OctetString(messageString)));
         pdu.setType(PDU.TRAP);
         if (!Utils.isEmpty(engineID)) {
           pdu.setContextEngineID(new OctetString(engineID));
diff --git a/plugins/actions/snmptrap/src/main/java/org/apache/hop/workflow/actions/snmptrap/ActionSNMPTrapDialog.java b/plugins/actions/snmptrap/src/main/java/org/apache/hop/workflow/actions/snmptrap/ActionSNMPTrapDialog.java
index 14f1a1a..9de8f2d 100644
--- a/plugins/actions/snmptrap/src/main/java/org/apache/hop/workflow/actions/snmptrap/ActionSNMPTrapDialog.java
+++ b/plugins/actions/snmptrap/src/main/java/org/apache/hop/workflow/actions/snmptrap/ActionSNMPTrapDialog.java
@@ -162,11 +162,11 @@ public class ActionSNMPTrapDialog extends ActionDialog implements IActionDialog
     wServerSettings.setText(
         BaseMessages.getString(PKG, "ActionSNMPTrap.ServerSettings.Group.Label"));
 
-    FormLayout ServerSettingsgroupLayout = new FormLayout();
-    ServerSettingsgroupLayout.marginWidth = 10;
-    ServerSettingsgroupLayout.marginHeight = 10;
+    FormLayout serverSettingsgroupLayout = new FormLayout();
+    serverSettingsgroupLayout.marginWidth = 10;
+    serverSettingsgroupLayout.marginHeight = 10;
 
-    wServerSettings.setLayout(ServerSettingsgroupLayout);
+    wServerSettings.setLayout(serverSettingsgroupLayout);
 
     // ServerName line
     wServerName =
@@ -240,10 +240,10 @@ public class ActionSNMPTrapDialog extends ActionDialog implements IActionDialog
     props.setLook(wAdvancedSettings);
     wAdvancedSettings.setText(
         BaseMessages.getString(PKG, "ActionSNMPTrap.AdvancedSettings.Group.Label"));
-    FormLayout AdvancedSettingsgroupLayout = new FormLayout();
-    AdvancedSettingsgroupLayout.marginWidth = 10;
-    AdvancedSettingsgroupLayout.marginHeight = 10;
-    wAdvancedSettings.setLayout(AdvancedSettingsgroupLayout);
+    FormLayout advancedSettingsgroupLayout = new FormLayout();
+    advancedSettingsgroupLayout.marginWidth = 10;
+    advancedSettingsgroupLayout.marginHeight = 10;
+    wAdvancedSettings.setLayout(advancedSettingsgroupLayout);
 
     // Target type
     Label wlTargetType = new Label(wAdvancedSettings, SWT.RIGHT);
@@ -377,10 +377,10 @@ public class ActionSNMPTrapDialog extends ActionDialog implements IActionDialog
     Group wMessageGroup = new Group(wGeneralComp, SWT.SHADOW_NONE);
     props.setLook(wMessageGroup);
     wMessageGroup.setText(BaseMessages.getString(PKG, "ActionSNMPTrap.MessageGroup.Group.Label"));
-    FormLayout MessageGroupgroupLayout = new FormLayout();
-    MessageGroupgroupLayout.marginWidth = 10;
-    MessageGroupgroupLayout.marginHeight = 10;
-    wMessageGroup.setLayout(MessageGroupgroupLayout);
+    FormLayout messageGroupgroupLayout = new FormLayout();
+    messageGroupgroupLayout.marginWidth = 10;
+    messageGroupgroupLayout.marginHeight = 10;
+    wMessageGroup.setLayout(messageGroupgroupLayout);
 
     // Message line
     Label wlMessage = new Label(wMessageGroup, SWT.RIGHT);
diff --git a/plugins/actions/sql/src/main/java/org/apache/hop/workflow/actions/sql/ActionSql.java b/plugins/actions/sql/src/main/java/org/apache/hop/workflow/actions/sql/ActionSql.java
index 16a1dc1..7cc2eaf 100644
--- a/plugins/actions/sql/src/main/java/org/apache/hop/workflow/actions/sql/ActionSql.java
+++ b/plugins/actions/sql/src/main/java/org/apache/hop/workflow/actions/sql/ActionSql.java
@@ -217,13 +217,14 @@ public class ActionSql extends ActionBase implements Cloneable, IAction {
               logDetailed(BaseMessages.getString(PKG, "ActionSQL.SQLFileExists", realfilename));
             }
 
-            InputStream IS = HopVfs.getInputStream(sqlFile);
+            InputStream inputStream = HopVfs.getInputStream(sqlFile);
             try {
-              InputStreamReader BIS = new InputStreamReader(new BufferedInputStream(IS, 500));
+              InputStreamReader inputStreamReader =
+                  new InputStreamReader(new BufferedInputStream(inputStream, 500));
               StringBuilder lineSB = new StringBuilder(256);
               lineSB.setLength(0);
 
-              BufferedReader buff = new BufferedReader(BIS);
+              BufferedReader buff = new BufferedReader(inputStreamReader);
               String sLine = null;
               theSql = Const.CR;
 
@@ -235,7 +236,7 @@ public class ActionSql extends ActionBase implements Cloneable, IAction {
                 }
               }
             } finally {
-              IS.close();
+              inputStream.close();
             }
           } catch (Exception e) {
             throw new HopDatabaseException(
diff --git a/plugins/actions/unzip/src/main/java/org/apache/hop/workflow/actions/unzip/ActionUnZipDialog.java b/plugins/actions/unzip/src/main/java/org/apache/hop/workflow/actions/unzip/ActionUnZipDialog.java
index 491bff2..4eabf39 100644
--- a/plugins/actions/unzip/src/main/java/org/apache/hop/workflow/actions/unzip/ActionUnZipDialog.java
+++ b/plugins/actions/unzip/src/main/java/org/apache/hop/workflow/actions/unzip/ActionUnZipDialog.java
@@ -57,7 +57,8 @@ public class ActionUnZipDialog extends ActionDialog implements IActionDialog {
   private Text wName;
 
   private Label wlZipFilename;
-  private Button wbZipFilename, wbSourceDirectory;
+  private Button wbZipFilename;
+  private Button wbSourceDirectory;
   private TextVar wZipFilename;
 
   private ActionUnZip action;
diff --git a/plugins/actions/waitforsql/src/main/java/org/apache/hop/workflow/actions/waitforsql/ActionWaitForSqlDialog.java b/plugins/actions/waitforsql/src/main/java/org/apache/hop/workflow/actions/waitforsql/ActionWaitForSqlDialog.java
index 1d321a6..2a6a041 100644
--- a/plugins/actions/waitforsql/src/main/java/org/apache/hop/workflow/actions/waitforsql/ActionWaitForSqlDialog.java
+++ b/plugins/actions/waitforsql/src/main/java/org/apache/hop/workflow/actions/waitforsql/ActionWaitForSqlDialog.java
@@ -52,7 +52,8 @@ import org.eclipse.swt.widgets.*;
 public class ActionWaitForSqlDialog extends ActionDialog implements IActionDialog {
   private static final Class<?> PKG = ActionWaitForSql.class; // For Translator
 
-  private Button wbTable, wbSqlTable;
+  private Button wbTable;
+  private Button wbSqlTable;
 
   private Text wName;
 
@@ -223,10 +224,10 @@ public class ActionWaitForSqlDialog extends ActionDialog implements IActionDialo
     props.setLook(wSuccessGroup);
     wSuccessGroup.setText(BaseMessages.getString(PKG, "ActionWaitForSQL.SuccessGroup.Group.Label"));
 
-    FormLayout SuccessGroupLayout = new FormLayout();
-    SuccessGroupLayout.marginWidth = 10;
-    SuccessGroupLayout.marginHeight = 10;
-    wSuccessGroup.setLayout(SuccessGroupLayout);
+    FormLayout successGroupLayout = new FormLayout();
+    successGroupLayout.marginWidth = 10;
+    successGroupLayout.marginHeight = 10;
+    wSuccessGroup.setLayout(successGroupLayout);
 
     // Success Condition
     Label wlSuccessCondition = new Label(wSuccessGroup, SWT.RIGHT);
@@ -363,10 +364,10 @@ public class ActionWaitForSqlDialog extends ActionDialog implements IActionDialo
     props.setLook(wCustomGroup);
     wCustomGroup.setText(BaseMessages.getString(PKG, "ActionWaitForSQL.CustomGroup.Group.Label"));
 
-    FormLayout CustomGroupLayout = new FormLayout();
-    CustomGroupLayout.marginWidth = 10;
-    CustomGroupLayout.marginHeight = 10;
-    wCustomGroup.setLayout(CustomGroupLayout);
+    FormLayout customGroupLayout = new FormLayout();
+    customGroupLayout.marginWidth = 10;
+    customGroupLayout.marginHeight = 10;
+    wCustomGroup.setLayout(customGroupLayout);
 
     // custom SQL?
     Label wlCustomSql = new Label(wCustomGroup, SWT.RIGHT);
diff --git a/plugins/actions/workflow/src/main/java/org/apache/hop/workflow/actions/workflow/ActionWorkflow.java b/plugins/actions/workflow/src/main/java/org/apache/hop/workflow/actions/workflow/ActionWorkflow.java
index d86af5c..751abad 100644
--- a/plugins/actions/workflow/src/main/java/org/apache/hop/workflow/actions/workflow/ActionWorkflow.java
+++ b/plugins/actions/workflow/src/main/java/org/apache/hop/workflow/actions/workflow/ActionWorkflow.java
@@ -78,8 +78,10 @@ public class ActionWorkflow extends ActionBase implements Cloneable, IAction {
   public String[] parameterValues;
 
   public boolean setLogfile;
-  public String logfile, logext;
-  public boolean addDate, addTime;
+  public String logfile;
+  public String logext;
+  public boolean addDate;
+  public boolean addTime;
   public LogLevel logFileLevel;
 
   public boolean parallel;
diff --git a/plugins/actions/writetofile/src/main/java/org/apache/hop/workflow/actions/writetofile/ActionWriteToFileDialog.java b/plugins/actions/writetofile/src/main/java/org/apache/hop/workflow/actions/writetofile/ActionWriteToFileDialog.java
index 640e5f3..4e379de 100644
--- a/plugins/actions/writetofile/src/main/java/org/apache/hop/workflow/actions/writetofile/ActionWriteToFileDialog.java
+++ b/plugins/actions/writetofile/src/main/java/org/apache/hop/workflow/actions/writetofile/ActionWriteToFileDialog.java
@@ -18,10 +18,10 @@
 package org.apache.hop.workflow.actions.writetofile;
 
 import org.apache.hop.core.Const;
+import org.apache.hop.core.Props;
 import org.apache.hop.core.util.Utils;
 import org.apache.hop.core.variables.IVariables;
 import org.apache.hop.i18n.BaseMessages;
-import org.apache.hop.ui.core.PropsUi;
 import org.apache.hop.ui.core.dialog.BaseDialog;
 import org.apache.hop.ui.core.gui.WindowProperty;
 import org.apache.hop.ui.core.widget.ComboVar;
@@ -134,10 +134,10 @@ public class ActionWriteToFileDialog extends ActionDialog implements IActionDial
     props.setLook(wFileGroup);
     wFileGroup.setText(BaseMessages.getString(PKG, "ActionWriteToFile.Group.File.Label"));
 
-    FormLayout FileGroupLayout = new FormLayout();
-    FileGroupLayout.marginWidth = 10;
-    FileGroupLayout.marginHeight = 10;
-    wFileGroup.setLayout(FileGroupLayout);
+    FormLayout fileGroupLayout = new FormLayout();
+    fileGroupLayout.marginWidth = 10;
+    fileGroupLayout.marginHeight = 10;
+    wFileGroup.setLayout(fileGroupLayout);
 
     // Filename line
     Label wlFilename = new Label(wFileGroup, SWT.RIGHT);
@@ -244,10 +244,10 @@ public class ActionWriteToFileDialog extends ActionDialog implements IActionDial
     props.setLook(wContentGroup);
     wContentGroup.setText(BaseMessages.getString(PKG, "ActionWriteToFile.Group.Content.Label"));
 
-    FormLayout ContentGroupLayout = new FormLayout();
-    ContentGroupLayout.marginWidth = 10;
-    ContentGroupLayout.marginHeight = 10;
-    wContentGroup.setLayout(ContentGroupLayout);
+    FormLayout contentGroupLayout = new FormLayout();
+    contentGroupLayout.marginWidth = 10;
+    contentGroupLayout.marginHeight = 10;
+    wContentGroup.setLayout(contentGroupLayout);
 
     // Encoding
     Label wlEncoding = new Label(wContentGroup, SWT.RIGHT);
@@ -270,7 +270,9 @@ public class ActionWriteToFileDialog extends ActionDialog implements IActionDial
     wEncoding.addFocusListener(
         new FocusListener() {
           @Override
-          public void focusLost(FocusEvent e) {}
+          public void focusLost(FocusEvent e) {
+            // Disable Focuslost
+          }
 
           @Override
           public void focusGained(FocusEvent e) {
@@ -289,7 +291,7 @@ public class ActionWriteToFileDialog extends ActionDialog implements IActionDial
 
     wContent =
         new Text(wContentGroup, SWT.MULTI | SWT.LEFT | SWT.BORDER | SWT.H_SCROLL | SWT.V_SCROLL);
-    props.setLook(wContent, PropsUi.WIDGET_STYLE_FIXED);
+    props.setLook(wContent, Props.WIDGET_STYLE_FIXED);
     wContent.addModifyListener(lsMod);
     FormData fdContent = new FormData();
     fdContent.left = new FormAttachment(middle, 0);
diff --git a/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/dtdvalidator/DtdValidatorUtil.java b/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/dtdvalidator/DtdValidatorUtil.java
index 08826b7..422d79c 100644
--- a/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/dtdvalidator/DtdValidatorUtil.java
+++ b/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/dtdvalidator/DtdValidatorUtil.java
@@ -162,13 +162,13 @@ public class DtdValidatorUtil {
 
             if (dtdFileObject.exists()) {
               if (xmlStartDTD != -1) {
-                int EndDTD = xmlStringbuffer.indexOf(">", xmlStartDTD);
-                xmlStringbuffer.replace(xmlStartDTD, EndDTD + 1, "");
+                int endDTD = xmlStringbuffer.indexOf(">", xmlStartDTD);
+                xmlStringbuffer.replace(xmlStartDTD, endDTD + 1, "");
               }
 
               String xmlRootnodeDTD = xmlDocDTD.getDocumentElement().getNodeName();
 
-              String RefDTD =
+              String refDTD =
                   "<?xml version='"
                       + xmlDocDTD.getXmlVersion()
                       + "' encoding='"
@@ -180,7 +180,7 @@ public class DtdValidatorUtil {
                       + "'>\n";
 
               int xmloffsetDTD = xmlStringbuffer.indexOf("<" + xmlRootnodeDTD);
-              xmlStringbuffer.replace(0, xmloffsetDTD, RefDTD);
+              xmlStringbuffer.replace(0, xmloffsetDTD, refDTD);
             } else {
               log.logError(
                   BaseMessages.getString(PKG, "ActionDTDValidator.ERRORDTDFileNotExists.Subject"),
diff --git a/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xmlwellformed/XmlWellFormed.java b/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xmlwellformed/XmlWellFormed.java
index 099b1d1..6b48541 100644
--- a/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xmlwellformed/XmlWellFormed.java
+++ b/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xmlwellformed/XmlWellFormed.java
@@ -60,26 +60,33 @@ import java.util.regex.Pattern;
 public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
   private static final Class<?> PKG = XmlWellFormed.class; // For Translator
 
-  public static String SUCCESS_IF_AT_LEAST_X_FILES_WELL_FORMED = "success_when_at_least";
-  public static String SUCCESS_IF_BAD_FORMED_FILES_LESS = "success_if_bad_formed_files_less";
-  public static String SUCCESS_IF_NO_ERRORS = "success_if_no_errors";
+  public static final String SUCCESS_IF_AT_LEAST_X_FILES_WELL_FORMED = "success_when_at_least";
+  public static final String SUCCESS_IF_BAD_FORMED_FILES_LESS = "success_if_bad_formed_files_less";
+  public static final String SUCCESS_IF_NO_ERRORS = "success_if_no_errors";
 
-  public static String ADD_ALL_FILENAMES = "all_filenames";
-  public static String ADD_WELL_FORMED_FILES_ONLY = "only_well_formed_filenames";
-  public static String ADD_BAD_FORMED_FILES_ONLY = "only_bad_formed_filenames";
+  public static final String ADD_ALL_FILENAMES = "all_filenames";
+  public static final String ADD_WELL_FORMED_FILES_ONLY = "only_well_formed_filenames";
+  public static final String ADD_BAD_FORMED_FILES_ONLY = "only_bad_formed_filenames";
 
+  /** @Deprecated no longer used */
   @Deprecated public boolean argFromPrevious;
+
+  /** @Deprecated no longer used */
   @Deprecated public boolean includeSubfolders;
 
+  /** @Deprecated no longer used */
   @Deprecated public String[] sourceFileFolders;
+
+  /** @Deprecated no longer used */
   @Deprecated public String[] wildcard;
+
   private String nrErrorsLessThan;
   private String successCondition;
   private String resultFilenames;
 
-  int NrAllErrors = 0;
-  int NrBadFormed = 0;
-  int NrWellFormed = 0;
+  int nrAllErrors = 0;
+  int nrBadFormed = 0;
+  int nrWellFormed = 0;
   int limitFiles = 0;
   int nrErrors = 0;
 
@@ -178,8 +185,8 @@ public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
     RowMetaAndData resultRow = null;
 
     nrErrors = 0;
-    NrWellFormed = 0;
-    NrBadFormed = 0;
+    nrWellFormed = 0;
+    nrBadFormed = 0;
     limitFiles = Const.toInt(resolve(getNrErrorsLessThan()), 10);
     successConditionBroken = false;
     successConditionBrokenExit = false;
@@ -204,12 +211,12 @@ public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
           if (!successConditionBrokenExit) {
             logError(
                 BaseMessages.getString(
-                    PKG, "ActionXMLWellFormed.Error.SuccessConditionbroken", "" + NrAllErrors));
+                    PKG, "ActionXMLWellFormed.Error.SuccessConditionbroken", "" + nrAllErrors));
             successConditionBrokenExit = true;
           }
-          result.setEntryNr(NrAllErrors);
-          result.setNrLinesRejected(NrBadFormed);
-          result.setNrLinesWritten(NrWellFormed);
+          result.setEntryNr(nrAllErrors);
+          result.setNrLinesRejected(nrBadFormed);
+          result.setNrLinesWritten(nrWellFormed);
           return result;
         }
 
@@ -236,12 +243,12 @@ public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
           if (!successConditionBrokenExit) {
             logError(
                 BaseMessages.getString(
-                    PKG, "ActionXMLWellFormed.Error.SuccessConditionbroken", "" + NrAllErrors));
+                    PKG, "ActionXMLWellFormed.Error.SuccessConditionbroken", "" + nrAllErrors));
             successConditionBrokenExit = true;
           }
-          result.setEntryNr(NrAllErrors);
-          result.setNrLinesRejected(NrBadFormed);
-          result.setNrLinesWritten(NrWellFormed);
+          result.setEntryNr(nrAllErrors);
+          result.setNrLinesRejected(nrBadFormed);
+          result.setNrLinesWritten(nrWellFormed);
           return result;
         }
 
@@ -259,9 +266,9 @@ public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
     }
 
     // Success Condition
-    result.setNrErrors(NrAllErrors);
-    result.setNrLinesRejected(NrBadFormed);
-    result.setNrLinesWritten(NrWellFormed);
+    result.setNrErrors(nrAllErrors);
+    result.setNrLinesRejected(nrBadFormed);
+    result.setNrLinesWritten(nrWellFormed);
     if (getSuccessStatus()) {
       result.setNrErrors(0);
       result.setResult(true);
@@ -279,18 +286,18 @@ public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
           BaseMessages.getString(PKG, "ActionXMLWellFormed.Log.Info.FilesInError", "" + nrErrors));
       logDetailed(
           BaseMessages.getString(
-              PKG, "ActionXMLWellFormed.Log.Info.FilesInBadFormed", "" + NrBadFormed));
+              PKG, "ActionXMLWellFormed.Log.Info.FilesInBadFormed", "" + nrBadFormed));
       logDetailed(
           BaseMessages.getString(
-              PKG, "ActionXMLWellFormed.Log.Info.FilesInWellFormed", "" + NrWellFormed));
+              PKG, "ActionXMLWellFormed.Log.Info.FilesInWellFormed", "" + nrWellFormed));
       logDetailed("=======================================");
     }
   }
 
   private boolean checkIfSuccessConditionBroken() {
     boolean retval = false;
-    if ((NrAllErrors > 0 && getSuccessCondition().equals(SUCCESS_IF_NO_ERRORS))
-        || (NrBadFormed >= limitFiles
+    if ((nrAllErrors > 0 && getSuccessCondition().equals(SUCCESS_IF_NO_ERRORS))
+        || (nrBadFormed >= limitFiles
             && getSuccessCondition().equals(SUCCESS_IF_BAD_FORMED_FILES_LESS))) {
       retval = true;
     }
@@ -300,10 +307,10 @@ public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
   private boolean getSuccessStatus() {
     boolean retval = false;
 
-    if ((NrAllErrors == 0 && getSuccessCondition().equals(SUCCESS_IF_NO_ERRORS))
-        || (NrWellFormed >= limitFiles
+    if ((nrAllErrors == 0 && getSuccessCondition().equals(SUCCESS_IF_NO_ERRORS))
+        || (nrWellFormed >= limitFiles
             && getSuccessCondition().equals(SUCCESS_IF_AT_LEAST_X_FILES_WELL_FORMED))
-        || (NrBadFormed < limitFiles
+        || (nrBadFormed < limitFiles
             && getSuccessCondition().equals(SUCCESS_IF_BAD_FORMED_FILES_LESS))) {
       retval = true;
     }
@@ -321,7 +328,7 @@ public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
   }
 
   private void updateAllErrors() {
-    NrAllErrors = nrErrors + NrBadFormed;
+    nrAllErrors = nrErrors + nrBadFormed;
   }
 
   public static class XMLTreeHandler extends DefaultHandler {}
@@ -343,7 +350,7 @@ public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
       String sourcefilefoldername, String wildcard, IWorkflowEngine parentWorkflow, Result result) {
     boolean entrystatus = false;
     FileObject sourcefilefolder = null;
-    FileObject CurrentFile = null;
+    FileObject currentFile = null;
 
     // Get real source file and wilcard
     String realSourceFilefoldername = resolve(sourcefilefoldername);
@@ -414,26 +421,26 @@ public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
                       BaseMessages.getString(
                           PKG,
                           "ActionXMLWellFormed.Error.SuccessConditionbroken",
-                          "" + NrAllErrors));
+                          "" + nrAllErrors));
                   successConditionBrokenExit = true;
                 }
                 return false;
               }
               // Fetch files in list one after one ...
-              CurrentFile = fileObjects[j];
+              currentFile = fileObjects[j];
 
-              if (!CurrentFile.getParent().toString().equals(sourcefilefolder.toString())) {
+              if (!currentFile.getParent().toString().equals(sourcefilefolder.toString())) {
                 // Not in the Base Folder..Only if include sub folders
                 if (includeSubfolders) {
-                  if (GetFileWildcard(CurrentFile.toString(), realWildcard)) {
-                    checkOneFile(CurrentFile, result, parentWorkflow);
+                  if (GetFileWildcard(currentFile.toString(), realWildcard)) {
+                    checkOneFile(currentFile, result, parentWorkflow);
                   }
                 }
 
               } else {
                 // In the base folder
-                if (GetFileWildcard(CurrentFile.toString(), realWildcard)) {
-                  checkOneFile(CurrentFile, result, parentWorkflow);
+                if (GetFileWildcard(currentFile.toString(), realWildcard)) {
+                  checkOneFile(currentFile, result, parentWorkflow);
                 }
               }
             }
@@ -469,9 +476,9 @@ public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
           /* Ignore */
         }
       }
-      if (CurrentFile != null) {
+      if (currentFile != null) {
         try {
-          CurrentFile.close();
+          currentFile.close();
         } catch (IOException ex) {
           /* Ignore */
         }
@@ -518,11 +525,11 @@ public class XmlWellFormed extends ActionBase implements Cloneable, IAction {
   }
 
   private void updateWellFormed() {
-    NrWellFormed++;
+    nrWellFormed++;
   }
 
   private void updateBadFormed() {
-    NrBadFormed++;
+    nrBadFormed++;
     updateAllErrors();
   }
 
diff --git a/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xmlwellformed/XmlWellFormedDialog.java b/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xmlwellformed/XmlWellFormedDialog.java
index fa2898c..2098814 100644
--- a/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xmlwellformed/XmlWellFormedDialog.java
+++ b/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xmlwellformed/XmlWellFormedDialog.java
@@ -58,7 +58,8 @@ public class XmlWellFormedDialog extends ActionDialog implements IActionDialog {
   private Text wName;
 
   private Label wlSourceFileFolder;
-  private Button wbSourceFileFolder, wbSourceDirectory;
+  private Button wbSourceFileFolder;
+  private Button wbSourceDirectory;
 
   private TextVar wSourceFileFolder;
 
@@ -84,7 +85,8 @@ public class XmlWellFormedDialog extends ActionDialog implements IActionDialog {
 
   // Add File to result
 
-  private CCombo wSuccessCondition, wAddFilenameToResult;
+  private CCombo wSuccessCondition;
+  private CCombo wAddFilenameToResult;
 
   private Label wlNrErrorsLessThan;
   private TextVar wNrErrorsLessThan;
@@ -803,19 +805,19 @@ public class XmlWellFormedDialog extends ActionDialog implements IActionDialog {
         nr++;
       }
     }
-    String[] source_filefolder = new String[nr];
+    String[] sourceFilefolder = new String[nr];
     String[] wildcard = new String[nr];
     nr = 0;
     for (int i = 0; i < nritems; i++) {
       String source = wFields.getNonEmpty(i).getText(1);
       String wild = wFields.getNonEmpty(i).getText(2);
       if (source != null && source.length() != 0) {
-        source_filefolder[nr] = source;
+        sourceFilefolder[nr] = source;
         wildcard[nr] = wild;
         nr++;
       }
     }
-    action.setSourceFileFolders(source_filefolder);
+    action.setSourceFileFolders(sourceFilefolder);
     action.setSourceWildcards(wildcard);
     dispose();
   }
diff --git a/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xsdvalidator/XsdValidator.java b/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xsdvalidator/XsdValidator.java
index 691b5cd..f7705a2 100644
--- a/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xsdvalidator/XsdValidator.java
+++ b/plugins/actions/xml/src/main/java/org/apache/hop/workflow/actions/xml/xsdvalidator/XsdValidator.java
@@ -152,14 +152,14 @@ public class XsdValidator extends ActionBase implements Cloneable, IAction {
 
         if (xmlfile.exists() && xsdfile.exists()) {
 
-          SchemaFactory factorytXSDValidator_1 =
+          SchemaFactory factorytXSDValidator1 =
               SchemaFactory.newInstance("http://www.w3.org/2001/XMLSchema");
 
           // Get XSD File
-          File XSDFile = new File(HopVfs.getFilename(xsdfile));
-          Schema SchematXSD = factorytXSDValidator_1.newSchema(XSDFile);
+          File xsdFile = new File(HopVfs.getFilename(xsdfile));
+          Schema schematXSD = factorytXSDValidator1.newSchema(xsdFile);
 
-          Validator xsdValidator = SchematXSD.newValidator();
+          Validator xsdValidator = schematXSD.newValidator();
 
           // Prevent against XML Entity Expansion (XEE) attacks.
           // https://www.owasp.org/index.php/XML_Security_Cheat_Sheet#XML_Entity_Expansion
@@ -179,11 +179,11 @@ public class XsdValidator extends ActionBase implements Cloneable, IAction {
           }
 
           // Get XML File
-          File xmlfiletXSDValidator_1 = new File(HopVfs.getFilename(xmlfile));
+          File xmlfiletXSDValidator1 = new File(HopVfs.getFilename(xmlfile));
 
-          Source sourcetXSDValidator_1 = new StreamSource(xmlfiletXSDValidator_1);
+          Source sourcetXSDValidator1 = new StreamSource(xmlfiletXSDValidator1);
 
-          xsdValidator.validate(sourcetXSDValidator_1);
+          xsdValidator.validate(sourcetXSDValidator1);
 
           // Everything is OK
           result.setResult(true);
diff --git a/plugins/actions/zipfile/src/main/java/org/apache/hop/workflow/actions/zipfile/ActionZipFile.java b/plugins/actions/zipfile/src/main/java/org/apache/hop/workflow/actions/zipfile/ActionZipFile.java
index 3d11298..387914f 100644
--- a/plugins/actions/zipfile/src/main/java/org/apache/hop/workflow/actions/zipfile/ActionZipFile.java
+++ b/plugins/actions/zipfile/src/main/java/org/apache/hop/workflow/actions/zipfile/ActionZipFile.java
@@ -241,7 +241,7 @@ public class ActionZipFile extends ActionBase implements Cloneable, IAction {
       String realSourceDirectoryOrFile,
       String realMovetodirectory,
       boolean createparentfolder) {
-    boolean Fileexists = false;
+    boolean fileexists = false;
     File tempFile = null;
     File fileZip;
     boolean resultat = false;
@@ -283,7 +283,7 @@ public class ActionZipFile extends ActionBase implements Cloneable, IAction {
         localrealZipfilename = HopVfs.getFilename(fileObject);
         // Check if Zip File exists
         if (fileObject.exists()) {
-          Fileexists = true;
+          fileexists = true;
           if (log.isDebug()) {
             logDebug(
                 BaseMessages.getString(PKG, "ActionZipFile.Zip_FileExists1.Label")
@@ -297,10 +297,10 @@ public class ActionZipFile extends ActionBase implements Cloneable, IAction {
         }
 
         // Let's start the process now
-        if (ifZipFileExists == 3 && Fileexists) {
+        if (ifZipFileExists == 3 && fileexists) {
           // the zip file exists and user want to Fail
           resultat = false;
-        } else if (ifZipFileExists == 2 && Fileexists) {
+        } else if (ifZipFileExists == 2 && fileexists) {
           // the zip file exists and user want to do nothing
           if (addFileToResult) {
             // Add file to result files name
@@ -374,7 +374,7 @@ public class ActionZipFile extends ActionBase implements Cloneable, IAction {
                 BaseMessages.getString(
                     PKG, "ActionZipFile.Log.NoFilesInFolder", localSourceFilename));
           } else {
-            if (ifZipFileExists == 0 && Fileexists) {
+            if (ifZipFileExists == 0 && fileexists) {
               // the zip file exists and user want to create new one with unique name
               // Format Date
 
@@ -392,7 +392,7 @@ public class ActionZipFile extends ActionBase implements Cloneable, IAction {
                         + localrealZipfilename
                         + BaseMessages.getString(PKG, "ActionZipFile.Zip_FileNameChange1.Label"));
               }
-            } else if (ifZipFileExists == 1 && Fileexists) {
+            } else if (ifZipFileExists == 1 && fileexists) {
               // the zip file exists and user want to append
               // get a temp file
               fileZip = getFile(localrealZipfilename);
@@ -821,11 +821,11 @@ public class ActionZipFile extends ActionBase implements Cloneable, IAction {
     String realMovetodirectory = resolve(movetoDirectory);
 
     // Sanity check
-    boolean SanityControlOK = true;
+    boolean sanityControlOK = true;
 
     if (afterZip == 2) {
       if (Utils.isEmpty(realMovetodirectory)) {
-        SanityControlOK = false;
+        sanityControlOK = false;
         logError(
             BaseMessages.getString(
                 PKG, "ActionZipFile.AfterZip_No_DestinationFolder_Defined.Label"));
@@ -841,7 +841,7 @@ public class ActionZipFile extends ActionBase implements Cloneable, IAction {
                         PKG, "ActionZipFile.Log.MoveToFolderExist", realMovetodirectory));
               }
             } else {
-              SanityControlOK = false;
+              sanityControlOK = false;
               logError(
                   BaseMessages.getString(
                       PKG, "ActionZipFile.Log.MoveToFolderNotFolder", realMovetodirectory));
@@ -860,14 +860,14 @@ public class ActionZipFile extends ActionBase implements Cloneable, IAction {
                         PKG, "ActionZipFile.Log.MoveToFolderCreaterd", realMovetodirectory));
               }
             } else {
-              SanityControlOK = false;
+              sanityControlOK = false;
               logError(
                   BaseMessages.getString(
                       PKG, "ActionZipFile.Log.MoveToFolderNotNotExist", realMovetodirectory));
             }
           }
         } catch (Exception e) {
-          SanityControlOK = false;
+          sanityControlOK = false;
           logError(
               BaseMessages.getString(
                   PKG, "ActionZipFile.ErrorGettingMoveToFolder.Label", realMovetodirectory),
@@ -879,14 +879,14 @@ public class ActionZipFile extends ActionBase implements Cloneable, IAction {
               moveToDirectory.close();
             } catch (Exception e) {
               logError("Error moving to directory", e);
-              SanityControlOK = false;
+              sanityControlOK = false;
             }
           }
         }
       }
     }
 
-    if (!SanityControlOK) {
+    if (!sanityControlOK) {
       return errorResult(result);
     }
 
diff --git a/plugins/actions/zipfile/src/main/java/org/apache/hop/workflow/actions/zipfile/ActionZipFileDialog.java b/plugins/actions/zipfile/src/main/java/org/apache/hop/workflow/actions/zipfile/ActionZipFileDialog.java
index 02a8b51..117ad2b 100644
--- a/plugins/actions/zipfile/src/main/java/org/apache/hop/workflow/actions/zipfile/ActionZipFileDialog.java
+++ b/plugins/actions/zipfile/src/main/java/org/apache/hop/workflow/actions/zipfile/ActionZipFileDialog.java
@@ -95,7 +95,8 @@ public class ActionZipFileDialog extends ActionDialog implements IActionDialog {
 
   private Button wAddFileToResult;
 
-  private Button wbSourceDirectory, wbSourceFile;
+  private Button wbSourceDirectory;
+  private Button wbSourceFile;
 
   private Button wbMovetoDirectory;
 
diff --git a/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/fn/HopKeyValueFn.java b/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/fn/HopKeyValueFn.java
index ed347d8..11a123e 100644
--- a/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/fn/HopKeyValueFn.java
+++ b/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/fn/HopKeyValueFn.java
@@ -46,7 +46,6 @@ public class HopKeyValueFn extends DoFn<HopRow, KV<HopRow, HopRow>> {
 
   private static final Logger LOG = LoggerFactory.getLogger(HopKeyValueFn.class);
 
-  private transient IRowMeta inputRowMeta;
   private transient int[] keyIndexes;
   private transient int[] valueIndexes;
 
@@ -80,7 +79,7 @@ public class HopKeyValueFn extends DoFn<HopRow, KV<HopRow, HopRow>> {
       // Initialize Hop Beam
       //
       BeamHop.init(transformPluginClasses, xpPluginClasses);
-      inputRowMeta = JsonRowMeta.fromJson(inputRowMetaJson);
+      IRowMeta inputRowMeta = JsonRowMeta.fromJson(inputRowMetaJson);
 
       // Calculate key indexes
       //
diff --git a/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/fn/HopToStringFn.java b/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/fn/HopToStringFn.java
index a2939db..47affb0 100644
--- a/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/fn/HopToStringFn.java
+++ b/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/fn/HopToStringFn.java
@@ -43,7 +43,6 @@ public class HopToStringFn extends DoFn<HopRow, String> {
   private List<String> xpPluginClasses;
 
   private transient IRowMeta rowMeta;
-  private transient Counter initCounter;
   private transient Counter readCounter;
   private transient Counter outputCounter;
   private transient Counter errorCounter;
@@ -71,7 +70,7 @@ public class HopToStringFn extends DoFn<HopRow, String> {
   @Setup
   public void setUp() {
     try {
-      initCounter = Metrics.counter(Pipeline.METRIC_NAME_INIT, counterName);
+      Counter initCounter = Metrics.counter(Pipeline.METRIC_NAME_INIT, counterName);
       readCounter = Metrics.counter(Pipeline.METRIC_NAME_READ, counterName);
       outputCounter = Metrics.counter(Pipeline.METRIC_NAME_OUTPUT, counterName);
       errorCounter = Metrics.counter(Pipeline.METRIC_NAME_ERROR, counterName);
diff --git a/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/transform/BeamKafkaInputTransform.java b/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/transform/BeamKafkaInputTransform.java
index d577548..8c4cc19 100644
--- a/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/transform/BeamKafkaInputTransform.java
+++ b/plugins/engines/beam/src/main/java/org/apache/hop/beam/core/transform/BeamKafkaInputTransform.java
@@ -82,7 +82,7 @@ public class BeamKafkaInputTransform extends PTransform<PBegin, PCollection<HopR
       boolean allowingCommitOnConsumedOffset,
       String[] configOptionParameters,
       String[] configOptionValues,
-      String configOptionTypes[],
+      String[] configOptionTypes,
       String rowMetaJson,
       List<String> transformPluginClasses,
       List<String> xpPluginClasses) {
diff --git a/plugins/misc/async/src/main/java/org/apache/hop/www/AsyncWebServiceEditor.java b/plugins/misc/async/src/main/java/org/apache/hop/www/AsyncWebServiceEditor.java
index facd681..213df3b 100644
--- a/plugins/misc/async/src/main/java/org/apache/hop/www/AsyncWebServiceEditor.java
+++ b/plugins/misc/async/src/main/java/org/apache/hop/www/AsyncWebServiceEditor.java
@@ -134,11 +134,7 @@ public class AsyncWebServiceEditor extends MetadataEditor<AsyncWebService> {
     fdbbFilename.right = new FormAttachment(100, 0);
     fdbbFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wbbFilename.setLayoutData(fdbbFilename);
-    wbbFilename.addListener(
-        SWT.Selection,
-        e -> {
-          selectWorkflowFilename(parent);
-        });
+    wbbFilename.addListener(SWT.Selection, e -> selectWorkflowFilename(parent));
 
     Button wbnFilename = new Button(parent, SWT.PUSH);
     props.setLook(wbnFilename);
@@ -147,11 +143,7 @@ public class AsyncWebServiceEditor extends MetadataEditor<AsyncWebService> {
     fdbnFilename.right = new FormAttachment(wbbFilename, -margin);
     fdbnFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wbnFilename.setLayoutData(fdbnFilename);
-    wbnFilename.addListener(
-        SWT.Selection,
-        e -> {
-          createWorkflowFile(parent);
-        });
+    wbnFilename.addListener(SWT.Selection, e -> createWorkflowFile(parent));
 
     Button wboFilename = new Button(parent, SWT.PUSH);
     props.setLook(wboFilename);
@@ -160,11 +152,7 @@ public class AsyncWebServiceEditor extends MetadataEditor<AsyncWebService> {
     fdboFilename.right = new FormAttachment(wbnFilename, -margin);
     fdboFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wboFilename.setLayoutData(fdboFilename);
-    wboFilename.addListener(
-        SWT.Selection,
-        e -> {
-          openWorkflowFile(parent);
-        });
+    wboFilename.addListener(SWT.Selection, e -> openWorkflowFile(parent));
 
     wFilename = new TextVar(manager.getVariables(), parent, SWT.SINGLE | SWT.BORDER | SWT.LEFT);
     props.setLook(wFilename);
diff --git a/plugins/misc/debug/src/main/java/org/apache/hop/debug/action/ActionDebugLevelDialog.java b/plugins/misc/debug/src/main/java/org/apache/hop/debug/action/ActionDebugLevelDialog.java
index e7a937a..3431208 100644
--- a/plugins/misc/debug/src/main/java/org/apache/hop/debug/action/ActionDebugLevelDialog.java
+++ b/plugins/misc/debug/src/main/java/org/apache/hop/debug/action/ActionDebugLevelDialog.java
@@ -47,13 +47,8 @@ public class ActionDebugLevelDialog extends Dialog {
   private Button wLoggingRows;
   private Button wLoggingFiles;
 
-  private Control lastControl;
-
   private PropsUi props;
 
-  private int middle;
-  private int margin;
-
   private boolean ok;
 
   public ActionDebugLevelDialog(Shell par, ActionDebugLevel debugLevel) {
@@ -71,8 +66,8 @@ public class ActionDebugLevelDialog extends Dialog {
     props.setLook(shell);
     shell.setImage(GuiResource.getInstance().getImageServer());
 
-    middle = props.getMiddlePct();
-    margin = Const.MARGIN + 2;
+    int middle = props.getMiddlePct();
+    int margin = Const.MARGIN + 2;
 
     FormLayout formLayout = new FormLayout();
     formLayout.marginWidth = Const.FORM_MARGIN;
@@ -98,7 +93,7 @@ public class ActionDebugLevelDialog extends Dialog {
     fdName.left = new FormAttachment(middle, 0); // To the right of the label
     fdName.right = new FormAttachment(100, 0);
     wLogLevel.setLayoutData(fdName);
-    lastControl = wLogLevel;
+    Control lastControl = wLogLevel;
 
     // Log result details?
     Label wlLoggingResult = new Label(shell, SWT.RIGHT);
diff --git a/plugins/misc/debug/src/main/java/org/apache/hop/debug/transform/TransformDebugLevelDialog.java b/plugins/misc/debug/src/main/java/org/apache/hop/debug/transform/TransformDebugLevelDialog.java
index 0b40fd8..9caee8d 100644
--- a/plugins/misc/debug/src/main/java/org/apache/hop/debug/transform/TransformDebugLevelDialog.java
+++ b/plugins/misc/debug/src/main/java/org/apache/hop/debug/transform/TransformDebugLevelDialog.java
@@ -28,8 +28,6 @@ import org.apache.hop.ui.core.gui.WindowProperty;
 import org.apache.hop.ui.core.widget.ConditionEditor;
 import org.apache.hop.ui.pipeline.transform.BaseTransformDialog;
 import org.eclipse.swt.SWT;
-import org.eclipse.swt.events.SelectionAdapter;
-import org.eclipse.swt.events.SelectionEvent;
 import org.eclipse.swt.layout.FormAttachment;
 import org.eclipse.swt.layout.FormData;
 import org.eclipse.swt.layout.FormLayout;
@@ -49,15 +47,9 @@ public class TransformDebugLevelDialog extends Dialog {
   private Combo wLogLevel;
   private Text wStartRow;
   private Text wEndRow;
-  private ConditionEditor wCondition;
-
-  private Control lastControl;
 
   private PropsUi props;
 
-  private int middle;
-  private int margin;
-
   private boolean ok;
 
   public TransformDebugLevelDialog(
@@ -77,8 +69,8 @@ public class TransformDebugLevelDialog extends Dialog {
     props.setLook(shell);
     shell.setImage(GuiResource.getInstance().getImageServer());
 
-    middle = props.getMiddlePct();
-    margin = Const.MARGIN + 2;
+    int middle = props.getMiddlePct();
+    int margin = Const.MARGIN + 2;
 
     FormLayout formLayout = new FormLayout();
     formLayout.marginWidth = Const.FORM_MARGIN;
@@ -104,7 +96,7 @@ public class TransformDebugLevelDialog extends Dialog {
     fdName.left = new FormAttachment(middle, 0); // To the right of the label
     fdName.right = new FormAttachment(100, 0);
     wLogLevel.setLayoutData(fdName);
-    lastControl = wLogLevel;
+    Control lastControl = wLogLevel;
 
     // Start row option
     Label wlStartRow = new Label(shell, SWT.RIGHT);
@@ -163,7 +155,8 @@ public class TransformDebugLevelDialog extends Dialog {
     fdlCondition.left = new FormAttachment(0, 0);
     fdlCondition.right = new FormAttachment(middle, -margin);
     wlCondition.setLayoutData(fdlCondition);
-    wCondition = new ConditionEditor(shell, SWT.NONE, debugLevel.getCondition(), inputRowMeta);
+    ConditionEditor wCondition =
+        new ConditionEditor(shell, SWT.NONE, debugLevel.getCondition(), inputRowMeta);
     props.setLook(wCondition);
     FormData fdCondition = new FormData();
     fdCondition.top = new FormAttachment(lastControl, margin);
@@ -171,7 +164,6 @@ public class TransformDebugLevelDialog extends Dialog {
     fdCondition.right = new FormAttachment(100, 0);
     fdCondition.bottom = new FormAttachment(wOK, 0);
     wCondition.setLayoutData(fdCondition);
-    lastControl = wCondition;
 
     getData();
 
diff --git a/plugins/misc/projects/src/main/java/org/apache/hop/projects/environment/LifecycleEnvironmentDialog.java b/plugins/misc/projects/src/main/java/org/apache/hop/projects/environment/LifecycleEnvironmentDialog.java
index a47a08e..b742551 100644
--- a/plugins/misc/projects/src/main/java/org/apache/hop/projects/environment/LifecycleEnvironmentDialog.java
+++ b/plugins/misc/projects/src/main/java/org/apache/hop/projects/environment/LifecycleEnvironmentDialog.java
@@ -58,12 +58,7 @@ public class LifecycleEnvironmentDialog extends Dialog {
   private Combo wProject;
   private TableView wConfigFiles;
 
-  private int margin;
-  private int middle;
-
   private IVariables variables;
-  private Button wbSelect;
-  private Button wbNew;
   private Button wbEdit;
 
   private String originalName;
@@ -92,8 +87,8 @@ public class LifecycleEnvironmentDialog extends Dialog {
     shell.setImage(GuiResource.getInstance().getImageHopUi());
     props.setLook(shell);
 
-    margin = Const.MARGIN + 2;
-    middle = Const.MIDDLE_PCT;
+    int margin = Const.MARGIN + 2;
+    int middle = Const.MIDDLE_PCT;
 
     FormLayout formLayout = new FormLayout();
     formLayout.marginWidth = Const.FORM_MARGIN;
@@ -177,7 +172,7 @@ public class LifecycleEnvironmentDialog extends Dialog {
     fdlConfigFiles.top = new FormAttachment(lastControl, margin);
     wlConfigFiles.setLayoutData(fdlConfigFiles);
 
-    wbSelect = new Button(shell, SWT.PUSH);
+    Button wbSelect = new Button(shell, SWT.PUSH);
     props.setLook(wbSelect);
     wbSelect.setText(BaseMessages.getString(PKG, "LifecycleEnvironmentDialog.Button.Select"));
     FormData fdAdd = new FormData();
@@ -214,7 +209,7 @@ public class LifecycleEnvironmentDialog extends Dialog {
     wConfigFiles.setLayoutData(fdConfigFiles);
     wConfigFiles.table.addListener(SWT.Selection, this::setButtonStates);
 
-    wbNew = new Button(shell, SWT.PUSH);
+    Button wbNew = new Button(shell, SWT.PUSH);
     props.setLook(wbNew);
     wbNew.setText(BaseMessages.getString(PKG, "LifecycleEnvironmentDialog.Button.New"));
     FormData fdNew = new FormData();
diff --git a/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/pipeline/meta/PipelineLogEditor.java b/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/pipeline/meta/PipelineLogEditor.java
index 7dee091..c79cde0 100644
--- a/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/pipeline/meta/PipelineLogEditor.java
+++ b/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/pipeline/meta/PipelineLogEditor.java
@@ -58,9 +58,6 @@ public class PipelineLogEditor extends MetadataEditor<PipelineLog> {
   private Label wlInterval;
   private TextVar wInterval;
 
-  private int middle;
-  private int margin;
-
   public PipelineLogEditor(
       HopGui hopGui, MetadataManager<PipelineLog> manager, PipelineLog metadata) {
     super(hopGui, manager, metadata);
@@ -71,8 +68,8 @@ public class PipelineLogEditor extends MetadataEditor<PipelineLog> {
 
     PropsUi props = PropsUi.getInstance();
 
-    middle = props.getMiddlePct();
-    margin = props.getMargin();
+    int middle = props.getMiddlePct();
+    int margin = props.getMargin();
 
     Label wIcon = new Label(parent, SWT.RIGHT);
     wIcon.setImage(getImage());
@@ -162,11 +159,7 @@ public class PipelineLogEditor extends MetadataEditor<PipelineLog> {
     fdbbFilename.right = new FormAttachment(100, 0);
     fdbbFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wbbFilename.setLayoutData(fdbbFilename);
-    wbbFilename.addListener(
-        SWT.Selection,
-        e -> {
-          selectPipelineFilename(parent);
-        });
+    wbbFilename.addListener(SWT.Selection, e -> selectPipelineFilename(parent));
 
     Button wbnFilename = new Button(parent, SWT.PUSH);
     props.setLook(wbnFilename);
@@ -175,11 +168,7 @@ public class PipelineLogEditor extends MetadataEditor<PipelineLog> {
     fdbnFilename.right = new FormAttachment(wbbFilename, -margin);
     fdbnFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wbnFilename.setLayoutData(fdbnFilename);
-    wbnFilename.addListener(
-        SWT.Selection,
-        e -> {
-          createPipelineFile(parent);
-        });
+    wbnFilename.addListener(SWT.Selection, e -> createPipelineFile(parent));
 
     Button wboFilename = new Button(parent, SWT.PUSH);
     props.setLook(wboFilename);
@@ -188,11 +177,7 @@ public class PipelineLogEditor extends MetadataEditor<PipelineLog> {
     fdboFilename.right = new FormAttachment(wbnFilename, -margin);
     fdboFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wboFilename.setLayoutData(fdboFilename);
-    wboFilename.addListener(
-        SWT.Selection,
-        e -> {
-          openPipelineFile(parent);
-        });
+    wboFilename.addListener(SWT.Selection, e -> openPipelineFile(parent));
 
     wFilename = new TextVar(manager.getVariables(), parent, SWT.SINGLE | SWT.BORDER | SWT.LEFT);
     props.setLook(wFilename);
diff --git a/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/probe/meta/PipelineProbeEditor.java b/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/probe/meta/PipelineProbeEditor.java
index b95dbcb..9b3735b 100644
--- a/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/probe/meta/PipelineProbeEditor.java
+++ b/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/probe/meta/PipelineProbeEditor.java
@@ -139,11 +139,7 @@ public class PipelineProbeEditor extends MetadataEditor<PipelineProbe> {
     fdbbFilename.right = new FormAttachment(100, 0);
     fdbbFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wbbFilename.setLayoutData(fdbbFilename);
-    wbbFilename.addListener(
-        SWT.Selection,
-        e -> {
-          selectPipelineFilename(parent);
-        });
+    wbbFilename.addListener(SWT.Selection, e -> selectPipelineFilename(parent));
 
     Button wbnFilename = new Button(parent, SWT.PUSH);
     props.setLook(wbnFilename);
@@ -152,11 +148,7 @@ public class PipelineProbeEditor extends MetadataEditor<PipelineProbe> {
     fdbnFilename.right = new FormAttachment(wbbFilename, -margin);
     fdbnFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wbnFilename.setLayoutData(fdbnFilename);
-    wbnFilename.addListener(
-        SWT.Selection,
-        e -> {
-          createPipelineFile(parent);
-        });
+    wbnFilename.addListener(SWT.Selection, e -> createPipelineFile(parent));
 
     Button wboFilename = new Button(parent, SWT.PUSH);
     props.setLook(wboFilename);
@@ -165,11 +157,7 @@ public class PipelineProbeEditor extends MetadataEditor<PipelineProbe> {
     fdboFilename.right = new FormAttachment(wbnFilename, -margin);
     fdboFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wboFilename.setLayoutData(fdboFilename);
-    wboFilename.addListener(
-        SWT.Selection,
-        e -> {
-          openPipelineFile(parent);
-        });
+    wboFilename.addListener(SWT.Selection, e -> openPipelineFile(parent));
 
     wFilename = new TextVar(manager.getVariables(), parent, SWT.SINGLE | SWT.BORDER | SWT.LEFT);
     props.setLook(wFilename);
diff --git a/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/probe/xp/PipelineDataProbeXp.java b/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/probe/xp/PipelineDataProbeXp.java
index 2070d0b..06b5804 100644
--- a/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/probe/xp/PipelineDataProbeXp.java
+++ b/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/probe/xp/PipelineDataProbeXp.java
@@ -236,10 +236,7 @@ public class PipelineDataProbeXp implements IExtensionPoint<Pipeline> {
 
             // If the pipeline we're the transform is and we can safely stop streaming...
             //
-            pipeline.addExecutionFinishedListener(
-                (pe) -> {
-                  rowProducer.finished();
-                });
+            pipeline.addExecutionFinishedListener(pe -> rowProducer.finished());
 
           } catch (HopException e) {
             throw new HopTransformException(
diff --git a/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/workflow/meta/WorkflowLogEditor.java b/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/workflow/meta/WorkflowLogEditor.java
index 22efa24..a4870b8 100644
--- a/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/workflow/meta/WorkflowLogEditor.java
+++ b/plugins/misc/reflection/src/main/java/org/apache/hop/reflection/workflow/meta/WorkflowLogEditor.java
@@ -58,9 +58,6 @@ public class WorkflowLogEditor extends MetadataEditor<WorkflowLog> {
   private Label wlInterval;
   private TextVar wInterval;
 
-  private int middle;
-  private int margin;
-
   public WorkflowLogEditor(
       HopGui hopGui, MetadataManager<WorkflowLog> manager, WorkflowLog metadata) {
     super(hopGui, manager, metadata);
@@ -71,8 +68,8 @@ public class WorkflowLogEditor extends MetadataEditor<WorkflowLog> {
 
     PropsUi props = PropsUi.getInstance();
 
-    middle = props.getMiddlePct();
-    margin = props.getMargin();
+    int middle = props.getMiddlePct();
+    int margin = props.getMargin();
 
     Label wIcon = new Label(parent, SWT.RIGHT);
     wIcon.setImage(getImage());
@@ -164,11 +161,7 @@ public class WorkflowLogEditor extends MetadataEditor<WorkflowLog> {
     fdbbFilename.right = new FormAttachment(100, 0);
     fdbbFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wbbFilename.setLayoutData(fdbbFilename);
-    wbbFilename.addListener(
-        SWT.Selection,
-        e -> {
-          selectPipelineFilename(parent);
-        });
+    wbbFilename.addListener(SWT.Selection, e -> selectPipelineFilename(parent));
 
     Button wbnFilename = new Button(parent, SWT.PUSH);
     props.setLook(wbnFilename);
@@ -177,11 +170,7 @@ public class WorkflowLogEditor extends MetadataEditor<WorkflowLog> {
     fdbnFilename.right = new FormAttachment(wbbFilename, -margin);
     fdbnFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wbnFilename.setLayoutData(fdbnFilename);
-    wbnFilename.addListener(
-        SWT.Selection,
-        e -> {
-          createPipelineFile(parent);
-        });
+    wbnFilename.addListener(SWT.Selection, e -> createPipelineFile(parent));
 
     Button wboFilename = new Button(parent, SWT.PUSH);
     props.setLook(wboFilename);
@@ -190,11 +179,7 @@ public class WorkflowLogEditor extends MetadataEditor<WorkflowLog> {
     fdboFilename.right = new FormAttachment(wbnFilename, -margin);
     fdboFilename.top = new FormAttachment(wlFilename, 0, SWT.CENTER);
     wboFilename.setLayoutData(fdboFilename);
-    wboFilename.addListener(
-        SWT.Selection,
-        e -> {
-          openPipelineFile(parent);
-        });
+    wboFilename.addListener(SWT.Selection, e -> openPipelineFile(parent));
 
     wFilename = new TextVar(manager.getVariables(), parent, SWT.SINGLE | SWT.BORDER | SWT.LEFT);
     props.setLook(wFilename);
diff --git a/plugins/misc/testing/src/main/java/org/apache/hop/testing/actions/runtests/RunPipelineTestsDialog.java b/plugins/misc/testing/src/main/java/org/apache/hop/testing/actions/runtests/RunPipelineTestsDialog.java
index f32dc2c..0b683aa 100644
--- a/plugins/misc/testing/src/main/java/org/apache/hop/testing/actions/runtests/RunPipelineTestsDialog.java
+++ b/plugins/misc/testing/src/main/java/org/apache/hop/testing/actions/runtests/RunPipelineTestsDialog.java
@@ -44,7 +44,7 @@ import java.util.List;
 
 public class RunPipelineTestsDialog extends ActionDialog implements IActionDialog {
 
-  private static Class<?> PKG = RunPipelineTestsDialog.class; // For Translator
+  private static final Class<?> PKG = RunPipelineTestsDialog.class; // For Translator
 
   private static final String COLON_SEPARATOR = " : ";
 
@@ -56,8 +56,6 @@ public class RunPipelineTestsDialog extends ActionDialog implements IActionDialo
 
   private TableView wTestNames;
 
-  private Button wOk, wGet, wCancel;
-
   public RunPipelineTestsDialog(
       Shell parent, IAction action, WorkflowMeta workflowMeta, IVariables variables) {
     super(parent, workflowMeta, variables);
@@ -118,13 +116,13 @@ public class RunPipelineTestsDialog extends ActionDialog implements IActionDialo
 
     // Add buttons first, then the script field can use dynamic sizing
     //
-    wOk = new Button(shell, SWT.PUSH);
+    Button wOk = new Button(shell, SWT.PUSH);
     wOk.setText(BaseMessages.getString(PKG, "System.Button.OK"));
     wOk.addListener(SWT.Selection, e -> ok());
-    wGet = new Button(shell, SWT.PUSH);
+    Button wGet = new Button(shell, SWT.PUSH);
     wGet.setText(BaseMessages.getString(PKG, "RunTestsDialog.Button.GetTestNames"));
     wGet.addListener(SWT.Selection, e -> getTestNames());
-    wCancel = new Button(shell, SWT.PUSH);
+    Button wCancel = new Button(shell, SWT.PUSH);
     wCancel.setText(BaseMessages.getString(PKG, "System.Button.Cancel"));
     wCancel.addListener(SWT.Selection, e -> cancel());
 
diff --git a/plugins/misc/testing/src/main/java/org/apache/hop/testing/xp/WriteToDataSetExtensionPoint.java b/plugins/misc/testing/src/main/java/org/apache/hop/testing/xp/WriteToDataSetExtensionPoint.java
index 2334475..b7b5876 100644
--- a/plugins/misc/testing/src/main/java/org/apache/hop/testing/xp/WriteToDataSetExtensionPoint.java
+++ b/plugins/misc/testing/src/main/java/org/apache/hop/testing/xp/WriteToDataSetExtensionPoint.java
@@ -141,10 +141,9 @@ public class WriteToDataSetExtensionPoint
     // At the end of the pipeline, write it...
     //
     pipeline.addExecutionFinishedListener(
-        engine -> {
-          // Write it
-          //
-          DataSetCsvUtil.writeDataSetData(pipeline, dataSet, setRowMeta, transformsForDbRows);
-        });
+        engine ->
+            // Write it
+            //
+            DataSetCsvUtil.writeDataSetData(pipeline, dataSet, setRowMeta, transformsForDbRows));
   }
 }
diff --git a/plugins/misc/testing/src/main/java/org/apache/hop/ui/testing/EditRowsDialog.java b/plugins/misc/testing/src/main/java/org/apache/hop/ui/testing/EditRowsDialog.java
index 51e9c14..5cc5b89 100644
--- a/plugins/misc/testing/src/main/java/org/apache/hop/ui/testing/EditRowsDialog.java
+++ b/plugins/misc/testing/src/main/java/org/apache/hop/ui/testing/EditRowsDialog.java
@@ -71,12 +71,15 @@ public class EditRowsDialog {
 
   private PropsUi props;
 
-  private String title, message;
+  private String title;
+  private String message;
 
   private Rectangle bounds;
 
-  private int hscroll, vscroll;
-  private int hmax, vmax;
+  private int hscroll;
+  private int vscroll;
+  private int hmax;
+  private int vmax;
 
   private IRowMeta rowMeta;
 
diff --git a/plugins/misc/testing/src/main/java/org/apache/hop/ui/testing/PipelineUnitTestSetLocationDialog.java b/plugins/misc/testing/src/main/java/org/apache/hop/ui/testing/PipelineUnitTestSetLocationDialog.java
index 0ba5f08..e827eda 100644
--- a/plugins/misc/testing/src/main/java/org/apache/hop/ui/testing/PipelineUnitTestSetLocationDialog.java
+++ b/plugins/misc/testing/src/main/java/org/apache/hop/ui/testing/PipelineUnitTestSetLocationDialog.java
@@ -192,7 +192,7 @@ public class PipelineUnitTestSetLocationDialog extends Dialog {
 
     // the field mapping grid in between on the left
     //
-    ColumnInfo[] FieldMappingColumns =
+    ColumnInfo[] fieldMappingColumns =
         new ColumnInfo[] {
           new ColumnInfo(
               BaseMessages.getString(
@@ -211,7 +211,7 @@ public class PipelineUnitTestSetLocationDialog extends Dialog {
             new Variables(),
             shell,
             SWT.BORDER | SWT.FULL_SELECTION | SWT.MULTI | SWT.V_SCROLL | SWT.H_SCROLL,
-            FieldMappingColumns,
+            fieldMappingColumns,
             location.getFieldMappings().size(),
             null,
             props);
@@ -225,7 +225,7 @@ public class PipelineUnitTestSetLocationDialog extends Dialog {
 
     // the field mapping grid in between on the left
     //
-    ColumnInfo[] FieldOrderColumns =
+    ColumnInfo[] fieldOrderColumns =
         new ColumnInfo[] {
           new ColumnInfo(
               BaseMessages.getString(
@@ -239,7 +239,7 @@ public class PipelineUnitTestSetLocationDialog extends Dialog {
             new Variables(),
             shell,
             SWT.BORDER | SWT.FULL_SELECTION | SWT.MULTI | SWT.V_SCROLL | SWT.H_SCROLL,
-            FieldOrderColumns,
+            fieldOrderColumns,
             location.getFieldOrder().size(),
             null,
             props);
diff --git a/plugins/tech/avro/src/main/java/org/apache/hop/avro/transforms/avrodecode/AvroDecodeDialog.java b/plugins/tech/avro/src/main/java/org/apache/hop/avro/transforms/avrodecode/AvroDecodeDialog.java
index 03efe0c..25d1a8d 100644
--- a/plugins/tech/avro/src/main/java/org/apache/hop/avro/transforms/avrodecode/AvroDecodeDialog.java
+++ b/plugins/tech/avro/src/main/java/org/apache/hop/avro/transforms/avrodecode/AvroDecodeDialog.java
@@ -62,7 +62,6 @@ public class AvroDecodeDialog extends BaseTransformDialog implements ITransformD
 
   private Combo wSourceField;
   private TableView wFields;
-  private ColumnInfo[] fieldsColumns;
   private RowProducer rowProducer;
 
   public AvroDecodeDialog(
@@ -153,7 +152,7 @@ public class AvroDecodeDialog extends BaseTransformDialog implements ITransformD
     fdlFields.top = new FormAttachment(lastControl, margin);
     wlFields.setLayoutData(fdlFields);
 
-    fieldsColumns =
+    ColumnInfo[] fieldsColumns =
         new ColumnInfo[] {
           new ColumnInfo(
               BaseMessages.getString(PKG, "AvroDecodeDialog.Fields.Column.SourceField"),
diff --git a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListener.java b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListener.java
index ee2da65..a221886 100644
--- a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListener.java
+++ b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListener.java
@@ -46,13 +46,13 @@ public class AzureListener extends BaseTransform<AzureListenerMeta, AzureListene
     implements ITransform<AzureListenerMeta, AzureListenerData> {
 
   public AzureListener(
-      TransformMeta TransformMeta,
+      TransformMeta transformMeta,
       AzureListenerMeta meta,
       AzureListenerData data,
       int copyNr,
       PipelineMeta pipelineMeta,
       Pipeline pipeline) {
-    super(TransformMeta, meta, data, copyNr, pipelineMeta, pipeline);
+    super(transformMeta, meta, data, copyNr, pipelineMeta, pipeline);
   }
 
   @Override
@@ -294,7 +294,7 @@ public class AzureListener extends BaseTransform<AzureListenerMeta, AzureListene
                 }
               })
           .thenAccept(
-              (unused) -> {
+              unused -> {
                 // This stage will only execute if registerEventProcessor succeeded.
                 // If it completed exceptionally, this stage will be skipped.
                 //
@@ -309,19 +309,18 @@ public class AzureListener extends BaseTransform<AzureListenerMeta, AzureListene
                 }
               })
           .thenCompose(
-              (unused) -> {
-                // This stage will only execute if registerEventProcessor succeeded.
-                //
-                // Processing of events continues until unregisterEventProcessor is called.
-                // Unregistering shuts down the
-                // receivers on all currently owned leases, shuts down the instances of the event
-                // processor class, and
-                // releases the leases for other instances of EventProcessorHost to claim.
-                //
-                return host.unregisterEventProcessor();
-              })
+              unused ->
+                  // This stage will only execute if registerEventProcessor succeeded.
+                  //
+                  // Processing of events continues until unregisterEventProcessor is called.
+                  // Unregistering shuts down the
+                  // receivers on all currently owned leases, shuts down the instances of the event
+                  // processor class, and
+                  // releases the leases for other instances of EventProcessorHost to claim.
+                  //
+                  host.unregisterEventProcessor())
           .exceptionally(
-              (e) -> {
+              e -> {
                 logError("Failure while unregistering: " + e.toString());
                 if (e.getCause() != null) {
                   logError("Inner exception: " + e.getCause().toString());
diff --git a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerDialog.java b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerDialog.java
index 4ae2e22..65e1cf3 100644
--- a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerDialog.java
+++ b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerDialog.java
@@ -41,7 +41,7 @@ import org.eclipse.swt.widgets.*;
 
 public class AzureListenerDialog extends BaseTransformDialog implements ITransformDialog {
 
-  private static Class<?> PKG =
+  private static final Class<?> PKG =
       AzureListenerMeta.class; // for i18n purposes, needed by Translator2!!
 
   private Text wTransformName;
diff --git a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerEventProcessor.java b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerEventProcessor.java
index aa34e84..f1e7e0c 100644
--- a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerEventProcessor.java
+++ b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerEventProcessor.java
@@ -48,8 +48,8 @@ public class AzureListenerEventProcessor implements IEventProcessor {
   private EventData lastData;
 
   public AzureListenerEventProcessor(
-      AzureListener Transform, AzureListenerData data, int checkpointBatchingSize) {
-    this.azureTransform = Transform;
+      AzureListener transform, AzureListenerData data, int checkpointBatchingSize) {
+    this.azureTransform = transform;
     this.azureData = data;
     this.checkpointBatchingSize = checkpointBatchingSize;
 
diff --git a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerMeta.java b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerMeta.java
index 48e51cc..33c80d0 100644
--- a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerMeta.java
+++ b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/listen/AzureListenerMeta.java
@@ -141,10 +141,10 @@ public class AzureListenerMeta extends BaseTransformMeta
       //
       try {
         PipelineMeta batchTransMeta = loadBatchPipelineMeta(this, metadataProvider, variables);
-        IRowMeta TransformFields =
+        IRowMeta transformFields =
             batchTransMeta.getTransformFields(variables, variables.resolve(batchOutputTransform));
         rowMeta.clear();
-        rowMeta.addRowMeta(TransformFields);
+        rowMeta.addRowMeta(transformFields);
         return;
       } catch (Exception e) {
         throw new HopTransformException(
diff --git a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/write/AzureWrite.java b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/write/AzureWrite.java
index 6645981..5913aab 100644
--- a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/write/AzureWrite.java
+++ b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/write/AzureWrite.java
@@ -39,13 +39,13 @@ public class AzureWrite extends BaseTransform<AzureWriterMeta, AzureWriterData>
     implements ITransform<AzureWriterMeta, AzureWriterData> {
 
   public AzureWrite(
-      TransformMeta TransformMeta,
+      TransformMeta transformMeta,
       AzureWriterMeta meta,
       AzureWriterData data,
       int copyNr,
       PipelineMeta pipelineMeta,
       Pipeline pipeline) {
-    super(TransformMeta, meta, data, copyNr, pipelineMeta, pipeline);
+    super(transformMeta, meta, data, copyNr, pipelineMeta, pipeline);
   }
 
   @Override
diff --git a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/write/AzureWriterDialog.java b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/write/AzureWriterDialog.java
index 5861e5c..970cd3b 100644
--- a/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/write/AzureWriterDialog.java
+++ b/plugins/tech/azure/src/main/java/org/apache/hop/pipeline/transforms/eventhubs/write/AzureWriterDialog.java
@@ -38,7 +38,7 @@ import org.eclipse.swt.widgets.*;
 
 public class AzureWriterDialog extends BaseTransformDialog implements ITransformDialog {
 
-  private static Class<?> PKG = AzureWriterMeta.class; // for i18n purposes, needed by Translator2!!
+  private static final Class<?> PKG = AzureWriterMeta.class; // for i18n purposes, needed by Translator2!!
 
   private Text wTransformName;
   private TextVar wNamespace;
diff --git a/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/DriverConnection.java b/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/DriverConnection.java
index 07d38bc..de2e30c 100644
--- a/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/DriverConnection.java
+++ b/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/DriverConnection.java
@@ -40,7 +40,8 @@ public class DriverConnection implements Connection, AutoCloseable {
 
   private String host;
   private int port = 9042;
-  private String username, password;
+  private String username;
+  private String password;
   private Map<String, String> opts = new HashMap<>();
   private Cluster cluster;
   private boolean useCompression;
diff --git a/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/DriverCqlRowHandler.java b/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/DriverCqlRowHandler.java
index ef100dc..0e3c67f 100644
--- a/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/DriverCqlRowHandler.java
+++ b/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/DriverCqlRowHandler.java
@@ -230,7 +230,9 @@ public class DriverCqlRowHandler implements CqlRowHandler {
 
   protected static <T> T[] copyExcluding(T[] source, T[] target, List<Integer> toRemove) {
     int removed = toRemove.size();
-    int start = 0, dest = 0, removeCount = 0;
+    int start = 0;
+    int dest = 0;
+    int removeCount = 0;
     for (int idx : toRemove) {
       int len = idx - start;
       if (len > 0) {
diff --git a/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/TableMetaData.java b/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/TableMetaData.java
index 4a95255..928ca0c 100644
--- a/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/TableMetaData.java
+++ b/plugins/tech/cassandra/src/main/java/org/apache/hop/databases/cassandra/datastax/TableMetaData.java
@@ -32,7 +32,6 @@ import java.util.stream.Collectors;
 
 public class TableMetaData implements ITableMetaData {
 
-  private DriverKeyspace keyspace;
   private TableMetadata meta;
 
   private String name;
@@ -48,8 +47,8 @@ public class TableMetaData implements ITableMetaData {
 
   @Override
   public void setKeyspace(Keyspace keyspace) {
-    this.keyspace = (DriverKeyspace) keyspace;
-    expandCollection = this.keyspace.getConnection().isExpandCollection();
+    DriverKeyspace keyspace1 = (DriverKeyspace) keyspace;
+    expandCollection = keyspace1.getConnection().isExpandCollection();
   }
 
   @Override
diff --git a/plugins/tech/cassandra/src/main/java/org/apache/hop/pipeline/transforms/cassandraoutput/CassandraOutputDialog.java b/plugins/tech/cassandra/src/main/java/org/apache/hop/pipeline/transforms/cassandraoutput/CassandraOutputDialog.java
index 570cd60..3734fda 100644
--- a/plugins/tech/cassandra/src/main/java/org/apache/hop/pipeline/transforms/cassandraoutput/CassandraOutputDialog.java
+++ b/plugins/tech/cassandra/src/main/java/org/apache/hop/pipeline/transforms/cassandraoutput/CassandraOutputDialog.java
@@ -75,11 +75,8 @@ public class CassandraOutputDialog extends BaseTransformDialog implements ITrans
 
   private Button wUnloggedBatch;
 
-  private Label wlKeyField;
   private TextVar wKeyField;
 
-  private Button wbGetFields;
-
   private Button wbCreateTable;
 
   private TextVar wWithClause;
@@ -393,7 +390,7 @@ public class CassandraOutputDialog extends BaseTransformDialog implements ITrans
         e -> wTtlValue.setToolTipText(variables.resolve(wTtlValue.getText())));
 
     // key field line
-    wlKeyField = new Label(wWriteComp, SWT.RIGHT);
+    Label wlKeyField = new Label(wWriteComp, SWT.RIGHT);
     props.setLook(wlKeyField);
     wlKeyField.setText(BaseMessages.getString(PKG, "CassandraOutputDialog.KeyField.Label"));
     FormData fdlKeyField = new FormData();
@@ -402,7 +399,7 @@ public class CassandraOutputDialog extends BaseTransformDialog implements ITrans
     fdlKeyField.right = new FormAttachment(middle, -margin);
     wlKeyField.setLayoutData(fdlKeyField);
 
-    wbGetFields = new Button(wWriteComp, SWT.PUSH | SWT.CENTER);
+    Button wbGetFields = new Button(wWriteComp, SWT.PUSH | SWT.CENTER);
     props.setLook(wbGetFields);
     wbGetFields.setText(BaseMessages.getString(PKG, "CassandraOutputDialog.GetFields.Button"));
     FormData fdbGetFields = new FormData();
diff --git a/plugins/tech/cassandra/src/main/java/org/apache/hop/pipeline/transforms/cassandrasstableoutput/writer/SSTableWriterBuilder.java b/plugins/tech/cassandra/src/main/java/org/apache/hop/pipeline/transforms/cassandrasstableoutput/writer/SSTableWriterBuilder.java
index 17d46af..10cfacd 100644
--- a/plugins/tech/cassandra/src/main/java/org/apache/hop/pipeline/transforms/cassandrasstableoutput/writer/SSTableWriterBuilder.java
+++ b/plugins/tech/cassandra/src/main/java/org/apache/hop/pipeline/transforms/cassandrasstableoutput/writer/SSTableWriterBuilder.java
@@ -26,9 +26,6 @@ public class SSTableWriterBuilder {
   /** Path to cassandra YAML config */
   private String configFilePath;
 
-  /** CQL Version */
-  private int cqlVersion;
-
   /** The directory to output to */
   private String directory;
 
@@ -87,7 +84,7 @@ public class SSTableWriterBuilder {
   }
 
   public SSTableWriterBuilder withCqlVersion(int cqlVersion) {
-    this.cqlVersion = cqlVersion;
+    /** CQL Version */
     return this;
   }
 
diff --git a/plugins/tech/cassandra/src/main/java/org/apache/hop/workflow/actions/execcql/ExecCqlDialog.java b/plugins/tech/cassandra/src/main/java/org/apache/hop/workflow/actions/execcql/ExecCqlDialog.java
index ee66db1..b4188dc 100644
--- a/plugins/tech/cassandra/src/main/java/org/apache/hop/workflow/actions/execcql/ExecCqlDialog.java
+++ b/plugins/tech/cassandra/src/main/java/org/apache/hop/workflow/actions/execcql/ExecCqlDialog.java
@@ -41,7 +41,7 @@ import org.eclipse.swt.layout.FormLayout;
 import org.eclipse.swt.widgets.*;
 
 public class ExecCqlDialog extends ActionDialog implements IActionDialog {
-  private static Class<?> PKG = ExecCqlDialog.class; // For Translator
+  private static final Class<?> PKG = ExecCqlDialog.class; // For Translator
 
   private Shell shell;
 
diff --git a/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/GoogleDriveFileObject.java b/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/GoogleDriveFileObject.java
index 1ad938d..ff2653a 100644
--- a/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/GoogleDriveFileObject.java
+++ b/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/GoogleDriveFileObject.java
@@ -220,11 +220,11 @@ public class GoogleDriveFileObject extends AbstractFileObject {
   /**
    * Creates an authorized Credential object.
    *
-   * @param HTTP_TRANSPORT The network HTTP Transport.
+   * @param httpTransport The network HTTP Transport.
    * @return An authorized Credential object.
    * @throws IOException If the credentials.json file cannot be found.
    */
-  private static Credential getCredentials(final NetHttpTransport HTTP_TRANSPORT)
+  private static Credential getCredentials(final NetHttpTransport httpTransport)
       throws IOException {
     // Load client secrets.
     InputStream in = new FileInputStream(getCredentialsFile());
@@ -236,7 +236,7 @@ public class GoogleDriveFileObject extends AbstractFileObject {
 
     // Build flow and trigger user authorization request.
     GoogleAuthorizationCodeFlow flow =
-        new GoogleAuthorizationCodeFlow.Builder(HTTP_TRANSPORT, JSON_FACTORY, clientSecrets, SCOPES)
+        new GoogleAuthorizationCodeFlow.Builder(httpTransport, JSON_FACTORY, clientSecrets, SCOPES)
             .setDataStoreFactory(new FileDataStoreFactory(getTokensFolder()))
             .setAccessType("offline")
             .build();
diff --git a/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/ui/GoogleAuthorizationDialog.java b/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/ui/GoogleAuthorizationDialog.java
index 4a2745b..8569826 100644
--- a/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/ui/GoogleAuthorizationDialog.java
+++ b/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/ui/GoogleAuthorizationDialog.java
@@ -115,9 +115,7 @@ public class GoogleAuthorizationDialog extends Dialog {
 
       helpLabel.addListener(
           SWT.MouseExit,
-          event -> {
-            helpLabel.setForeground(new Color(display, props.contrastColor(0, 94, 170)));
-          });
+          event -> helpLabel.setForeground(new Color(display, props.contrastColor(0, 94, 170))));
 
       Label cancelButton = new Label(dialog, SWT.NONE);
       Image closeImage =
diff --git a/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/util/CustomDataStoreFactory.java b/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/util/CustomDataStoreFactory.java
index 156be51..f871e5f 100644
--- a/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/util/CustomDataStoreFactory.java
+++ b/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/util/CustomDataStoreFactory.java
@@ -117,10 +117,10 @@ public class CustomDataStoreFactory extends AbstractDataStoreFactory {
 
       try {
         List<V> result = Lists.newArrayList();
-        Iterator i$ = this.keyValueMap.values().iterator();
+        Iterator iterator = this.keyValueMap.values().iterator();
 
-        while (i$.hasNext()) {
-          byte[] bytes = (byte[]) i$.next();
+        while (iterator.hasNext()) {
+          byte[] bytes = (byte[]) iterator.next();
           result.add(IOUtils.deserialize(bytes));
         }
 
diff --git a/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/util/CustomLocalServerReceiver.java b/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/util/CustomLocalServerReceiver.java
index f3ee98e..430598b 100644
--- a/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/util/CustomLocalServerReceiver.java
+++ b/plugins/tech/google/src/main/java/org/apache/hop/vfs/googledrive/util/CustomLocalServerReceiver.java
@@ -61,11 +61,11 @@ public class CustomLocalServerReceiver implements VerificationCodeReceiver {
     }
 
     this.server = new Server(this.port);
-    Connector[] arr$ = this.server.getConnectors();
-    int len$ = arr$.length;
+    Connector[] connectors = this.server.getConnectors();
+    int length = connectors.length;
 
-    for (int i$ = 0; i$ < len$; ++i$) {
-      Connector c = arr$[i$];
+    for (int i = 0; i < length; ++i) {
+      Connector c = connectors[i];
       c.setHost(this.host);
     }
 
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/check/CheckConnectionsDialog.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/check/CheckConnectionsDialog.java
index fce1ada..bbf17c1 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/check/CheckConnectionsDialog.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/check/CheckConnectionsDialog.java
@@ -47,7 +47,7 @@ import java.util.List;
 
 public class CheckConnectionsDialog extends ActionDialog implements IActionDialog {
 
-  private static Class<?> PKG = CheckConnectionsDialog.class; // For Translator
+  private static final Class<?> PKG = CheckConnectionsDialog.class; // For Translator
 
   private Shell shell;
 
@@ -58,10 +58,6 @@ public class CheckConnectionsDialog extends ActionDialog implements IActionDialo
   private Text wName;
   private TableView wConnections;
 
-  private Button wOk, wCancel;
-
-  private String[] availableConnectionNames;
-
   public CheckConnectionsDialog(
       Shell parent, IAction iAction, WorkflowMeta workflowMeta, IVariables variables) {
     super(parent, workflowMeta, variables);
@@ -96,10 +92,10 @@ public class CheckConnectionsDialog extends ActionDialog implements IActionDialo
     // Add buttons first, then the list of connections dynamically sizing
     // Put these buttons at the bottom
     //
-    wOk = new Button(shell, SWT.PUSH);
+    Button wOk = new Button(shell, SWT.PUSH);
     wOk.setText(BaseMessages.getString(PKG, "System.Button.OK"));
     wOk.addListener(SWT.Selection, e -> ok());
-    wCancel = new Button(shell, SWT.PUSH);
+    Button wCancel = new Button(shell, SWT.PUSH);
     wCancel.setText(BaseMessages.getString(PKG, "System.Button.Cancel"));
     wCancel.addListener(SWT.Selection, e -> cancel());
     BaseTransformDialog.positionBottomButtons(
@@ -136,6 +132,7 @@ public class CheckConnectionsDialog extends ActionDialog implements IActionDialo
     fdlConnections.top = new FormAttachment(wName, margin);
     wlConnections.setLayoutData(fdlConnections);
 
+    String[] availableConnectionNames;
     try {
       IHopMetadataSerializer<NeoConnection> connectionSerializer =
           getMetadataProvider().getSerializer(NeoConnection.class);
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/constraint/Neo4jConstraintDialog.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/constraint/Neo4jConstraintDialog.java
index d72a598..cfed79c 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/constraint/Neo4jConstraintDialog.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/constraint/Neo4jConstraintDialog.java
@@ -45,7 +45,7 @@ import org.eclipse.swt.widgets.*;
 import java.util.List;
 
 public class Neo4jConstraintDialog extends ActionDialog implements IActionDialog {
-  private static Class<?> PKG = Neo4jConstraintDialog.class; // For Translator
+  private static final Class<?> PKG = Neo4jConstraintDialog.class; // For Translator
 
   private Shell shell;
 
@@ -57,8 +57,6 @@ public class Neo4jConstraintDialog extends ActionDialog implements IActionDialog
   private MetaSelectionLine<NeoConnection> wConnection;
   private TableView wUpdates;
 
-  private Button wCancel;
-
   public Neo4jConstraintDialog(
       Shell parent, IAction iAction, WorkflowMeta workflowMeta, IVariables variables) {
     super(parent, workflowMeta, variables);
@@ -135,7 +133,7 @@ public class Neo4jConstraintDialog extends ActionDialog implements IActionDialog
     Button wOk = new Button(shell, SWT.PUSH);
     wOk.setText(BaseMessages.getString(PKG, "System.Button.OK"));
     wOk.addListener(SWT.Selection, e -> ok());
-    wCancel = new Button(shell, SWT.PUSH);
+    Button wCancel = new Button(shell, SWT.PUSH);
     wCancel.setText(BaseMessages.getString(PKG, "System.Button.Cancel"));
     wCancel.addListener(SWT.Selection, e -> cancel());
 
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/cypherscript/CypherScriptDialog.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/cypherscript/CypherScriptDialog.java
index 7201a65..c800f88 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/cypherscript/CypherScriptDialog.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/cypherscript/CypherScriptDialog.java
@@ -42,7 +42,7 @@ import org.eclipse.swt.layout.FormLayout;
 import org.eclipse.swt.widgets.*;
 
 public class CypherScriptDialog extends ActionDialog implements IActionDialog {
-  private static Class<?> PKG = CypherScriptDialog.class; // For Translator
+  private static final Class<?> PKG = CypherScriptDialog.class; // For Translator
 
   private Shell shell;
 
@@ -55,8 +55,6 @@ public class CypherScriptDialog extends ActionDialog implements IActionDialog {
   private TextVar wScript;
   private Button wReplaceVariables;
 
-  private Button wOk, wCancel;
-
   public CypherScriptDialog(
       Shell parent, IAction iAction, WorkflowMeta workflowMeta, IVariables variables) {
     super(parent, workflowMeta, variables);
@@ -130,10 +128,10 @@ public class CypherScriptDialog extends ActionDialog implements IActionDialog {
 
     // Add buttons first, then the script field can use dynamic sizing
     //
-    wOk = new Button(shell, SWT.PUSH);
+    Button wOk = new Button(shell, SWT.PUSH);
     wOk.setText(BaseMessages.getString(PKG, "System.Button.OK"));
     wOk.addListener(SWT.Selection, e -> ok());
-    wCancel = new Button(shell, SWT.PUSH);
+    Button wCancel = new Button(shell, SWT.PUSH);
     wCancel.setText(BaseMessages.getString(PKG, "System.Button.Cancel"));
     wCancel.addListener(SWT.Selection, e -> cancel());
 
@@ -180,7 +178,7 @@ public class CypherScriptDialog extends ActionDialog implements IActionDialog {
     BaseTransformDialog.positionBottomButtons(
         shell,
         new Button[] {
-          wOk, wCancel,
+                wOk, wCancel,
         },
         margin,
         null);
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/index/Neo4jIndexDialog.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/index/Neo4jIndexDialog.java
index 193d777..c220206 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/index/Neo4jIndexDialog.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/actions/index/Neo4jIndexDialog.java
@@ -45,7 +45,7 @@ import org.eclipse.swt.widgets.*;
 import java.util.List;
 
 public class Neo4jIndexDialog extends ActionDialog implements IActionDialog {
-  private static Class<?> PKG = Neo4jIndexDialog.class; // For Translator
+  private static final Class<?> PKG = Neo4jIndexDialog.class; // For Translator
 
   private Shell shell;
 
@@ -57,8 +57,6 @@ public class Neo4jIndexDialog extends ActionDialog implements IActionDialog {
   private MetaSelectionLine<NeoConnection> wConnection;
   private TableView wUpdates;
 
-  private Button wCancel;
-
   public Neo4jIndexDialog(
       Shell parent, IAction iAction, WorkflowMeta workflowMeta, IVariables variables) {
     super(parent, workflowMeta, variables);
@@ -135,7 +133,7 @@ public class Neo4jIndexDialog extends ActionDialog implements IActionDialog {
     Button wOk = new Button(shell, SWT.PUSH);
     wOk.setText(BaseMessages.getString(PKG, "System.Button.OK"));
     wOk.addListener(SWT.Selection, e -> ok());
-    wCancel = new Button(shell, SWT.PUSH);
+    Button wCancel = new Button(shell, SWT.PUSH);
     wCancel.setText(BaseMessages.getString(PKG, "System.Button.Cancel"));
     wCancel.addListener(SWT.Selection, e -> cancel());
 
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/model/GraphModelEditor.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/model/GraphModelEditor.java
index ba2acf8..af09127 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/model/GraphModelEditor.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/model/GraphModelEditor.java
@@ -73,7 +73,7 @@ import java.util.*;
 
 public class GraphModelEditor extends MetadataEditor<GraphModel> {
 
-  private static Class<?> PKG =
+  private static final Class<?> PKG =
       GraphModelEditor.class; // for i18n purposes, needed by Translator2!!
 
   private CTabFolder wTabs;
@@ -106,7 +106,6 @@ public class GraphModelEditor extends MetadataEditor<GraphModel> {
   private GraphModel graphModel;
   private GraphNode activeNode;
   private GraphRelationship activeRelationship;
-  private Button wImportNode;
 
   private Point mouseDownPoint;
   private Canvas wCanvas;
@@ -403,7 +402,7 @@ public class GraphModelEditor extends MetadataEditor<GraphModel> {
     fdImportGraph.right = new FormAttachment(75, 0);
     fdImportGraph.top = new FormAttachment(lastControl, 50);
     wImportGraph.setLayoutData(fdImportGraph);
-    wImportGraph.addListener(SWT.Selection, (e) -> importGraphFromFile());
+    wImportGraph.addListener(SWT.Selection, e -> importGraphFromFile());
     lastControl = wImportGraph;
 
     Button wExportGraph = new Button(wModelComp, SWT.PUSH);
@@ -414,7 +413,7 @@ public class GraphModelEditor extends MetadataEditor<GraphModel> {
     fdExportGraph.right = new FormAttachment(75, 0);
     fdExportGraph.top = new FormAttachment(lastControl, margin);
     wExportGraph.setLayoutData(fdExportGraph);
-    wExportGraph.addListener(SWT.Selection, (e) -> exportGraphToFile());
+    wExportGraph.addListener(SWT.Selection, e -> exportGraphToFile());
     lastControl = wExportGraph;
 
     Button wSolutionsWorkbenchImportGraph = new Button(wModelComp, SWT.PUSH);
@@ -427,7 +426,7 @@ public class GraphModelEditor extends MetadataEditor<GraphModel> {
     fdSolutionsWorkbenchImportGraph.top = new FormAttachment(lastControl, 50);
     wSolutionsWorkbenchImportGraph.setLayoutData(fdSolutionsWorkbenchImportGraph);
     wSolutionsWorkbenchImportGraph.addListener(
-        SWT.Selection, (e) -> importGraphFromSolutionsWorkbench());
+        SWT.Selection, e -> importGraphFromSolutionsWorkbench());
     lastControl = wSolutionsWorkbenchImportGraph;
 
     Button wArrowsAppImportGraph = new Button(wModelComp, SWT.PUSH);
@@ -439,7 +438,7 @@ public class GraphModelEditor extends MetadataEditor<GraphModel> {
     fdArrowsAppImportGraph.right = new FormAttachment(75, 0);
     fdArrowsAppImportGraph.top = new FormAttachment(lastControl, margin);
     wArrowsAppImportGraph.setLayoutData(fdArrowsAppImportGraph);
-    wArrowsAppImportGraph.addListener(SWT.Selection, (e) -> importGraphFromArrowsApp());
+    wArrowsAppImportGraph.addListener(SWT.Selection, e -> importGraphFromArrowsApp());
     lastControl = wArrowsAppImportGraph;
 
     Button wCreateIndexAction = new Button(wModelComp, SWT.PUSH);
@@ -451,7 +450,7 @@ public class GraphModelEditor extends MetadataEditor<GraphModel> {
     fdCreateIndexAction.right = new FormAttachment(75, 0);
     fdCreateIndexAction.top = new FormAttachment(lastControl, 50);
     wCreateIndexAction.setLayoutData(fdCreateIndexAction);
-    wCreateIndexAction.addListener(SWT.Selection, (e) -> copyIndexActionToClipboard());
+    wCreateIndexAction.addListener(SWT.Selection, e -> copyIndexActionToClipboard());
 
     FormData fdModelComp = new FormData();
     fdModelComp.left = new FormAttachment(0, 0);
@@ -501,23 +500,23 @@ public class GraphModelEditor extends MetadataEditor<GraphModel> {
     //
     Button wNewNode = new Button(wNodesComp, SWT.PUSH);
     wNewNode.setText("New node");
-    wNewNode.addListener(SWT.Selection, (e) -> newNode());
+    wNewNode.addListener(SWT.Selection, e -> newNode());
 
     Button wDeleteNode = new Button(wNodesComp, SWT.PUSH);
     wDeleteNode.setText("Delete node");
-    wDeleteNode.addListener(SWT.Selection, (e) -> deleteNode());
+    wDeleteNode.addListener(SWT.Selection, e -> deleteNode());
 
     Button wCopyNode = new Button(wNodesComp, SWT.PUSH);
     wCopyNode.setText("Copy node");
-    wCopyNode.addListener(SWT.Selection, (e) -> copyNode());
+    wCopyNode.addListener(SWT.Selection, e -> copyNode());
 
-    wImportNode = new Button(wNodesComp, SWT.PUSH);
+    Button wImportNode = new Button(wNodesComp, SWT.PUSH);
     wImportNode.setText("Import properties");
-    wImportNode.addListener(SWT.Selection, (e) -> importNodeProperties());
+    wImportNode.addListener(SWT.Selection, e -> importNodeProperties());
 
     Button wNewRelationshipNode = new Button(wNodesComp, SWT.PUSH);
     wNewRelationshipNode.setText("New relationship");
-    wNewRelationshipNode.addListener(SWT.Selection, (e) -> newRelationshipFromNode());
+    wNewRelationshipNode.addListener(SWT.Selection, e -> newRelationshipFromNode());
 
     BaseTransformDialog.positionBottomButtons(
         wNodesComp,
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/perspective/HopNeo4jPerspective.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/perspective/HopNeo4jPerspective.java
index 25f17f3..a8da8d2 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/perspective/HopNeo4jPerspective.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/perspective/HopNeo4jPerspective.java
@@ -83,19 +83,15 @@ public class HopNeo4jPerspective implements IHopPerspective {
 
   public static final String ID_PERSPECTIVE_TOOLBAR_ITEM = "9000-perspective-neo4j";
 
-  private Image neo4jImage;
-
   private HopGui hopGui;
   private Composite parent;
   private Composite composite;
-  private FormData formData;
   private Combo wExecutions;
   private CTabFolder tabFolder;
   private TableView wResults;
   private Text wLogging;
   private Tree wTree;
   private Text wCypher;
-  private Image lineageImage;
   private Color errorLineBackground;
   private Combo wAmount;
   private Button wOnlyRoot;
@@ -151,10 +147,10 @@ public class HopNeo4jPerspective implements IHopPerspective {
     PropsUi props = PropsUi.getInstance();
 
     int size = (int) Math.round((double) ConstUi.SMALL_ICON_SIZE * props.getZoomFactor());
-    neo4jImage =
+    Image neo4jImage =
         SwtSvgImageUtil.getImage(
             hopGui.getDisplay(), this.getClass().getClassLoader(), "neo4j_logo.svg", size, size);
-    lineageImage =
+    Image lineageImage =
         SwtSvgImageUtil.getImage(
             hopGui.getDisplay(), this.getClass().getClassLoader(), "lineage.svg", size, size);
     errorLineBackground = new Color(hopGui.getDisplay(), 201, 232, 251);
@@ -168,7 +164,7 @@ public class HopNeo4jPerspective implements IHopPerspective {
     layout.marginBottom = props.getMargin();
     composite.setLayout(layout);
 
-    formData = new FormData();
+    FormData formData = new FormData();
     formData.left = new FormAttachment(0, 0);
     formData.top = new FormAttachment(0, 0);
     formData.right = new FormAttachment(100, 0);
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/shared/NeoConnectionEditor.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/shared/NeoConnectionEditor.java
index 63bc66b..532e03a 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/shared/NeoConnectionEditor.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/shared/NeoConnectionEditor.java
@@ -478,35 +478,12 @@ public class NeoConnectionEditor extends MetadataEditor<NeoConnection> {
             getMetadata().getManualUrls().size(),
             e -> setChanged(),
             props);
-    wUrls.table.addListener(
-        SWT.Selection,
-        e -> {
-          enableFields();
-        });
-    wUrls.table.addListener(
-        SWT.MouseDown,
-        e -> {
-          enableFields();
-        });
-    wUrls.table.addListener(
-        SWT.MouseUp,
-        e -> {
-          enableFields();
-        });
-    wUrls.table.addListener(
-        SWT.FocusIn,
-        e -> {
-          enableFields();
-        });
-    wUrls.table.addListener(
-        SWT.FocusOut,
-        e -> {
-          enableFields();
-        });
-    wUrls.addModifyListener(
-        e -> {
-          enableFields();
-        });
+    wUrls.table.addListener(SWT.Selection, e -> enableFields());
+    wUrls.table.addListener(SWT.MouseDown, e -> enableFields());
+    wUrls.table.addListener(SWT.MouseUp, e -> enableFields());
+    wUrls.table.addListener(SWT.FocusIn, e -> enableFields());
+    wUrls.table.addListener(SWT.FocusOut, e -> enableFields());
+    wUrls.addModifyListener(e -> enableFields());
 
     FormData fdUrls = new FormData();
     fdUrls.top = new FormAttachment(0, 0);
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/cypher/CypherDialog.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/cypher/CypherDialog.java
index bda2cfb..9881742 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/cypher/CypherDialog.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/cypher/CypherDialog.java
@@ -66,7 +66,8 @@ import java.util.Map;
 
 public class CypherDialog extends BaseTransformDialog implements ITransformDialog {
 
-  private static Class<?> PKG = CypherMeta.class; // for i18n purposes, needed by Translator2!!
+  private static final Class<?> PKG =
+      CypherMeta.class; // for i18n purposes, needed by Translator2!!
 
   private CTabFolder wTabFolder;
 
@@ -460,7 +461,7 @@ public class CypherDialog extends BaseTransformDialog implements ITransformDialo
     wbGetParameters.setLayoutData(fdbGetParameters);
     wbGetParameters.addListener(
         SWT.Selection,
-        (e) -> {
+        e -> {
           try {
             IRowMeta r = pipelineMeta.getPrevTransformFields(variables, transformMeta);
 
@@ -572,7 +573,7 @@ public class CypherDialog extends BaseTransformDialog implements ITransformDialo
     fdbGetReturnFields.right = new FormAttachment(100, 0);
     fdbGetReturnFields.top = new FormAttachment(wlReturns, 0, SWT.BOTTOM);
     wbGetReturnFields.setLayoutData(fdbGetReturnFields);
-    wbGetReturnFields.addListener(SWT.Selection, (e) -> getReturnValues());
+    wbGetReturnFields.addListener(SWT.Selection, e -> getReturnValues());
 
     wReturns =
         new TableView(
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/gencsv/GenerateCsvDialog.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/gencsv/GenerateCsvDialog.java
index 5456c69..244f166 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/gencsv/GenerateCsvDialog.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/gencsv/GenerateCsvDialog.java
@@ -41,7 +41,8 @@ import org.eclipse.swt.widgets.*;
 
 public class GenerateCsvDialog extends BaseTransformDialog implements ITransformDialog {
 
-  private static Class<?> PKG = GenerateCsvMeta.class; // for i18n purposes, needed by Translator2!!
+  private static final Class<?> PKG =
+      GenerateCsvMeta.class; // for i18n purposes, needed by Translator2!!
 
   private Text wTransformName;
 
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/graph/GraphOutputDialog.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/graph/GraphOutputDialog.java
index 1709b0e..64fbec9 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/graph/GraphOutputDialog.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/graph/GraphOutputDialog.java
@@ -53,24 +53,15 @@ import org.eclipse.swt.custom.CTabItem;
 import org.eclipse.swt.layout.FormAttachment;
 import org.eclipse.swt.layout.FormData;
 import org.eclipse.swt.layout.FormLayout;
-import org.eclipse.swt.widgets.Button;
-import org.eclipse.swt.widgets.Composite;
-import org.eclipse.swt.widgets.Control;
-import org.eclipse.swt.widgets.Label;
-import org.eclipse.swt.widgets.Shell;
-import org.eclipse.swt.widgets.TableItem;
-import org.eclipse.swt.widgets.Text;
-
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Collections;
-import java.util.HashSet;
+import org.eclipse.swt.widgets.*;
+
 import java.util.List;
-import java.util.Set;
+import java.util.*;
 
 public class GraphOutputDialog extends BaseTransformDialog implements ITransformDialog {
 
-  private static Class<?> PKG = GraphOutputMeta.class; // for i18n purposes, needed by Translator2!!
+  private static final Class<?> PKG =
+      GraphOutputMeta.class; // for i18n purposes, needed by Translator2!!
 
   private Text wTransformName;
 
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/importer/ImporterDialog.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/importer/ImporterDialog.java
index 9704d19..8cc7fc3 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/importer/ImporterDialog.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/importer/ImporterDialog.java
@@ -41,7 +41,8 @@ import org.eclipse.swt.widgets.*;
 
 public class ImporterDialog extends BaseTransformDialog implements ITransformDialog {
 
-  private static Class<?> PKG = ImporterMeta.class; // for i18n purposes, needed by Translator2!!
+  private static final Class<?> PKG =
+      ImporterMeta.class; // for i18n purposes, needed by Translator2!!
 
   private Text wTransformName;
 
@@ -51,7 +52,6 @@ public class ImporterDialog extends BaseTransformDialog implements ITransformDia
   private TextVar wAdminCommand;
   private TextVar wBaseFolder;
 
-  private Button wVerbose;
   private Button wHighIo;
   private Button wCacheOnHeap;
   private Button wIgnoreEmptyStrings;
@@ -262,7 +262,7 @@ public class ImporterDialog extends BaseTransformDialog implements ITransformDia
     fdlVerbose.right = new FormAttachment(middle, -margin);
     fdlVerbose.top = new FormAttachment(lastControl, 2 * margin);
     wlVerbose.setLayoutData(fdlVerbose);
-    wVerbose = new Button(wComposite, SWT.CHECK | SWT.LEFT);
+    Button wVerbose = new Button(wComposite, SWT.CHECK | SWT.LEFT);
     props.setLook(wVerbose);
     FormData fdVerbose = new FormData();
     fdVerbose.left = new FormAttachment(middle, 0);
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/loginfo/GetLoggingInfoDialog.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/loginfo/GetLoggingInfoDialog.java
index 2f7c1d9..b0d1af7 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/loginfo/GetLoggingInfoDialog.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/loginfo/GetLoggingInfoDialog.java
@@ -43,15 +43,12 @@ import org.eclipse.swt.layout.FormLayout;
 import org.eclipse.swt.widgets.*;
 
 public class GetLoggingInfoDialog extends BaseTransformDialog implements ITransformDialog {
-  private static Class<?> PKG = GetLoggingInfo.class; // for i18n purposes, needed by Translator2!!
+  private static final Class<?> PKG =
+      GetLoggingInfo.class; // for i18n purposes, needed by Translator2!!
 
-  private Label wlTransformname;
   private Text wTransformname;
-  private FormData fdlTransformname, fdTransformname;
 
-  private Label wlFields;
   private TableView wFields;
-  private FormData fdlFields, fdFields;
 
   private GetLoggingInfoMeta input;
 
@@ -108,10 +105,10 @@ public class GetLoggingInfoDialog extends BaseTransformDialog implements ITransf
     isReceivingInput = pipelineMeta.findPreviousTransforms(transformMeta).size() > 0;
 
     // Transform name line
-    wlTransformname = new Label(shell, SWT.RIGHT);
+    Label wlTransformname = new Label(shell, SWT.RIGHT);
     wlTransformname.setText(BaseMessages.getString(PKG, "System.Label.TransformName"));
     props.setLook(wlTransformname);
-    fdlTransformname = new FormData();
+    FormData fdlTransformname = new FormData();
     fdlTransformname.left = new FormAttachment(0, 0);
     fdlTransformname.right = new FormAttachment(middle, -margin);
     fdlTransformname.top = new FormAttachment(0, margin);
@@ -120,16 +117,16 @@ public class GetLoggingInfoDialog extends BaseTransformDialog implements ITransf
     wTransformname.setText(transformName);
     props.setLook(wTransformname);
     wTransformname.addModifyListener(lsMod);
-    fdTransformname = new FormData();
+    FormData fdTransformname = new FormData();
     fdTransformname.left = new FormAttachment(middle, 0);
     fdTransformname.top = new FormAttachment(0, margin);
     fdTransformname.right = new FormAttachment(100, 0);
     wTransformname.setLayoutData(fdTransformname);
 
-    wlFields = new Label(shell, SWT.NONE);
+    Label wlFields = new Label(shell, SWT.NONE);
     wlFields.setText(BaseMessages.getString(PKG, "GetLoggingInfoDialog.Fields.Label"));
     props.setLook(wlFields);
-    fdlFields = new FormData();
+    FormData fdlFields = new FormData();
     fdlFields.left = new FormAttachment(0, 0);
     fdlFields.top = new FormAttachment(wTransformname, margin);
     wlFields.setLayoutData(fdlFields);
@@ -189,7 +186,7 @@ public class GetLoggingInfoDialog extends BaseTransformDialog implements ITransf
             lsMod,
             props);
 
-    fdFields = new FormData();
+    FormData fdFields = new FormData();
     fdFields.left = new FormAttachment(0, 0);
     fdFields.top = new FormAttachment(wlFields, margin);
     fdFields.right = new FormAttachment(100, 0);
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/loginfo/GetLoggingInfoMeta.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/loginfo/GetLoggingInfoMeta.java
index af6a4fa..4589d92 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/loginfo/GetLoggingInfoMeta.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/loginfo/GetLoggingInfoMeta.java
@@ -54,7 +54,7 @@ import java.util.List;
 @InjectionSupported(localizationPrefix = "GetLoggingInfoMeta.Injection.")
 public class GetLoggingInfoMeta extends BaseTransformMeta
     implements ITransformMeta<GetLoggingInfo, GetLoggingInfoData> {
-  private static Class<?> PKG =
+  private static final Class<?> PKG =
       GetLoggingInfoMeta.class; // for i18n purposes, needed by Translator2!!
 
   @Injection(name = "FIELD_NAME")
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/output/Neo4JOutput.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/output/Neo4JOutput.java
index 79db59a..9d093d7 100755
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/output/Neo4JOutput.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/output/Neo4JOutput.java
@@ -47,7 +47,8 @@ import java.util.stream.Collectors;
 public class Neo4JOutput extends BaseNeoTransform<Neo4JOutputMeta, Neo4JOutputData>
     implements ITransform<Neo4JOutputMeta, Neo4JOutputData> {
 
-  private static Class<?> PKG = Neo4JOutput.class; // for i18n purposes, needed by Translator2!!
+  private static final Class<?> PKG =
+      Neo4JOutput.class; // for i18n purposes, needed by Translator2!!
 
   public Neo4JOutput(
       TransformMeta s,
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/output/Neo4JOutputDialog.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/output/Neo4JOutputDialog.java
index a5a0584..98a94e0 100755
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/output/Neo4JOutputDialog.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/output/Neo4JOutputDialog.java
@@ -55,7 +55,8 @@ import org.eclipse.swt.layout.FormLayout;
 import org.eclipse.swt.widgets.*;
 
 public class Neo4JOutputDialog extends BaseTransformDialog implements ITransformDialog {
-  private static Class<?> PKG = Neo4JOutputMeta.class; // for i18n purposes, needed by Translator2!!
+  private static final Class<?> PKG =
+      Neo4JOutputMeta.class; // for i18n purposes, needed by Translator2!!
 
   private Neo4JOutputMeta input;
 
@@ -79,7 +80,6 @@ public class Neo4JOutputDialog extends BaseTransformDialog implements ITransform
   private TableView wToPropsGrid;
   private TableView wToLabelGrid;
   private TableView wRelPropsGrid;
-  private String[] fieldNames;
 
   private Button wReadOnlyFromNode;
   private Button wReadOnlyToNode;
@@ -104,6 +104,7 @@ public class Neo4JOutputDialog extends BaseTransformDialog implements ITransform
     changed = input.hasChanged();
 
     // Fields
+    String[] fieldNames;
     try {
       IRowMeta prevFields = pipelineMeta.getPrevTransformFields(variables, transformName);
       fieldNames = prevFields.getFieldNames();
@@ -791,8 +792,8 @@ public class Neo4JOutputDialog extends BaseTransformDialog implements ITransform
     wReadOnlyToNode.setSelection(input.isReadOnlyToNode());
 
     if (input.getFromNodeLabels() != null) {
-      String fromNodeLabels[] = input.getFromNodeLabels();
-      String fromNodeLabelValues[] = input.getFromNodeLabelValues();
+      String[] fromNodeLabels = input.getFromNodeLabels();
+      String[] fromNodeLabelValues = input.getFromNodeLabelValues();
 
       for (int i = 0; i < fromNodeLabels.length; i++) {
         TableItem item = wFromLabelGrid.table.getItem(i);
@@ -813,8 +814,8 @@ public class Neo4JOutputDialog extends BaseTransformDialog implements ITransform
     }
 
     if (input.getToNodeLabels() != null) {
-      String toNodeLabels[] = input.getToNodeLabels();
-      String toNodeLabelValues[] = input.getToNodeLabelValues();
+      String[] toNodeLabels = input.getToNodeLabels();
+      String[] toNodeLabelValues = input.getToNodeLabelValues();
 
       for (int i = 0; i < toNodeLabels.length; i++) {
         TableItem item = wToLabelGrid.table.getItem(i);
@@ -868,8 +869,8 @@ public class Neo4JOutputDialog extends BaseTransformDialog implements ITransform
     input.setReadOnlyFromNode(wReadOnlyFromNode.getSelection());
     input.setReadOnlyToNode(wReadOnlyToNode.getSelection());
 
-    String fromNodeLabels[] = new String[wFromLabelGrid.nrNonEmpty()];
-    String fromNodeLabelValues[] = new String[wFromLabelGrid.nrNonEmpty()];
+    String[] fromNodeLabels = new String[wFromLabelGrid.nrNonEmpty()];
+    String[] fromNodeLabelValues = new String[wFromLabelGrid.nrNonEmpty()];
     for (int i = 0; i < fromNodeLabels.length; i++) {
       TableItem item = wFromLabelGrid.table.getItem(i);
       fromNodeLabels[i] = item.getText(1);
@@ -878,8 +879,8 @@ public class Neo4JOutputDialog extends BaseTransformDialog implements ITransform
     input.setFromNodeLabels(fromNodeLabels);
     input.setFromNodeLabelValues(fromNodeLabelValues);
 
-    String toNodeLabels[] = new String[wToLabelGrid.nrNonEmpty()];
-    String toNodeLabelValues[] = new String[wToLabelGrid.nrNonEmpty()];
+    String[] toNodeLabels = new String[wToLabelGrid.nrNonEmpty()];
+    String[] toNodeLabelValues = new String[wToLabelGrid.nrNonEmpty()];
     for (int i = 0; i < toNodeLabels.length; i++) {
       TableItem item = wToLabelGrid.table.getItem(i);
       toNodeLabels[i] = item.getText(1);
@@ -889,10 +890,10 @@ public class Neo4JOutputDialog extends BaseTransformDialog implements ITransform
     input.setToNodeLabelValues(toNodeLabelValues);
 
     int nbFromPropLines = wFromPropsGrid.nrNonEmpty();
-    String fromNodeProps[] = new String[nbFromPropLines];
-    String fromNodePropNames[] = new String[nbFromPropLines];
-    String fromNodePropTypes[] = new String[nbFromPropLines];
-    boolean fromNodePropPrimary[] = new boolean[nbFromPropLines];
+    String[] fromNodeProps = new String[nbFromPropLines];
+    String[] fromNodePropNames = new String[nbFromPropLines];
+    String[] fromNodePropTypes = new String[nbFromPropLines];
+    boolean[] fromNodePropPrimary = new boolean[nbFromPropLines];
 
     for (int i = 0; i < fromNodeProps.length; i++) {
       TableItem item = wFromPropsGrid.table.getItem(i);
@@ -907,10 +908,10 @@ public class Neo4JOutputDialog extends BaseTransformDialog implements ITransform
     input.setFromNodePropPrimary(fromNodePropPrimary);
 
     int nbToPropLines = wToPropsGrid.nrNonEmpty();
-    String toNodeProps[] = new String[nbToPropLines];
-    String toNodePropNames[] = new String[nbToPropLines];
-    String toNodePropTypes[] = new String[nbToPropLines];
-    boolean toNodePropPrimary[] = new boolean[nbToPropLines];
+    String[] toNodeProps = new String[nbToPropLines];
+    String[] toNodePropNames = new String[nbToPropLines];
+    String[] toNodePropTypes = new String[nbToPropLines];
+    boolean[] toNodePropPrimary = new boolean[nbToPropLines];
 
     for (int i = 0; i < toNodeProps.length; i++) {
       TableItem item = wToPropsGrid.table.getItem(i);
@@ -928,9 +929,9 @@ public class Neo4JOutputDialog extends BaseTransformDialog implements ITransform
     input.setRelationshipValue(wRelValue.getText());
 
     int nbRelProps = wRelPropsGrid.nrNonEmpty();
-    String relProps[] = new String[nbRelProps];
-    String relPropNames[] = new String[nbRelProps];
-    String relPropTypes[] = new String[nbRelProps];
+    String[] relProps = new String[nbRelProps];
+    String[] relPropNames = new String[nbRelProps];
+    String[] relPropTypes = new String[nbRelProps];
     for (int i = 0; i < relProps.length; i++) {
       TableItem item = wRelPropsGrid.table.getItem(i);
       relProps[i] = item.getText(1);
diff --git a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/split/SplitGraphDialog.java b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/split/SplitGraphDialog.java
index d7507bc..0586e46 100644
--- a/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/split/SplitGraphDialog.java
+++ b/plugins/tech/neo4j/src/main/java/org/apache/hop/neo4j/transforms/split/SplitGraphDialog.java
@@ -41,7 +41,8 @@ import org.eclipse.swt.widgets.*;
 
 public class SplitGraphDialog extends BaseTransformDialog implements ITransformDialog {
 
-  private static Class<?> PKG = SplitGraphMeta.class; // for i18n purposes, needed by Translator2!!
+  private static final Class<?> PKG =
+      SplitGraphMeta.class; // for i18n purposes, needed by Translator2!!
 
   private Text wTransformName;
 
diff --git a/plugins/transforms/calculator/src/main/java/org/apache/hop/pipeline/transforms/calculator/CalculatorDialog.java b/plugins/transforms/calculator/src/main/java/org/apache/hop/pipeline/transforms/calculator/CalculatorDialog.java
index 9d89f11..705e6e7 100644
--- a/plugins/transforms/calculator/src/main/java/org/apache/hop/pipeline/transforms/calculator/CalculatorDialog.java
+++ b/plugins/transforms/calculator/src/main/java/org/apache/hop/pipeline/transforms/calculator/CalculatorDialog.java
@@ -293,10 +293,9 @@ public class CalculatorDialog extends BaseTransformDialog implements ITransformD
     new Thread(runnable).start();
 
     wFields.addModifyListener(
-        arg0 -> {
-          // Now set the combo's
-          shell.getDisplay().asyncExec(() -> setComboBoxes());
-        });
+        arg0 ->
+            // Now set the combo's
+            shell.getDisplay().asyncExec(() -> setComboBoxes()));
 
     getData();
 
diff --git a/plugins/transforms/combinationlookup/src/main/java/org/apache/hop/pipeline/transforms/combinationlookup/CombinationLookupDialog.java b/plugins/transforms/combinationlookup/src/main/java/org/apache/hop/pipeline/transforms/combinationlookup/CombinationLookupDialog.java
index b8e9680..3a10ce1 100644
--- a/plugins/transforms/combinationlookup/src/main/java/org/apache/hop/pipeline/transforms/combinationlookup/CombinationLookupDialog.java
+++ b/plugins/transforms/combinationlookup/src/main/java/org/apache/hop/pipeline/transforms/combinationlookup/CombinationLookupDialog.java
@@ -601,9 +601,9 @@ public class CombinationLookupDialog extends BaseTransformDialog implements ITra
     Runnable fieldLoader =
         () -> {
           if (!wTable.isDisposed() && !wConnection.isDisposed() && !wSchema.isDisposed()) {
-            final String tableName = wTable.getText(),
-                connectionName = wConnection.getText(),
-                schemaName = wSchema.getText();
+            final String tableName = wTable.getText();
+            final String connectionName = wConnection.getText();
+            final String schemaName = wSchema.getText();
 
             // clear
             for (ColumnInfo colInfo : tableFieldColumns) {
diff --git a/plugins/transforms/combinationlookup/src/main/java/org/apache/hop/pipeline/transforms/combinationlookup/CombinationLookupMeta.java b/plugins/transforms/combinationlookup/src/main/java/org/apache/hop/pipeline/transforms/combinationlookup/CombinationLookupMeta.java
index b744c1f..3cc9710 100644
--- a/plugins/transforms/combinationlookup/src/main/java/org/apache/hop/pipeline/transforms/combinationlookup/CombinationLookupMeta.java
+++ b/plugins/transforms/combinationlookup/src/main/java/org/apache/hop/pipeline/transforms/combinationlookup/CombinationLookupMeta.java
@@ -136,9 +136,9 @@ public class CombinationLookupMeta extends BaseTransformMeta
   @Injection(name = "LAST_UPDATE_FIELD")
   private String lastUpdateField;
 
-  public static String CREATION_METHOD_AUTOINC = "autoinc";
-  public static String CREATION_METHOD_SEQUENCE = "sequence";
-  public static String CREATION_METHOD_TABLEMAX = "tablemax";
+  public static final String CREATION_METHOD_AUTOINC = "autoinc";
+  public static final String CREATION_METHOD_SEQUENCE = "sequence";
+  public static final String CREATION_METHOD_TABLEMAX = "tablemax";
 
   @Injection(name = "CONNECTIONNAME")
   public void setConnection(String connectionName) {
@@ -325,7 +325,8 @@ public class CombinationLookupMeta extends BaseTransformMeta
       throws HopXmlException {
     this.databases = databases;
     try {
-      String commit, csize;
+      String commit;
+      String csize;
 
       schemaName = XmlHandler.getTagValue(transformNode, "schema");
       tableName = XmlHandler.getTagValue(transformNode, "table");
@@ -823,7 +824,7 @@ public class CombinationLookupMeta extends BaseTransformMeta
             // What fields do we put int the index?
             // Only the hashcode or all fields?
             String crIndex = "";
-            String cr_uniqIndex = "";
+            String crUniqIndex = "";
             String[] idxFields = null;
             if (useHash) {
               if (hashField != null && hashField.length() > 0) {
@@ -858,10 +859,10 @@ public class CombinationLookupMeta extends BaseTransformMeta
               String[] techKeyArr = new String[] {technicalKeyField};
               if (!db.checkIndexExists(schemaTable, techKeyArr)) {
                 String indexname = "idx_" + tableName + "_pk";
-                cr_uniqIndex =
+                crUniqIndex =
                     db.getCreateIndexStatement(
                         schemaTable, indexname, techKeyArr, true, true, false, true);
-                cr_uniqIndex += Const.CR;
+                crUniqIndex += Const.CR;
               }
             }
 
@@ -884,7 +885,7 @@ public class CombinationLookupMeta extends BaseTransformMeta
                 crSeq += Const.CR;
               }
             }
-            retval.setSql(variables.resolve(crTable + cr_uniqIndex + crIndex + crSeq));
+            retval.setSql(variables.resolve(crTable + crUniqIndex + crIndex + crSeq));
           } catch (HopException e) {
             retval.setError(
                 BaseMessages.getString(PKG, "CombinationLookupMeta.ReturnValue.ErrorOccurred")
diff --git a/plugins/transforms/concatfields/src/main/java/org/apache/hop/pipeline/transforms/concatfields/ConcatFieldsMeta.java b/plugins/transforms/concatfields/src/main/java/org/apache/hop/pipeline/transforms/concatfields/ConcatFieldsMeta.java
index 109c58d..c652b3c 100644
--- a/plugins/transforms/concatfields/src/main/java/org/apache/hop/pipeline/transforms/concatfields/ConcatFieldsMeta.java
+++ b/plugins/transforms/concatfields/src/main/java/org/apache/hop/pipeline/transforms/concatfields/ConcatFieldsMeta.java
@@ -156,7 +156,8 @@ public class ConcatFieldsMeta extends BaseTransformMeta
     disableEnclosureFix = false;
     padded = false;
 
-    int i, nrFields = 0;
+    int i;
+    int nrFields = 0;
 
     allocate(nrFields);
 
diff --git a/plugins/transforms/creditcardvalidator/src/main/java/org/apache/hop/pipeline/transforms/creditcardvalidator/CreditCardValidatorDialog.java b/plugins/transforms/creditcardvalidator/src/main/java/org/apache/hop/pipeline/transforms/creditcardvalidator/CreditCardValidatorDialog.java
index 56391a2..69bbd98 100644
--- a/plugins/transforms/creditcardvalidator/src/main/java/org/apache/hop/pipeline/transforms/creditcardvalidator/CreditCardValidatorDialog.java
+++ b/plugins/transforms/creditcardvalidator/src/main/java/org/apache/hop/pipeline/transforms/creditcardvalidator/CreditCardValidatorDialog.java
@@ -49,7 +49,8 @@ public class CreditCardValidatorDialog extends BaseTransformDialog implements IT
 
   private CCombo wFieldName;
 
-  private TextVar wResult, wFileType;
+  private TextVar wResult;
+  private TextVar wFileType;
 
   private TextVar wNotValidMsg;
 
@@ -126,7 +127,9 @@ public class CreditCardValidatorDialog extends BaseTransformDialog implements IT
     wFieldName.addFocusListener(
         new FocusListener() {
           @Override
-          public void focusLost(FocusEvent e) {}
+          public void focusLost(FocusEvent e) {
+            // Disable focuslost
+          }
 
           @Override
           public void focusGained(FocusEvent e) {
@@ -166,10 +169,10 @@ public class CreditCardValidatorDialog extends BaseTransformDialog implements IT
     wOutputFields.setText(
         BaseMessages.getString(PKG, "CreditCardValidatorDialog.OutputFields.Label"));
 
-    FormLayout OutputFieldsgroupLayout = new FormLayout();
-    OutputFieldsgroupLayout.marginWidth = 10;
-    OutputFieldsgroupLayout.marginHeight = 10;
-    wOutputFields.setLayout(OutputFieldsgroupLayout);
+    FormLayout outputFieldsgroupLayout = new FormLayout();
+    outputFieldsgroupLayout.marginWidth = 10;
+    outputFieldsgroupLayout.marginHeight = 10;
+    wOutputFields.setLayout(outputFieldsgroupLayout);
 
     // Result fieldname ...
     Label wlResult = new Label(wOutputFields, SWT.RIGHT);
diff --git a/plugins/transforms/creditcardvalidator/src/main/java/org/apache/hop/pipeline/transforms/creditcardvalidator/CreditCardVerifier.java b/plugins/transforms/creditcardvalidator/src/main/java/org/apache/hop/pipeline/transforms/creditcardvalidator/CreditCardVerifier.java
index d130100..b549a20 100644
--- a/plugins/transforms/creditcardvalidator/src/main/java/org/apache/hop/pipeline/transforms/creditcardvalidator/CreditCardVerifier.java
+++ b/plugins/transforms/creditcardvalidator/src/main/java/org/apache/hop/pipeline/transforms/creditcardvalidator/CreditCardVerifier.java
@@ -86,23 +86,23 @@ public class CreditCardVerifier {
     return (id > -1 && id < NotValidCardNames.length ? NotValidCardNames[id] : null);
   }
 
-  public static ReturnIndicator CheckCC(String CardNumber) {
+  public static ReturnIndicator CheckCC(String cardNumber) {
     ReturnIndicator ri = new ReturnIndicator();
 
-    if (Utils.isEmpty(CardNumber)) {
+    if (Utils.isEmpty(cardNumber)) {
       ri.UnValidMsg = BaseMessages.getString(PKG, "CreditCardValidator.Log.EmptyNumber");
       return ri;
     }
 
-    Matcher m = Pattern.compile("[^\\d\\s.-]").matcher(CardNumber);
+    Matcher m = Pattern.compile("[^\\d\\s.-]").matcher(cardNumber);
     if (m.find()) {
       ri.UnValidMsg = BaseMessages.getString(PKG, "CreditCardValidator.OnlyNumbers");
       return ri;
     }
 
-    int cardId = getCardID(CardNumber);
+    int cardId = getCardID(cardNumber);
     if (cardId > -1) {
-      if (luhnValidate(CardNumber)) {
+      if (luhnValidate(cardNumber)) {
         ri.CardValid = true;
         ri.CardType = getCardName(cardId);
       } else {
@@ -110,7 +110,7 @@ public class CreditCardVerifier {
         ri.UnValidMsg = getNotValidCardNames(cardId);
       }
     } else {
-      if (luhnValidate(CardNumber)) {
+      if (luhnValidate(cardNumber)) {
         ri.CardValid = true;
       } else {
         ri.UnValidMsg = BaseMessages.getString(PKG, "CreditCardValidator.Log.CardNotValid");
diff --git a/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/DatabaseLookupDialog.java b/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/DatabaseLookupDialog.java
index 0fd20ab..238731e 100644
--- a/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/DatabaseLookupDialog.java
+++ b/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/DatabaseLookupDialog.java
@@ -26,7 +26,6 @@ import org.apache.hop.core.row.IRowMeta;
 import org.apache.hop.core.row.RowMeta;
 import org.apache.hop.core.row.value.ValueMetaBase;
 import org.apache.hop.core.row.value.ValueMetaFactory;
-import org.apache.hop.core.row.value.ValueMetaString;
 import org.apache.hop.core.util.Utils;
 import org.apache.hop.core.variables.IVariables;
 import org.apache.hop.i18n.BaseMessages;
@@ -350,13 +349,13 @@ public class DatabaseLookupDialog extends BaseTransformDialog implements ITransf
     fdlReturn.top = new FormAttachment(wKey, margin);
     wlReturn.setLayoutData(fdlReturn);
 
-    int UpInsCols = 5;
-    int UpInsRows =
+    int upInsCols = 5;
+    int upInsRows =
         input.getLookup().getReturnValues().isEmpty()
             ? 1
             : input.getLookup().getReturnValues().size();
 
-    ColumnInfo[] ciReturn = new ColumnInfo[UpInsCols];
+    ColumnInfo[] ciReturn = new ColumnInfo[upInsCols];
 
     ciReturn[0] =
         new ColumnInfo(
@@ -387,7 +386,7 @@ public class DatabaseLookupDialog extends BaseTransformDialog implements ITransf
         new ColumnInfo(
             BaseMessages.getString(PKG, "DatabaseLookupDialog.TrimTypeColumn.Column"),
             ColumnInfo.COLUMN_TYPE_CCOMBO,
-            ValueMetaString.trimTypeDesc,
+            ValueMetaBase.trimTypeDesc,
             true);
 
     tableFieldColumns.add(ciReturn[0]);
@@ -398,7 +397,7 @@ public class DatabaseLookupDialog extends BaseTransformDialog implements ITransf
             shell,
             SWT.BORDER | SWT.FULL_SELECTION | SWT.MULTI | SWT.V_SCROLL | SWT.H_SCROLL,
             ciReturn,
-            UpInsRows,
+            upInsRows,
             lsMod,
             props);
 
@@ -542,9 +541,9 @@ public class DatabaseLookupDialog extends BaseTransformDialog implements ITransf
     Runnable fieldLoader =
         () -> {
           if (!wTable.isDisposed() && !wConnection.isDisposed() && !wSchema.isDisposed()) {
-            final String tableName = wTable.getText(),
-                connectionName = wConnection.getText(),
-                schemaName = wSchema.getText();
+            final String tableName = wTable.getText();
+            final String connectionName = wConnection.getText();
+            final String schemaName = wSchema.getText();
             if (!Utils.isEmpty(tableName)) {
               DatabaseMeta ci = pipelineMeta.findDatabase(connectionName, variables);
               if (ci != null) {
@@ -629,8 +628,8 @@ public class DatabaseLookupDialog extends BaseTransformDialog implements ITransf
       item.setText(
           5,
           Const.NVL(
-              ValueMetaString.getTrimTypeDesc(
-                  ValueMetaString.getTrimTypeByCode(returnValue.getTrimType())),
+              ValueMetaBase.getTrimTypeDesc(
+                  ValueMetaBase.getTrimTypeByCode(returnValue.getTrimType())),
               ValueMetaBase.trimTypeCode[0]));
     }
     wSchema.setText(Const.NVL(input.getSchemaName(), ""));
@@ -686,7 +685,7 @@ public class DatabaseLookupDialog extends BaseTransformDialog implements ITransf
       returnValue.setDefaultValue(item.getText(3));
       returnValue.setDefaultType(item.getText(4));
       returnValue.setTrimType(
-          ValueMetaString.getTrimTypeCode(ValueMetaString.getTrimTypeByDesc(item.getText(5))));
+          ValueMetaBase.getTrimTypeCode(ValueMetaBase.getTrimTypeByDesc(item.getText(5))));
       lookup.getReturnValues().add(returnValue);
     }
 
diff --git a/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/GtIndex.java b/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/GtIndex.java
index 2778b28..25d252e 100644
--- a/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/GtIndex.java
+++ b/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/GtIndex.java
@@ -52,7 +52,8 @@ class GtIndex extends Index {
     } else {
       BitSet bitSet = context.getWorkingSet();
 
-      int start, end;
+      int start;
+      int end;
       if (firstValue < length / 2) {
         start = 0;
         end = firstValue;
diff --git a/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/IsNullIndex.java b/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/IsNullIndex.java
index f2020ad..26f590e 100644
--- a/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/IsNullIndex.java
+++ b/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/IsNullIndex.java
@@ -49,7 +49,8 @@ class IsNullIndex extends Index implements Comparator<Index.IndexedValue> {
     } else {
       int length = values.length;
 
-      int start, end;
+      int start;
+      int end;
       if (afterLastValue < length / 2) {
         start = 0;
         end = afterLastValue;
diff --git a/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/LtIndex.java b/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/LtIndex.java
index 420c346..0ae6a50 100644
--- a/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/LtIndex.java
+++ b/plugins/transforms/databaselookup/src/main/java/org/apache/hop/pipeline/transforms/databaselookup/readallcache/LtIndex.java
@@ -52,7 +52,8 @@ class LtIndex extends Index {
     } else {
       BitSet bitSet = context.getWorkingSet();
 
-      int start, end;
+      int start;
+      int end;
       if (firstValue < values.length / 2) {
         start = 0;
         end = firstValue;
diff --git a/plugins/transforms/denormaliser/src/main/java/org/apache/hop/pipeline/transforms/denormaliser/DenormaliserDialog.java b/plugins/transforms/denormaliser/src/main/java/org/apache/hop/pipeline/transforms/denormaliser/DenormaliserDialog.java
index fa51f9c..35fe6ef 100644
--- a/plugins/transforms/denormaliser/src/main/java/org/apache/hop/pipeline/transforms/denormaliser/DenormaliserDialog.java
+++ b/plugins/transforms/denormaliser/src/main/java/org/apache/hop/pipeline/transforms/denormaliser/DenormaliserDialog.java
@@ -187,7 +187,7 @@ public class DenormaliserDialog extends BaseTransformDialog implements ITransfor
     fdlTarget.top = new FormAttachment(wGroup, margin);
     wlTarget.setLayoutData(fdlTarget);
 
-    int UpInsRows =
+    int upInsRows =
         (input.getDenormaliserTargetFields() != null
             ? input.getDenormaliserTargetFields().size()
             : 1);
@@ -256,7 +256,7 @@ public class DenormaliserDialog extends BaseTransformDialog implements ITransfor
             shell,
             SWT.BORDER | SWT.FULL_SELECTION | SWT.MULTI | SWT.V_SCROLL | SWT.H_SCROLL,
             ciTarget,
-            UpInsRows,
+            upInsRows,
             lsMod,
             props);
 
diff --git a/plugins/transforms/dimensionlookup/src/main/java/org/apache/hop/pipeline/transforms/dimensionlookup/DimensionLookupMeta.java b/plugins/transforms/dimensionlookup/src/main/java/org/apache/hop/pipeline/transforms/dimensionlookup/DimensionLookupMeta.java
index 78182ae..6a67ea6 100644
--- a/plugins/transforms/dimensionlookup/src/main/java/org/apache/hop/pipeline/transforms/dimensionlookup/DimensionLookupMeta.java
+++ b/plugins/transforms/dimensionlookup/src/main/java/org/apache/hop/pipeline/transforms/dimensionlookup/DimensionLookupMeta.java
@@ -213,9 +213,9 @@ public class DimensionLookupMeta extends BaseTransformMeta
   @Injection(name = "TECHNICAL_KEY_CREATION")
   private String techKeyCreation = null;
 
-  public static String CREATION_METHOD_AUTOINC = "autoinc";
-  public static String CREATION_METHOD_SEQUENCE = "sequence";
-  public static String CREATION_METHOD_TABLEMAX = "tablemax";
+  public static final String CREATION_METHOD_AUTOINC = "autoinc";
+  public static final String CREATION_METHOD_SEQUENCE = "sequence";
+  public static final String CREATION_METHOD_TABLEMAX = "tablemax";
 
   /** The size of the cache in ROWS : -1 means: not set, 0 means: cache all */
   @Injection(name = "CACHE_SIZE")
@@ -607,7 +607,8 @@ public class DimensionLookupMeta extends BaseTransformMeta
 
   @Override
   public void setDefault() {
-    int nrkeys, nrFields;
+    int nrkeys;
+    int nrFields;
 
     schemaName = "";
     tableName = BaseMessages.getString(PKG, "DimensionLookupMeta.DefualtTableName");
@@ -825,7 +826,8 @@ public class DimensionLookupMeta extends BaseTransformMeta
     this.metadataProvider = metadataProvider;
     try {
       String upd;
-      int nrkeys, nrFields;
+      int nrkeys;
+      int nrFields;
       String commit;
       this.databases = databases;
       schemaName = XmlHandler.getTagValue(transformNode, "schema");
@@ -1248,7 +1250,7 @@ public class DimensionLookupMeta extends BaseTransformMeta
             if (prev != null && prev.size() > 0) {
               // Start at the top, see if the key fields exist:
               first = true;
-              boolean warning_found = false;
+              boolean warningFound = false;
               for (i = 0; i < keyStream.length; i++) {
                 // Does the field exist in the input stream?
                 String strfield = keyStream[i];
@@ -1300,7 +1302,7 @@ public class DimensionLookupMeta extends BaseTransformMeta
                                     PKG, "DimensionLookupMeta.CheckResult.KeyhasProblem3")
                                 + Const.CR;
                       }
-                      warning_found = true;
+                      warningFound = true;
                       errorMessage +=
                           "\t\t"
                               + strfield
@@ -1323,7 +1325,7 @@ public class DimensionLookupMeta extends BaseTransformMeta
               }
               if (errorFound) {
                 cr = new CheckResult(ICheckResult.TYPE_RESULT_ERROR, errorMessage, transforminfo);
-              } else if (warning_found) {
+              } else if (warningFound) {
                 cr = new CheckResult(ICheckResult.TYPE_RESULT_WARNING, errorMessage, transforminfo);
               } else {
                 cr =
diff --git a/plugins/transforms/excelinput/src/main/java/org/apache/hop/pipeline/transforms/excelinput/ExcelInputDialog.java b/plugins/transforms/excelinput/src/main/java/org/apache/hop/pipeline/transforms/excelinput/ExcelInputDialog.java
index 2d0b968..8026981 100644
--- a/plugins/transforms/excelinput/src/main/java/org/apache/hop/pipeline/transforms/excelinput/ExcelInputDialog.java
+++ b/plugins/transforms/excelinput/src/main/java/org/apache/hop/pipeline/transforms/excelinput/ExcelInputDialog.java
@@ -797,10 +797,10 @@ public class ExcelInputDialog extends BaseTransformDialog implements ITransformD
     props.setLook(wAddFileResult);
     wAddFileResult.setText(BaseMessages.getString(PKG, "ExcelInputDialog.AddFileResult.Label"));
 
-    FormLayout AddFileResultgroupLayout = new FormLayout();
-    AddFileResultgroupLayout.marginWidth = 10;
-    AddFileResultgroupLayout.marginHeight = 10;
-    wAddFileResult.setLayout(AddFileResultgroupLayout);
+    FormLayout addFileResultgroupLayout = new FormLayout();
+    addFileResultgroupLayout.marginWidth = 10;
+    addFileResultgroupLayout.marginHeight = 10;
+    wAddFileResult.setLayout(addFileResultgroupLayout);
 
     Label wlAddResult = new Label(wAddFileResult, SWT.RIGHT);
     wlAddResult.setText(BaseMessages.getString(PKG, "ExcelInputDialog.AddResult.Label"));
@@ -865,8 +865,8 @@ public class ExcelInputDialog extends BaseTransformDialog implements ITransformD
     setButtonPositions(new Button[] {wbGetFields}, margin, null);
 
     final int FieldsRows = input.getField().length;
-    int FieldsWidth = 600;
-    int FieldsHeight = 150;
+    int fieldsWidth = 600;
+    int fieldsHeight = 150;
 
     ColumnInfo[] colinf =
         new ColumnInfo[] {
@@ -923,7 +923,7 @@ public class ExcelInputDialog extends BaseTransformDialog implements ITransformD
             FieldsRows,
             lsMod,
             props);
-    wFields.setSize(FieldsWidth, FieldsHeight);
+    wFields.setSize(fieldsWidth, fieldsHeight);
     wFields.addModifyListener(arg0 -> checkAlerts());
 
     FormData fdFields = new FormData();
diff --git a/plugins/transforms/excelwriter/src/main/java/org/apache/hop/pipeline/transforms/excelwriter/ExcelWriterTransformMeta.java b/plugins/transforms/excelwriter/src/main/java/org/apache/hop/pipeline/transforms/excelwriter/ExcelWriterTransformMeta.java
index 267edbe..be32c80 100644
--- a/plugins/transforms/excelwriter/src/main/java/org/apache/hop/pipeline/transforms/excelwriter/ExcelWriterTransformMeta.java
+++ b/plugins/transforms/excelwriter/src/main/java/org/apache/hop/pipeline/transforms/excelwriter/ExcelWriterTransformMeta.java
@@ -377,7 +377,7 @@ public class ExcelWriterTransformMeta extends BaseTransformMeta
     return retval;
   }
 
-  public String buildFilename(IRowMeta rowMeta, Object row[], IVariables variables) {
+  public String buildFilename(IRowMeta rowMeta, Object[] row, IVariables variables) {
     int filenameFieldIdx = rowMeta.indexOfValue(variables.resolve(getFile().getFileNameField()));
     String retval = (String) row[filenameFieldIdx];
     String realextension = variables.resolve(file.getExtension());
diff --git a/plugins/transforms/execprocess/src/main/java/org/apache/hop/pipeline/transforms/execprocess/ExecProcessDialog.java b/plugins/transforms/execprocess/src/main/java/org/apache/hop/pipeline/transforms/execprocess/ExecProcessDialog.java
index 6f8c3f7..10bd30d 100644
--- a/plugins/transforms/execprocess/src/main/java/org/apache/hop/pipeline/transforms/execprocess/ExecProcessDialog.java
+++ b/plugins/transforms/execprocess/src/main/java/org/apache/hop/pipeline/transforms/execprocess/ExecProcessDialog.java
@@ -56,7 +56,10 @@ public class ExecProcessDialog extends BaseTransformDialog implements ITransform
 
   private Button wFailWhenNotSuccess;
 
-  private LabelTextVar wOutputDelim, wResult, wExitValue, wError;
+  private LabelTextVar wOutputDelim;
+  private LabelTextVar wResult;
+  private LabelTextVar wExitValue;
+  private LabelTextVar wError;
 
   private final ExecProcessMeta input;
   private boolean gotPreviousFields = false;
diff --git a/plugins/transforms/execsqlrow/src/main/java/org/apache/hop/pipeline/transforms/execsqlrow/ExecSqlRowDialog.java b/plugins/transforms/execsqlrow/src/main/java/org/apache/hop/pipeline/transforms/execsqlrow/ExecSqlRowDialog.java
index 25583b5..0063401 100644
--- a/plugins/transforms/execsqlrow/src/main/java/org/apache/hop/pipeline/transforms/execsqlrow/ExecSqlRowDialog.java
+++ b/plugins/transforms/execsqlrow/src/main/java/org/apache/hop/pipeline/transforms/execsqlrow/ExecSqlRowDialog.java
@@ -228,10 +228,10 @@ public class ExecSqlRowDialog extends BaseTransformDialog implements ITransformD
     wAdditionalFields.setText(
         BaseMessages.getString(PKG, "ExecSqlRowDialog.wAdditionalFields.Label"));
 
-    FormLayout AdditionalFieldsgroupLayout = new FormLayout();
-    AdditionalFieldsgroupLayout.marginWidth = 10;
-    AdditionalFieldsgroupLayout.marginHeight = 10;
-    wAdditionalFields.setLayout(AdditionalFieldsgroupLayout);
+    FormLayout additionalFieldsgroupLayout = new FormLayout();
+    additionalFieldsgroupLayout.marginWidth = 10;
+    additionalFieldsgroupLayout.marginHeight = 10;
+    wAdditionalFields.setLayout(additionalFieldsgroupLayout);
 
     // insert field
     Label wlInsertField = new Label(wAdditionalFields, SWT.RIGHT);
diff --git a/plugins/transforms/filemetadata/src/main/java/org/apache/hop/pipeline/transforms/filemetadata/FileMetadata.java b/plugins/transforms/filemetadata/src/main/java/org/apache/hop/pipeline/transforms/filemetadata/FileMetadata.java
index 585a7ac..aeae912 100644
--- a/plugins/transforms/filemetadata/src/main/java/org/apache/hop/pipeline/transforms/filemetadata/FileMetadata.java
+++ b/plugins/transforms/filemetadata/src/main/java/org/apache/hop/pipeline/transforms/filemetadata/FileMetadata.java
@@ -44,11 +44,6 @@ public class FileMetadata extends BaseTransform<FileMetadataMeta, FileMetadataDa
     implements ITransform<FileMetadataMeta, FileMetadataData> {
 
   private Object[] r;
-  private int idx;
-  private Object[] outputRow;
-  private DelimiterDetector.DetectionResult delimiters;
-  private String fileName;
-  private Charset detectedCharset;
   private Charset defaultCharset = Charsets.ISO_8859_1;
   private long limitRows;
 
@@ -143,16 +138,16 @@ public class FileMetadata extends BaseTransform<FileMetadataMeta, FileMetadataDa
   private void buildOutputRows() throws HopTransformException {
 
     // which index does the next field go to
-    idx = data.isReceivingInput ? getInputRowMeta().size() : 0;
+    int idx = data.isReceivingInput ? getInputRowMeta().size() : 0;
 
     // prepare an output row
-    outputRow =
+    Object[] outputRow =
         data.isReceivingInput
             ? RowDataUtil.createResizedCopy(r, data.outputRowMeta.size())
             : RowDataUtil.allocateRowData(data.outputRowMeta.size());
 
     // get the configuration from the dialog
-    fileName = resolve(meta.getFileName());
+    String fileName = resolve(meta.getFileName());
 
     // if the file does not exist, just send an empty row
     try {
@@ -202,11 +197,11 @@ public class FileMetadata extends BaseTransform<FileMetadataMeta, FileMetadataDa
     }
 
     // guess the charset
-    detectedCharset = detectCharset(fileName);
+    Charset detectedCharset = detectCharset(fileName);
     outputRow[idx++] = detectedCharset;
 
     // guess the delimiters
-    delimiters =
+    DelimiterDetector.DetectionResult delimiters =
         detectDelimiters(fileName, detectedCharset, delimiterCandidates, enclosureCandidates);
 
     if (delimiters == null) {
diff --git a/plugins/transforms/fuzzymatch/src/main/java/org/apache/hop/pipeline/transforms/fuzzymatch/FuzzyMatchDialog.java b/plugins/transforms/fuzzymatch/src/main/java/org/apache/hop/pipeline/transforms/fuzzymatch/FuzzyMatchDialog.java
index a2ce4fe..0096937 100644
--- a/plugins/transforms/fuzzymatch/src/main/java/org/apache/hop/pipeline/transforms/fuzzymatch/FuzzyMatchDialog.java
+++ b/plugins/transforms/fuzzymatch/src/main/java/org/apache/hop/pipeline/transforms/fuzzymatch/FuzzyMatchDialog.java
@@ -156,10 +156,10 @@ public class FuzzyMatchDialog extends BaseTransformDialog implements ITransformD
     Composite wGeneralComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wGeneralComp);
 
-    FormLayout GeneralLayout = new FormLayout();
-    GeneralLayout.marginWidth = 3;
-    GeneralLayout.marginHeight = 3;
-    wGeneralComp.setLayout(GeneralLayout);
+    FormLayout generalLayout = new FormLayout();
+    generalLayout.marginWidth = 3;
+    generalLayout.marginHeight = 3;
+    wGeneralComp.setLayout(generalLayout);
 
     // /////////////////////////////////
     // START OF Lookup Fields GROUP
@@ -169,10 +169,10 @@ public class FuzzyMatchDialog extends BaseTransformDialog implements ITransformD
     props.setLook(wLookupGroup);
     wLookupGroup.setText(BaseMessages.getString(PKG, "FuzzyMatchDialog.Group.Lookup.Label"));
 
-    FormLayout LookupgroupLayout = new FormLayout();
-    LookupgroupLayout.marginWidth = 10;
-    LookupgroupLayout.marginHeight = 10;
-    wLookupGroup.setLayout(LookupgroupLayout);
+    FormLayout lookupgroupLayout = new FormLayout();
+    lookupgroupLayout.marginWidth = 10;
+    lookupgroupLayout.marginHeight = 10;
+    wLookupGroup.setLayout(lookupgroupLayout);
 
     // Source transform line...
     Label wlTransform = new Label(wLookupGroup, SWT.RIGHT);
@@ -250,10 +250,10 @@ public class FuzzyMatchDialog extends BaseTransformDialog implements ITransformD
     wMainStreamGroup.setText(
         BaseMessages.getString(PKG, "FuzzyMatchDialog.Group.MainStreamGroup.Label"));
 
-    FormLayout MainStreamgroupLayout = new FormLayout();
-    MainStreamgroupLayout.marginWidth = 10;
-    MainStreamgroupLayout.marginHeight = 10;
-    wMainStreamGroup.setLayout(MainStreamgroupLayout);
+    FormLayout mainStreamgroupLayout = new FormLayout();
+    mainStreamgroupLayout.marginWidth = 10;
+    mainStreamgroupLayout.marginHeight = 10;
+    wMainStreamGroup.setLayout(mainStreamgroupLayout);
 
     // MainStreamFieldname field
     Label wlMainStreamField = new Label(wMainStreamGroup, SWT.RIGHT);
@@ -305,10 +305,10 @@ public class FuzzyMatchDialog extends BaseTransformDialog implements ITransformD
     wSettingsGroup.setText(
         BaseMessages.getString(PKG, "FuzzyMatchDialog.Group.SettingsGroup.Label"));
 
-    FormLayout SettingsgroupLayout = new FormLayout();
-    SettingsgroupLayout.marginWidth = 10;
-    SettingsgroupLayout.marginHeight = 10;
-    wSettingsGroup.setLayout(SettingsgroupLayout);
+    FormLayout settingsgroupLayout = new FormLayout();
+    settingsgroupLayout.marginWidth = 10;
+    settingsgroupLayout.marginHeight = 10;
+    wSettingsGroup.setLayout(settingsgroupLayout);
 
     // Algorithm
     Label wlAlgorithm = new Label(wSettingsGroup, SWT.RIGHT);
@@ -486,10 +486,10 @@ public class FuzzyMatchDialog extends BaseTransformDialog implements ITransformD
     Composite wFieldsComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wFieldsComp);
 
-    FormLayout FieldsLayout = new FormLayout();
-    FieldsLayout.marginWidth = 3;
-    FieldsLayout.marginHeight = 3;
-    wFieldsComp.setLayout(FieldsLayout);
+    FormLayout fieldsLayout = new FormLayout();
+    fieldsLayout.marginWidth = 3;
+    fieldsLayout.marginHeight = 3;
+    wFieldsComp.setLayout(fieldsLayout);
 
     // /////////////////////////////////
     // START OF OutputFields Fields GROUP
@@ -500,10 +500,10 @@ public class FuzzyMatchDialog extends BaseTransformDialog implements ITransformD
     wOutputFieldsGroup.setText(
         BaseMessages.getString(PKG, "FuzzyMatchDialog.Group.OutputFieldsGroup.Label"));
 
-    FormLayout OutputFieldsgroupLayout = new FormLayout();
-    OutputFieldsgroupLayout.marginWidth = 10;
-    OutputFieldsgroupLayout.marginHeight = 10;
-    wOutputFieldsGroup.setLayout(OutputFieldsgroupLayout);
+    FormLayout outputFieldsgroupLayout = new FormLayout();
+    outputFieldsgroupLayout.marginWidth = 10;
+    outputFieldsgroupLayout.marginHeight = 10;
+    wOutputFieldsGroup.setLayout(outputFieldsgroupLayout);
 
     Label wlmatchField = new Label(wOutputFieldsGroup, SWT.RIGHT);
     wlmatchField.setText(BaseMessages.getString(PKG, "FuzzyMatchDialog.MatchField.Label"));
@@ -566,10 +566,10 @@ public class FuzzyMatchDialog extends BaseTransformDialog implements ITransformD
     fdlu.right = new FormAttachment(100, 0);
     wGetLU.setLayoutData(fdlu);
 
-    int UpInsCols = 2;
-    int UpInsRows = (input.getValue() != null ? input.getValue().length : 1);
+    int upInsCols = 2;
+    int upInsRows = (input.getValue() != null ? input.getValue().length : 1);
 
-    ciReturn = new ColumnInfo[UpInsCols];
+    ciReturn = new ColumnInfo[upInsCols];
     ciReturn[0] =
         new ColumnInfo(
             BaseMessages.getString(PKG, "FuzzyMatchDialog.ColumnInfo.FieldReturn"),
@@ -588,7 +588,7 @@ public class FuzzyMatchDialog extends BaseTransformDialog implements ITransformD
             wFieldsComp,
             SWT.BORDER | SWT.FULL_SELECTION | SWT.MULTI | SWT.V_SCROLL | SWT.H_SCROLL,
             ciReturn,
-            UpInsRows,
+            upInsRows,
             lsMod,
             props);
 
diff --git a/plugins/transforms/getfilesrowcount/src/main/java/org/apache/hop/pipeline/transforms/getfilesrowcount/GetFilesRowsCountDialog.java b/plugins/transforms/getfilesrowcount/src/main/java/org/apache/hop/pipeline/transforms/getfilesrowcount/GetFilesRowsCountDialog.java
index 181b30f..9b77a38 100644
--- a/plugins/transforms/getfilesrowcount/src/main/java/org/apache/hop/pipeline/transforms/getfilesrowcount/GetFilesRowsCountDialog.java
+++ b/plugins/transforms/getfilesrowcount/src/main/java/org/apache/hop/pipeline/transforms/getfilesrowcount/GetFilesRowsCountDialog.java
@@ -83,7 +83,9 @@ public class GetFilesRowsCountDialog extends BaseTransformDialog implements ITra
 
   private GetFilesRowsCountMeta input;
 
-  private Button wFileField, wAddResult, wSmartCount;
+  private Button wFileField;
+  private Button wAddResult;
+  private Button wSmartCount;
 
   private Label wlFilenameField;
   private CCombo wFilenameField;
@@ -172,10 +174,10 @@ public class GetFilesRowsCountDialog extends BaseTransformDialog implements ITra
     props.setLook(wOriginFiles);
     wOriginFiles.setText(BaseMessages.getString(PKG, "GetFilesRowsCountDialog.wOriginFiles.Label"));
 
-    FormLayout OriginFilesgroupLayout = new FormLayout();
-    OriginFilesgroupLayout.marginWidth = 10;
-    OriginFilesgroupLayout.marginHeight = 10;
-    wOriginFiles.setLayout(OriginFilesgroupLayout);
+    FormLayout originFilesgroupLayout = new FormLayout();
+    originFilesgroupLayout.marginWidth = 10;
+    originFilesgroupLayout.marginHeight = 10;
+    wOriginFiles.setLayout(originFilesgroupLayout);
 
     // Is Filename defined in a Field
     Label wlFileField = new Label(wOriginFiles, SWT.RIGHT);
@@ -666,10 +668,10 @@ public class GetFilesRowsCountDialog extends BaseTransformDialog implements ITra
     wAddFileResult.setText(
         BaseMessages.getString(PKG, "GetFilesRowsCountDialog.wAddFileResult.Label"));
 
-    FormLayout AddFileResultgroupLayout = new FormLayout();
-    AddFileResultgroupLayout.marginWidth = 10;
-    AddFileResultgroupLayout.marginHeight = 10;
-    wAddFileResult.setLayout(AddFileResultgroupLayout);
+    FormLayout addFileResultgroupLayout = new FormLayout();
+    addFileResultgroupLayout.marginWidth = 10;
+    addFileResultgroupLayout.marginHeight = 10;
+    wAddFileResult.setLayout(addFileResultgroupLayout);
 
     Label wlAddResult = new Label(wAddFileResult, SWT.RIGHT);
     wlAddResult.setText(BaseMessages.getString(PKG, "GetFilesRowsCountDialog.AddResult.Label"));
@@ -835,10 +837,7 @@ public class GetFilesRowsCountDialog extends BaseTransformDialog implements ITra
         });
 
     // Whenever something changes, set the tooltip to the expanded version of the filename:
-    wFilename.addModifyListener(
-        e -> {
-          wFilename.setToolTipText("");
-        });
+    wFilename.addModifyListener(e -> wFilename.setToolTipText(""));
 
     // Listen to the Browse... button
     wbbFilename.addListener(
diff --git a/plugins/transforms/getfilesrowcount/src/main/java/org/apache/hop/pipeline/transforms/getfilesrowcount/GetFilesRowsCountMeta.java b/plugins/transforms/getfilesrowcount/src/main/java/org/apache/hop/pipeline/transforms/getfilesrowcount/GetFilesRowsCountMeta.java
index 7c1fb8e..503b250 100644
--- a/plugins/transforms/getfilesrowcount/src/main/java/org/apache/hop/pipeline/transforms/getfilesrowcount/GetFilesRowsCountMeta.java
+++ b/plugins/transforms/getfilesrowcount/src/main/java/org/apache/hop/pipeline/transforms/getfilesrowcount/GetFilesRowsCountMeta.java
@@ -65,7 +65,6 @@ public class GetFilesRowsCountMeta extends BaseTransformMeta
         BaseMessages.getString(PKG, "System.Combo.Yes")
       };
   public static final String[] RequiredFilesCode = new String[] {"N", "Y"};
-  private static final String NO = "N";
   private static final String YES = "Y";
 
   public static final String DEFAULT_ROWSCOUNT_FIELDNAME = "rowscount";
@@ -89,10 +88,10 @@ public class GetFilesRowsCountMeta extends BaseTransformMeta
   private String rowsCountFieldName;
 
   /** The row separator type */
-  private String RowSeparatorFormat;
+  private String rowSeparatorFormat;
 
   /** The row separator */
-  private String RowSeparator;
+  private String rowSeparator;
 
   /** file name from previous fields */
   private boolean filefield;
@@ -116,17 +115,17 @@ public class GetFilesRowsCountMeta extends BaseTransformMeta
 
   /** @return Returns the row separator. */
   public String getRowSeparator() {
-    return RowSeparator;
+    return rowSeparator;
   }
 
-  /** @param RowSeparatorin The RowSeparator to set. */
-  public void setRowSeparator(String RowSeparatorin) {
-    this.RowSeparator = RowSeparatorin;
+  /** @param rowSeparatorin The RowSeparator to set. */
+  public void setRowSeparator(String rowSeparatorin) {
+    this.rowSeparator = rowSeparatorin;
   }
 
   /** @return Returns the row separator format. */
   public String getRowSeparatorFormat() {
-    return RowSeparatorFormat;
+    return rowSeparatorFormat;
   }
 
   /** @param isaddresult The isaddresult to set. */
@@ -179,9 +178,9 @@ public class GetFilesRowsCountMeta extends BaseTransformMeta
     this.filefield = filefield;
   }
 
-  /** @param RowSeparatorFormatin The RowSeparator_format to set. */
-  public void setRowSeparatorFormat(String RowSeparatorFormatin) {
-    this.RowSeparatorFormat = RowSeparatorFormatin;
+  /** @param rowSeparatorFormatin The RowSeparator_format to set. */
+  public void setRowSeparatorFormat(String rowSeparatorFormatin) {
+    this.rowSeparatorFormat = rowSeparatorFormatin;
   }
 
   /** @return Returns the fileMask. */
@@ -309,8 +308,8 @@ public class GetFilesRowsCountMeta extends BaseTransformMeta
     retval
         .append("    ")
         .append(XmlHandler.addTagValue("rows_count_fieldname", rowsCountFieldName));
-    retval.append("    ").append(XmlHandler.addTagValue("rowseparator_format", RowSeparatorFormat));
-    retval.append("    ").append(XmlHandler.addTagValue("row_separator", RowSeparator));
+    retval.append("    ").append(XmlHandler.addTagValue("rowseparator_format", rowSeparatorFormat));
+    retval.append("    ").append(XmlHandler.addTagValue("row_separator", rowSeparator));
     retval.append("    ").append(XmlHandler.addTagValue("isaddresult", isaddresult));
     retval.append("    ").append(XmlHandler.addTagValue("filefield", filefield));
     retval.append("    ").append(XmlHandler.addTagValue("filename_Field", outputFilenameField));
@@ -359,9 +358,9 @@ public class GetFilesRowsCountMeta extends BaseTransformMeta
       filesCountFieldName = XmlHandler.getTagValue(transformNode, "files_count_fieldname");
       rowsCountFieldName = XmlHandler.getTagValue(transformNode, "rows_count_fieldname");
 
-      RowSeparatorFormat =
+      rowSeparatorFormat =
           scrubOldRowSeparator(XmlHandler.getTagValue(transformNode, "rowseparator_format"));
-      RowSeparator = XmlHandler.getTagValue(transformNode, "row_separator");
+      rowSeparator = XmlHandler.getTagValue(transformNode, "row_separator");
 
       smartCount = "Y".equalsIgnoreCase(XmlHandler.getTagValue(transformNode, "smartCount"));
 
@@ -414,8 +413,8 @@ public class GetFilesRowsCountMeta extends BaseTransformMeta
     includeFilesCount = false;
     filesCountFieldName = "";
     rowsCountFieldName = "rowscount";
-    RowSeparatorFormat = "CR";
-    RowSeparator = "";
+    rowSeparatorFormat = "CR";
+    rowSeparator = "";
     int nrFiles = 0;
 
     allocate(nrFiles);
@@ -517,7 +516,7 @@ public class GetFilesRowsCountMeta extends BaseTransformMeta
       remarks.add(cr);
     }
 
-    if ((RowSeparatorFormat.equals("CUSTOM")) && (RowSeparator == null)) {
+    if ((rowSeparatorFormat.equals("CUSTOM")) && (rowSeparator == null)) {
       cr =
           new CheckResult(
               ICheckResult.TYPE_RESULT_ERROR,
diff --git a/plugins/transforms/gettablenames/src/main/java/org/apache/hop/pipeline/transforms/gettablenames/GetTableNames.java b/plugins/transforms/gettablenames/src/main/java/org/apache/hop/pipeline/transforms/gettablenames/GetTableNames.java
index 6495c18..90b6fa6 100644
--- a/plugins/transforms/gettablenames/src/main/java/org/apache/hop/pipeline/transforms/gettablenames/GetTableNames.java
+++ b/plugins/transforms/gettablenames/src/main/java/org/apache/hop/pipeline/transforms/gettablenames/GetTableNames.java
@@ -139,7 +139,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
       throws HopDatabaseException, HopTransformException, HopValueException {
     if (meta.isIncludeSynonym()) {
       String[] synonyms = data.db.getSynonyms(data.realSchemaName, meta.isAddSchemaInOut());
-      String ObjectType = BaseMessages.getString(PKG, "GetTableNamesDialog.ObjectType.Synonym");
+      String objectType = BaseMessages.getString(PKG, "GetTableNamesDialog.ObjectType.Synonym");
 
       for (int i = 0; i < synonyms.length && !isStopped(); i++) {
         Object[] outputRowSyn = outputRow.clone();
@@ -150,7 +150,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
         outputRowSyn[outputIndex++] = synonym;
 
         if (!Utils.isEmpty(data.realObjectTypeFieldName)) {
-          outputRowSyn[outputIndex++] = ObjectType;
+          outputRowSyn[outputIndex++] = objectType;
         }
         if (!Utils.isEmpty(data.realIsSystemObjectFieldName)) {
           outputRowSyn[outputIndex++] = Boolean.valueOf(data.db.isSystemTable(synonym));
@@ -170,7 +170,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
       throws HopDatabaseException, HopTransformException, HopValueException {
     if (meta.isIncludeProcedure()) {
       String[] procNames = data.db.getProcedures();
-      String ObjectType = BaseMessages.getString(PKG, "GetTableNamesDialog.ObjectType.Procedure");
+      String objectType = BaseMessages.getString(PKG, "GetTableNamesDialog.ObjectType.Procedure");
       for (int i = 0; i < procNames.length && !isStopped(); i++) {
         Object[] outputRowProc = outputRow.clone();
         int outputIndex = data.totalpreviousfields;
@@ -179,7 +179,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
         outputRowProc[outputIndex++] = procName;
 
         if (!Utils.isEmpty(data.realObjectTypeFieldName)) {
-          outputRowProc[outputIndex++] = ObjectType;
+          outputRowProc[outputIndex++] = objectType;
         }
         if (!Utils.isEmpty(data.realIsSystemObjectFieldName)) {
           outputRowProc[outputIndex++] = Boolean.valueOf(data.db.isSystemTable(procName));
@@ -202,7 +202,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
       try {
         String[] viewNames = data.db.getViews(data.realSchemaName, meta.isAddSchemaInOut());
         String[] viewNamesWithoutSchema = data.db.getViews(data.realSchemaName, false);
-        String ObjectType = BaseMessages.getString(PKG, "GetTableNamesDialog.ObjectType.View");
+        String objectType = BaseMessages.getString(PKG, "GetTableNamesDialog.ObjectType.View");
         for (int i = 0; i < viewNames.length && !isStopped(); i++) {
           Object[] outputRowView = outputRow.clone();
           int outputIndex = data.totalpreviousfields;
@@ -212,7 +212,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
           outputRowView[outputIndex++] = viewName;
 
           if (!Utils.isEmpty(data.realObjectTypeFieldName)) {
-            outputRowView[outputIndex++] = ObjectType;
+            outputRowView[outputIndex++] = objectType;
           }
           if (!Utils.isEmpty(data.realIsSystemObjectFieldName)) {
             outputRowView[outputIndex++] =
@@ -242,7 +242,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
       String[] tableNames = data.db.getTablenames(data.realSchemaName, meta.isAddSchemaInOut());
       String[] tableNamesWithoutSchema = data.db.getTablenames(data.realSchemaName, false);
 
-      String ObjectType = BaseMessages.getString(PKG, "GetTableNamesDialog.ObjectType.Table");
+      String objectType = BaseMessages.getString(PKG, "GetTableNamesDialog.ObjectType.Table");
 
       for (int i = 0; i < tableNames.length && !isStopped(); i++) {
         Object[] outputRowTable = outputRow.clone();
@@ -254,7 +254,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
         outputRowTable[outputIndex++] = tableName;
 
         if (!Utils.isEmpty(data.realObjectTypeFieldName)) {
-          outputRowTable[outputIndex++] = ObjectType;
+          outputRowTable[outputIndex++] = objectType;
         }
         if (!Utils.isEmpty(data.realIsSystemObjectFieldName)) {
           outputRowTable[outputIndex++] =
@@ -279,9 +279,9 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
 
         if (pkc != null) {
           // add composite primary key (several fields in primary key)
-          int IndexOfLastClosedBracket = sql.lastIndexOf(")");
-          if (IndexOfLastClosedBracket > -1) {
-            sql = sql.substring(0, IndexOfLastClosedBracket);
+          int indexOfLastClosedBracket = sql.lastIndexOf(")");
+          if (indexOfLastClosedBracket > -1) {
+            sql = sql.substring(0, indexOfLastClosedBracket);
             sql += ", PRIMARY KEY (";
             for (int k = 0; k < pkc.length; k++) {
               if (k > 0) {
@@ -308,7 +308,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
       throws HopDatabaseException, HopTransformException, HopValueException {
     // Schemas
     if (meta.isIncludeSchema()) {
-      String ObjectType = BaseMessages.getString(PKG, "GetTableNamesDialog.ObjectType.Schema");
+      String objectType = BaseMessages.getString(PKG, "GetTableNamesDialog.ObjectType.Schema");
       // Views
       String[] schemaNames = new String[] {};
       if (!Utils.isEmpty(data.realSchemaName)) {
@@ -327,7 +327,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
         outputRowSchema[outputIndex++] = schemaName;
 
         if (!Utils.isEmpty(data.realObjectTypeFieldName)) {
-          outputRowSchema[outputIndex++] = ObjectType;
+          outputRowSchema[outputIndex++] = objectType;
         }
         if (!Utils.isEmpty(data.realIsSystemObjectFieldName)) {
           outputRowSchema[outputIndex++] = Boolean.valueOf(data.db.isSystemTable(schemaName));
@@ -347,7 +347,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
       throws HopDatabaseException, HopTransformException, HopValueException {
     // Catalogs
     if (meta.isIncludeCatalog()) {
-      String ObjectType = BaseMessages.getString(PKG, "GetTableNames.ObjectType.Catalog");
+      String objectType = BaseMessages.getString(PKG, "GetTableNames.ObjectType.Catalog");
       // Views
       String[] catalogsNames = data.db.getCatalogs();
 
@@ -362,7 +362,7 @@ public class GetTableNames extends BaseTransform<GetTableNamesMeta, GetTableName
         outputRowCatalog[outputIndex++] = catalogName;
 
         if (!Utils.isEmpty(data.realObjectTypeFieldName)) {
-          outputRowCatalog[outputIndex++] = ObjectType;
+          outputRowCatalog[outputIndex++] = objectType;
         }
         if (!Utils.isEmpty(data.realIsSystemObjectFieldName)) {
           outputRowCatalog[outputIndex++] = Boolean.valueOf(data.db.isSystemTable(catalogName));
diff --git a/plugins/transforms/gettablenames/src/main/java/org/apache/hop/pipeline/transforms/gettablenames/GetTableNamesDialog.java b/plugins/transforms/gettablenames/src/main/java/org/apache/hop/pipeline/transforms/gettablenames/GetTableNamesDialog.java
index b8d77b1..9e3b6fe 100644
--- a/plugins/transforms/gettablenames/src/main/java/org/apache/hop/pipeline/transforms/gettablenames/GetTableNamesDialog.java
+++ b/plugins/transforms/gettablenames/src/main/java/org/apache/hop/pipeline/transforms/gettablenames/GetTableNamesDialog.java
@@ -220,7 +220,9 @@ public class GetTableNamesDialog extends BaseTransformDialog implements ITransfo
     wSchemaField.addFocusListener(
         new FocusListener() {
           @Override
-          public void focusLost(org.eclipse.swt.events.FocusEvent e) {}
+          public void focusLost(org.eclipse.swt.events.FocusEvent e) {
+            // Disable focuslost
+          }
 
           @Override
           public void focusGained(org.eclipse.swt.events.FocusEvent e) {
@@ -237,10 +239,10 @@ public class GetTableNamesDialog extends BaseTransformDialog implements ITransfo
     props.setLook(wSettings);
     wSettings.setText(BaseMessages.getString(PKG, "GetTableNamesDialog.wSettings.Label"));
 
-    FormLayout SettingsgroupLayout = new FormLayout();
-    SettingsgroupLayout.marginWidth = 10;
-    SettingsgroupLayout.marginHeight = 10;
-    wSettings.setLayout(SettingsgroupLayout);
+    FormLayout settingsgroupLayout = new FormLayout();
+    settingsgroupLayout.marginWidth = 10;
+    settingsgroupLayout.marginHeight = 10;
+    wSettings.setLayout(settingsgroupLayout);
 
     // Include Catalogs
     wlIncludeCatalog = new Label(wSettings, SWT.RIGHT);
@@ -447,10 +449,10 @@ public class GetTableNamesDialog extends BaseTransformDialog implements ITransfo
     props.setLook(wOutputFields);
     wOutputFields.setText(BaseMessages.getString(PKG, "GetTableNamesDialog.wOutputFields.Label"));
 
-    FormLayout OutputFieldsgroupLayout = new FormLayout();
-    OutputFieldsgroupLayout.marginWidth = 10;
-    OutputFieldsgroupLayout.marginHeight = 10;
-    wOutputFields.setLayout(OutputFieldsgroupLayout);
+    FormLayout outputFieldsgroupLayout = new FormLayout();
+    outputFieldsgroupLayout.marginWidth = 10;
+    outputFieldsgroupLayout.marginHeight = 10;
+    wOutputFields.setLayout(outputFieldsgroupLayout);
 
     // TablenameField fieldname ...
     Label wlTablenameField = new Label(wOutputFields, SWT.RIGHT);
diff --git a/plugins/transforms/http/src/main/java/org/apache/hop/pipeline/transforms/http/HttpDialog.java b/plugins/transforms/http/src/main/java/org/apache/hop/pipeline/transforms/http/HttpDialog.java
index c0c1bd0..4139f48 100644
--- a/plugins/transforms/http/src/main/java/org/apache/hop/pipeline/transforms/http/HttpDialog.java
+++ b/plugins/transforms/http/src/main/java/org/apache/hop/pipeline/transforms/http/HttpDialog.java
@@ -176,10 +176,10 @@ public class HttpDialog extends BaseTransformDialog implements ITransformDialog
 
     Group gSettings = new Group(wGeneralComp, SWT.SHADOW_ETCHED_IN);
     gSettings.setText(BaseMessages.getString(PKG, "HTTPDialog.SettingsGroup.Label"));
-    FormLayout SettingsLayout = new FormLayout();
-    SettingsLayout.marginWidth = 3;
-    SettingsLayout.marginHeight = 3;
-    gSettings.setLayout(SettingsLayout);
+    FormLayout settingsLayout = new FormLayout();
+    settingsLayout.marginWidth = 3;
+    settingsLayout.marginHeight = 3;
+    gSettings.setLayout(settingsLayout);
     props.setLook(gSettings);
 
     // The URL to use
@@ -374,10 +374,10 @@ public class HttpDialog extends BaseTransformDialog implements ITransformDialog
 
     Group gOutputFields = new Group(wGeneralComp, SWT.SHADOW_ETCHED_IN);
     gOutputFields.setText(BaseMessages.getString(PKG, "HTTPDialog.OutputFieldsGroup.Label"));
-    FormLayout OutputFieldsLayout = new FormLayout();
-    OutputFieldsLayout.marginWidth = 3;
-    OutputFieldsLayout.marginHeight = 3;
-    gOutputFields.setLayout(OutputFieldsLayout);
+    FormLayout outputFieldsLayout = new FormLayout();
+    outputFieldsLayout.marginWidth = 3;
+    outputFieldsLayout.marginHeight = 3;
+    gOutputFields.setLayout(outputFieldsLayout);
     props.setLook(gOutputFields);
 
     // Result line...
diff --git a/plugins/transforms/ifnull/src/main/java/org/apache/hop/pipeline/transforms/ifnull/IfNull.java b/plugins/transforms/ifnull/src/main/java/org/apache/hop/pipeline/transforms/ifnull/IfNull.java
index ee4e5ff..9234910 100644
--- a/plugins/transforms/ifnull/src/main/java/org/apache/hop/pipeline/transforms/ifnull/IfNull.java
+++ b/plugins/transforms/ifnull/src/main/java/org/apache/hop/pipeline/transforms/ifnull/IfNull.java
@@ -107,13 +107,13 @@ public class IfNull extends BaseTransform<IfNullMeta, IfNullData>
           data.setEmptyString = new boolean[typeLength];
 
           // return all type codes
-          HashSet<String> AlllistTypes = new HashSet<>();
+          HashSet<String> alllistTypes = new HashSet<>();
           for (int i = 0; i < IValueMeta.typeCodes.length; i++) {
-            AlllistTypes.add(IValueMeta.typeCodes[i]);
+            alllistTypes.add(IValueMeta.typeCodes[i]);
           }
 
           for (int i = 0; i < meta.getValueTypes().length; i++) {
-            if (!AlllistTypes.contains(meta.getValueTypes()[i].getTypeName())) {
+            if (!alllistTypes.contains(meta.getValueTypes()[i].getTypeName())) {
               throw new HopException(
                   BaseMessages.getString(
                       PKG,
diff --git a/plugins/transforms/ifnull/src/main/java/org/apache/hop/pipeline/transforms/ifnull/IfNullDialog.java b/plugins/transforms/ifnull/src/main/java/org/apache/hop/pipeline/transforms/ifnull/IfNullDialog.java
index afb5a90..e8f1254 100644
--- a/plugins/transforms/ifnull/src/main/java/org/apache/hop/pipeline/transforms/ifnull/IfNullDialog.java
+++ b/plugins/transforms/ifnull/src/main/java/org/apache/hop/pipeline/transforms/ifnull/IfNullDialog.java
@@ -63,9 +63,12 @@ public class IfNullDialog extends BaseTransformDialog implements ITransformDialo
   /** List of ColumnInfo that should have the previous fields combo box */
   private final List<ColumnInfo> fieldColumns = new ArrayList<>();
 
-  private Button wSelectFields, wSelectValuesType;
-  private Label wlFields, wlValueTypes;
-  private TableView wFields, wValueTypes;
+  private Button wSelectFields;
+  private Button wSelectValuesType;
+  private Label wlFields;
+  private Label wlValueTypes;
+  private TableView wFields;
+  private TableView wValueTypes;
 
   private Label wlReplaceByValue;
 
@@ -146,10 +149,10 @@ public class IfNullDialog extends BaseTransformDialog implements ITransformDialo
     props.setLook(wAllFields);
     wAllFields.setText(BaseMessages.getString(PKG, "IfNullDialog.AllFields.Label"));
 
-    FormLayout AllFieldsgroupLayout = new FormLayout();
-    AllFieldsgroupLayout.marginWidth = 10;
-    AllFieldsgroupLayout.marginHeight = 10;
-    wAllFields.setLayout(AllFieldsgroupLayout);
+    FormLayout allFieldsgroupLayout = new FormLayout();
+    allFieldsgroupLayout.marginWidth = 10;
+    allFieldsgroupLayout.marginHeight = 10;
+    wAllFields.setLayout(allFieldsgroupLayout);
 
     // Replace by Value
     wlReplaceByValue = new Label(wAllFields, SWT.RIGHT);
@@ -349,8 +352,8 @@ public class IfNullDialog extends BaseTransformDialog implements ITransformDialo
   }
 
   private void addFields() {
-    int FieldsCols = 4;
-    ColumnInfo[] colinf = new ColumnInfo[FieldsCols];
+    int fieldsCols = 4;
+    ColumnInfo[] colinf = new ColumnInfo[fieldsCols];
 
     // Table with fields
     wlFields = new Label(shell, SWT.NONE);
diff --git a/plugins/transforms/insertupdate/src/main/java/org/apache/hop/pipeline/transforms/insertupdate/InsertUpdateDialog.java b/plugins/transforms/insertupdate/src/main/java/org/apache/hop/pipeline/transforms/insertupdate/InsertUpdateDialog.java
index f4cab50..1f059ae 100644
--- a/plugins/transforms/insertupdate/src/main/java/org/apache/hop/pipeline/transforms/insertupdate/InsertUpdateDialog.java
+++ b/plugins/transforms/insertupdate/src/main/java/org/apache/hop/pipeline/transforms/insertupdate/InsertUpdateDialog.java
@@ -341,13 +341,13 @@ public class InsertUpdateDialog extends BaseTransformDialog implements ITransfor
     fdlReturn.top = new FormAttachment(wKey, margin);
     wlReturn.setLayoutData(fdlReturn);
 
-    int UpInsCols = 3;
-    int UpInsRows =
+    int upInsCols = 3;
+    int upInsRows =
         (input.getInsertUpdateLookupField().getValueFields() != null
             ? input.getInsertUpdateLookupField().getValueFields().size()
             : 1);
 
-    ciReturn = new ColumnInfo[UpInsCols];
+    ciReturn = new ColumnInfo[upInsCols];
     ciReturn[0] =
         new ColumnInfo(
             BaseMessages.getString(PKG, "InsertUpdateDialog.ColumnInfo.TableField"),
@@ -372,7 +372,7 @@ public class InsertUpdateDialog extends BaseTransformDialog implements ITransfor
             shell,
             SWT.BORDER | SWT.FULL_SELECTION | SWT.MULTI | SWT.V_SCROLL | SWT.H_SCROLL,
             ciReturn,
-            UpInsRows,
+            upInsRows,
             lsMod,
             props);
 
@@ -751,9 +751,9 @@ public class InsertUpdateDialog extends BaseTransformDialog implements ITransfor
     Runnable fieldLoader =
         () -> {
           if (!wTable.isDisposed() && !wConnection.isDisposed() && !wSchema.isDisposed()) {
-            final String tableName = wTable.getText(),
-                connectionName = wConnection.getText(),
-                schemaName = wSchema.getText();
+            final String tableName = wTable.getText();
+            final String connectionName = wConnection.getText();
+            final String schemaName = wSchema.getText();
 
             // clear
             for (ColumnInfo colInfo : tableFieldColumns) {
diff --git a/plugins/transforms/janino/src/main/java/org/apache/hop/pipeline/transforms/janino/JaninoDialog.java b/plugins/transforms/janino/src/main/java/org/apache/hop/pipeline/transforms/janino/JaninoDialog.java
index 4ad8439..72f0620 100644
--- a/plugins/transforms/janino/src/main/java/org/apache/hop/pipeline/transforms/janino/JaninoDialog.java
+++ b/plugins/transforms/janino/src/main/java/org/apache/hop/pipeline/transforms/janino/JaninoDialog.java
@@ -193,10 +193,9 @@ public class JaninoDialog extends BaseTransformDialog implements ITransformDialo
     new Thread(runnable).start();
 
     wFields.addModifyListener(
-        arg0 -> {
-          // Now set the combo's
-          shell.getDisplay().asyncExec(() -> setComboBoxes());
-        });
+        arg0 ->
+            // Now set the combo's
+            shell.getDisplay().asyncExec(() -> setComboBoxes()));
 
     getData();
     currentMeta.setChanged(changed);
diff --git a/plugins/transforms/janino/src/main/java/org/apache/hop/pipeline/transforms/userdefinedjavaclass/UserDefinedJavaClassDialog.java b/plugins/transforms/janino/src/main/java/org/apache/hop/pipeline/transforms/userdefinedjavaclass/UserDefinedJavaClassDialog.java
index bb7b961..0e037bc 100644
--- a/plugins/transforms/janino/src/main/java/org/apache/hop/pipeline/transforms/userdefinedjavaclass/UserDefinedJavaClassDialog.java
+++ b/plugins/transforms/janino/src/main/java/org/apache/hop/pipeline/transforms/userdefinedjavaclass/UserDefinedJavaClassDialog.java
@@ -85,9 +85,12 @@ public class UserDefinedJavaClassDialog extends BaseTransformDialog implements I
   private Tree wTree;
   private TreeItem wTreeClassesItem;
 
-  private Image imageActiveScript, imageInactiveScript;
-  private CTabFolder folder, wTabFolder;
-  private Menu cMenu, tMenu;
+  private Image imageActiveScript;
+  private Image imageInactiveScript;
+  private CTabFolder folder;
+  private CTabFolder wTabFolder;
+  private Menu cMenu;
+  private Menu tMenu;
 
   // Suport for Rename Tree
   private TreeItem[] lastItem;
@@ -113,16 +116,23 @@ public class UserDefinedJavaClassDialog extends BaseTransformDialog implements I
 
   private static final GuiResource guiResource = GuiResource.getInstance();
 
-  private TreeItem itemInput, itemInfo, itemOutput;
-  private IRowMeta inputRowMeta, infoRowMeta, outputRowMeta;
+  private TreeItem itemInput;
+  private TreeItem itemInfo;
+  private TreeItem itemOutput;
+  private IRowMeta inputRowMeta;
+  private IRowMeta infoRowMeta;
+  private IRowMeta outputRowMeta;
 
   private RowGeneratorMeta genMeta;
 
   private CTabItem fieldsTab;
 
   private int margin;
-  private TableView wInfoTransforms, wTargetTransforms, wParameters;
-  private String[] prevTransformNames, nextTransformNames;
+  private TableView wInfoTransforms;
+  private TableView wTargetTransforms;
+  private TableView wParameters;
+  private String[] prevTransformNames;
+  private String[] nextTransformNames;
 
   public UserDefinedJavaClassDialog(
       Shell parent, IVariables variables, Object in, PipelineMeta pipelineMeta, String sname) {
@@ -1748,9 +1758,11 @@ public class UserDefinedJavaClassDialog extends BaseTransformDialog implements I
                   Point size = TextSizeUtilFacade.textExtent(leftText + e.text + rightText);
                   size = text.computeSize(size.x, SWT.DEFAULT);
                   editor.horizontalAlignment = SWT.LEFT;
-                  Rectangle itemRect = item.getBounds(), rect = wTree.getClientArea();
+                  Rectangle itemRect = item.getBounds();
+                  Rectangle rect = wTree.getClientArea();
                   editor.minimumWidth = Math.max(size.x, itemRect.width) + inset * 2;
-                  int left = itemRect.x, right = rect.x + rect.width;
+                  int left = itemRect.x;
+                  int right = rect.x + rect.width;
                   editor.minimumWidth = Math.min(editor.minimumWidth, right - left);
                   editor.minimumHeight = size.y + inset * 2;
                   editor.layout();
diff --git a/plugins/transforms/javascript/src/main/java/org/apache/hop/pipeline/transforms/javascript/ScriptValuesAddedFunctions.java b/plugins/transforms/javascript/src/main/java/org/apache/hop/pipeline/transforms/javascript/ScriptValuesAddedFunctions.java
index a1848a3..560c7b4 100644
--- a/plugins/transforms/javascript/src/main/java/org/apache/hop/pipeline/transforms/javascript/ScriptValuesAddedFunctions.java
+++ b/plugins/transforms/javascript/src/main/java/org/apache/hop/pipeline/transforms/javascript/ScriptValuesAddedFunctions.java
@@ -2166,7 +2166,8 @@ public class ScriptValuesAddedFunctions extends ScriptableObject {
           && !isNull(argList[1])
           && !isUndefined(argList[0])
           && !isUndefined(argList[1])) {
-        FileObject fileSource = null, fileDestination = null;
+        FileObject fileSource = null;
+        FileObject fileDestination = null;
 
         try {
           // Source file to copy
diff --git a/plugins/transforms/javascript/src/main/java/org/apache/hop/pipeline/transforms/javascript/ScriptValuesDialog.java b/plugins/transforms/javascript/src/main/java/org/apache/hop/pipeline/transforms/javascript/ScriptValuesDialog.java
index eac3266..8216415 100644
--- a/plugins/transforms/javascript/src/main/java/org/apache/hop/pipeline/transforms/javascript/ScriptValuesDialog.java
+++ b/plugins/transforms/javascript/src/main/java/org/apache/hop/pipeline/transforms/javascript/ScriptValuesDialog.java
@@ -1260,7 +1260,8 @@ public class ScriptValuesDialog extends BaseTransformDialog implements ITransfor
               if (!varname.equalsIgnoreCase("row")
                   && !varname.equalsIgnoreCase("pipeline_Status")) {
                 int type = IValueMeta.TYPE_STRING;
-                int length = -1, precision = -1;
+                int length = -1;
+                int precision = -1;
                 Object result = jsscope.get(varname, jsscope);
                 if (result != null) {
                   String classname = result.getClass().getName();
@@ -1864,9 +1865,11 @@ public class ScriptValuesDialog extends BaseTransformDialog implements ITransfor
                   Point size = TextSizeUtilFacade.textExtent(leftText + e.text + rightText);
                   size = text.computeSize(size.x, SWT.DEFAULT);
                   editor.horizontalAlignment = SWT.LEFT;
-                  Rectangle itemRect = item.getBounds(), rect = wTree.getClientArea();
+                  Rectangle itemRect = item.getBounds();
+                  Rectangle rect = wTree.getClientArea();
                   editor.minimumWidth = Math.max(size.x, itemRect.width) + inset * 2;
-                  int left = itemRect.x, right = rect.x + rect.width;
+                  int left = itemRect.x;
+                  int right = rect.x + rect.width;
                   editor.minimumWidth = Math.min(editor.minimumWidth, right - left);
                   editor.minimumHeight = size.y + inset * 2;
                   editor.layout();
diff --git a/plugins/transforms/json/src/main/java/org/apache/hop/pipeline/transforms/jsonoutputenhanced/JsonOutputField.java b/plugins/transforms/json/src/main/java/org/apache/hop/pipeline/transforms/jsonoutputenhanced/JsonOutputField.java
index 6cfb9d8..67237ab 100644
--- a/plugins/transforms/json/src/main/java/org/apache/hop/pipeline/transforms/jsonoutputenhanced/JsonOutputField.java
+++ b/plugins/transforms/json/src/main/java/org/apache/hop/pipeline/transforms/jsonoutputenhanced/JsonOutputField.java
@@ -37,8 +37,8 @@ public class JsonOutputField implements Cloneable {
     return isJSONFragment;
   }
 
-  public void setJSONFragment(boolean JSONFragment) {
-    isJSONFragment = JSONFragment;
+  public void setJSONFragment(boolean jsonFragment) {
+    isJSONFragment = jsonFragment;
   }
 
   public boolean isRemoveIfBlank() {
diff --git a/plugins/transforms/json/src/main/java/org/apache/hop/pipeline/transforms/jsonoutputenhanced/JsonOutputMeta.java b/plugins/transforms/json/src/main/java/org/apache/hop/pipeline/transforms/jsonoutputenhanced/JsonOutputMeta.java
index 6d58017..caa808e 100644
--- a/plugins/transforms/json/src/main/java/org/apache/hop/pipeline/transforms/jsonoutputenhanced/JsonOutputMeta.java
+++ b/plugins/transforms/json/src/main/java/org/apache/hop/pipeline/transforms/jsonoutputenhanced/JsonOutputMeta.java
@@ -56,7 +56,7 @@ import java.util.List;
     groups = {"GENERAL", "FIELDS"})
 public class JsonOutputMeta extends BaseFileOutputMeta
     implements ITransformMeta<JsonOutput, JsonOutputData> {
-  private static Class<?> PKG = JsonOutputMeta.class;
+  private static final Class<?> PKG = JsonOutputMeta.class;
 
   /** Operations type */
   @Injection(name = "OPERATION", group = "GENERAL")
diff --git a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapConnection.java b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapConnection.java
index 00c4838..7ed46bb 100644
--- a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapConnection.java
+++ b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapConnection.java
@@ -660,34 +660,34 @@ public class LdapConnection {
   }
 
   /**
-   * Convert the SID into string format
+   * Convert the sid into string format
    *
-   * @param SID
-   * @return String representation of SID
+   * @param sid
+   * @return String representation of sid
    */
-  private static String getSIDAsString(byte[] SID) {
+  private static String getSIDAsString(byte[] sid) {
     long version;
     long authority;
     long count;
     long rid;
     String strSID;
     strSID = "S";
-    version = SID[0];
+    version = sid[0];
     strSID = strSID + "-" + Long.toString(version);
-    authority = SID[4];
+    authority = sid[4];
     for (int i = 0; i < 4; i++) {
       authority <<= 8;
-      authority += SID[4 + i] & 0xFF;
+      authority += sid[4 + i] & 0xFF;
     }
     strSID = strSID + "-" + Long.toString(authority);
-    count = SID[2];
+    count = sid[2];
     count <<= 8;
-    count += SID[1] & 0xFF;
+    count += sid[1] & 0xFF;
     for (int j = 0; j < count; j++) {
-      rid = SID[11 + (j * 4)] & 0xFF;
+      rid = sid[11 + (j * 4)] & 0xFF;
       for (int k = 1; k < 4; k++) {
         rid <<= 8;
-        rid += SID[11 - k + (j * 4)] & 0xFF;
+        rid += sid[11 - k + (j * 4)] & 0xFF;
       }
       strSID = strSID + "-" + Long.toString(rid);
     }
diff --git a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputDialog.java b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputDialog.java
index b27ec31..1002fb6 100644
--- a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputDialog.java
+++ b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputDialog.java
@@ -206,10 +206,10 @@ public class LdapInputDialog extends BaseTransformDialog implements ITransformDi
     props.setLook(wHostGroup);
     wHostGroup.setText(BaseMessages.getString(PKG, "LdapInputDialog.Group.HostGroup.Label"));
 
-    FormLayout HostGroupLayout = new FormLayout();
-    HostGroupLayout.marginWidth = 10;
-    HostGroupLayout.marginHeight = 10;
-    wHostGroup.setLayout(HostGroupLayout);
+    FormLayout hostGroupLayout = new FormLayout();
+    hostGroupLayout.marginWidth = 10;
+    hostGroupLayout.marginHeight = 10;
+    wHostGroup.setLayout(hostGroupLayout);
 
     // Host line
     Label wlHost = new Label(wHostGroup, SWT.RIGHT);
@@ -297,10 +297,10 @@ public class LdapInputDialog extends BaseTransformDialog implements ITransformDi
     wAuthenticationGroup.setText(
         BaseMessages.getString(PKG, "LdapInputDialog.Group.AuthenticationGroup.Label"));
 
-    FormLayout AuthenticationGroupLayout = new FormLayout();
-    AuthenticationGroupLayout.marginWidth = 10;
-    AuthenticationGroupLayout.marginHeight = 10;
-    wAuthenticationGroup.setLayout(AuthenticationGroupLayout);
+    FormLayout authenticationGroupLayout = new FormLayout();
+    authenticationGroupLayout.marginWidth = 10;
+    authenticationGroupLayout.marginHeight = 10;
+    wAuthenticationGroup.setLayout(authenticationGroupLayout);
 
     // using authentication ?
     Label wlUsingAuthentication = new Label(wAuthenticationGroup, SWT.RIGHT);
@@ -388,10 +388,10 @@ public class LdapInputDialog extends BaseTransformDialog implements ITransformDi
     wCertificateGroup.setText(
         BaseMessages.getString(PKG, "LdapInputDialog.Group.CertificateGroup.Label"));
 
-    FormLayout CertificateGroupLayout = new FormLayout();
-    CertificateGroupLayout.marginWidth = 10;
-    CertificateGroupLayout.marginHeight = 10;
-    wCertificateGroup.setLayout(CertificateGroupLayout);
+    FormLayout certificateGroupLayout = new FormLayout();
+    certificateGroupLayout.marginWidth = 10;
+    certificateGroupLayout.marginHeight = 10;
+    wCertificateGroup.setLayout(certificateGroupLayout);
 
     // set TrustStore?
     wlSetTrustStore = new Label(wCertificateGroup, SWT.RIGHT);
@@ -551,13 +551,13 @@ public class LdapInputDialog extends BaseTransformDialog implements ITransformDi
     CTabItem wSearchTab = new CTabItem(wTabFolder, SWT.NONE);
     wSearchTab.setText(BaseMessages.getString(PKG, "LdapInputDialog.Search.Tab"));
 
-    FormLayout SearchLayout = new FormLayout();
-    SearchLayout.marginWidth = 3;
-    SearchLayout.marginHeight = 3;
+    FormLayout searchLayout = new FormLayout();
+    searchLayout.marginWidth = 3;
+    searchLayout.marginHeight = 3;
 
     Composite wSearchComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wSearchComp);
-    wSearchComp.setLayout(SearchLayout);
+    wSearchComp.setLayout(searchLayout);
 
     // /////////////////////////////////
     // START OF Search GROUP
diff --git a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputField.java b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputField.java
index 67e4f69..fe9287b 100644
--- a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputField.java
+++ b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputField.java
@@ -282,24 +282,24 @@ public class LdapInputField implements Cloneable {
     return groupSymbol;
   }
 
-  public void setGroupSymbol(String group_symbol) {
-    this.groupSymbol = group_symbol;
+  public void setGroupSymbol(String groupSymbol) {
+    this.groupSymbol = groupSymbol;
   }
 
   public String getDecimalSymbol() {
     return decimalSymbol;
   }
 
-  public void setDecimalSymbol(String decimal_symbol) {
-    this.decimalSymbol = decimal_symbol;
+  public void setDecimalSymbol(String decimalSymbol) {
+    this.decimalSymbol = decimalSymbol;
   }
 
   public String getCurrencySymbol() {
     return currencySymbol;
   }
 
-  public void setCurrencySymbol(String currency_symbol) {
-    this.currencySymbol = currency_symbol;
+  public void setCurrencySymbol(String currencySymbol) {
+    this.currencySymbol = currencySymbol;
   }
 
   public int getPrecision() {
diff --git a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputMeta.java b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputMeta.java
index dcd2113..3050b05 100644
--- a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputMeta.java
+++ b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapinput/LdapInputMeta.java
@@ -75,7 +75,7 @@ public class LdapInputMeta extends BaseTransformMeta
   private int rowLimit;
 
   /** The Host name */
-  private String Host;
+  private String host;
 
   /** The User name */
   private String userName;
@@ -274,12 +274,12 @@ public class LdapInputMeta extends BaseTransformMeta
   /** @return Returns the host name. */
   @Override
   public String getHost() {
-    return Host;
+    return host;
   }
 
   /** @param host The host to set. */
   public void setHost(String host) {
-    this.Host = host;
+    this.host = host;
   }
 
   /** @return Returns the user name. */
@@ -415,7 +415,7 @@ public class LdapInputMeta extends BaseTransformMeta
     retval.append("    ").append(XmlHandler.addTagValue("useauthentication", useAuthentication));
     retval.append("    ").append(XmlHandler.addTagValue("rownum", includeRowNumber));
     retval.append("    ").append(XmlHandler.addTagValue("rownum_field", rowNumberField));
-    retval.append("    ").append(XmlHandler.addTagValue("host", Host));
+    retval.append("    ").append(XmlHandler.addTagValue("host", host));
     retval.append("    ").append(XmlHandler.addTagValue("username", userName));
     retval
         .append("    ")
@@ -524,7 +524,7 @@ public class LdapInputMeta extends BaseTransformMeta
           "Y".equalsIgnoreCase(XmlHandler.getTagValue(transformNode, "useauthentication"));
       includeRowNumber = "Y".equalsIgnoreCase(XmlHandler.getTagValue(transformNode, "rownum"));
       rowNumberField = XmlHandler.getTagValue(transformNode, "rownum_field");
-      Host = XmlHandler.getTagValue(transformNode, "host");
+      host = XmlHandler.getTagValue(transformNode, "host");
       userName = XmlHandler.getTagValue(transformNode, "username");
       setPassword(
           Encr.decryptPasswordOptionallyEncrypted(
@@ -628,7 +628,7 @@ public class LdapInputMeta extends BaseTransformMeta
     this.useAuthentication = false;
     this.includeRowNumber = false;
     this.rowNumberField = "";
-    this.Host = "";
+    this.host = "";
     this.userName = "";
     this.password = "";
     this.port = "389";
@@ -728,8 +728,8 @@ public class LdapInputMeta extends BaseTransformMeta
       PipelineMeta pipelineMeta,
       TransformMeta transformMeta,
       IRowMeta prev,
-      String input[],
-      String output[],
+      String[] input,
+      String[] output,
       IRowMeta info,
       IVariables variables,
       IHopMetadataProvider metadataProvider) {
@@ -769,7 +769,7 @@ public class LdapInputMeta extends BaseTransformMeta
     remarks.add(cr);
 
     // Check hostname
-    if (Utils.isEmpty(Host)) {
+    if (Utils.isEmpty(host)) {
       cr =
           new CheckResult(
               TYPE_RESULT_ERROR,
diff --git a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapoutput/LdapOutputDialog.java b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapoutput/LdapOutputDialog.java
index 2a62039..fdfae62 100644
--- a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapoutput/LdapOutputDialog.java
+++ b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapoutput/LdapOutputDialog.java
@@ -360,10 +360,10 @@ public class LdapOutputDialog extends BaseTransformDialog implements ITransformD
     wAuthenticationGroup.setText(
         BaseMessages.getString(PKG, "LdapOutputDialog.Group.AuthenticationGroup.Label"));
 
-    FormLayout AuthenticationGroupLayout = new FormLayout();
-    AuthenticationGroupLayout.marginWidth = 10;
-    AuthenticationGroupLayout.marginHeight = 10;
-    wAuthenticationGroup.setLayout(AuthenticationGroupLayout);
+    FormLayout authenticationGroupLayout = new FormLayout();
+    authenticationGroupLayout.marginWidth = 10;
+    authenticationGroupLayout.marginHeight = 10;
+    wAuthenticationGroup.setLayout(authenticationGroupLayout);
 
     // using authentication ?
     Label wlUsingAuthentication = new Label(wAuthenticationGroup, SWT.RIGHT);
@@ -621,10 +621,10 @@ public class LdapOutputDialog extends BaseTransformDialog implements ITransformD
     props.setLook(wSettings);
     wSettings.setText(BaseMessages.getString(PKG, "LdapOutputDialog.Group.Settings.Label"));
 
-    FormLayout SettingsLayout = new FormLayout();
-    SettingsLayout.marginWidth = 10;
-    SettingsLayout.marginHeight = 10;
-    wSettings.setLayout(SettingsLayout);
+    FormLayout settingsLayout = new FormLayout();
+    settingsLayout.marginWidth = 10;
+    settingsLayout.marginHeight = 10;
+    wSettings.setLayout(settingsLayout);
 
     // Operation
     Label wlOperation = new Label(wSettings, SWT.RIGHT);
@@ -749,10 +749,10 @@ public class LdapOutputDialog extends BaseTransformDialog implements ITransformD
     props.setLook(wRenameGroup);
     wRenameGroup.setText(BaseMessages.getString(PKG, "LdapOutputDialog.Group.RenameGroup.Label"));
 
-    FormLayout RenameGroupLayout = new FormLayout();
-    RenameGroupLayout.marginWidth = 10;
-    RenameGroupLayout.marginHeight = 10;
-    wRenameGroup.setLayout(RenameGroupLayout);
+    FormLayout renameGroupLayout = new FormLayout();
+    renameGroupLayout.marginWidth = 10;
+    renameGroupLayout.marginHeight = 10;
+    wRenameGroup.setLayout(renameGroupLayout);
 
     // OldDn fieldname
     wlOldDnField = new Label(wRenameGroup, SWT.RIGHT);
@@ -883,10 +883,10 @@ public class LdapOutputDialog extends BaseTransformDialog implements ITransformD
     props.setLook(wFields);
     wFields.setText(BaseMessages.getString(PKG, "LdapOutputDialog.Group.Fields.Label"));
 
-    FormLayout FieldsLayout = new FormLayout();
-    FieldsLayout.marginWidth = 10;
-    FieldsLayout.marginHeight = 10;
-    wFields.setLayout(FieldsLayout);
+    FormLayout fieldsLayout2 = new FormLayout();
+    fieldsLayout2.marginWidth = 10;
+    fieldsLayout2.marginHeight = 10;
+    wFields.setLayout(fieldsLayout2);
 
     // Basedn line
     wlBaseDN = new Label(wFields, SWT.RIGHT);
@@ -925,10 +925,10 @@ public class LdapOutputDialog extends BaseTransformDialog implements ITransformD
     fdlReturn.top = new FormAttachment(wBaseDN, margin);
     wlReturn.setLayoutData(fdlReturn);
 
-    int UpInsCols = 3;
-    int UpInsRows = (input.getUpdateLookup() != null ? input.getUpdateLookup().length : 1);
+    int upInsCols = 3;
+    int upInsRows = (input.getUpdateLookup() != null ? input.getUpdateLookup().length : 1);
 
-    ciReturn = new ColumnInfo[UpInsCols];
+    ciReturn = new ColumnInfo[upInsCols];
     ciReturn[0] =
         new ColumnInfo(
             BaseMessages.getString(PKG, "LdapOutputUpdateDialog.ColumnInfo.TableField"),
@@ -954,7 +954,7 @@ public class LdapOutputDialog extends BaseTransformDialog implements ITransformD
             wFields,
             SWT.BORDER | SWT.FULL_SELECTION | SWT.MULTI | SWT.V_SCROLL | SWT.H_SCROLL,
             ciReturn,
-            UpInsRows,
+            upInsRows,
             lsMod,
             props);
 
diff --git a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapoutput/LdapOutputMeta.java b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapoutput/LdapOutputMeta.java
index f1868b2..ea3e83a 100644
--- a/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapoutput/LdapOutputMeta.java
+++ b/plugins/transforms/ldap/src/main/java/org/apache/hop/pipeline/transforms/ldapoutput/LdapOutputMeta.java
@@ -49,7 +49,7 @@ import java.util.List;
     documentationUrl = "/pipeline/transforms/ldapoutput.html")
 public class LdapOutputMeta extends BaseTransformMeta
     implements ILdapMeta, ITransformMeta<LdapOutput, LdapOutputData> {
-  private static Class<?> PKG = LdapOutputMeta.class; // For Translator
+  private static final Class<?> PKG = LdapOutputMeta.class; // For Translator
 
   /** Flag indicating that we use authentication for connection */
   private boolean useAuthentication;
diff --git a/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputData.java b/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputData.java
index 469f15d..54f8e12 100644
--- a/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputData.java
+++ b/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputData.java
@@ -28,7 +28,9 @@ import java.util.Date;
 public class LoadFileInputData extends BaseTransformData implements ITransformData {
   public IRowMeta outputRowMeta;
   public IRowMeta convertRowMeta;
-  public String thisline, nextline, lastline;
+  public String thisline;
+  public String nextline;
+  public String lastline;
   public Object[] previousRow;
   public int nr_repeats;
 
diff --git a/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputDialog.java b/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputDialog.java
index 9ed262e..d1bcb0d 100644
--- a/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputDialog.java
+++ b/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputDialog.java
@@ -87,7 +87,8 @@ public class LoadFileInputDialog extends BaseTransformDialog implements ITransfo
   private Button wFilenameInField;
 
   private Label wlInclFilename;
-  private Button wInclFilename, wAddResult;
+  private Button wInclFilename;
+  private Button wAddResult;
 
   private Label wlInclFilenameField;
   private TextVar wInclFilenameField;
@@ -494,10 +495,10 @@ public class LoadFileInputDialog extends BaseTransformDialog implements ITransfo
     props.setLook(wFileConf);
     wFileConf.setText(BaseMessages.getString(PKG, "LoadFileInputDialog.FileConf.Label"));
 
-    FormLayout XmlConfgroupLayout = new FormLayout();
-    XmlConfgroupLayout.marginWidth = 10;
-    XmlConfgroupLayout.marginHeight = 10;
-    wFileConf.setLayout(XmlConfgroupLayout);
+    FormLayout xmlConfgroupLayout = new FormLayout();
+    xmlConfgroupLayout.marginWidth = 10;
+    xmlConfgroupLayout.marginHeight = 10;
+    wFileConf.setLayout(xmlConfgroupLayout);
 
     wlEncoding = new Label(wFileConf, SWT.RIGHT);
     wlEncoding.setText(BaseMessages.getString(PKG, "LoadFileInputDialog.Encoding.Label"));
@@ -616,10 +617,10 @@ public class LoadFileInputDialog extends BaseTransformDialog implements ITransfo
     wAdditionalFields.setText(
         BaseMessages.getString(PKG, "LoadFileInputDialog.wAdditionalFields.Label"));
 
-    FormLayout AdditionalFieldsgroupLayout = new FormLayout();
-    AdditionalFieldsgroupLayout.marginWidth = 10;
-    AdditionalFieldsgroupLayout.marginHeight = 10;
-    wAdditionalFields.setLayout(AdditionalFieldsgroupLayout);
+    FormLayout additionalFieldsgroupLayout = new FormLayout();
+    additionalFieldsgroupLayout.marginWidth = 10;
+    additionalFieldsgroupLayout.marginHeight = 10;
+    wAdditionalFields.setLayout(additionalFieldsgroupLayout);
 
     wlInclFilename = new Label(wAdditionalFields, SWT.RIGHT);
     wlInclFilename.setText(BaseMessages.getString(PKG, "LoadFileInputDialog.InclFilename.Label"));
@@ -709,10 +710,10 @@ public class LoadFileInputDialog extends BaseTransformDialog implements ITransfo
     props.setLook(wAddFileResult);
     wAddFileResult.setText(BaseMessages.getString(PKG, "LoadFileInputDialog.wAddFileResult.Label"));
 
-    FormLayout AddFileResultgroupLayout = new FormLayout();
-    AddFileResultgroupLayout.marginWidth = 10;
-    AddFileResultgroupLayout.marginHeight = 10;
-    wAddFileResult.setLayout(AddFileResultgroupLayout);
+    FormLayout addFileResultgroupLayout = new FormLayout();
+    addFileResultgroupLayout.marginWidth = 10;
+    addFileResultgroupLayout.marginHeight = 10;
+    wAddFileResult.setLayout(addFileResultgroupLayout);
 
     wlAddResult = new Label(wAddFileResult, SWT.RIGHT);
     wlAddResult.setText(BaseMessages.getString(PKG, "LoadFileInputDialog.AddResult.Label"));
diff --git a/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputField.java b/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputField.java
index 9289a56..a5531ec 100644
--- a/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputField.java
+++ b/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputField.java
@@ -281,24 +281,24 @@ public class LoadFileInputField implements Cloneable {
     return groupSymbol;
   }
 
-  public void setGroupSymbol(String group_symbol) {
-    this.groupSymbol = group_symbol;
+  public void setGroupSymbol(String groupSymbol) {
+    this.groupSymbol = groupSymbol;
   }
 
   public String getDecimalSymbol() {
     return decimalSymbol;
   }
 
-  public void setDecimalSymbol(String decimal_symbol) {
-    this.decimalSymbol = decimal_symbol;
+  public void setDecimalSymbol(String decimalSymbol) {
+    this.decimalSymbol = decimalSymbol;
   }
 
   public String getCurrencySymbol() {
     return currencySymbol;
   }
 
-  public void setCurrencySymbol(String currency_symbol) {
-    this.currencySymbol = currency_symbol;
+  public void setCurrencySymbol(String currencySymbol) {
+    this.currencySymbol = currencySymbol;
   }
 
   public int getPrecision() {
@@ -327,5 +327,7 @@ public class LoadFileInputField implements Cloneable {
     return enc;
   }
 
-  public void guess() {}
+  public void guess() {
+    // Do nothing
+  }
 }
diff --git a/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputMeta.java b/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputMeta.java
index 66a6370..8381ece 100644
--- a/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputMeta.java
+++ b/plugins/transforms/loadfileinput/src/main/java/org/apache/hop/pipeline/transforms/loadfileinput/LoadFileInputMeta.java
@@ -126,7 +126,7 @@ public class LoadFileInputMeta extends BaseTransformMeta
   private String encoding;
 
   /** Dynamic FilenameField */
-  private String DynamicFilenameField;
+  private String dynamicFilenameField;
 
   /** Is In fields */
   private boolean fileinfield;
@@ -292,12 +292,12 @@ public class LoadFileInputMeta extends BaseTransformMeta
    *************************************/
   /** */
   public String getDynamicFilenameField() {
-    return DynamicFilenameField;
+    return dynamicFilenameField;
   }
 
   /** */
-  public void setDynamicFilenameField(String DynamicFilenameField) {
-    this.DynamicFilenameField = DynamicFilenameField;
+  public void setDynamicFilenameField(String dynamicFilenameField) {
+    this.dynamicFilenameField = dynamicFilenameField;
   }
 
   /************************************
@@ -308,8 +308,8 @@ public class LoadFileInputMeta extends BaseTransformMeta
     return fileinfield;
   }
 
-  public void setFileInFields(boolean IsInFields) {
-    this.fileinfield = IsInFields;
+  public void setFileInFields(boolean isInFields) {
+    this.fileinfield = isInFields;
   }
 
   /** @return Returns the fileMask. */
@@ -484,7 +484,7 @@ public class LoadFileInputMeta extends BaseTransformMeta
     retval.append("      </" + FIELDS + ">" + Const.CR);
     retval.append("    " + XmlHandler.addTagValue(LIMIT, rowLimit));
     retval.append("    " + XmlHandler.addTagValue(IS_IN_FIELDS, fileinfield));
-    retval.append("    " + XmlHandler.addTagValue(DYNAMIC_FILENAME_FIELD, DynamicFilenameField));
+    retval.append("    " + XmlHandler.addTagValue(DYNAMIC_FILENAME_FIELD, dynamicFilenameField));
     retval.append("    ").append(XmlHandler.addTagValue(SHORT_FILE_FIELD_NAME, shortFileFieldName));
     retval.append("    ").append(XmlHandler.addTagValue(PATH_FIELD_NAME, pathFieldName));
     retval.append("    ").append(XmlHandler.addTagValue(HIDDEN_FIELD_NAME, hiddenFieldName));
@@ -548,7 +548,7 @@ public class LoadFileInputMeta extends BaseTransformMeta
 
       fileinfield = "Y".equalsIgnoreCase(XmlHandler.getTagValue(transformNode, IS_IN_FIELDS));
 
-      DynamicFilenameField = XmlHandler.getTagValue(transformNode, DYNAMIC_FILENAME_FIELD);
+      dynamicFilenameField = XmlHandler.getTagValue(transformNode, DYNAMIC_FILENAME_FIELD);
       shortFileFieldName = XmlHandler.getTagValue(transformNode, SHORT_FILE_FIELD_NAME);
       pathFieldName = XmlHandler.getTagValue(transformNode, PATH_FIELD_NAME);
       hiddenFieldName = XmlHandler.getTagValue(transformNode, HIDDEN_FIELD_NAME);
@@ -612,7 +612,7 @@ public class LoadFileInputMeta extends BaseTransformMeta
     rowLimit = 0;
 
     fileinfield = false;
-    DynamicFilenameField = null;
+    dynamicFilenameField = null;
   }
 
   @Override
@@ -888,9 +888,9 @@ public class LoadFileInputMeta extends BaseTransformMeta
     if (rowLimit != that.rowLimit) {
       return false;
     }
-    if (DynamicFilenameField != null
-        ? !DynamicFilenameField.equals(that.DynamicFilenameField)
-        : that.DynamicFilenameField != null) {
+    if (dynamicFilenameField != null
+        ? !dynamicFilenameField.equals(that.dynamicFilenameField)
+        : that.dynamicFilenameField != null) {
       return false;
     }
     if (encoding != null ? !encoding.equals(that.encoding) : that.encoding != null) {
@@ -971,7 +971,7 @@ public class LoadFileInputMeta extends BaseTransformMeta
     result = 31 * result + (int) (rowLimit ^ (rowLimit >>> 32));
     result = 31 * result + (inputFields != null ? Arrays.hashCode(inputFields) : 0);
     result = 31 * result + (encoding != null ? encoding.hashCode() : 0);
-    result = 31 * result + (DynamicFilenameField != null ? DynamicFilenameField.hashCode() : 0);
+    result = 31 * result + (dynamicFilenameField != null ? dynamicFilenameField.hashCode() : 0);
     result = 31 * result + (fileinfield ? 1 : 0);
     result = 31 * result + (addresultfile ? 1 : 0);
     result = 31 * result + (fileRequired != null ? Arrays.hashCode(fileRequired) : 0);
diff --git a/plugins/transforms/mailinput/src/main/java/org/apache/hop/pipeline/transforms/mailinput/MailInputDialog.java b/plugins/transforms/mailinput/src/main/java/org/apache/hop/pipeline/transforms/mailinput/MailInputDialog.java
index 3a4fb1b..4cf7918 100644
--- a/plugins/transforms/mailinput/src/main/java/org/apache/hop/pipeline/transforms/mailinput/MailInputDialog.java
+++ b/plugins/transforms/mailinput/src/main/java/org/apache/hop/pipeline/transforms/mailinput/MailInputDialog.java
@@ -133,7 +133,8 @@ public class MailInputDialog extends BaseTransformDialog implements ITransformDi
 
   private Button wSelectFolder;
 
-  private Label wlFolderField, wlDynamicFolder;
+  private Label wlFolderField;
+  private Label wlDynamicFolder;
   private CCombo wFolderField;
   private Button wDynamicFolder;
 
diff --git a/plugins/transforms/mapping/src/main/java/org/apache/hop/pipeline/transforms/mapping/SimpleMappingDialog.java b/plugins/transforms/mapping/src/main/java/org/apache/hop/pipeline/transforms/mapping/SimpleMappingDialog.java
index f4f5b8f..d6167f7 100644
--- a/plugins/transforms/mapping/src/main/java/org/apache/hop/pipeline/transforms/mapping/SimpleMappingDialog.java
+++ b/plugins/transforms/mapping/src/main/java/org/apache/hop/pipeline/transforms/mapping/SimpleMappingDialog.java
@@ -60,11 +60,8 @@ public class SimpleMappingDialog extends BaseTransformDialog implements ITransfo
 
   private SimpleMappingMeta mappingMeta;
 
-  private Label wlPath;
   private TextVar wPath;
 
-  private Button wbBrowse;
-
   private CTabFolder wTabFolder;
 
   private PipelineMeta mappingPipelineMeta = null;
@@ -73,10 +70,6 @@ public class SimpleMappingDialog extends BaseTransformDialog implements ITransfo
 
   private ModifyListener lsMod;
 
-  private int middle;
-
-  private int margin;
-
   private MappingParameters mappingParameters;
 
   private MappingIODefinition inputMapping;
@@ -178,8 +171,7 @@ public class SimpleMappingDialog extends BaseTransformDialog implements ITransfo
     formLayout.marginWidth = 15;
     formLayout.marginHeight = 15;
 
-    margin = props.getMargin();
-    middle = props.getMiddlePct();
+    int margin = props.getMargin();
 
     shell.setLayout(formLayout);
     shell.setText(BaseMessages.getString(PKG, "SimpleMappingDialog.Shell.Title"));
@@ -227,7 +219,7 @@ public class SimpleMappingDialog extends BaseTransformDialog implements ITransfo
     fdSpacer.right = new FormAttachment(100, 0);
     spacer.setLayoutData(fdSpacer);
 
-    wlPath = new Label(shell, SWT.LEFT);
+    Label wlPath = new Label(shell, SWT.LEFT);
     props.setLook(wlPath);
     wlPath.setText(BaseMessages.getString(PKG, "SimpleMappingDialog.Pipeline.Label"));
     FormData fdlTransformation = new FormData();
@@ -236,7 +228,7 @@ public class SimpleMappingDialog extends BaseTransformDialog implements ITransfo
     fdlTransformation.right = new FormAttachment(50, 0);
     wlPath.setLayoutData(fdlTransformation);
 
-    wbBrowse = new Button(shell, SWT.PUSH);
+    Button wbBrowse = new Button(shell, SWT.PUSH);
     props.setLook(wbBrowse);
     wbBrowse.setText(BaseMessages.getString(PKG, "SimpleMappingDialog.Browse.Label"));
     FormData fdBrowse = new FormData();
diff --git a/plugins/transforms/memgroupby/src/main/java/org/apache/hop/pipeline/transforms/memgroupby/MemoryGroupByDialog.java b/plugins/transforms/memgroupby/src/main/java/org/apache/hop/pipeline/transforms/memgroupby/MemoryGroupByDialog.java
index fabc51e..24fe832 100644
--- a/plugins/transforms/memgroupby/src/main/java/org/apache/hop/pipeline/transforms/memgroupby/MemoryGroupByDialog.java
+++ b/plugins/transforms/memgroupby/src/main/java/org/apache/hop/pipeline/transforms/memgroupby/MemoryGroupByDialog.java
@@ -191,10 +191,10 @@ public class MemoryGroupByDialog extends BaseTransformDialog implements ITransfo
     fdlAgg.top = new FormAttachment(wGroup, margin);
     wlAgg.setLayoutData(fdlAgg);
 
-    int UpInsCols = 4;
-    int UpInsRows = (input.getAggregateField() != null ? input.getAggregateField().length : 1);
+    int upInsCols = 4;
+    int upInsRows = (input.getAggregateField() != null ? input.getAggregateField().length : 1);
 
-    ciReturn = new ColumnInfo[UpInsCols];
+    ciReturn = new ColumnInfo[upInsCols];
     ciReturn[0] =
         new ColumnInfo(
             BaseMessages.getString(PKG, "MemoryGroupByDialog.ColumnInfo.Name"),
@@ -226,7 +226,7 @@ public class MemoryGroupByDialog extends BaseTransformDialog implements ITransfo
             shell,
             SWT.BORDER | SWT.FULL_SELECTION | SWT.MULTI | SWT.V_SCROLL | SWT.H_SCROLL,
             ciReturn,
-            UpInsRows,
+            upInsRows,
             lsMod,
             props);
 
diff --git a/plugins/transforms/mergejoin/src/main/java/org/apache/hop/pipeline/transforms/mergejoin/MergeJoinData.java b/plugins/transforms/mergejoin/src/main/java/org/apache/hop/pipeline/transforms/mergejoin/MergeJoinData.java
index 224aaba..78955d4 100644
--- a/plugins/transforms/mergejoin/src/main/java/org/apache/hop/pipeline/transforms/mergejoin/MergeJoinData.java
+++ b/plugins/transforms/mergejoin/src/main/java/org/apache/hop/pipeline/transforms/mergejoin/MergeJoinData.java
@@ -25,13 +25,19 @@ import org.apache.hop.pipeline.transform.ITransformData;
 import java.util.List;
 
 public class MergeJoinData extends BaseTransformData implements ITransformData {
-  public Object[] one, two;
-  public IRowMeta oneMeta, twoMeta;
+  public Object[] one;
+  public Object[] two;
+  public IRowMeta oneMeta;
+  public IRowMeta twoMeta;
   public IRowMeta outputRowMeta; // just for speed: oneMeta+twoMeta
-  public Object[] one_dummy, two_dummy;
-  public List<Object[]> ones, twos;
-  public Object[] one_next, two_next;
-  public boolean one_optional, two_optional;
+  public Object[] one_dummy;
+  public Object[] two_dummy;
+  public List<Object[]> ones;
+  public List<Object[]> twos;
+  public Object[] one_next;
+  public Object[] two_next;
+  public boolean one_optional;
+  public boolean two_optional;
   public int[] keyNrs1;
   public int[] keyNrs2;
 
diff --git a/plugins/transforms/mergerows/src/main/java/org/apache/hop/pipeline/transforms/mergerows/MergeRowsData.java b/plugins/transforms/mergerows/src/main/java/org/apache/hop/pipeline/transforms/mergerows/MergeRowsData.java
index b949e51..1e6324d 100644
--- a/plugins/transforms/mergerows/src/main/java/org/apache/hop/pipeline/transforms/mergerows/MergeRowsData.java
+++ b/plugins/transforms/mergerows/src/main/java/org/apache/hop/pipeline/transforms/mergerows/MergeRowsData.java
@@ -25,7 +25,8 @@ import org.apache.hop.pipeline.transform.ITransformData;
 public class MergeRowsData extends BaseTransformData implements ITransformData {
   public IRowMeta outputRowMeta;
 
-  public Object[] one, two;
+  public Object[] one;
+  public Object[] two;
   public int[] keyNrs;
   public int[] valueNrs;
 
diff --git a/plugins/transforms/metainject/src/main/java/org/apache/hop/pipeline/transforms/metainject/MetaInjectDialog.java b/plugins/transforms/metainject/src/main/java/org/apache/hop/pipeline/transforms/metainject/MetaInjectDialog.java
index 872bc75..779cf66 100644
--- a/plugins/transforms/metainject/src/main/java/org/apache/hop/pipeline/transforms/metainject/MetaInjectDialog.java
+++ b/plugins/transforms/metainject/src/main/java/org/apache/hop/pipeline/transforms/metainject/MetaInjectDialog.java
@@ -102,7 +102,6 @@ public class MetaInjectDialog extends BaseTransformDialog implements ITransformD
   // the target file
   //
   private TextVar wTargetFile;
-  private Button wbFilename; // Browse for optional target file
 
   // don't execute the transformation
   //
@@ -452,7 +451,8 @@ public class MetaInjectDialog extends BaseTransformDialog implements ITransformD
     fdlTargetFile.top = new FormAttachment(wSourceFields, 10);
     wlTargetFile.setLayoutData(fdlTargetFile);
 
-    wbFilename = new Button(wOptionsComp, SWT.PUSH | SWT.CENTER);
+    // Browse for optional target file
+    Button wbFilename = new Button(wOptionsComp, SWT.PUSH | SWT.CENTER);
     props.setLook(wbFilename);
     wbFilename.setText(BaseMessages.getString(PKG, "System.Button.Browse"));
     wbFilename.setToolTipText(
@@ -485,21 +485,21 @@ public class MetaInjectDialog extends BaseTransformDialog implements ITransformD
 
     wCreateParentFolder = new Button(wOptionsComp, SWT.CHECK);
     wCreateParentFolder.setText(
-            BaseMessages.getString(PKG, "MetaInjectDialog.CreateParentFolder.Label"));
+        BaseMessages.getString(PKG, "MetaInjectDialog.CreateParentFolder.Label"));
     wCreateParentFolder.setToolTipText(
-            BaseMessages.getString(PKG, "MetaInjectDialog.CreateParentFolder.Tooltip"));
+        BaseMessages.getString(PKG, "MetaInjectDialog.CreateParentFolder.Tooltip"));
     props.setLook(wCreateParentFolder);
     FormData fdCreateParentFolder = new FormData();
     fdCreateParentFolder.left = new FormAttachment(0, 0);
     fdCreateParentFolder.top = new FormAttachment(wTargetFile, margin);
     wCreateParentFolder.setLayoutData(fdCreateParentFolder);
     wCreateParentFolder.addSelectionListener(
-            new SelectionAdapter() {
-              @Override
-              public void widgetSelected(SelectionEvent e) {
-                metaInjectMeta.setChanged();
-              }
-            });
+        new SelectionAdapter() {
+          @Override
+          public void widgetSelected(SelectionEvent e) {
+            metaInjectMeta.setChanged();
+          }
+        });
 
     // the streaming source transform
     //
diff --git a/plugins/transforms/metastructure/src/main/java/org/apache/hop/pipeline/transforms/metastructure/TransformMetaStructureDialog.java b/plugins/transforms/metastructure/src/main/java/org/apache/hop/pipeline/transforms/metastructure/TransformMetaStructureDialog.java
index 37dd705..b3b49c9 100644
--- a/plugins/transforms/metastructure/src/main/java/org/apache/hop/pipeline/transforms/metastructure/TransformMetaStructureDialog.java
+++ b/plugins/transforms/metastructure/src/main/java/org/apache/hop/pipeline/transforms/metastructure/TransformMetaStructureDialog.java
@@ -40,7 +40,7 @@ import org.eclipse.swt.widgets.Shell;
 import org.eclipse.swt.widgets.Text;
 
 public class TransformMetaStructureDialog extends BaseTransformDialog implements ITransformDialog {
-  private static Class<?> PKG =
+  private static final Class<?> PKG =
       TransformMetaStructureMeta.class; // for i18n purposes, needed by Translator2!!
 
   private final TransformMetaStructureMeta input;
diff --git a/plugins/transforms/metastructure/src/main/java/org/apache/hop/pipeline/transforms/metastructure/TransformMetaStructureMeta.java b/plugins/transforms/metastructure/src/main/java/org/apache/hop/pipeline/transforms/metastructure/TransformMetaStructureMeta.java
index 0a20732..79fc1c3 100644
--- a/plugins/transforms/metastructure/src/main/java/org/apache/hop/pipeline/transforms/metastructure/TransformMetaStructureMeta.java
+++ b/plugins/transforms/metastructure/src/main/java/org/apache/hop/pipeline/transforms/metastructure/TransformMetaStructureMeta.java
@@ -48,7 +48,7 @@ import java.util.List;
 public class TransformMetaStructureMeta extends BaseTransformMeta
     implements ITransformMeta<TransformMetaStructure, TransformMetaStructureData> {
 
-  private static Class<?> PKG = TransformMetaStructureMeta.class; // needed by Translator
+  private static final Class<?> PKG = TransformMetaStructureMeta.class; // needed by Translator
 
   @HopMetadataProperty(defaultBoolean = true)
   private boolean includePositionField;
diff --git a/plugins/transforms/mongodb/src/main/java/org/apache/hop/mongo/MongoPropToOption.java b/plugins/transforms/mongodb/src/main/java/org/apache/hop/mongo/MongoPropToOption.java
index 75901ce..6fc74ba 100644
--- a/plugins/transforms/mongodb/src/main/java/org/apache/hop/mongo/MongoPropToOption.java
+++ b/plugins/transforms/mongodb/src/main/java/org/apache/hop/mongo/MongoPropToOption.java
@@ -28,7 +28,7 @@ import java.util.ArrayList;
 import java.util.Arrays;
 
 class MongoPropToOption {
-  private static Class<?> PKG = MongoPropToOption.class; // For Translator
+  private static final Class<?> PKG = MongoPropToOption.class; // For Translator
 
   private MongoUtilLogger log;
 
diff --git a/plugins/transforms/mongodb/src/main/java/org/apache/hop/mongo/wrapper/NoAuthMongoClientWrapper.java b/plugins/transforms/mongodb/src/main/java/org/apache/hop/mongo/wrapper/NoAuthMongoClientWrapper.java
index 4bd73cc..ae843f8 100644
--- a/plugins/transforms/mongodb/src/main/java/org/apache/hop/mongo/wrapper/NoAuthMongoClientWrapper.java
+++ b/plugins/transforms/mongodb/src/main/java/org/apache/hop/mongo/wrapper/NoAuthMongoClientWrapper.java
@@ -34,7 +34,7 @@ import java.util.Set;
  * instantiated by MongoClientWrapperFactory.
  */
 class NoAuthMongoClientWrapper implements MongoClientWrapper {
-  private static Class<?> PKG = NoAuthMongoClientWrapper.class; // For Translator
+  private static final Class<?> PKG = NoAuthMongoClientWrapper.class; // For Translator
   public static final int MONGO_DEFAULT_PORT = 27017;
 
   public static final String LOCAL_DB = "local";
diff --git a/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInput.java b/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInput.java
index 1dc832b..beef949 100644
--- a/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInput.java
+++ b/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInput.java
@@ -39,7 +39,7 @@ import java.util.List;
 
 public class MongoDbInput extends BaseTransform<MongoDbInputMeta, MongoDbInputData>
     implements ITransform<MongoDbInputMeta, MongoDbInputData> {
-  private static Class<?> PKG = MongoDbInputMeta.class; // For i18n - Translator
+  private static final Class<?> PKG = MongoDbInputMeta.class; // For i18n - Translator
 
   private boolean serverDetermined;
   private Object[] currentInputRowDrivingQuery = null;
diff --git a/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInputDialog.java b/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInputDialog.java
index 8b6670f..9693943 100644
--- a/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInputDialog.java
+++ b/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInputDialog.java
@@ -53,7 +53,7 @@ import java.util.List;
 import java.util.*;
 
 public class MongoDbInputDialog extends BaseTransformDialog implements ITransformDialog {
-  private static Class<?> PKG = MongoDbInputMeta.class; // For i18n - Translator
+  private static final Class<?> PKG = MongoDbInputMeta.class; // For i18n - Translator
 
   private MetaSelectionLine<MongoDbConnection> wConnection;
 
diff --git a/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInputMeta.java b/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInputMeta.java
index a1940dd..1c685c8 100644
--- a/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInputMeta.java
+++ b/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodbinput/MongoDbInputMeta.java
@@ -55,7 +55,7 @@ import java.util.List;
 @InjectionSupported(localizationPrefix = "MongoDbInput.Injection.", groups = ("FIELDS"))
 public class MongoDbInputMeta extends MongoDbMeta<MongoDbInput, MongoDbInputData>
     implements ITransformMeta<MongoDbInput, MongoDbInputData> {
-  protected static Class<?> PKG = MongoDbInputMeta.class; // For Translator
+  protected static final Class<?> PKG = MongoDbInputMeta.class; // For Translator
 
   @Injection(name = "JSON_OUTPUT_FIELD")
   private String jsonFieldName;
@@ -118,13 +118,13 @@ public class MongoDbInputMeta extends MongoDbMeta<MongoDbInput, MongoDbInputData
         executeForEachIncomingRow = executeForEachR.equalsIgnoreCase("Y");
       }
 
-      Node mongo_fields = XmlHandler.getSubNode(node, "mongo_fields");
-      if (mongo_fields != null && XmlHandler.countNodes(mongo_fields, "mongo_field") > 0) {
-        int nrFields = XmlHandler.countNodes(mongo_fields, "mongo_field");
+      Node mongoFields = XmlHandler.getSubNode(node, "mongo_fields");
+      if (mongoFields != null && XmlHandler.countNodes(mongoFields, "mongo_field") > 0) {
+        int nrFields = XmlHandler.countNodes(mongoFields, "mongo_field");
 
         fields = new ArrayList<>();
         for (int i = 0; i < nrFields; i++) {
-          Node fieldNode = XmlHandler.getSubNodeByNr(mongo_fields, "mongo_field", i);
+          Node fieldNode = XmlHandler.getSubNodeByNr(mongoFields, "mongo_field", i);
 
           MongoField newField = new MongoField();
           newField.fieldName = XmlHandler.getTagValue(fieldNode, "field_name");
diff --git a/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodboutput/MongoDbOutput.java b/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodboutput/MongoDbOutput.java
index fbf9bc9..31277d3 100644
--- a/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodboutput/MongoDbOutput.java
+++ b/plugins/transforms/mongodb/src/main/java/org/apache/hop/pipeline/transforms/mongodboutput/MongoDbOutput.java
@@ -47,7 +47,7 @@ import java.util.Set;
  */
 public class MongoDbOutput extends BaseTransform<MongoDbOutputMeta, MongoDbOutputData>
     implements ITransform<MongoDbOutputMeta, MongoDbOutputData> {
-  private static Class<?> PKG = MongoDbOutputMeta.class; // For Translator
+  private static final Class<?> PKG = MongoDbOutputMeta.class; // For Translator
 
   protected MongoDbOutputData.MongoTopLevel mongoTopLevelStructure =
       MongoDbOutputData.MongoTopLevel.INCONSISTENT;
diff --git a/plugins/transforms/mongodb/src/test/java/org/apache/hop/mongo/wrapper/NoAuthMongoClientWrapperTest.java b/plugins/transforms/mongodb/src/test/java/org/apache/hop/mongo/wrapper/NoAuthMongoClientWrapperTest.java
index e4ff6f2..0c3655f 100644
--- a/plugins/transforms/mongodb/src/test/java/org/apache/hop/mongo/wrapper/NoAuthMongoClientWrapperTest.java
+++ b/plugins/transforms/mongodb/src/test/java/org/apache/hop/mongo/wrapper/NoAuthMongoClientWrapperTest.java
@@ -98,7 +98,7 @@ public class NoAuthMongoClientWrapperTest {
 
   private NoAuthMongoClientWrapper noAuthMongoClientWrapper;
 
-  private static Class<?> PKG = NoAuthMongoClientWrapper.class; // For Translator
+  private static final Class<?> PKG = NoAuthMongoClientWrapper.class; // For Translator
 
   @Before
   public void setUp() throws Exception {
diff --git a/plugins/transforms/multimerge/src/main/java/org/apache/hop/pipeline/transforms/multimerge/MultiMergeJoinDialog.java b/plugins/transforms/multimerge/src/main/java/org/apache/hop/pipeline/transforms/multimerge/MultiMergeJoinDialog.java
index e4a684a..d5e8674 100644
--- a/plugins/transforms/multimerge/src/main/java/org/apache/hop/pipeline/transforms/multimerge/MultiMergeJoinDialog.java
+++ b/plugins/transforms/multimerge/src/main/java/org/apache/hop/pipeline/transforms/multimerge/MultiMergeJoinDialog.java
@@ -216,7 +216,8 @@ public class MultiMergeJoinDialog extends BaseTransformDialog implements ITransf
     String[] inputTransforms = getInputTransformNames();
     for (int index = 0; index < inputTransforms.length; index++) {
       Label wlTransform;
-      FormData fdlTransform, fdTransform1;
+      FormData fdlTransform;
+      FormData fdTransform1;
 
       wlTransform = new Label(shell, SWT.LEFT);
       wlTransform.setText(
diff --git a/plugins/transforms/normaliser/src/main/java/org/apache/hop/pipeline/transforms/normaliser/Normaliser.java b/plugins/transforms/normaliser/src/main/java/org/apache/hop/pipeline/transforms/normaliser/Normaliser.java
index ff85725..4682a0e 100644
--- a/plugins/transforms/normaliser/src/main/java/org/apache/hop/pipeline/transforms/normaliser/Normaliser.java
+++ b/plugins/transforms/normaliser/src/main/java/org/apache/hop/pipeline/transforms/normaliser/Normaliser.java
@@ -57,7 +57,8 @@ public class Normaliser extends BaseTransform<NormaliserMeta, NormaliserData>
     }
 
     List<Integer> normFieldList;
-    int i, e;
+    int i;
+    int e;
 
     if (first) { // INITIALISE
 
@@ -139,7 +140,7 @@ public class Normaliser extends BaseTransform<NormaliserMeta, NormaliserData>
     // of re-creating them - better for GC over time
     String typeValue;
     Object[] outputRowData;
-    int outputIndex, nr, normFieldListSz;
+    int outputIndex, nr;
     Object value;
 
     // Now do the normalization
@@ -167,7 +168,7 @@ public class Normaliser extends BaseTransform<NormaliserMeta, NormaliserData>
       // Then add the normalized fields...
       //
       normFieldList = data.typeToFieldIndex.get(typeValue);
-      normFieldListSz = normFieldList.size();
+      int normFieldListSz = normFieldList.size();
       for (i = 0; i < normFieldListSz; i++) {
         value = r[normFieldList.get(i)];
         outputRowData[outputIndex++] = value;
diff --git a/plugins/transforms/normaliser/src/main/java/org/apache/hop/pipeline/transforms/normaliser/NormaliserMeta.java b/plugins/transforms/normaliser/src/main/java/org/apache/hop/pipeline/transforms/normaliser/NormaliserMeta.java
index 9cdf16c..4f66846 100644
--- a/plugins/transforms/normaliser/src/main/java/org/apache/hop/pipeline/transforms/normaliser/NormaliserMeta.java
+++ b/plugins/transforms/normaliser/src/main/java/org/apache/hop/pipeline/transforms/normaliser/NormaliserMeta.java
@@ -200,13 +200,13 @@ public class NormaliserMeta extends BaseTransformMeta
 
     // Get a unique list of the occurrences of the type
     //
-    List<String> norm_occ = new ArrayList<>();
-    List<String> field_occ = new ArrayList<>();
+    List<String> normOcc = new ArrayList<>();
+    List<String> fieldOcc = new ArrayList<>();
     int maxlen = 0;
     for (int i = 0; i < normaliserFields.length; i++) {
-      if (!norm_occ.contains(normaliserFields[i].getNorm())) {
-        norm_occ.add(normaliserFields[i].getNorm());
-        field_occ.add(normaliserFields[i].getName());
+      if (!normOcc.contains(normaliserFields[i].getNorm())) {
+        normOcc.add(normaliserFields[i].getNorm());
+        fieldOcc.add(normaliserFields[i].getName());
       }
 
       if (normaliserFields[i].getValue().length() > maxlen) {
@@ -225,9 +225,9 @@ public class NormaliserMeta extends BaseTransformMeta
     // Add the new fields that need to be created.
     // Use the same data type as the original fieldname...
     //
-    for (int i = 0; i < norm_occ.size(); i++) {
-      String normname = norm_occ.get(i);
-      String fieldname = field_occ.get(i);
+    for (int i = 0; i < normOcc.size(); i++) {
+      String normname = normOcc.get(i);
+      String fieldname = fieldOcc.get(i);
       IValueMeta v = row.searchValueMeta(fieldname);
       if (v != null) {
         v = v.clone();
@@ -375,7 +375,9 @@ public class NormaliserMeta extends BaseTransformMeta
     @Injection(name = "NORMALISED", group = "FIELDS")
     private String norm;
 
-    public NormaliserField() {}
+    public NormaliserField() {
+      // Do nothing
+    }
 
     /** @return the name */
     public String getName() {
diff --git a/plugins/transforms/pgp/src/main/java/org/apache/hop/pipeline/transforms/pgpdecryptstream/PGPDecryptStreamDialog.java b/plugins/transforms/pgp/src/main/java/org/apache/hop/pipeline/transforms/pgpdecryptstream/PGPDecryptStreamDialog.java
index fe37f13..8cdb85c 100644
--- a/plugins/transforms/pgp/src/main/java/org/apache/hop/pipeline/transforms/pgpdecryptstream/PGPDecryptStreamDialog.java
+++ b/plugins/transforms/pgp/src/main/java/org/apache/hop/pipeline/transforms/pgpdecryptstream/PGPDecryptStreamDialog.java
@@ -119,10 +119,10 @@ public class PGPDecryptStreamDialog extends BaseTransformDialog implements ITran
     props.setLook(wGPGGroup);
     wGPGGroup.setText(BaseMessages.getString(PKG, "PGPDecryptStreamDialog.GPGGroup.Label"));
 
-    FormLayout GPGGroupgroupLayout = new FormLayout();
-    GPGGroupgroupLayout.marginWidth = 10;
-    GPGGroupgroupLayout.marginHeight = 10;
-    wGPGGroup.setLayout(GPGGroupgroupLayout);
+    FormLayout gpggroupgrouplayout = new FormLayout();
+    gpggroupgrouplayout.marginWidth = 10;
+    gpggroupgrouplayout.marginHeight = 10;
+    wGPGGroup.setLayout(gpggroupgrouplayout);
 
     // GPGLocation fieldname ...
     Label wlGPGLocation = new Label(wGPGGroup, SWT.RIGHT);
diff --git a/plugins/transforms/pgp/src/main/java/org/apache/hop/pipeline/transforms/pgpencryptstream/PGPEncryptStreamDialog.java b/plugins/transforms/pgp/src/main/java/org/apache/hop/pipeline/transforms/pgpencryptstream/PGPEncryptStreamDialog.java
index d5a5e69..0ce82a9 100644
--- a/plugins/transforms/pgp/src/main/java/org/apache/hop/pipeline/transforms/pgpencryptstream/PGPEncryptStreamDialog.java
+++ b/plugins/transforms/pgp/src/main/java/org/apache/hop/pipeline/transforms/pgpencryptstream/PGPEncryptStreamDialog.java
@@ -114,10 +114,10 @@ public class PGPEncryptStreamDialog extends BaseTransformDialog implements ITran
     props.setLook(wGPGGroup);
     wGPGGroup.setText(BaseMessages.getString(PKG, "PGPEncryptStreamDialog.GPGGroup.Label"));
 
-    FormLayout GPGGroupgroupLayout = new FormLayout();
-    GPGGroupgroupLayout.marginWidth = 10;
-    GPGGroupgroupLayout.marginHeight = 10;
-    wGPGGroup.setLayout(GPGGroupgroupLayout);
+    FormLayout gpggroupgrouplayout = new FormLayout();
+    gpggroupgrouplayout.marginWidth = 10;
+    gpggroupgrouplayout.marginHeight = 10;
+    wGPGGroup.setLayout(gpggroupgrouplayout);
 
     // GPGLocation fieldname ...
     Label wlGPGLocation = new Label(wGPGGroup, SWT.RIGHT);
@@ -386,7 +386,7 @@ public class PGPEncryptStreamDialog extends BaseTransformDialog implements ITran
       try {
         String fieldvalue = wStreamFieldName.getText();
         wStreamFieldName.removeAll();
-        String Keyfieldvalue = wKeyNameFieldName.getText();
+        String keyNameFieldNameText = wKeyNameFieldName.getText();
         wKeyNameFieldName.removeAll();
         IRowMeta r = pipelineMeta.getPrevTransformFields(variables, transformName);
         if (r != null) {
@@ -396,8 +396,8 @@ public class PGPEncryptStreamDialog extends BaseTransformDialog implements ITran
         if (fieldvalue != null) {
           wStreamFieldName.setText(fieldvalue);
         }
-        if (Keyfieldvalue != null) {
-          wKeyNameFieldName.setText(Keyfieldvalue);
+        if (keyNameFieldNameText != null) {
+          wKeyNameFieldName.setText(keyNameFieldNameText);
         }
         gotPreviousFields = true;
       } catch (HopException ke) {
diff --git a/plugins/transforms/pipelineexecutor/src/main/java/org/apache/hop/pipeline/transforms/pipelineexecutor/PipelineExecutorDialog.java b/plugins/transforms/pipelineexecutor/src/main/java/org/apache/hop/pipeline/transforms/pipelineexecutor/PipelineExecutorDialog.java
index 6faca4c..f52bc65 100644
--- a/plugins/transforms/pipelineexecutor/src/main/java/org/apache/hop/pipeline/transforms/pipelineexecutor/PipelineExecutorDialog.java
+++ b/plugins/transforms/pipelineexecutor/src/main/java/org/apache/hop/pipeline/transforms/pipelineexecutor/PipelineExecutorDialog.java
@@ -66,8 +66,8 @@ import java.util.List;
 public class PipelineExecutorDialog extends BaseTransformDialog implements ITransformDialog {
   private static final Class<?> PKG = PipelineExecutorDialog.class; // For Translator
 
-  private static int FIELD_DESCRIPTION = 1;
-  private static int FIELD_NAME = 2;
+  private static final int FIELD_DESCRIPTION = 1;
+  private static final int FIELD_NAME = 2;
 
   private PipelineExecutorMeta pipelineExecutorMeta;
 
@@ -77,8 +77,6 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
   protected Label wlRunConfiguration;
   protected ComboVar wRunConfiguration;
 
-  private Button wbBrowse;
-
   private Button wbPipelineNameInField;
 
   private Label wlPipelineNameField;
@@ -101,7 +99,6 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
   private Label wlGroupTime;
   private TextVar wGroupTime;
 
-  private Label wlExecutionResultTarget;
   private CCombo wExecutionResultTarget;
   private TableItem tiExecutionTimeField;
   private TableItem tiExecutionResultField;
@@ -122,25 +119,14 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
 
   private ColumnInfo[] parameterColumns;
 
-  private Label wlResultFilesTarget;
-
   private CCombo wResultFilesTarget;
 
-  private Label wlResultFileNameField;
-
   private TextVar wResultFileNameField;
 
-  private Label wlResultRowsTarget;
-
   private CCombo wOutputRowsSource;
 
-  private Label wlOutputFields;
-
   private TableView wOutputFields;
 
-  private Button wGetParameters;
-  private Button wMapParameters;
-
   private boolean gotPreviousFields = false;
 
   public PipelineExecutorDialog(
@@ -169,7 +155,6 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
 
     ModifyListener lsMod = e -> pipelineExecutorMeta.setChanged();
 
-    int middle = props.getMiddlePct();
     int margin = props.getMargin();
 
     Label wicon = new Label(shell, SWT.RIGHT);
@@ -224,7 +209,7 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
     fdlTransformation.right = new FormAttachment(50, 0);
     wlPath.setLayoutData(fdlTransformation);
 
-    wbBrowse = new Button(shell, SWT.PUSH);
+    Button wbBrowse = new Button(shell, SWT.PUSH);
     props.setLook(wbBrowse);
     wbBrowse.setText(BaseMessages.getString(PKG, "PipelineExecutorDialog.Browse.Label"));
     FormData fdBrowse = new FormData();
@@ -244,9 +229,9 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
     wbPipelineNameInField = new Button(shell, SWT.CHECK);
     props.setLook(wbPipelineNameInField);
     wbPipelineNameInField.setText(
-            BaseMessages.getString(PKG, "PipelineExecutorDialog.PipelineNameInField.Label"));
+        BaseMessages.getString(PKG, "PipelineExecutorDialog.PipelineNameInField.Label"));
     FormData fdPipelineNameInField = new FormData();
-    fdPipelineNameInField.left = new FormAttachment(0,0);
+    fdPipelineNameInField.left = new FormAttachment(0, 0);
     fdPipelineNameInField.top = new FormAttachment(wPath, margin);
     wbPipelineNameInField.setLayoutData(fdPipelineNameInField);
     wbPipelineNameInField.addSelectionListener(
@@ -300,7 +285,8 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
     props.setLook(wlRunConfiguration);
     FormData fdlRunConfiguration = new FormData();
     fdlRunConfiguration.left = new FormAttachment(0, 0);
-    fdlRunConfiguration.top = new FormAttachment(wPipelineNameField, PropsUi.getInstance().getMargin());
+    fdlRunConfiguration.top =
+        new FormAttachment(wPipelineNameField, PropsUi.getInstance().getMargin());
     fdlRunConfiguration.right = new FormAttachment(50, 0);
     wlRunConfiguration.setLayoutData(fdlRunConfiguration);
 
@@ -365,10 +351,10 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
         }
       } catch (HopException ke) {
         new ErrorDialog(
-                shell,
-                BaseMessages.getString(PKG, "TextFileOutputDialog.FailedToGetFields.DialogTitle"),
-                BaseMessages.getString(PKG, "TextFileOutputDialog.FailedToGetFields.DialogMessage"),
-                ke);
+            shell,
+            BaseMessages.getString(PKG, "TextFileOutputDialog.FailedToGetFields.DialogTitle"),
+            BaseMessages.getString(PKG, "TextFileOutputDialog.FailedToGetFields.DialogMessage"),
+            ke);
       }
       gotPreviousFields = true;
     }
@@ -600,7 +586,7 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
 
     // Add a button: get parameters
     //
-    wGetParameters = new Button(wParametersComposite, SWT.PUSH);
+    Button wGetParameters = new Button(wParametersComposite, SWT.PUSH);
     wGetParameters.setText(
         BaseMessages.getString(PKG, "PipelineExecutorDialog.Parameters.GetParameters"));
     props.setLook(wGetParameters);
@@ -613,7 +599,7 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
 
     // Add a button: get parameters
     //
-    wMapParameters = new Button(wParametersComposite, SWT.PUSH);
+    Button wMapParameters = new Button(wParametersComposite, SWT.PUSH);
     wMapParameters.setText(
         BaseMessages.getString(PKG, "PipelineExecutorDialog.Parameters.MapParameters"));
     props.setLook(wMapParameters);
@@ -805,7 +791,8 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
     wlGroupSize = new Label(wInputComposite, SWT.RIGHT);
     props.setLook(wlGroupSize);
     wlGroupSize.setText(BaseMessages.getString(PKG, "PipelineExecutorDialog.GroupSize.Label"));
-    wlGroupSize.setToolTipText(BaseMessages.getString(PKG, "PipelineExecutorDialog.GroupSize.Tooltip"));
+    wlGroupSize.setToolTipText(
+        BaseMessages.getString(PKG, "PipelineExecutorDialog.GroupSize.Tooltip"));
     FormData fdlGroupSize = new FormData();
     fdlGroupSize.top = new FormAttachment(0, 0);
     fdlGroupSize.left = new FormAttachment(0, 0);
@@ -882,7 +869,7 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
     tabLayout.marginHeight = 15;
     wInputComposite.setLayout(tabLayout);
 
-    wlExecutionResultTarget = new Label(wInputComposite, SWT.RIGHT);
+    Label wlExecutionResultTarget = new Label(wInputComposite, SWT.RIGHT);
     props.setLook(wlExecutionResultTarget);
     wlExecutionResultTarget.setText(
         BaseMessages.getString(PKG, "PipelineExecutorDialog.ExecutionResultTarget.Label"));
@@ -1028,7 +1015,7 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
     tabLayout.marginHeight = 15;
     wInputComposite.setLayout(tabLayout);
 
-    wlResultFilesTarget = new Label(wInputComposite, SWT.RIGHT);
+    Label wlResultFilesTarget = new Label(wInputComposite, SWT.RIGHT);
     props.setLook(wlResultFilesTarget);
     wlResultFilesTarget.setText(
         BaseMessages.getString(PKG, "PipelineExecutorDialog.ResultFilesTarget.Label"));
@@ -1047,7 +1034,7 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
 
     // ResultFileNameField
     //
-    wlResultFileNameField = new Label(wInputComposite, SWT.RIGHT);
+    Label wlResultFileNameField = new Label(wInputComposite, SWT.RIGHT);
     props.setLook(wlResultFileNameField);
     wlResultFileNameField.setText(
         BaseMessages.getString(PKG, "PipelineExecutorDialog.ResultFileNameField.Label"));
@@ -1096,7 +1083,7 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
     tabLayout.marginHeight = 15;
     wInputComposite.setLayout(tabLayout);
 
-    wlResultRowsTarget = new Label(wInputComposite, SWT.RIGHT);
+    Label wlResultRowsTarget = new Label(wInputComposite, SWT.RIGHT);
     props.setLook(wlResultRowsTarget);
     wlResultRowsTarget.setText(
         BaseMessages.getString(PKG, "PipelineExecutorDialog.OutputRowsSource.Label"));
@@ -1113,7 +1100,7 @@ public class PipelineExecutorDialog extends BaseTransformDialog implements ITran
     fdResultRowsTarget.left = new FormAttachment(0, 0); // To the right
     wOutputRowsSource.setLayoutData(fdResultRowsTarget);
 
-    wlOutputFields = new Label(wInputComposite, SWT.NONE);
+    Label wlOutputFields = new Label(wInputComposite, SWT.NONE);
     wlOutputFields.setText(
         BaseMessages.getString(PKG, "PipelineExecutorDialog.ResultFields.Label"));
     props.setLook(wlOutputFields);
diff --git a/plugins/transforms/propertyinput/src/main/java/org/apache/hop/pipeline/transforms/propertyinput/PropertyInputDialog.java b/plugins/transforms/propertyinput/src/main/java/org/apache/hop/pipeline/transforms/propertyinput/PropertyInputDialog.java
index 2eaa963..3144ce8 100644
--- a/plugins/transforms/propertyinput/src/main/java/org/apache/hop/pipeline/transforms/propertyinput/PropertyInputDialog.java
+++ b/plugins/transforms/propertyinput/src/main/java/org/apache/hop/pipeline/transforms/propertyinput/PropertyInputDialog.java
@@ -234,10 +234,10 @@ public class PropertyInputDialog extends BaseTransformDialog implements ITransfo
     props.setLook(wOriginFiles);
     wOriginFiles.setText(BaseMessages.getString(PKG, "PropertyInputDialog.wOriginFiles.Label"));
 
-    FormLayout OriginFilesgroupLayout = new FormLayout();
-    OriginFilesgroupLayout.marginWidth = 10;
-    OriginFilesgroupLayout.marginHeight = 10;
-    wOriginFiles.setLayout(OriginFilesgroupLayout);
+    FormLayout originFilesgroupLayout = new FormLayout();
+    originFilesgroupLayout.marginWidth = 10;
+    originFilesgroupLayout.marginHeight = 10;
+    wOriginFiles.setLayout(originFilesgroupLayout);
 
     // Is Filename defined in a Field
     Label wlFileField = new Label(wOriginFiles, SWT.RIGHT);
@@ -810,10 +810,10 @@ public class PropertyInputDialog extends BaseTransformDialog implements ITransfo
     props.setLook(wAddFileResult);
     wAddFileResult.setText(BaseMessages.getString(PKG, "PropertyInputDialog.wAddFileResult.Label"));
 
-    FormLayout AddFileResultgroupLayout = new FormLayout();
-    AddFileResultgroupLayout.marginWidth = 10;
-    AddFileResultgroupLayout.marginHeight = 10;
-    wAddFileResult.setLayout(AddFileResultgroupLayout);
+    FormLayout addFileResultgroupLayout = new FormLayout();
+    addFileResultgroupLayout.marginWidth = 10;
+    addFileResultgroupLayout.marginHeight = 10;
+    wAddFileResult.setLayout(addFileResultgroupLayout);
 
     Label wlAddResult = new Label(wAddFileResult, SWT.RIGHT);
     wlAddResult.setText(BaseMessages.getString(PKG, "PropertyInputDialog.AddResult.Label"));
diff --git a/plugins/transforms/propertyinput/src/main/java/org/apache/hop/pipeline/transforms/propertyinput/PropertyInputField.java b/plugins/transforms/propertyinput/src/main/java/org/apache/hop/pipeline/transforms/propertyinput/PropertyInputField.java
index 56e5ae8..0d624c2 100644
--- a/plugins/transforms/propertyinput/src/main/java/org/apache/hop/pipeline/transforms/propertyinput/PropertyInputField.java
+++ b/plugins/transforms/propertyinput/src/main/java/org/apache/hop/pipeline/transforms/propertyinput/PropertyInputField.java
@@ -248,24 +248,24 @@ public class PropertyInputField implements Cloneable {
     return groupSymbol;
   }
 
-  public void setGroupSymbol(String group_symbol) {
-    this.groupSymbol = group_symbol;
+  public void setGroupSymbol(String groupSymbol) {
+    this.groupSymbol = groupSymbol;
   }
 
   public String getDecimalSymbol() {
     return decimalSymbol;
   }
 
-  public void setDecimalSymbol(String decimal_symbol) {
-    this.decimalSymbol = decimal_symbol;
+  public void setDecimalSymbol(String decimalSymbol) {
+    this.decimalSymbol = decimalSymbol;
   }
 
   public String getCurrencySymbol() {
     return currencySymbol;
   }
 
-  public void setCurrencySymbol(String currency_symbol) {
-    this.currencySymbol = currency_symbol;
+  public void setCurrencySymbol(String currencySymbol) {
+    this.currencySymbol = currencySymbol;
   }
 
   public int getPrecision() {
diff --git a/plugins/transforms/propertyoutput/src/main/java/org/apache/hop/pipeline/transforms/propertyoutput/PropertyOutputMeta.java b/plugins/transforms/propertyoutput/src/main/java/org/apache/hop/pipeline/transforms/propertyoutput/PropertyOutputMeta.java
index 817afd0..e98c60a 100644
--- a/plugins/transforms/propertyoutput/src/main/java/org/apache/hop/pipeline/transforms/propertyoutput/PropertyOutputMeta.java
+++ b/plugins/transforms/propertyoutput/src/main/java/org/apache/hop/pipeline/transforms/propertyoutput/PropertyOutputMeta.java
@@ -484,9 +484,9 @@ public class PropertyOutputMeta extends BaseTransformMeta
     return valuefield;
   }
 
-  /** @param KeyField the keyfield to set */
-  public void setKeyField(String KeyField) {
-    this.keyfield = KeyField;
+  /** @param keyField the keyfield to set */
+  public void setKeyField(String keyField) {
+    this.keyfield = keyField;
   }
 
   /** @param valuefield the valuefield to set */
diff --git a/plugins/transforms/regexeval/src/main/java/org/apache/hop/pipeline/transforms/regexeval/RegexEvalHelperDialog.java b/plugins/transforms/regexeval/src/main/java/org/apache/hop/pipeline/transforms/regexeval/RegexEvalHelperDialog.java
index 576ddc9..72beb70 100644
--- a/plugins/transforms/regexeval/src/main/java/org/apache/hop/pipeline/transforms/regexeval/RegexEvalHelperDialog.java
+++ b/plugins/transforms/regexeval/src/main/java/org/apache/hop/pipeline/transforms/regexeval/RegexEvalHelperDialog.java
@@ -73,21 +73,21 @@ public class RegexEvalHelperDialog extends Dialog {
    * Dialog to allow someone to test regular expression
    *
    * @param parent The parent shell to use
-   * @param RegexScript The expression to test
-   * @param RegexOptions Any extended options for the regular expression
+   * @param regexScript The expression to test
+   * @param regexOptions Any extended options for the regular expression
    * @param canonicalEqualityFlagSet canonical equality choice
    */
   public RegexEvalHelperDialog(
       Shell parent,
       IVariables variables,
-      String RegexScript,
-      String RegexOptions,
+      String regexScript,
+      String regexOptions,
       boolean canonicalEqualityFlagSet) {
     super(parent, SWT.NONE);
     this.variables = variables;
     props = PropsUi.getInstance();
-    this.regexScript = RegexScript;
-    this.regexOptions = RegexOptions;
+    this.regexScript = regexScript;
+    this.regexOptions = regexOptions;
     this.errorDisplayed = false;
     this.canonicalEqualityFlagSet = canonicalEqualityFlagSet;
   }
diff --git a/plugins/transforms/rest/src/main/java/org/apache/hop/pipeline/transforms/rest/RestDialog.java b/plugins/transforms/rest/src/main/java/org/apache/hop/pipeline/transforms/rest/RestDialog.java
index 4b8217e..1cbd462 100644
--- a/plugins/transforms/rest/src/main/java/org/apache/hop/pipeline/transforms/rest/RestDialog.java
+++ b/plugins/transforms/rest/src/main/java/org/apache/hop/pipeline/transforms/rest/RestDialog.java
@@ -82,7 +82,8 @@ public class RestDialog extends BaseTransformDialog implements ITransformDialog
   private Label wlBody;
   private ComboVar wBody;
 
-  private ColumnInfo[] colinf, colinfoparams;
+  private ColumnInfo[] colinf;
+  private ColumnInfo[] colinfoparams;
 
   private String[] fieldNames;
 
@@ -94,8 +95,10 @@ public class RestDialog extends BaseTransformDialog implements ITransformDialog
 
   private TextVar wProxyPort;
 
-  private Label wlParameters, wlMatrixParameters;
-  private TableView wParameters, wMatrixParameters;
+  private Label wlParameters;
+  private Label wlMatrixParameters;
+  private TableView wParameters;
+  private TableView wMatrixParameters;
 
   private TextVar wResponseTime;
   private TextVar wResponseHeader;
@@ -187,10 +190,10 @@ public class RestDialog extends BaseTransformDialog implements ITransformDialog
 
     Group gSettings = new Group(wGeneralComp, SWT.SHADOW_ETCHED_IN);
     gSettings.setText(BaseMessages.getString(PKG, "RestDialog.SettingsGroup.Label"));
-    FormLayout SettingsLayout = new FormLayout();
-    SettingsLayout.marginWidth = 3;
-    SettingsLayout.marginHeight = 3;
-    gSettings.setLayout(SettingsLayout);
+    FormLayout settingsLayout = new FormLayout();
+    settingsLayout.marginWidth = 3;
+    settingsLayout.marginHeight = 3;
+    gSettings.setLayout(settingsLayout);
     props.setLook(gSettings);
 
     wlUrl = new Label(gSettings, SWT.RIGHT);
@@ -435,10 +438,10 @@ public class RestDialog extends BaseTransformDialog implements ITransformDialog
 
     Group gOutputFields = new Group(wGeneralComp, SWT.SHADOW_ETCHED_IN);
     gOutputFields.setText(BaseMessages.getString(PKG, "RestDialog.OutputFieldsGroup.Label"));
-    FormLayout OutputFieldsLayout = new FormLayout();
-    OutputFieldsLayout.marginWidth = 3;
-    OutputFieldsLayout.marginHeight = 3;
-    gOutputFields.setLayout(OutputFieldsLayout);
+    FormLayout outputFieldsLayout = new FormLayout();
+    outputFieldsLayout.marginWidth = 3;
+    outputFieldsLayout.marginHeight = 3;
+    gOutputFields.setLayout(outputFieldsLayout);
     props.setLook(gOutputFields);
 
     // Result line...
@@ -717,10 +720,10 @@ public class RestDialog extends BaseTransformDialog implements ITransformDialog
 
     Group gSSLTrustStore = new Group(wSSLComp, SWT.SHADOW_ETCHED_IN);
     gSSLTrustStore.setText(BaseMessages.getString(PKG, "RestDialog.SSLTrustStoreGroup.Label"));
-    FormLayout SSLTrustStoreLayout = new FormLayout();
-    SSLTrustStoreLayout.marginWidth = 3;
-    SSLTrustStoreLayout.marginHeight = 3;
-    gSSLTrustStore.setLayout(SSLTrustStoreLayout);
+    FormLayout sslTrustStoreLayout = new FormLayout();
+    sslTrustStoreLayout.marginWidth = 3;
+    sslTrustStoreLayout.marginHeight = 3;
+    gSSLTrustStore.setLayout(sslTrustStoreLayout);
     props.setLook(gSSLTrustStore);
 
     // TrustStoreFile line
diff --git a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceConnection.java b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceConnection.java
index 3dc07d1..594b024 100644
--- a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceConnection.java
+++ b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceConnection.java
@@ -46,7 +46,8 @@ public class SalesforceConnection {
   private static final FieldType ID_FIELD_TYPE = FieldType.id;
   private static final FieldType REFERENCE_FIELD_TYPE = FieldType.reference;
 
-  private static Class<?> PKG = SalesforceConnection.class; // For Translator
+  private static final
+  Class<?> PKG = SalesforceConnection.class; // For Translator
 
   private String url;
   private String username;
@@ -696,7 +697,7 @@ public class SalesforceConnection {
     }
   }
 
-  public String[] getAllAvailableObjects(boolean OnlyQueryableObjects) throws HopException {
+  public String[] getAllAvailableObjects(boolean onlyQueryableObjects) throws HopException {
     DescribeGlobalResult dgr = null;
     List<String> objects = null;
     DescribeGlobalSObjectResult[] sobjectResults = null;
@@ -711,7 +712,7 @@ public class SalesforceConnection {
 
       for (int i = 0; i < nrObjects; i++) {
         DescribeGlobalSObjectResult o = dgr.getSobjects()[i];
-        if ((OnlyQueryableObjects && o.isQueryable()) || !OnlyQueryableObjects) {
+        if ((onlyQueryableObjects && o.isQueryable()) || !onlyQueryableObjects) {
           objects.add(o.getName());
         }
       }
diff --git a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceConnectionUtils.java b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceConnectionUtils.java
index af0ac8b..78b3f1e 100644
--- a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceConnectionUtils.java
+++ b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceConnectionUtils.java
@@ -24,7 +24,7 @@ public class SalesforceConnectionUtils {
 
   public static final int MAX_UPDATED_OBJECTS_IDS = 2000;
 
-  private static Class<?> PKG = SalesforceInputMeta.class; // For Translator
+  private static final Class<?> PKG = SalesforceInputMeta.class; // For Translator
 
   public static final String TARGET_DEFAULT_URL =
       "https://login.salesforce.com/services/Soap/u/50.0";
diff --git a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceTransformMeta.java b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceTransformMeta.java
index f9b5f23..1de2c21 100644
--- a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceTransformMeta.java
+++ b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforce/SalesforceTransformMeta.java
@@ -40,7 +40,7 @@ public abstract class SalesforceTransformMeta<
         Main extends SalesforceTransform, Data extends SalesforceTransformData>
     extends BaseTransformMeta implements ITransformMeta<Main, Data> {
 
-  private static Class<?> PKG = SalesforceTransformMeta.class; // For Translator
+  private static final Class<?> PKG = SalesforceTransformMeta.class; // For Translator
 
   /** The Salesforce Target URL */
   @Injection(name = "SALESFORCE_URL")
diff --git a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforcedelete/SalesforceDeleteDialog.java b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforcedelete/SalesforceDeleteDialog.java
index c5926ef..612300d 100644
--- a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforcedelete/SalesforceDeleteDialog.java
+++ b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforcedelete/SalesforceDeleteDialog.java
@@ -48,11 +48,13 @@ import org.eclipse.swt.widgets.*;
 
 public class SalesforceDeleteDialog extends SalesforceTransformDialog {
 
-  private static Class<?> PKG = SalesforceDeleteMeta.class; // For Translator
+  private static final Class<?> PKG = SalesforceDeleteMeta.class; // For Translator
 
   private SalesforceDeleteMeta input;
 
-  private LabelTextVar wUserName, wURL, wPassword;
+  private LabelTextVar wUserName;
+  private LabelTextVar wURL;
+  private LabelTextVar wPassword;
 
   private TextVar wBatchSize;
 
diff --git a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforcedelete/SalesforceDeleteMeta.java b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforcedelete/SalesforceDeleteMeta.java
index 2d9d6ce..4565575 100644
--- a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforcedelete/SalesforceDeleteMeta.java
+++ b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforcedelete/SalesforceDeleteMeta.java
@@ -47,10 +47,10 @@ import java.util.List;
     documentationUrl = "/pipeline/transforms/salesforcedelete.html")
 public class SalesforceDeleteMeta
     extends SalesforceTransformMeta<SalesforceDelete, SalesforceDeleteData> {
-  private static Class<?> PKG = SalesforceDeleteMeta.class; // For Translator
+  private static final Class<?> PKG = SalesforceDeleteMeta.class; // For Translator
 
   /** Deletefield */
-  private String DeleteField;
+  private String deleteField;
 
   /** Batch size */
   private String batchSize;
@@ -71,14 +71,14 @@ public class SalesforceDeleteMeta
     this.rollbackAllChangesOnError = rollbackAllChangesOnError;
   }
 
-  /** @param DeleteField The DeleteField to set. */
-  public void setDeleteField(String DeleteField) {
-    this.DeleteField = DeleteField;
+  /** @param deleteField The DeleteField to set. */
+  public void setDeleteField(String deleteField) {
+    this.deleteField = deleteField;
   }
 
   /** @return Returns the DeleteField. */
   public String getDeleteField() {
-    return this.DeleteField;
+    return this.deleteField;
   }
 
   /** @param batchSize */
diff --git a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinput/SalesforceInputField.java b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinput/SalesforceInputField.java
index 68e8770..2096c82 100644
--- a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinput/SalesforceInputField.java
+++ b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinput/SalesforceInputField.java
@@ -28,7 +28,7 @@ import org.w3c.dom.Node;
 
 /** Describes an SalesforceInput field */
 public class SalesforceInputField implements Cloneable {
-  private static Class<?> PKG = SalesforceInputMeta.class; // For Translator
+  private static final Class<?> PKG = SalesforceInputMeta.class; // For Translator
 
   public static final int TYPE_TRIM_NONE = 0;
   public static final int TYPE_TRIM_LEFT = 1;
diff --git a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinput/SalesforceInputMeta.java b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinput/SalesforceInputMeta.java
index 9031279..667d1b1 100644
--- a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinput/SalesforceInputMeta.java
+++ b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinput/SalesforceInputMeta.java
@@ -62,7 +62,7 @@ public class SalesforceInputMeta
     extends SalesforceTransformMeta<SalesforceInput, SalesforceInputData> {
   public static String DATE_TIME_FORMAT = "yyyy-MM-dd HH:mm:ss";
 
-  private static Class<?> PKG = SalesforceInputMeta.class; // For Translator
+  private static final Class<?> PKG = SalesforceInputMeta.class; // For Translator
 
   /** Flag indicating that we should include the generated SQL in the output */
   @Injection(name = "INCLUDE_SQL_IN_OUTPUT")
diff --git a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinsert/SalesforceInsertMeta.java b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinsert/SalesforceInsertMeta.java
index baa8222..9ebb990 100644
--- a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinsert/SalesforceInsertMeta.java
+++ b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceinsert/SalesforceInsertMeta.java
@@ -50,7 +50,7 @@ import java.util.List;
     documentationUrl = "/pipeline/transforms/salesforceinsert.html")
 public class SalesforceInsertMeta
     extends SalesforceTransformMeta<SalesforceInsert, SalesforceInsertData> {
-  private static Class<?> PKG = SalesforceInsertMeta.class; // For Translator
+  private static final Class<?> PKG = SalesforceInsertMeta.class; // For Translator
 
   /** Field value to update */
   private String[] updateLookup;
diff --git a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceupdate/SalesforceUpdateMeta.java b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceupdate/SalesforceUpdateMeta.java
index d7235bd..841d00e 100644
--- a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceupdate/SalesforceUpdateMeta.java
+++ b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceupdate/SalesforceUpdateMeta.java
@@ -47,7 +47,7 @@ import java.util.List;
     documentationUrl = "/pipeline/transforms/salesforceupdate.html")
 public class SalesforceUpdateMeta
     extends SalesforceTransformMeta<SalesforceUpdate, SalesforceUpdateData> {
-  private static Class<?> PKG = SalesforceUpdateMeta.class; // For Translator
+  private static final Class<?> PKG = SalesforceUpdateMeta.class; // For Translator
 
   /** Field value to update */
   private String[] updateLookup;
diff --git a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceupsert/SalesforceUpsertMeta.java b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceupsert/SalesforceUpsertMeta.java
index b1be7ed..a608966 100644
--- a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceupsert/SalesforceUpsertMeta.java
+++ b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceupsert/SalesforceUpsertMeta.java
@@ -50,7 +50,7 @@ import java.util.List;
     documentationUrl = "/pipeline/transforms/salesforceupsert.html")
 public class SalesforceUpsertMeta
     extends SalesforceTransformMeta<SalesforceUpsert, SalesforceUpsertData> {
-  private static Class<?> PKG = SalesforceUpsertMeta.class; // For Translator
+  private static final Class<?> PKG = SalesforceUpsertMeta.class; // For Translator
 
   /** UpsertField */
   private String UpsertField;
diff --git a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceutils/SalesforceUtils.java b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceutils/SalesforceUtils.java
index eeb9260..42cc6f2 100644
--- a/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceutils/SalesforceUtils.java
+++ b/plugins/transforms/salesforce/src/main/java/org/apache/hop/pipeline/transforms/salesforceutils/SalesforceUtils.java
@@ -27,7 +27,7 @@ public class SalesforceUtils {
 
   private SalesforceUtils() {}
 
-  private static Class<?> PKG = SalesforceUtils.class; // For Translator
+  private static final Class<?> PKG = SalesforceUtils.class; // For Translator
 
   private static final String EXTID_SEPARATOR = "/";
 
diff --git a/plugins/transforms/samplerows/src/main/java/org/apache/hop/pipeline/transforms/samplerows/SampleRowsDialog.java b/plugins/transforms/samplerows/src/main/java/org/apache/hop/pipeline/transforms/samplerows/SampleRowsDialog.java
index dd91143..05caccb 100644
--- a/plugins/transforms/samplerows/src/main/java/org/apache/hop/pipeline/transforms/samplerows/SampleRowsDialog.java
+++ b/plugins/transforms/samplerows/src/main/java/org/apache/hop/pipeline/transforms/samplerows/SampleRowsDialog.java
@@ -41,7 +41,6 @@ public class SampleRowsDialog extends BaseTransformDialog implements ITransformD
   private static final Class<?> PKG = SampleRowsMeta.class; // For Translator
 
   private LabelTextVar wLinesRange;
-  private FormData fdLinesRange, fdLineNumberField;
   private LabelTextVar wLineNumberField;
   private SampleRowsMeta input;
 
@@ -100,7 +99,7 @@ public class SampleRowsDialog extends BaseTransformDialog implements ITransformD
             BaseMessages.getString(PKG, "SampleRowsDialog.LinesRange.Tooltip"));
     props.setLook(wLinesRange);
     wLinesRange.addModifyListener(lsMod);
-    fdLinesRange = new FormData();
+    FormData fdLinesRange = new FormData();
     fdLinesRange.left = new FormAttachment(0, -margin);
     fdLinesRange.top = new FormAttachment(wTransformName, 2 * margin);
     fdLinesRange.right = new FormAttachment(100, -margin);
@@ -115,7 +114,7 @@ public class SampleRowsDialog extends BaseTransformDialog implements ITransformD
             BaseMessages.getString(PKG, "SampleRowsDialog.LineNumberField.Tooltip"));
     props.setLook(wLinesRange);
     wLineNumberField.addModifyListener(lsMod);
-    fdLineNumberField = new FormData();
+    FormData fdLineNumberField = new FormData();
     fdLineNumberField.left = new FormAttachment(0, -margin);
     fdLineNumberField.top = new FormAttachment(wLinesRange, 2 * margin);
     fdLineNumberField.right = new FormAttachment(100, -margin);
diff --git a/plugins/transforms/sasinput/src/main/java/org/apache/hop/pipeline/transforms/sasinput/SasInputDialog.java b/plugins/transforms/sasinput/src/main/java/org/apache/hop/pipeline/transforms/sasinput/SasInputDialog.java
index 0d762ab..323e7c8 100644
--- a/plugins/transforms/sasinput/src/main/java/org/apache/hop/pipeline/transforms/sasinput/SasInputDialog.java
+++ b/plugins/transforms/sasinput/src/main/java/org/apache/hop/pipeline/transforms/sasinput/SasInputDialog.java
@@ -53,7 +53,7 @@ import java.io.InputStream;
 import java.util.List;
 
 public class SasInputDialog extends BaseTransformDialog implements ITransformDialog {
-  private static Class<?> PKG = SasInputMeta.class; // for Translator
+  private static final Class<?> PKG = SasInputMeta.class; // for Translator
 
   private CCombo wAccField;
 
diff --git a/plugins/transforms/sasinput/src/main/java/org/apache/hop/pipeline/transforms/sasinput/SasInputMeta.java b/plugins/transforms/sasinput/src/main/java/org/apache/hop/pipeline/transforms/sasinput/SasInputMeta.java
index aabca47..94c5790 100644
--- a/plugins/transforms/sasinput/src/main/java/org/apache/hop/pipeline/transforms/sasinput/SasInputMeta.java
+++ b/plugins/transforms/sasinput/src/main/java/org/apache/hop/pipeline/transforms/sasinput/SasInputMeta.java
@@ -51,7 +51,7 @@ import java.util.List;
     documentationUrl = "/pipeline/transforms/sasinput.html")
 public class SasInputMeta extends BaseTransformMeta
     implements ITransformMeta<SasInput, SasInputData> {
-  private static Class<?> PKG = SasInputMeta.class; // for i18n purposes,
+  private static final Class<?> PKG = SasInputMeta.class; // for i18n purposes,
 
   public static final String Xml_TAG_FIELD = "field";
 
diff --git a/plugins/transforms/serverstatus/src/main/java/org/apache/hop/pipeline/transforms/serverstatus/GetServerStatusDialog.java b/plugins/transforms/serverstatus/src/main/java/org/apache/hop/pipeline/transforms/serverstatus/GetServerStatusDialog.java
index ca4b00b..35890c2 100644
--- a/plugins/transforms/serverstatus/src/main/java/org/apache/hop/pipeline/transforms/serverstatus/GetServerStatusDialog.java
+++ b/plugins/transforms/serverstatus/src/main/java/org/apache/hop/pipeline/transforms/serverstatus/GetServerStatusDialog.java
@@ -33,7 +33,7 @@ import org.eclipse.swt.layout.FormLayout;
 import org.eclipse.swt.widgets.*;
 
 public class GetServerStatusDialog extends BaseTransformDialog implements ITransformDialog {
-  private static Class<?> PKG = GetServerStatusDialog.class; // For Translator
+  private static final Class<?> PKG = GetServerStatusDialog.class; // For Translator
   private final GetServerStatusMeta input;
 
   int middle;
diff --git a/plugins/transforms/setvalueconstant/src/main/java/org/apache/hop/pipeline/transforms/setvalueconstant/SetValueConstantDialog.java b/plugins/transforms/setvalueconstant/src/main/java/org/apache/hop/pipeline/transforms/setvalueconstant/SetValueConstantDialog.java
index c39fd70..9c4c0b8 100644
--- a/plugins/transforms/setvalueconstant/src/main/java/org/apache/hop/pipeline/transforms/setvalueconstant/SetValueConstantDialog.java
+++ b/plugins/transforms/setvalueconstant/src/main/java/org/apache/hop/pipeline/transforms/setvalueconstant/SetValueConstantDialog.java
@@ -144,9 +144,9 @@ public class SetValueConstantDialog extends BaseTransformDialog implements ITran
     fdlFields.top = new FormAttachment(wUseVars, margin);
     wlFields.setLayoutData(fdlFields);
 
-    int FieldsCols = 4;
+    int fieldsCols = 4;
     final int FieldsRows = input.getFields().size();
-    colinf = new ColumnInfo[FieldsCols];
+    colinf = new ColumnInfo[fieldsCols];
     colinf[0] =
         new ColumnInfo(
             BaseMessages.getString(PKG, "SetValueConstantDialog.Fieldname.Column"),
diff --git a/plugins/transforms/setvaluefield/src/main/java/org/apache/hop/pipeline/transforms/setvaluefield/SetValueField.java b/plugins/transforms/setvaluefield/src/main/java/org/apache/hop/pipeline/transforms/setvaluefield/SetValueField.java
index 30eeba9..eb4d1dc 100644
--- a/plugins/transforms/setvaluefield/src/main/java/org/apache/hop/pipeline/transforms/setvaluefield/SetValueField.java
+++ b/plugins/transforms/setvaluefield/src/main/java/org/apache/hop/pipeline/transforms/setvaluefield/SetValueField.java
@@ -27,11 +27,10 @@ import org.apache.hop.pipeline.PipelineMeta;
 import org.apache.hop.pipeline.transform.BaseTransform;
 import org.apache.hop.pipeline.transform.ITransform;
 import org.apache.hop.pipeline.transform.TransformMeta;
+
 import java.util.List;
 
-/**
- * Set value field with another value field.
- */
+/** Set value field with another value field. */
 public class SetValueField extends BaseTransform<SetValueFieldMeta, SetValueFieldData>
     implements ITransform<SetValueFieldMeta, SetValueFieldData> {
   private static final Class<?> PKG = SetValueFieldMeta.class; // For Translator
@@ -64,15 +63,14 @@ public class SetValueField extends BaseTransform<SetValueFieldMeta, SetValueFiel
       data.outputRowMeta = getInputRowMeta().clone();
       meta.getFields(data.outputRowMeta, getTransformName(), null, null, this, metadataProvider);
 
-      
       List<SetField> fields = meta.getFields();
-      
+
       data.indexOfField = new int[fields.size()];
       data.indexOfReplaceByValue = new int[fields.size()];
       for (int i = 0; i < fields.size(); i++) {
         SetField field = fields.get(i);
-        // Check if this field was specified only one time        
-        for (int j = 0; j <fields.size(); j++) {
+        // Check if this field was specified only one time
+        for (int j = 0; j < fields.size(); j++) {
           if (j != i && field.equals(fields.get(j))) {
             throw new HopException(
                 BaseMessages.getString(
@@ -101,16 +99,17 @@ public class SetValueField extends BaseTransform<SetValueFieldMeta, SetValueFiel
               BaseMessages.getString(PKG, "SetValueField.Log.CouldNotFindFieldInRow", sourceField));
         }
         // Compare fields type
-        IValueMeta SourceValue = getInputRowMeta().getValueMeta(data.indexOfField[i]);
-        IValueMeta ReplaceByValue = getInputRowMeta().getValueMeta(data.indexOfReplaceByValue[i]);
+        IValueMeta valueMeta = getInputRowMeta().getValueMeta(data.indexOfField[i]);
+        IValueMeta replaceByValueMeta =
+            getInputRowMeta().getValueMeta(data.indexOfReplaceByValue[i]);
 
-        if (SourceValue.getType() != ReplaceByValue.getType()) {
+        if (valueMeta.getType() != replaceByValueMeta.getType()) {
           String err =
               BaseMessages.getString(
                   PKG,
                   "SetValueField.Log.FieldsTypeDifferent",
-                  SourceValue.getName() + " (" + SourceValue.getTypeDesc() + ")",
-                  ReplaceByValue.getName() + " (" + ReplaceByValue.getTypeDesc() + ")");
+                  valueMeta.getName() + " (" + valueMeta.getTypeDesc() + ")",
+                  replaceByValueMeta.getName() + " (" + replaceByValueMeta.getTypeDesc() + ")");
           throw new HopTransformException(err);
         }
       }
diff --git a/plugins/transforms/splunk/src/main/java/org/apache/hop/pipeline/transforms/splunkinput/SplunkInputDialog.java b/plugins/transforms/splunk/src/main/java/org/apache/hop/pipeline/transforms/splunkinput/SplunkInputDialog.java
index 2d06ac6..8b0b0e6 100644
--- a/plugins/transforms/splunk/src/main/java/org/apache/hop/pipeline/transforms/splunkinput/SplunkInputDialog.java
+++ b/plugins/transforms/splunk/src/main/java/org/apache/hop/pipeline/transforms/splunkinput/SplunkInputDialog.java
@@ -221,7 +221,7 @@ public class SplunkInputDialog extends BaseTransformDialog implements ITransform
     fdbGetReturnFields.right = new FormAttachment(100, 0);
     fdbGetReturnFields.top = new FormAttachment(lastControl, margin);
     wbGetReturnFields.setLayoutData(fdbGetReturnFields);
-    wbGetReturnFields.addListener(SWT.Selection, (e) -> getReturnValues());
+    wbGetReturnFields.addListener(SWT.Selection, e -> getReturnValues());
     lastControl = wbGetReturnFields;
 
     wReturns =
diff --git a/plugins/transforms/splunk/src/main/java/org/apache/hop/splunk/SplunkConnectionEditor.java b/plugins/transforms/splunk/src/main/java/org/apache/hop/splunk/SplunkConnectionEditor.java
index a3d99e5..aee3409 100644
--- a/plugins/transforms/splunk/src/main/java/org/apache/hop/splunk/SplunkConnectionEditor.java
+++ b/plugins/transforms/splunk/src/main/java/org/apache/hop/splunk/SplunkConnectionEditor.java
@@ -39,7 +39,7 @@ import org.eclipse.swt.widgets.*;
  * @see SplunkConnection
  */
 public class SplunkConnectionEditor extends MetadataEditor<SplunkConnection> {
-  private static Class<?> PKG =
+  private static final Class<?> PKG =
       SplunkConnectionEditor.class; // for i18n purposes, needed by Translator2!!
 
   // Connection properties
diff --git a/plugins/transforms/sqlfileoutput/src/main/java/org/apache/hop/pipeline/transforms/sqlfileoutput/SQLFileOutputMeta.java b/plugins/transforms/sqlfileoutput/src/main/java/org/apache/hop/pipeline/transforms/sqlfileoutput/SQLFileOutputMeta.java
index 8db669f..45535c5 100644
--- a/plugins/transforms/sqlfileoutput/src/main/java/org/apache/hop/pipeline/transforms/sqlfileoutput/SQLFileOutputMeta.java
+++ b/plugins/transforms/sqlfileoutput/src/main/java/org/apache/hop/pipeline/transforms/sqlfileoutput/SQLFileOutputMeta.java
@@ -69,7 +69,7 @@ public class SQLFileOutputMeta extends BaseTransformMeta
   private String tableName;
   private boolean truncateTable;
 
-  private boolean AddToResult;
+  private boolean addToResult;
 
   private boolean createTable;
 
@@ -106,12 +106,12 @@ public class SQLFileOutputMeta extends BaseTransformMeta
   private String dateformat;
 
   /** Start New line for each statement */
-  private boolean StartNewLine;
+  private boolean startNewLine;
 
   /** Flag: create parent folder if needed */
   private boolean createparentfolder;
 
-  private boolean DoNotOpenNewFileInit;
+  private boolean doNotOpenNewFileInit;
 
   @Override
   public void loadXml(Node transformNode, IHopMetadataProvider metadataProvider)
@@ -250,20 +250,20 @@ public class SQLFileOutputMeta extends BaseTransformMeta
 
   /** @return Returns the Add to result filesname flag. */
   public boolean AddToResult() {
-    return AddToResult;
+    return addToResult;
   }
 
   /** @return Returns the Start new line flag. */
   public boolean StartNewLine() {
-    return StartNewLine;
+    return startNewLine;
   }
 
   public boolean isDoNotOpenNewFileInit() {
-    return DoNotOpenNewFileInit;
+    return doNotOpenNewFileInit;
   }
 
-  public void setDoNotOpenNewFileInit(boolean DoNotOpenNewFileInit) {
-    this.DoNotOpenNewFileInit = DoNotOpenNewFileInit;
+  public void setDoNotOpenNewFileInit(boolean doNotOpenNewFileInit) {
+    this.doNotOpenNewFileInit = doNotOpenNewFileInit;
   }
 
   /** @return Returns the create table flag. */
@@ -276,14 +276,14 @@ public class SQLFileOutputMeta extends BaseTransformMeta
     this.truncateTable = truncateTable;
   }
 
-  /** @param AddToResult The Add file to result to set. */
-  public void setAddToResult(boolean AddToResult) {
-    this.AddToResult = AddToResult;
+  /** @param addToResult The Add file to result to set. */
+  public void setAddToResult(boolean addToResult) {
+    this.addToResult = addToResult;
   }
 
-  /** @param StartNewLine The Start NEw Line to set. */
-  public void setStartNewLine(boolean StartNewLine) {
-    this.StartNewLine = StartNewLine;
+  /** @param startNewLine The Start NEw Line to set. */
+  public void setStartNewLine(boolean startNewLine) {
+    this.startNewLine = startNewLine;
   }
 
   /** @param createTable The create table flag to set. */
@@ -386,9 +386,9 @@ public class SQLFileOutputMeta extends BaseTransformMeta
       createTable = "Y".equalsIgnoreCase(XmlHandler.getTagValue(transformNode, "create"));
       encoding = XmlHandler.getTagValue(transformNode, "encoding");
       dateformat = XmlHandler.getTagValue(transformNode, "dateformat");
-      AddToResult = "Y".equalsIgnoreCase(XmlHandler.getTagValue(transformNode, "AddToResult"));
+      addToResult = "Y".equalsIgnoreCase(XmlHandler.getTagValue(transformNode, "AddToResult"));
 
-      StartNewLine = "Y".equalsIgnoreCase(XmlHandler.getTagValue(transformNode, "StartNewLine"));
+      startNewLine = "Y".equalsIgnoreCase(XmlHandler.getTagValue(transformNode, "StartNewLine"));
 
       fileName = XmlHandler.getTagValue(transformNode, "file", "name");
       createparentfolder =
@@ -406,7 +406,7 @@ public class SQLFileOutputMeta extends BaseTransformMeta
       timeInFilename =
           "Y".equalsIgnoreCase(XmlHandler.getTagValue(transformNode, "file", "add_time"));
       splitEvery = Const.toInt(XmlHandler.getTagValue(transformNode, "file", "splitevery"), 0);
-      DoNotOpenNewFileInit =
+      doNotOpenNewFileInit =
           "Y"
               .equalsIgnoreCase(
                   XmlHandler.getTagValue(transformNode, "file", "DoNotOpenNewFileInit"));
@@ -421,7 +421,7 @@ public class SQLFileOutputMeta extends BaseTransformMeta
     databaseMeta = null;
     tableName = "";
     createparentfolder = false;
-    DoNotOpenNewFileInit = false;
+    doNotOpenNewFileInit = false;
   }
 
   @Override
@@ -438,9 +438,9 @@ public class SQLFileOutputMeta extends BaseTransformMeta
     retval.append("    " + XmlHandler.addTagValue("create", createTable));
     retval.append("    " + XmlHandler.addTagValue("encoding", encoding));
     retval.append("    " + XmlHandler.addTagValue("dateformat", dateformat));
-    retval.append("    " + XmlHandler.addTagValue("addtoresult", AddToResult));
+    retval.append("    " + XmlHandler.addTagValue("addtoresult", addToResult));
 
-    retval.append("    " + XmlHandler.addTagValue("startnewline", StartNewLine));
+    retval.append("    " + XmlHandler.addTagValue("startnewline", startNewLine));
 
     retval.append("    <file>" + Const.CR);
     retval.append("      " + XmlHandler.addTagValue("name", fileName));
@@ -452,7 +452,7 @@ public class SQLFileOutputMeta extends BaseTransformMeta
     retval.append("      " + XmlHandler.addTagValue("add_time", timeInFilename));
     retval.append("      " + XmlHandler.addTagValue("splitevery", splitEvery));
     retval.append("      " + XmlHandler.addTagValue("create_parent_folder", createparentfolder));
-    retval.append("      " + XmlHandler.addTagValue("DoNotOpenNewFileInit", DoNotOpenNewFileInit));
+    retval.append("      " + XmlHandler.addTagValue("DoNotOpenNewFileInit", doNotOpenNewFileInit));
 
     retval.append("      </file>" + Const.CR);
 
@@ -570,7 +570,8 @@ public class SQLFileOutputMeta extends BaseTransformMeta
                           PKG, "SQLFileOutputMeta.CheckResult.FieldsNotFound", errorMessage);
 
                   cr =
-                      new CheckResult(CheckResult.TYPE_RESULT_WARNING, errorMessage, transformMeta);
+                      new CheckResult(
+                          ICheckResult.TYPE_RESULT_WARNING, errorMessage, transformMeta);
                   remarks.add(cr);
                 } else {
                   cr =
diff --git a/plugins/transforms/ssh/src/main/java/org/apache/hop/pipeline/transforms/ssh/SSHDialog.java b/plugins/transforms/ssh/src/main/java/org/apache/hop/pipeline/transforms/ssh/SSHDialog.java
index c537b62..2f02ddc 100644
--- a/plugins/transforms/ssh/src/main/java/org/apache/hop/pipeline/transforms/ssh/SSHDialog.java
+++ b/plugins/transforms/ssh/src/main/java/org/apache/hop/pipeline/transforms/ssh/SSHDialog.java
@@ -19,6 +19,7 @@ package org.apache.hop.pipeline.transforms.ssh;
 
 import com.trilead.ssh2.Connection;
 import org.apache.hop.core.Const;
+import org.apache.hop.core.Props;
 import org.apache.hop.core.exception.HopException;
 import org.apache.hop.core.row.IRowMeta;
 import org.apache.hop.core.util.Utils;
@@ -29,7 +30,6 @@ import org.apache.hop.pipeline.PipelineMeta;
 import org.apache.hop.pipeline.PipelinePreviewFactory;
 import org.apache.hop.pipeline.transform.BaseTransformMeta;
 import org.apache.hop.pipeline.transform.ITransformDialog;
-import org.apache.hop.ui.core.PropsUi;
 import org.apache.hop.ui.core.dialog.*;
 import org.apache.hop.ui.core.widget.LabelTextVar;
 import org.apache.hop.ui.core.widget.StyledTextComp;
@@ -71,7 +71,8 @@ public class SSHDialog extends BaseTransformDialog implements ITransformDialog {
 
   private LabelTextVar wPassphrase;
 
-  private LabelTextVar wResultOutFieldName, wResultErrFieldName;
+  private LabelTextVar wResultOutFieldName;
+  private LabelTextVar wResultErrFieldName;
 
   private Label wlCommand;
   private StyledTextComp wCommand;
@@ -149,7 +150,7 @@ public class SSHDialog extends BaseTransformDialog implements ITransformDialog {
     wTransformName.setLayoutData(fdTransformName);
 
     CTabFolder wTabFolder = new CTabFolder(shell, SWT.BORDER);
-    props.setLook(wTabFolder, PropsUi.WIDGET_STYLE_TAB);
+    props.setLook(wTabFolder, Props.WIDGET_STYLE_TAB);
 
     // ////////////////////////
     // START OF GENERAL TAB ///
@@ -446,13 +447,13 @@ public class SSHDialog extends BaseTransformDialog implements ITransformDialog {
     CTabItem wSettingsTab = new CTabItem(wTabFolder, SWT.NONE);
     wSettingsTab.setText(BaseMessages.getString(PKG, "SSHDialog.Settings.Tab"));
 
-    FormLayout SettingsLayout = new FormLayout();
-    SettingsLayout.marginWidth = 3;
-    SettingsLayout.marginHeight = 3;
+    FormLayout settingsLayout = new FormLayout();
+    settingsLayout.marginWidth = 3;
+    settingsLayout.marginHeight = 3;
 
     Composite wSettingsComp = new Composite(wTabFolder, SWT.NONE);
     props.setLook(wSettingsComp);
-    wSettingsComp.setLayout(SettingsLayout);
+    wSettingsComp.setLayout(settingsLayout);
 
     // ///////////////////////////////
     // START OF Output GROUP //
@@ -513,11 +514,11 @@ public class SSHDialog extends BaseTransformDialog implements ITransformDialog {
     props.setLook(wCommands);
     wCommands.setText(BaseMessages.getString(PKG, "SSHDialog.LogSettings.Group.Label"));
 
-    FormLayout LogSettingsgroupLayout = new FormLayout();
-    LogSettingsgroupLayout.marginWidth = 10;
-    LogSettingsgroupLayout.marginHeight = 10;
+    FormLayout logSettingsgroupLayout = new FormLayout();
+    logSettingsgroupLayout.marginWidth = 10;
+    logSettingsgroupLayout.marginHeight = 10;
 
-    wCommands.setLayout(LogSettingsgroupLayout);
+    wCommands.setLayout(logSettingsgroupLayout);
 
     // Is command defined in a Field
     Label wlDynamicCommand = new Label(wCommands, SWT.RIGHT);
diff --git a/plugins/transforms/streamlookup/src/main/java/org/apache/hop/pipeline/transforms/streamlookup/StreamLookupDialog.java b/plugins/transforms/streamlookup/src/main/java/org/apache/hop/pipeline/transforms/streamlookup/StreamLookupDialog.java
index 61bd8bc..0f5c41e 100644
--- a/plugins/transforms/streamlookup/src/main/java/org/apache/hop/pipeline/transforms/streamlookup/StreamLookupDialog.java
+++ b/plugins/transforms/streamlookup/src/main/java/org/apache/hop/pipeline/transforms/streamlookup/StreamLookupDialog.java
@@ -299,10 +299,10 @@ public class StreamLookupDialog extends BaseTransformDialog implements ITransfor
     fdlReturn.top = new FormAttachment(wKey, margin);
     wlReturn.setLayoutData(fdlReturn);
 
-    int UpInsCols = 4;
-    int UpInsRows = (input.getValue() != null ? input.getValue().length : 1);
+    int upInsCols = 4;
+    int upInsRows = (input.getValue() != null ? input.getValue().length : 1);
 
-    ciReturn = new ColumnInfo[UpInsCols];
+    ciReturn = new ColumnInfo[upInsCols];
     ciReturn[0] =
         new ColumnInfo(
             BaseMessages.getString(PKG, "StreamLookupDialog.ColumnInfo.FieldReturn"),
@@ -331,7 +331,7 @@ public class StreamLookupDialog extends BaseTransformDialog implements ITransfor
             shell,
             SWT.BORDER | SWT.FULL_SELECTION | SWT.MULTI | SWT.V_SCROLL | SWT.H_SCROLL,
             ciReturn,
-            UpInsRows,
+            upInsRows,
             lsMod,
             props);
 
diff --git a/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/SchemaMapper.java b/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/SchemaMapper.java
index d83d6ec..a22b905 100644
--- a/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/SchemaMapper.java
+++ b/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/SchemaMapper.java
@@ -32,7 +32,7 @@ public class SchemaMapper {
   IRowMeta row; // resolved row meta
   int[][] mapping;
 
-  public SchemaMapper(IRowMeta info[]) throws HopPluginException {
+  public SchemaMapper(IRowMeta[] info) throws HopPluginException {
     unionMerge(info);
   }
 
@@ -42,7 +42,7 @@ public class SchemaMapper {
    *
    * @param info row metas for the fields to merge
    */
-  private void unionMerge(IRowMeta info[]) throws HopPluginException {
+  private void unionMerge(IRowMeta[] info) throws HopPluginException {
     // do set up
     mapping = new int[info.length][];
     IRowMeta base = info[0].clone();
diff --git a/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/StreamSchemaData.java b/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/StreamSchemaData.java
index a641c14..72a0f81 100644
--- a/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/StreamSchemaData.java
+++ b/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/StreamSchemaData.java
@@ -28,7 +28,8 @@ import java.util.List;
 /** Holds data objects used in StreamSchema */
 public class StreamSchemaData extends BaseTransformData implements ITransformData {
 
-  public IRowMeta outputRowMeta, inRowMeta; // outgoing and incoming row meta
+  public IRowMeta outputRowMeta;
+  public IRowMeta inRowMeta; // outgoing and incoming row meta
 
   public StreamSchemaData() {
     super();
@@ -44,8 +45,8 @@ public class StreamSchemaData extends BaseTransformData implements ITransformDat
 
   public int[][] mapping; // mappings for all incoming rows
 
-  public int numTransforms,
-      streamNum; // incoming transforms and what stream the current row is from
+  public int numTransforms;
+  public int streamNum; // incoming transforms and what stream the current row is from
 
   public String currentName; // name of the rowset that sent the current row
 
diff --git a/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/StreamSchemaMeta.java b/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/StreamSchemaMeta.java
index 3042bba..8398104 100644
--- a/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/StreamSchemaMeta.java
+++ b/plugins/transforms/streamschemamerge/src/main/java/org/apache/hop/pipeline/transforms/streamschemamerge/StreamSchemaMeta.java
@@ -273,8 +273,8 @@ public class StreamSchemaMeta extends BaseTransformMeta
       PipelineMeta pipelineMeta,
       TransformMeta transformMeta,
       IRowMeta prev,
-      String input[],
-      String output[],
+      String[] input,
+      String[] output,
       IRowMeta info,
       IVariables variables,
       IHopMetadataProvider metadataProvider) {
diff --git a/plugins/transforms/stringoperations/src/main/java/org/apache/hop/pipeline/transforms/stringoperations/StringOperations.java b/plugins/transforms/stringoperations/src/main/java/org/apache/hop/pipeline/transforms/stringoperations/StringOperations.java
index 51c3e42..b7ff6a2 100644
--- a/plugins/transforms/stringoperations/src/main/java/org/apache/hop/pipeline/transforms/stringoperations/StringOperations.java
+++ b/plugins/transforms/stringoperations/src/main/java/org/apache/hop/pipeline/transforms/stringoperations/StringOperations.java
@@ -187,9 +187,9 @@ public class StringOperations extends BaseTransform<StringOperationsMeta, String
 
   private Object[] processRow(IRowMeta rowMeta, Object[] row) throws HopException {
 
-    Object[] RowData = new Object[data.outputRowMeta.size()];
+    Object[] rowData = new Object[data.outputRowMeta.size()];
     // Copy the input fields.
-    System.arraycopy(row, 0, RowData, 0, rowMeta.size());
+    System.arraycopy(row, 0, rowData, 0, rowMeta.size());
     int j = 0; // Index into "new fields" area, past the first {data.inputFieldsNr} records
     for (int i = 0; i < data.nrFieldsInStream; i++) {
       if (data.inStreamNrs[i] >= 0) {
@@ -210,18 +210,18 @@ public class StringOperations extends BaseTransform<StringOperationsMeta, String
                 data.removeSpecialCharacters[i]);
         if (Utils.isEmpty(data.outStreamNrs[i])) {
           // Update field
-          RowData[data.inStreamNrs[i]] = value;
+          rowData[data.inStreamNrs[i]] = value;
           data.outputRowMeta
               .getValueMeta(data.inStreamNrs[i])
               .setStorageType(IValueMeta.STORAGE_TYPE_NORMAL);
         } else {
           // create a new Field
-          RowData[data.inputFieldsNr + j] = value;
+          rowData[data.inputFieldsNr + j] = value;
           j++;
         }
       }
     }
-    return RowData;
+    return rowData;
   }
 
   @Override
diff --git a/plugins/transforms/synchronizeaftermerge/src/main/java/org/apache/hop/pipeline/transforms/synchronizeaftermerge/SynchronizeAfterMergeMeta.java b/plugins/transforms/synchronizeaftermerge/src/main/java/org/apache/hop/pipeline/transforms/synchronizeaftermerge/SynchronizeAfterMergeMeta.java
index 332393c..ce4417c 100644
--- a/plugins/transforms/synchronizeaftermerge/src/main/java/org/apache/hop/pipeline/transforms/synchronizeaftermerge/SynchronizeAfterMergeMeta.java
+++ b/plugins/transforms/synchronizeaftermerge/src/main/java/org/apache/hop/pipeline/transforms/synchronizeaftermerge/SynchronizeAfterMergeMeta.java
@@ -125,13 +125,13 @@ public class SynchronizeAfterMergeMeta extends BaseTransformMeta
   private boolean performLookup;
 
   @Injection(name = "ORDER_INSERT")
-  private String OrderInsert;
+  private String orderInsert;
 
   @Injection(name = "ORDER_UPDATE")
-  private String OrderUpdate;
+  private String orderUpdate;
 
   @Injection(name = "ORDER_DELETE")
-  private String OrderDelete;
+  private String orderDelete;
 
   public SynchronizeAfterMergeMeta() {
... 4666 lines suppressed ...