You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pinot.apache.org by xi...@apache.org on 2022/02/13 18:22:19 UTC

[pinot] branch master updated: Adding more checkstyle rules (#8197)

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

xiangfu pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/pinot.git


The following commit(s) were added to refs/heads/master by this push:
     new bad7106  Adding more checkstyle rules (#8197)
bad7106 is described below

commit bad7106d5c714edf9d52b63dd4428d15cabd79c8
Author: Xiang Fu <xi...@gmail.com>
AuthorDate: Sun Feb 13 10:21:54 2022 -0800

    Adding more checkstyle rules (#8197)
---
 config/checkstyle.xml                              | 20 ++++++++++++
 .../broker/BrokerServiceAutoDiscoveryFeature.java  |  1 -
 .../pinot/client/DynamicBrokerSelectorTest.java    |  1 -
 .../apache/pinot/client/PreparedStatementTest.java |  1 -
 .../apache/pinot/client/ResultSetGroupTest.java    |  1 -
 .../java/org/apache/pinot/client/PinotMeta.java    |  1 -
 .../pinot/client/base/AbstractBaseConnection.java  |  2 --
 .../client/controller/request/TableRequest.java    |  1 -
 .../response/ControllerTenantBrokerResponse.java   |  1 -
 .../client/controller/response/TableResponse.java  |  1 -
 .../pinot/client/DummyPinotClientTransport.java    |  1 -
 .../client/DummyPinotControllerTransport.java      |  1 -
 .../apache/pinot/client/PinotResultSetTest.java    |  1 -
 .../scalar/DataTypeConversionFunctions.java        |  1 -
 .../common/function/scalar/StringFunctions.java    |  6 ++--
 .../common/minion/MinionTaskMetadataUtils.java     |  1 -
 .../pinot/common/request/AggregationInfo.java      |  3 --
 .../apache/pinot/common/request/BrokerRequest.java |  5 ---
 .../apache/pinot/common/request/DataSource.java    |  3 --
 .../apache/pinot/common/request/Expression.java    |  3 --
 .../apache/pinot/common/request/FilterQuery.java   |  3 --
 .../pinot/common/request/FilterQueryMap.java       |  3 --
 .../org/apache/pinot/common/request/Function.java  |  3 --
 .../org/apache/pinot/common/request/GroupBy.java   |  3 --
 .../pinot/common/request/HavingFilterQuery.java    |  3 --
 .../pinot/common/request/HavingFilterQueryMap.java |  3 --
 .../apache/pinot/common/request/Identifier.java    |  3 --
 .../pinot/common/request/InstanceRequest.java      |  3 --
 .../org/apache/pinot/common/request/Literal.java   |  2 --
 .../apache/pinot/common/request/PinotQuery.java    |  4 ---
 .../apache/pinot/common/request/QuerySource.java   |  3 --
 .../org/apache/pinot/common/request/QueryType.java |  3 --
 .../org/apache/pinot/common/request/Selection.java |  5 ---
 .../apache/pinot/common/request/SelectionSort.java |  3 --
 .../pinot/common/response/ProcessingException.java |  3 --
 .../apache/pinot/common/utils/PinotAppConfigs.java |  1 -
 .../apache/pinot/parsers/CompilerConstants.java    |  1 -
 .../apache/pinot/parsers/utils/ParserUtils.java    |  1 -
 .../common/utils/config/TableConfigUtilsTest.java  |  1 -
 .../pinot/sql/parsers/CalciteSqlCompilerTest.java  |  1 -
 .../api/events/DefaultMetadataEventNotifier.java   |  2 --
 .../DefaultMetadataEventNotifierFactory.java       |  1 -
 .../helix/ControllerTenantStatelessTest.java       |  1 -
 .../segment/SegmentFlushThresholdComputerTest.java |  2 +-
 .../core/metadata/MetadataExtractorFactory.java    |  1 -
 .../scheduler/resources/QueryExecutorService.java  |  1 -
 .../processing/filter/RecordFilterFactory.java     |  1 -
 .../processing/partitioner/PartitionerFactory.java |  1 -
 .../transformer/RecordTransformerFactory.java      |  1 -
 .../pinot/core/transport/ListenerConfig.java       |  2 +-
 .../apache/pinot/core/util/ListenerConfigUtil.java |  4 +--
 .../core/util/SegmentCompletionProtocolUtils.java  |  2 +-
 .../pinot/server/access/HttpRequesterIdentity.java |  2 +-
 .../BaseTableDataManagerAcquireSegmentTest.java    |  1 -
 .../realtime/PinotFSSegmentUploaderTest.java       |  1 -
 .../RealtimeConsumptionRateManagerTest.java        |  3 +-
 .../core/query/optimizer/statement/TestHelper.java |  1 -
 .../impl/fakestream/FakeStreamLevelConsumer.java   |  3 --
 .../pinot/spi/crypt/PinotCrypterFactoryTest.java   |  2 --
 .../pinot/integration/tests/ClusterTest.java       |  1 -
 .../BrokerServiceDiscoveryIntegrationTest.java     |  2 +-
 .../tests/GrpcBrokerClusterIntegrationTest.java    |  2 +-
 .../CertBasedTlsChannelAccessControlFactory.java   |  2 +-
 .../pinot/perf/BenchmarkFilteredAggregations.java  |  2 +-
 .../standalone/SegmentGenerationJobRunnerTest.java | 26 +++++++--------
 .../pinot/plugin/filesystem/AzurePinotFS.java      |  1 -
 .../pinot/plugin/filesystem/HadoopPinotFS.java     |  1 -
 .../inputformat/orc/ORCRecordReaderTest.java       |  2 --
 .../dropwizard/DropwizardMetricsFactory.java       |  1 -
 .../metrics/yammer/YammerMetricsFactory.java       |  1 -
 .../stream/kafka09/SimpleConsumerFactory.java      |  1 -
 .../stream/kafka/KafkaJSONMessageDecoder.java      |  1 -
 .../stream/kinesis/KinesisMsgOffsetFactory.java    |  1 -
 .../stream/pulsar/PulsarStreamLevelConsumer.java   |  1 -
 .../io/compression/ChunkCompressorFactory.java     |  1 -
 .../local/io/compression/LZ4Compressor.java        |  1 -
 .../local/io/compression/ZstandardCompressor.java  |  1 -
 .../io/compression/ZstandardDecompressor.java      |  1 -
 .../creator/impl/SegmentColumnarIndexCreator.java  |  2 +-
 .../startree/v2/builder/MultipleTreesBuilder.java  |  4 +--
 .../startree/v2/store/StarTreeIndexMapUtils.java   |  4 +--
 .../local/utils/nativefst/FSTTraversal.java        |  4 +--
 .../local/utils/nativefst/StateVisitor.java        |  2 +-
 .../local/utils/nativefst/automaton/Automaton.java |  2 +-
 .../nativefst/automaton/StringUnionOperations.java |  2 +-
 .../utils/nativefst/automaton/Transition.java      |  2 +-
 .../utils/nativefst/builder/FSTSerializer.java     |  2 +-
 .../local/utils/nativefst/builder/FSTUtils.java    |  6 ++--
 .../mutablefst/utils/MutableFSTUtils.java          |  1 -
 .../nativefst/utils/RealTimeRegexpMatcher.java     |  2 +-
 .../pinot/segment/spi/index/IndexingOverrides.java |  2 +-
 .../spi/index/reader/ForwardIndexReader.java       |  1 -
 .../server/api/resources/ServerResourceUtils.java  |  1 -
 .../OffsetBasedConsumptionStatusCheckerTest.java   |  2 +-
 .../apache/pinot/spi/crypt/NoOpPinotCrypter.java   |  1 -
 .../pinot/spi/crypt/PinotCrypterFactory.java       |  1 -
 .../pinot/spi/data/readers/RecordReaderConfig.java |  1 -
 .../pinot/spi/env/CommonsConfigurationUtils.java   |  4 +--
 .../apache/pinot/spi/env/PinotConfiguration.java   | 38 +++++++++++-----------
 .../apache/pinot/spi/plugin/PluginClassLoader.java |  3 +-
 .../org/apache/pinot/spi/plugin/PluginManager.java |  4 +--
 .../apache/pinot/spi/stream/OffsetCriteria.java    |  1 -
 .../pinot/spi/stream/PartitionGroupConsumer.java   |  1 -
 .../org/apache/pinot/spi/utils/Obfuscator.java     |  2 --
 .../pinot/spi/env/PinotConfigurationTest.java      |  6 ++--
 .../pinot/spi/filesystem/LocalPinotFSTest.java     |  1 -
 .../apache/pinot/spi/filesystem/PinotFSTest.java   |  2 --
 pinot-spi/src/test/resources/TestRecordReader.java |  1 -
 .../resources/pinot-configuration-1.properties     |  2 +-
 .../resources/pinot-configuration-2.properties     |  2 +-
 .../apache/pinot/tools/AbstractBaseCommand.java    |  2 --
 .../pinot/tools/AutoAddInvertedIndexTool.java      | 16 ++++-----
 .../org/apache/pinot/tools/UpdateSegmentState.java |  2 +-
 .../apache/pinot/tools/ValidateTableRetention.java |  4 +--
 .../tools/admin/command/AddSchemaCommand.java      |  1 -
 .../tools/admin/command/AnonymizeDataCommand.java  |  4 +--
 .../tools/admin/command/BootstrapTableCommand.java |  1 -
 .../admin/command/ChangeNumReplicasCommand.java    |  2 +-
 .../tools/admin/command/ChangeTableState.java      |  1 -
 .../tools/admin/command/CreateSegmentCommand.java  |  2 +-
 .../tools/admin/command/DeleteClusterCommand.java  |  1 -
 .../tools/admin/command/GenerateDataCommand.java   |  3 +-
 .../tools/admin/command/ImportDataCommand.java     |  2 +-
 .../tools/admin/command/MoveReplicaGroup.java      |  3 +-
 .../OfflineSegmentIntervalCheckerCommand.java      |  3 +-
 .../admin/command/OperateClusterConfigCommand.java |  3 +-
 .../tools/admin/command/PostQueryCommand.java      |  1 -
 .../command/RealtimeProvisioningHelperCommand.java | 18 +++++-----
 .../tools/admin/command/RebalanceTableCommand.java | 16 ++++-----
 .../tools/admin/command/StartBrokerCommand.java    |  1 -
 .../admin/command/StartControllerCommand.java      |  3 +-
 .../tools/admin/command/StartServerCommand.java    |  5 ++-
 .../tools/admin/command/StopProcessCommand.java    |  1 -
 .../admin/command/StreamAvroIntoKafkaCommand.java  |  4 +--
 .../admin/command/StreamGitHubEventsCommand.java   |  4 +--
 .../tools/admin/command/UploadSegmentCommand.java  |  1 -
 .../tools/admin/command/ValidateConfigCommand.java |  4 +--
 .../admin/command/VerifyClusterStateCommand.java   |  2 +-
 .../tools/admin/command/VerifySegmentState.java    |  2 +-
 .../tools/filesystem/PinotFSBenchmarkRunner.java   | 10 +++---
 .../pinot/tools/perf/PerfBenchmarkRunner.java      | 16 ++++-----
 .../org/apache/pinot/tools/perf/QueryRunner.java   | 14 ++++----
 .../converter/PinotSegmentConvertCommand.java      |  6 ++--
 .../pinot/tools/streams/AirlineDataStream.java     |  1 -
 144 files changed, 164 insertions(+), 292 deletions(-)

diff --git a/config/checkstyle.xml b/config/checkstyle.xml
index 4fbd34e..a1c6c21 100644
--- a/config/checkstyle.xml
+++ b/config/checkstyle.xml
@@ -261,4 +261,24 @@
   <module name="SuppressionFilter">
     <property name="file" value="${config_loc}/suppressions.xml"/>
   </module>
+
+  <module name="NewlineAtEndOfFile">
+    <property name="lineSeparator" value="lf" />
+  </module>
+  <module name="RegexpMultiline">
+    <property name="format" value="\r" />
+    <property name="message" value="Line contains carriage return" />
+  </module>
+  <module name="RegexpMultiline">
+    <property name="format" value=" \n" />
+    <property name="message" value="Line has trailing whitespace" />
+  </module>
+  <module name="RegexpMultiline">
+    <property name="format" value="\n\n\Z" />
+    <property name="message" value="Blank line before end of file" />
+  </module>
+  <module name="RegexpMultiline">
+    <property name="format" value="\n\n\s*\}" />
+    <property name="message" value="Blank line before closing brace" />
+  </module>
 </module>
diff --git a/pinot-broker/src/main/java/org/apache/pinot/broker/broker/BrokerServiceAutoDiscoveryFeature.java b/pinot-broker/src/main/java/org/apache/pinot/broker/broker/BrokerServiceAutoDiscoveryFeature.java
index c50cfd4..f1a2d2d 100644
--- a/pinot-broker/src/main/java/org/apache/pinot/broker/broker/BrokerServiceAutoDiscoveryFeature.java
+++ b/pinot-broker/src/main/java/org/apache/pinot/broker/broker/BrokerServiceAutoDiscoveryFeature.java
@@ -85,7 +85,6 @@ public class BrokerServiceAutoDiscoveryFeature implements Feature {
             populator.populate(
                     new ClasspathDescriptorFileFinder(this.getClass().getClassLoader()),
                     new DuplicatePostProcessor());
-
         } catch (IOException | MultiException ex) {
             LOGGER.error("Failed to register service locator. Auto-discovery will fail, but app will continue", ex);
         }
diff --git a/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/DynamicBrokerSelectorTest.java b/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/DynamicBrokerSelectorTest.java
index c032f85..c13b930 100644
--- a/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/DynamicBrokerSelectorTest.java
+++ b/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/DynamicBrokerSelectorTest.java
@@ -131,5 +131,4 @@ public class DynamicBrokerSelectorTest {
 
     Mockito.verify(_mockZkClient, times(1)).close();
   }
-
 }
diff --git a/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/PreparedStatementTest.java b/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/PreparedStatementTest.java
index dbb7619..ef7bc04 100644
--- a/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/PreparedStatementTest.java
+++ b/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/PreparedStatementTest.java
@@ -83,7 +83,6 @@ public class PreparedStatementTest {
     @Override
     public void close()
         throws PinotClientException {
-
     }
   }
 
diff --git a/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/ResultSetGroupTest.java b/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/ResultSetGroupTest.java
index e9bee63..d986a39 100644
--- a/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/ResultSetGroupTest.java
+++ b/pinot-clients/pinot-java-client/src/test/java/org/apache/pinot/client/ResultSetGroupTest.java
@@ -185,7 +185,6 @@ public class ResultSetGroupTest {
     @Override
     public void close()
         throws PinotClientException {
-
     }
   }
 
diff --git a/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/PinotMeta.java b/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/PinotMeta.java
index 663290e..bb94bdd 100644
--- a/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/PinotMeta.java
+++ b/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/PinotMeta.java
@@ -31,7 +31,6 @@ public class PinotMeta {
   private Map<String, List<String>> _dataSchema = new HashMap<>();
 
   public PinotMeta() {
-
   }
 
   public PinotMeta(List<List<Object>> rows, Map<String, List<String>> dataSchema) {
diff --git a/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/base/AbstractBaseConnection.java b/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/base/AbstractBaseConnection.java
index 250d12c..73a1d19 100644
--- a/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/base/AbstractBaseConnection.java
+++ b/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/base/AbstractBaseConnection.java
@@ -147,7 +147,6 @@ public abstract class AbstractBaseConnection implements Connection {
   @Override
   public void setClientInfo(Properties properties)
       throws SQLClientInfoException {
-
   }
 
   @Override
@@ -311,7 +310,6 @@ public abstract class AbstractBaseConnection implements Connection {
   @Override
   public void setClientInfo(String name, String value)
       throws SQLClientInfoException {
-
   }
 
   @Override
diff --git a/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/request/TableRequest.java b/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/request/TableRequest.java
index a3ef5bc..e96279d 100644
--- a/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/request/TableRequest.java
+++ b/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/request/TableRequest.java
@@ -19,5 +19,4 @@
 package org.apache.pinot.client.controller.request;
 
 public class TableRequest {
-
 }
diff --git a/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/response/ControllerTenantBrokerResponse.java b/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/response/ControllerTenantBrokerResponse.java
index 4bc3d65..1ba9068 100644
--- a/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/response/ControllerTenantBrokerResponse.java
+++ b/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/response/ControllerTenantBrokerResponse.java
@@ -34,7 +34,6 @@ public class ControllerTenantBrokerResponse {
   private JsonNode _brokers;
 
   private ControllerTenantBrokerResponse() {
-
   }
 
   private ControllerTenantBrokerResponse(JsonNode controllerTenantBrokerResponse) {
diff --git a/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/response/TableResponse.java b/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/response/TableResponse.java
index 16dc239..8f41afc 100644
--- a/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/response/TableResponse.java
+++ b/pinot-clients/pinot-jdbc-client/src/main/java/org/apache/pinot/client/controller/response/TableResponse.java
@@ -34,7 +34,6 @@ public class TableResponse {
   private JsonNode _tables;
 
   private TableResponse() {
-
   }
 
   private TableResponse(JsonNode tableResponse) {
diff --git a/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/DummyPinotClientTransport.java b/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/DummyPinotClientTransport.java
index 3277a9d..86ad814 100644
--- a/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/DummyPinotClientTransport.java
+++ b/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/DummyPinotClientTransport.java
@@ -59,6 +59,5 @@ public class DummyPinotClientTransport implements PinotClientTransport {
   @Override
   public void close()
       throws PinotClientException {
-
   }
 }
diff --git a/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/DummyPinotControllerTransport.java b/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/DummyPinotControllerTransport.java
index b718ef4..1993ce6 100644
--- a/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/DummyPinotControllerTransport.java
+++ b/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/DummyPinotControllerTransport.java
@@ -34,7 +34,6 @@ public class DummyPinotControllerTransport extends PinotControllerTransport {
       JsonNode dummyBrokerJsonResponse = objectMapper.readTree(jsonString);
       return ControllerTenantBrokerResponse.fromJson(dummyBrokerJsonResponse);
     } catch (Exception e) {
-
     }
     return ControllerTenantBrokerResponse.empty();
   }
diff --git a/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/PinotResultSetTest.java b/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/PinotResultSetTest.java
index 468675f..4c3c3cd 100644
--- a/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/PinotResultSetTest.java
+++ b/pinot-clients/pinot-jdbc-client/src/test/java/org/apache/pinot/client/PinotResultSetTest.java
@@ -209,7 +209,6 @@ public class PinotResultSetTest {
     @Override
     public void close()
         throws PinotClientException {
-
     }
   }
 
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/function/scalar/DataTypeConversionFunctions.java b/pinot-common/src/main/java/org/apache/pinot/common/function/scalar/DataTypeConversionFunctions.java
index 9758fc9..47c9ce9 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/function/scalar/DataTypeConversionFunctions.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/function/scalar/DataTypeConversionFunctions.java
@@ -30,7 +30,6 @@ import org.apache.pinot.spi.utils.BytesUtils;
  */
 public class DataTypeConversionFunctions {
   private DataTypeConversionFunctions() {
-
   }
 
   /**
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/function/scalar/StringFunctions.java b/pinot-common/src/main/java/org/apache/pinot/common/function/scalar/StringFunctions.java
index bb081c9..77d21eb 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/function/scalar/StringFunctions.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/function/scalar/StringFunctions.java
@@ -192,10 +192,10 @@ public class StringFunctions {
   }
 
   /**
-   * @see #StringFunctions#regexpExtract(String, String, int, String) 
-   * @param value 
+   * @see #StringFunctions#regexpExtract(String, String, int, String)
+   * @param value
    * @param regexp
-   * @param group 
+   * @param group
    * @return the matched result.
    */
   @ScalarFunction
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/minion/MinionTaskMetadataUtils.java b/pinot-common/src/main/java/org/apache/pinot/common/minion/MinionTaskMetadataUtils.java
index 16cb922..5a11202 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/minion/MinionTaskMetadataUtils.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/minion/MinionTaskMetadataUtils.java
@@ -33,7 +33,6 @@ import org.apache.zookeeper.data.Stat;
 public final class MinionTaskMetadataUtils {
 
   private MinionTaskMetadataUtils() {
-
   }
 
   /**
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/AggregationInfo.java b/pinot-common/src/main/java/org/apache/pinot/common/request/AggregationInfo.java
index cd18620..bd35241 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/AggregationInfo.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/AggregationInfo.java
@@ -327,7 +327,6 @@ public class AggregationInfo implements org.apache.thrift.TBase<AggregationInfo,
         setExpressions((java.util.List<java.lang.String>)value);
       }
       break;
-
     }
   }
 
@@ -345,7 +344,6 @@ public class AggregationInfo implements org.apache.thrift.TBase<AggregationInfo,
 
     case EXPRESSIONS:
       return getExpressions();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -706,7 +704,6 @@ public class AggregationInfo implements org.apache.thrift.TBase<AggregationInfo,
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class AggregationInfoTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/BrokerRequest.java b/pinot-common/src/main/java/org/apache/pinot/common/request/BrokerRequest.java
index c73c78f..0dbaecf 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/BrokerRequest.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/BrokerRequest.java
@@ -249,7 +249,6 @@ public class BrokerRequest implements org.apache.thrift.TBase<BrokerRequest, Bro
 
   public BrokerRequest() {
     this.limit = 0;
-
   }
 
   /**
@@ -348,7 +347,6 @@ public class BrokerRequest implements org.apache.thrift.TBase<BrokerRequest, Bro
     this.pinotQuery = null;
     this.orderBy = null;
     this.limit = 0;
-
   }
 
   @org.apache.thrift.annotation.Nullable
@@ -1010,7 +1008,6 @@ public class BrokerRequest implements org.apache.thrift.TBase<BrokerRequest, Bro
         setLimit((java.lang.Integer)value);
       }
       break;
-
     }
   }
 
@@ -1073,7 +1070,6 @@ public class BrokerRequest implements org.apache.thrift.TBase<BrokerRequest, Bro
 
     case LIMIT:
       return getLimit();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -2253,7 +2249,6 @@ public class BrokerRequest implements org.apache.thrift.TBase<BrokerRequest, Bro
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class BrokerRequestTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/DataSource.java b/pinot-common/src/main/java/org/apache/pinot/common/request/DataSource.java
index 3994790..7afdfb6 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/DataSource.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/DataSource.java
@@ -161,7 +161,6 @@ public class DataSource implements org.apache.thrift.TBase<DataSource, DataSourc
         setTableName((java.lang.String)value);
       }
       break;
-
     }
   }
 
@@ -170,7 +169,6 @@ public class DataSource implements org.apache.thrift.TBase<DataSource, DataSourc
     switch (field) {
     case TABLE_NAME:
       return getTableName();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -348,7 +346,6 @@ public class DataSource implements org.apache.thrift.TBase<DataSource, DataSourc
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class DataSourceTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/Expression.java b/pinot-common/src/main/java/org/apache/pinot/common/request/Expression.java
index ca86c41..5d62bd2 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/Expression.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/Expression.java
@@ -309,7 +309,6 @@ public class Expression implements org.apache.thrift.TBase<Expression, Expressio
         setIdentifier((Identifier)value);
       }
       break;
-
     }
   }
 
@@ -327,7 +326,6 @@ public class Expression implements org.apache.thrift.TBase<Expression, Expressio
 
     case IDENTIFIER:
       return getIdentifier();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -658,7 +656,6 @@ public class Expression implements org.apache.thrift.TBase<Expression, Expressio
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class ExpressionTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/FilterQuery.java b/pinot-common/src/main/java/org/apache/pinot/common/request/FilterQuery.java
index 5a5e7ac..14a3c63 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/FilterQuery.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/FilterQuery.java
@@ -407,7 +407,6 @@ public class FilterQuery implements org.apache.thrift.TBase<FilterQuery, FilterQ
         setNestedFilterQueryIds((java.util.List<java.lang.Integer>)value);
       }
       break;
-
     }
   }
 
@@ -428,7 +427,6 @@ public class FilterQuery implements org.apache.thrift.TBase<FilterQuery, FilterQ
 
     case NESTED_FILTER_QUERY_IDS:
       return getNestedFilterQueryIds();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -826,7 +824,6 @@ public class FilterQuery implements org.apache.thrift.TBase<FilterQuery, FilterQ
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class FilterQueryTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/FilterQueryMap.java b/pinot-common/src/main/java/org/apache/pinot/common/request/FilterQueryMap.java
index 8843582..78ad46b 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/FilterQueryMap.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/FilterQueryMap.java
@@ -191,7 +191,6 @@ public class FilterQueryMap implements org.apache.thrift.TBase<FilterQueryMap, F
         setFilterQueryMap((java.util.Map<java.lang.Integer,FilterQuery>)value);
       }
       break;
-
     }
   }
 
@@ -200,7 +199,6 @@ public class FilterQueryMap implements org.apache.thrift.TBase<FilterQueryMap, F
     switch (field) {
     case FILTER_QUERY_MAP:
       return getFilterQueryMap();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -399,7 +397,6 @@ public class FilterQueryMap implements org.apache.thrift.TBase<FilterQueryMap, F
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class FilterQueryMapTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/Function.java b/pinot-common/src/main/java/org/apache/pinot/common/request/Function.java
index d58983d..c836999 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/Function.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/Function.java
@@ -232,7 +232,6 @@ public class Function implements org.apache.thrift.TBase<Function, Function._Fie
         setOperands((java.util.List<Expression>)value);
       }
       break;
-
     }
   }
 
@@ -244,7 +243,6 @@ public class Function implements org.apache.thrift.TBase<Function, Function._Fie
 
     case OPERANDS:
       return getOperands();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -490,7 +488,6 @@ public class Function implements org.apache.thrift.TBase<Function, Function._Fie
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class FunctionTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/GroupBy.java b/pinot-common/src/main/java/org/apache/pinot/common/request/GroupBy.java
index ab548cc..28f831d 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/GroupBy.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/GroupBy.java
@@ -288,7 +288,6 @@ public class GroupBy implements org.apache.thrift.TBase<GroupBy, GroupBy._Fields
         setExpressions((java.util.List<java.lang.String>)value);
       }
       break;
-
     }
   }
 
@@ -303,7 +302,6 @@ public class GroupBy implements org.apache.thrift.TBase<GroupBy, GroupBy._Fields
 
     case EXPRESSIONS:
       return getExpressions();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -611,7 +609,6 @@ public class GroupBy implements org.apache.thrift.TBase<GroupBy, GroupBy._Fields
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class GroupByTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/HavingFilterQuery.java b/pinot-common/src/main/java/org/apache/pinot/common/request/HavingFilterQuery.java
index 21d8d0e..52ef17a 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/HavingFilterQuery.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/HavingFilterQuery.java
@@ -407,7 +407,6 @@ public class HavingFilterQuery implements org.apache.thrift.TBase<HavingFilterQu
         setNestedFilterQueryIds((java.util.List<java.lang.Integer>)value);
       }
       break;
-
     }
   }
 
@@ -428,7 +427,6 @@ public class HavingFilterQuery implements org.apache.thrift.TBase<HavingFilterQu
 
     case NESTED_FILTER_QUERY_IDS:
       return getNestedFilterQueryIds();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -827,7 +825,6 @@ public class HavingFilterQuery implements org.apache.thrift.TBase<HavingFilterQu
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class HavingFilterQueryTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/HavingFilterQueryMap.java b/pinot-common/src/main/java/org/apache/pinot/common/request/HavingFilterQueryMap.java
index b24ba2e..7152cab 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/HavingFilterQueryMap.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/HavingFilterQueryMap.java
@@ -186,7 +186,6 @@ public class HavingFilterQueryMap implements org.apache.thrift.TBase<HavingFilte
         setFilterQueryMap((java.util.Map<java.lang.Integer,HavingFilterQuery>)value);
       }
       break;
-
     }
   }
 
@@ -195,7 +194,6 @@ public class HavingFilterQueryMap implements org.apache.thrift.TBase<HavingFilte
     switch (field) {
     case FILTER_QUERY_MAP:
       return getFilterQueryMap();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -394,7 +392,6 @@ public class HavingFilterQueryMap implements org.apache.thrift.TBase<HavingFilte
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class HavingFilterQueryMapTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/Identifier.java b/pinot-common/src/main/java/org/apache/pinot/common/request/Identifier.java
index 79ad9b3..260e808 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/Identifier.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/Identifier.java
@@ -167,7 +167,6 @@ public class Identifier implements org.apache.thrift.TBase<Identifier, Identifie
         setName((java.lang.String)value);
       }
       break;
-
     }
   }
 
@@ -176,7 +175,6 @@ public class Identifier implements org.apache.thrift.TBase<Identifier, Identifie
     switch (field) {
     case NAME:
       return getName();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -354,7 +352,6 @@ public class Identifier implements org.apache.thrift.TBase<Identifier, Identifie
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class IdentifierTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/InstanceRequest.java b/pinot-common/src/main/java/org/apache/pinot/common/request/InstanceRequest.java
index b676666..3cc6f54 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/InstanceRequest.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/InstanceRequest.java
@@ -364,7 +364,6 @@ public class InstanceRequest implements org.apache.thrift.TBase<InstanceRequest,
         setBrokerId((java.lang.String)value);
       }
       break;
-
     }
   }
 
@@ -385,7 +384,6 @@ public class InstanceRequest implements org.apache.thrift.TBase<InstanceRequest,
 
     case BROKER_ID:
       return getBrokerId();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -772,7 +770,6 @@ public class InstanceRequest implements org.apache.thrift.TBase<InstanceRequest,
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class InstanceRequestTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/Literal.java b/pinot-common/src/main/java/org/apache/pinot/common/request/Literal.java
index 5ce1cc4..a769f6a 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/Literal.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/Literal.java
@@ -720,6 +720,4 @@ public class Literal extends org.apache.thrift.TUnion<Literal, Literal._Fields>
       throw new java.io.IOException(te);
     }
   }
-
-
 }
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/PinotQuery.java b/pinot-common/src/main/java/org/apache/pinot/common/request/PinotQuery.java
index e7fac81..d053056 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/PinotQuery.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/PinotQuery.java
@@ -200,7 +200,6 @@ public class PinotQuery implements org.apache.thrift.TBase<PinotQuery, PinotQuer
     this.limit = 10;
 
     this.offset = 0;
-
   }
 
   /**
@@ -723,7 +722,6 @@ public class PinotQuery implements org.apache.thrift.TBase<PinotQuery, PinotQuer
         setExplain((java.lang.Boolean)value);
       }
       break;
-
     }
   }
 
@@ -765,7 +763,6 @@ public class PinotQuery implements org.apache.thrift.TBase<PinotQuery, PinotQuer
 
     case EXPLAIN:
       return isExplain();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -1571,7 +1568,6 @@ public class PinotQuery implements org.apache.thrift.TBase<PinotQuery, PinotQuer
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class PinotQueryTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/QuerySource.java b/pinot-common/src/main/java/org/apache/pinot/common/request/QuerySource.java
index eefc1c0..a7db794 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/QuerySource.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/QuerySource.java
@@ -166,7 +166,6 @@ public class QuerySource implements org.apache.thrift.TBase<QuerySource, QuerySo
         setTableName((java.lang.String)value);
       }
       break;
-
     }
   }
 
@@ -175,7 +174,6 @@ public class QuerySource implements org.apache.thrift.TBase<QuerySource, QuerySo
     switch (field) {
     case TABLE_NAME:
       return getTableName();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -353,7 +351,6 @@ public class QuerySource implements org.apache.thrift.TBase<QuerySource, QuerySo
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class QuerySourceTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/QueryType.java b/pinot-common/src/main/java/org/apache/pinot/common/request/QueryType.java
index 23d84e7..fdb4aa1 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/QueryType.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/QueryType.java
@@ -330,7 +330,6 @@ public class QueryType implements org.apache.thrift.TBase<QueryType, QueryType._
         setHasHaving((java.lang.Boolean)value);
       }
       break;
-
     }
   }
 
@@ -351,7 +350,6 @@ public class QueryType implements org.apache.thrift.TBase<QueryType, QueryType._
 
     case HAS_HAVING:
       return isHasHaving();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -701,7 +699,6 @@ public class QueryType implements org.apache.thrift.TBase<QueryType, QueryType._
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class QueryTypeTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/Selection.java b/pinot-common/src/main/java/org/apache/pinot/common/request/Selection.java
index a2c6099..c1a7559 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/Selection.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/Selection.java
@@ -142,7 +142,6 @@ public class Selection implements org.apache.thrift.TBase<Selection, Selection._
     this.offset = 0;
 
     this.size = 10;
-
   }
 
   /**
@@ -176,7 +175,6 @@ public class Selection implements org.apache.thrift.TBase<Selection, Selection._
     this.offset = 0;
 
     this.size = 10;
-
   }
 
   public int getSelectionColumnsSize() {
@@ -336,7 +334,6 @@ public class Selection implements org.apache.thrift.TBase<Selection, Selection._
         setSize((java.lang.Integer)value);
       }
       break;
-
     }
   }
 
@@ -354,7 +351,6 @@ public class Selection implements org.apache.thrift.TBase<Selection, Selection._
 
     case SIZE:
       return getSize();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -707,7 +703,6 @@ public class Selection implements org.apache.thrift.TBase<Selection, Selection._
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class SelectionTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/request/SelectionSort.java b/pinot-common/src/main/java/org/apache/pinot/common/request/SelectionSort.java
index d017230..dfa9c5a 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/request/SelectionSort.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/request/SelectionSort.java
@@ -210,7 +210,6 @@ public class SelectionSort implements org.apache.thrift.TBase<SelectionSort, Sel
         setIsAsc((java.lang.Boolean)value);
       }
       break;
-
     }
   }
 
@@ -222,7 +221,6 @@ public class SelectionSort implements org.apache.thrift.TBase<SelectionSort, Sel
 
     case IS_ASC:
       return isIsAsc();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -446,7 +444,6 @@ public class SelectionSort implements org.apache.thrift.TBase<SelectionSort, Sel
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class SelectionSortTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/response/ProcessingException.java b/pinot-common/src/main/java/org/apache/pinot/common/response/ProcessingException.java
index 4c58610..5866442 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/response/ProcessingException.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/response/ProcessingException.java
@@ -216,7 +216,6 @@ public class ProcessingException extends org.apache.thrift.TException implements
         setMessage((java.lang.String)value);
       }
       break;
-
     }
   }
 
@@ -228,7 +227,6 @@ public class ProcessingException extends org.apache.thrift.TException implements
 
     case MESSAGE:
       return getMessage();
-
     }
     throw new java.lang.IllegalStateException();
   }
@@ -450,7 +448,6 @@ public class ProcessingException extends org.apache.thrift.TException implements
       oprot.writeFieldStop();
       oprot.writeStructEnd();
     }
-
   }
 
   private static class ProcessingExceptionTupleSchemeFactory implements org.apache.thrift.scheme.SchemeFactory {
diff --git a/pinot-common/src/main/java/org/apache/pinot/common/utils/PinotAppConfigs.java b/pinot-common/src/main/java/org/apache/pinot/common/utils/PinotAppConfigs.java
index 254d2a8..35d8e44 100644
--- a/pinot-common/src/main/java/org/apache/pinot/common/utils/PinotAppConfigs.java
+++ b/pinot-common/src/main/java/org/apache/pinot/common/utils/PinotAppConfigs.java
@@ -73,7 +73,6 @@ public class PinotAppConfigs {
   @JsonCreator
   @SuppressWarnings("unused")
   public PinotAppConfigs() {
-
   }
 
   public PinotAppConfigs(PinotConfiguration pinotConfig) {
diff --git a/pinot-common/src/main/java/org/apache/pinot/parsers/CompilerConstants.java b/pinot-common/src/main/java/org/apache/pinot/parsers/CompilerConstants.java
index 6a486b7..ebe61d8 100644
--- a/pinot-common/src/main/java/org/apache/pinot/parsers/CompilerConstants.java
+++ b/pinot-common/src/main/java/org/apache/pinot/parsers/CompilerConstants.java
@@ -27,6 +27,5 @@ public class CompilerConstants {
 
   // Private constructor to prevent instantiation
   private CompilerConstants() {
-
   }
 }
diff --git a/pinot-common/src/main/java/org/apache/pinot/parsers/utils/ParserUtils.java b/pinot-common/src/main/java/org/apache/pinot/parsers/utils/ParserUtils.java
index c1d0781..be0ad84 100644
--- a/pinot-common/src/main/java/org/apache/pinot/parsers/utils/ParserUtils.java
+++ b/pinot-common/src/main/java/org/apache/pinot/parsers/utils/ParserUtils.java
@@ -37,7 +37,6 @@ import org.apache.pinot.spi.utils.CommonConstants.Query.Range;
 public class ParserUtils {
   // Private constructor to disable instantiation.
   private ParserUtils() {
-
   }
 
   private static final Map<FilterKind, FilterOperator> FILTER_OPERATOR_MAP;
diff --git a/pinot-common/src/test/java/org/apache/pinot/common/utils/config/TableConfigUtilsTest.java b/pinot-common/src/test/java/org/apache/pinot/common/utils/config/TableConfigUtilsTest.java
index 0a769a5..9fa44ed 100644
--- a/pinot-common/src/test/java/org/apache/pinot/common/utils/config/TableConfigUtilsTest.java
+++ b/pinot-common/src/test/java/org/apache/pinot/common/utils/config/TableConfigUtilsTest.java
@@ -119,7 +119,6 @@ public class TableConfigUtilsTest {
     @Override
     public void init(Map<String, String> props, Set<String> fieldsToRead, String topicName)
         throws Exception {
-
     }
 
     @Override
diff --git a/pinot-common/src/test/java/org/apache/pinot/sql/parsers/CalciteSqlCompilerTest.java b/pinot-common/src/test/java/org/apache/pinot/sql/parsers/CalciteSqlCompilerTest.java
index 6c49c46..e706de9 100644
--- a/pinot-common/src/test/java/org/apache/pinot/sql/parsers/CalciteSqlCompilerTest.java
+++ b/pinot-common/src/test/java/org/apache/pinot/sql/parsers/CalciteSqlCompilerTest.java
@@ -2513,6 +2513,5 @@ public class CalciteSqlCompilerTest {
 
     Assert.expectThrows(SqlCompilationException.class,
         () -> CalciteSqlParser.compileToPinotQuery("SELECT UPPER(col1), avg(col2) from foo"));
-
   }
 }
diff --git a/pinot-controller/src/main/java/org/apache/pinot/controller/api/events/DefaultMetadataEventNotifier.java b/pinot-controller/src/main/java/org/apache/pinot/controller/api/events/DefaultMetadataEventNotifier.java
index 608c5e6..a3fc070 100644
--- a/pinot-controller/src/main/java/org/apache/pinot/controller/api/events/DefaultMetadataEventNotifier.java
+++ b/pinot-controller/src/main/java/org/apache/pinot/controller/api/events/DefaultMetadataEventNotifier.java
@@ -24,10 +24,8 @@ import org.apache.pinot.spi.data.Schema;
 
 public class DefaultMetadataEventNotifier implements MetadataEventNotifier {
   public void notifyOnSchemaEvents(Schema schema, SchemaEventType eventType) {
-
   }
 
   public void notifyOnSegmentFlush(TableConfig tableConfig) {
-
   }
 }
diff --git a/pinot-controller/src/main/java/org/apache/pinot/controller/api/events/DefaultMetadataEventNotifierFactory.java b/pinot-controller/src/main/java/org/apache/pinot/controller/api/events/DefaultMetadataEventNotifierFactory.java
index 6b6d4c8..aa148f4 100644
--- a/pinot-controller/src/main/java/org/apache/pinot/controller/api/events/DefaultMetadataEventNotifierFactory.java
+++ b/pinot-controller/src/main/java/org/apache/pinot/controller/api/events/DefaultMetadataEventNotifierFactory.java
@@ -28,6 +28,5 @@ public class DefaultMetadataEventNotifierFactory extends MetadataEventNotifierFa
   }
 
   public void init(PinotConfiguration configuration) {
-
   }
 }
diff --git a/pinot-controller/src/test/java/org/apache/pinot/controller/helix/ControllerTenantStatelessTest.java b/pinot-controller/src/test/java/org/apache/pinot/controller/helix/ControllerTenantStatelessTest.java
index 1a36024..15a695f 100644
--- a/pinot-controller/src/test/java/org/apache/pinot/controller/helix/ControllerTenantStatelessTest.java
+++ b/pinot-controller/src/test/java/org/apache/pinot/controller/helix/ControllerTenantStatelessTest.java
@@ -117,7 +117,6 @@ public class ControllerTenantStatelessTest extends ControllerTest {
       sendGetRequest(_controllerRequestURLBuilder.forServerTenantGet("doesn't_exist"));
       Assert.fail();
     } catch (Exception e) {
-
     }
   }
 
diff --git a/pinot-controller/src/test/java/org/apache/pinot/controller/helix/core/realtime/segment/SegmentFlushThresholdComputerTest.java b/pinot-controller/src/test/java/org/apache/pinot/controller/helix/core/realtime/segment/SegmentFlushThresholdComputerTest.java
index a420acc..6cb21af 100644
--- a/pinot-controller/src/test/java/org/apache/pinot/controller/helix/core/realtime/segment/SegmentFlushThresholdComputerTest.java
+++ b/pinot-controller/src/test/java/org/apache/pinot/controller/helix/core/realtime/segment/SegmentFlushThresholdComputerTest.java
@@ -311,4 +311,4 @@ public class SegmentFlushThresholdComputerTest {
     // (0.1 * 0.25) + (0.9 * 0.15)
     assertEquals(computer.getLatestSegmentRowsToSizeRatio(), 0.16);
   }
-}
\ No newline at end of file
+}
diff --git a/pinot-core/src/main/java/org/apache/pinot/core/metadata/MetadataExtractorFactory.java b/pinot-core/src/main/java/org/apache/pinot/core/metadata/MetadataExtractorFactory.java
index fe26c3f..62ff2f1 100644
--- a/pinot-core/src/main/java/org/apache/pinot/core/metadata/MetadataExtractorFactory.java
+++ b/pinot-core/src/main/java/org/apache/pinot/core/metadata/MetadataExtractorFactory.java
@@ -31,7 +31,6 @@ public class MetadataExtractorFactory {
 
   // Prevent factory from being instantiated
   private MetadataExtractorFactory() {
-
   }
 
   public static MetadataExtractor create(String metadataClassName) {
diff --git a/pinot-core/src/main/java/org/apache/pinot/core/query/scheduler/resources/QueryExecutorService.java b/pinot-core/src/main/java/org/apache/pinot/core/query/scheduler/resources/QueryExecutorService.java
index 254413f..63b240e 100644
--- a/pinot-core/src/main/java/org/apache/pinot/core/query/scheduler/resources/QueryExecutorService.java
+++ b/pinot-core/src/main/java/org/apache/pinot/core/query/scheduler/resources/QueryExecutorService.java
@@ -48,7 +48,6 @@ public abstract class QueryExecutorService implements ExecutorService {
   }
 
   public void releaseWorkers() {
-
   }
 
   @Override
diff --git a/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/filter/RecordFilterFactory.java b/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/filter/RecordFilterFactory.java
index 1e8573d..3a8763d 100644
--- a/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/filter/RecordFilterFactory.java
+++ b/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/filter/RecordFilterFactory.java
@@ -27,7 +27,6 @@ import com.google.common.base.Preconditions;
 public final class RecordFilterFactory {
 
   private RecordFilterFactory() {
-
   }
 
   public enum RecordFilterType {
diff --git a/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/partitioner/PartitionerFactory.java b/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/partitioner/PartitionerFactory.java
index acefd87..40814e2 100644
--- a/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/partitioner/PartitionerFactory.java
+++ b/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/partitioner/PartitionerFactory.java
@@ -26,7 +26,6 @@ import com.google.common.base.Preconditions;
  */
 public final class PartitionerFactory {
   private PartitionerFactory() {
-
   }
 
   public enum PartitionerType {
diff --git a/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/transformer/RecordTransformerFactory.java b/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/transformer/RecordTransformerFactory.java
index 7394ab4..4a8d1dc 100644
--- a/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/transformer/RecordTransformerFactory.java
+++ b/pinot-core/src/main/java/org/apache/pinot/core/segment/processing/transformer/RecordTransformerFactory.java
@@ -23,7 +23,6 @@ package org.apache.pinot.core.segment.processing.transformer;
  */
 public final class RecordTransformerFactory {
   private RecordTransformerFactory() {
-
   }
 
   /**
diff --git a/pinot-core/src/main/java/org/apache/pinot/core/transport/ListenerConfig.java b/pinot-core/src/main/java/org/apache/pinot/core/transport/ListenerConfig.java
index 8fd8652..73faeaa 100644
--- a/pinot-core/src/main/java/org/apache/pinot/core/transport/ListenerConfig.java
+++ b/pinot-core/src/main/java/org/apache/pinot/core/transport/ListenerConfig.java
@@ -19,7 +19,7 @@
 package org.apache.pinot.core.transport;
 
 /**
- * Provides configuration settings expected by an Http Server to 
+ * Provides configuration settings expected by an Http Server to
  * setup listeners for http and https protocols.
  */
 public class ListenerConfig {
diff --git a/pinot-core/src/main/java/org/apache/pinot/core/util/ListenerConfigUtil.java b/pinot-core/src/main/java/org/apache/pinot/core/util/ListenerConfigUtil.java
index 2c16d85..c31d254 100644
--- a/pinot-core/src/main/java/org/apache/pinot/core/util/ListenerConfigUtil.java
+++ b/pinot-core/src/main/java/org/apache/pinot/core/util/ListenerConfigUtil.java
@@ -51,7 +51,7 @@ import org.glassfish.jersey.server.ResourceConfig;
 
 
 /**
- * Utility class that generates Http {@link ListenerConfig} instances 
+ * Utility class that generates Http {@link ListenerConfig} instances
  * based on the properties provided by a property namespace in {@link PinotConfiguration}.
  */
 public final class ListenerConfigUtil {
@@ -72,7 +72,7 @@ public final class ListenerConfigUtil {
    * @param config property holders for controller configuration
    * @param namespace property namespace to extract from
    *
-   * @return List of {@link ListenerConfig} for which http listeners 
+   * @return List of {@link ListenerConfig} for which http listeners
    * should be created.
    */
   public static List<ListenerConfig> buildListenerConfigs(PinotConfiguration config, String namespace,
diff --git a/pinot-core/src/main/java/org/apache/pinot/core/util/SegmentCompletionProtocolUtils.java b/pinot-core/src/main/java/org/apache/pinot/core/util/SegmentCompletionProtocolUtils.java
index cf93f75..fbd0c6e 100644
--- a/pinot-core/src/main/java/org/apache/pinot/core/util/SegmentCompletionProtocolUtils.java
+++ b/pinot-core/src/main/java/org/apache/pinot/core/util/SegmentCompletionProtocolUtils.java
@@ -24,7 +24,7 @@ import org.apache.pinot.common.protocols.SegmentCompletionProtocol;
 
 
 /**
- * Util methods related to low level consumers' segment completion protocols. 
+ * Util methods related to low level consumers' segment completion protocols.
  */
 public class SegmentCompletionProtocolUtils {
   private SegmentCompletionProtocolUtils() {
diff --git a/pinot-core/src/main/java/org/apache/pinot/server/access/HttpRequesterIdentity.java b/pinot-core/src/main/java/org/apache/pinot/server/access/HttpRequesterIdentity.java
index 2233ccd..2d73580 100644
--- a/pinot-core/src/main/java/org/apache/pinot/server/access/HttpRequesterIdentity.java
+++ b/pinot-core/src/main/java/org/apache/pinot/server/access/HttpRequesterIdentity.java
@@ -50,4 +50,4 @@ public class HttpRequesterIdentity extends RequesterIdentity {
   public void setEndpointUrl(String endpointUrl) {
     _endpointUrl = endpointUrl;
   }
-}
\ No newline at end of file
+}
diff --git a/pinot-core/src/test/java/org/apache/pinot/core/data/manager/BaseTableDataManagerAcquireSegmentTest.java b/pinot-core/src/test/java/org/apache/pinot/core/data/manager/BaseTableDataManagerAcquireSegmentTest.java
index 43be64b..86299bf 100644
--- a/pinot-core/src/test/java/org/apache/pinot/core/data/manager/BaseTableDataManagerAcquireSegmentTest.java
+++ b/pinot-core/src/test/java/org/apache/pinot/core/data/manager/BaseTableDataManagerAcquireSegmentTest.java
@@ -268,7 +268,6 @@ public class BaseTableDataManagerAcquireSegmentTest {
     try {
       Thread.sleep(runTimeSec * 1000);
     } catch (InterruptedException e) {
-
     }
     _closing = true;
 
diff --git a/pinot-core/src/test/java/org/apache/pinot/core/data/manager/realtime/PinotFSSegmentUploaderTest.java b/pinot-core/src/test/java/org/apache/pinot/core/data/manager/realtime/PinotFSSegmentUploaderTest.java
index eb1c9b5..9238d54 100644
--- a/pinot-core/src/test/java/org/apache/pinot/core/data/manager/realtime/PinotFSSegmentUploaderTest.java
+++ b/pinot-core/src/test/java/org/apache/pinot/core/data/manager/realtime/PinotFSSegmentUploaderTest.java
@@ -93,7 +93,6 @@ public class PinotFSSegmentUploaderTest {
 
     @Override
     public void init(PinotConfiguration config) {
-
     }
 
     @Override
diff --git a/pinot-core/src/test/java/org/apache/pinot/core/data/manager/realtime/RealtimeConsumptionRateManagerTest.java b/pinot-core/src/test/java/org/apache/pinot/core/data/manager/realtime/RealtimeConsumptionRateManagerTest.java
index 660196e..7253276 100644
--- a/pinot-core/src/test/java/org/apache/pinot/core/data/manager/realtime/RealtimeConsumptionRateManagerTest.java
+++ b/pinot-core/src/test/java/org/apache/pinot/core/data/manager/realtime/RealtimeConsumptionRateManagerTest.java
@@ -69,5 +69,4 @@ public class RealtimeConsumptionRateManagerTest {
     rateLimiter = _consumptionRateManager.createRateLimiter(STREAM_CONFIG_C, TABLE_NAME);
     assertEquals(rateLimiter, NOOP_RATE_LIMITER);
   }
-
-}
\ No newline at end of file
+}
diff --git a/pinot-core/src/test/java/org/apache/pinot/core/query/optimizer/statement/TestHelper.java b/pinot-core/src/test/java/org/apache/pinot/core/query/optimizer/statement/TestHelper.java
index 8fede3a..78b2b0a 100644
--- a/pinot-core/src/test/java/org/apache/pinot/core/query/optimizer/statement/TestHelper.java
+++ b/pinot-core/src/test/java/org/apache/pinot/core/query/optimizer/statement/TestHelper.java
@@ -55,5 +55,4 @@ class TestHelper {
     Assert.assertEquals(userQuery.toString(),
         rewrittenQuery.toString().replace("stringValue:-Infinity", "doubleValue:-Infinity"));
   }
-
 }
diff --git a/pinot-core/src/test/java/org/apache/pinot/core/realtime/impl/fakestream/FakeStreamLevelConsumer.java b/pinot-core/src/test/java/org/apache/pinot/core/realtime/impl/fakestream/FakeStreamLevelConsumer.java
index e302b6e..3331c24 100644
--- a/pinot-core/src/test/java/org/apache/pinot/core/realtime/impl/fakestream/FakeStreamLevelConsumer.java
+++ b/pinot-core/src/test/java/org/apache/pinot/core/realtime/impl/fakestream/FakeStreamLevelConsumer.java
@@ -30,7 +30,6 @@ public class FakeStreamLevelConsumer implements StreamLevelConsumer {
   @Override
   public void start()
       throws Exception {
-
   }
 
   @Override
@@ -40,12 +39,10 @@ public class FakeStreamLevelConsumer implements StreamLevelConsumer {
 
   @Override
   public void commit() {
-
   }
 
   @Override
   public void shutdown()
       throws Exception {
-
   }
 }
diff --git a/pinot-core/src/test/java/org/apache/pinot/spi/crypt/PinotCrypterFactoryTest.java b/pinot-core/src/test/java/org/apache/pinot/spi/crypt/PinotCrypterFactoryTest.java
index 38c9d2e..2587afa 100644
--- a/pinot-core/src/test/java/org/apache/pinot/spi/crypt/PinotCrypterFactoryTest.java
+++ b/pinot-core/src/test/java/org/apache/pinot/spi/crypt/PinotCrypterFactoryTest.java
@@ -58,12 +58,10 @@ public class PinotCrypterFactoryTest {
 
     @Override
     public void encrypt(File decryptedFile, File encryptedFile) {
-
     }
 
     @Override
     public void decrypt(File encryptedFile, File decryptedFile) {
-
     }
   }
 }
diff --git a/pinot-integration-test-base/src/test/java/org/apache/pinot/integration/tests/ClusterTest.java b/pinot-integration-test-base/src/test/java/org/apache/pinot/integration/tests/ClusterTest.java
index 5f6364f..e9627da 100644
--- a/pinot-integration-test-base/src/test/java/org/apache/pinot/integration/tests/ClusterTest.java
+++ b/pinot-integration-test-base/src/test/java/org/apache/pinot/integration/tests/ClusterTest.java
@@ -361,7 +361,6 @@ public abstract class ClusterTest extends ControllerTest {
     } catch (Exception e) {
       throw new RuntimeException(e);
     }
-
   }
 
   protected void stopMinion() {
diff --git a/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/BrokerServiceDiscoveryIntegrationTest.java b/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/BrokerServiceDiscoveryIntegrationTest.java
index 81b353f..da93bad 100644
--- a/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/BrokerServiceDiscoveryIntegrationTest.java
+++ b/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/BrokerServiceDiscoveryIntegrationTest.java
@@ -59,8 +59,8 @@ public class BrokerServiceDiscoveryIntegrationTest extends BaseClusterIntegratio
     startController();
     startBrokers(1);
     startServers(1);
-
   }
+
   @AfterClass
   public void tearDown()
           throws Exception {
diff --git a/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/GrpcBrokerClusterIntegrationTest.java b/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/GrpcBrokerClusterIntegrationTest.java
index 94f0ec8..5d5d87d 100644
--- a/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/GrpcBrokerClusterIntegrationTest.java
+++ b/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/GrpcBrokerClusterIntegrationTest.java
@@ -105,7 +105,7 @@ public class GrpcBrokerClusterIntegrationTest extends BaseClusterIntegrationTest
 
     startController(properties);
 
-    startBrokers(1, DEFAULT_BROKER_PORT, getZkUrl(), 
+    startBrokers(1, DEFAULT_BROKER_PORT, getZkUrl(),
         Collections.singletonMap(CommonConstants.Broker.BROKER_REQUEST_HANDLER_TYPE, "grpc"));
 
     // Enable gRPC server
diff --git a/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/access/CertBasedTlsChannelAccessControlFactory.java b/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/access/CertBasedTlsChannelAccessControlFactory.java
index dd65e77..49bfa55 100644
--- a/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/access/CertBasedTlsChannelAccessControlFactory.java
+++ b/pinot-integration-tests/src/test/java/org/apache/pinot/integration/tests/access/CertBasedTlsChannelAccessControlFactory.java
@@ -72,4 +72,4 @@ public class CertBasedTlsChannelAccessControlFactory implements AccessControlFac
       return true;
     }
   }
-}
\ No newline at end of file
+}
diff --git a/pinot-perf/src/main/java/org/apache/pinot/perf/BenchmarkFilteredAggregations.java b/pinot-perf/src/main/java/org/apache/pinot/perf/BenchmarkFilteredAggregations.java
index 8019aa2..82bb6a9 100644
--- a/pinot-perf/src/main/java/org/apache/pinot/perf/BenchmarkFilteredAggregations.java
+++ b/pinot-perf/src/main/java/org/apache/pinot/perf/BenchmarkFilteredAggregations.java
@@ -78,7 +78,7 @@ public class BenchmarkFilteredAggregations extends BaseQueriesTest {
   private int _numRows;
   @Param("0")
   int _intBaseValue;
-  
+
   private IndexSegment _indexSegment;
   private List<IndexSegment> _indexSegments;
 
diff --git a/pinot-plugins/pinot-batch-ingestion/pinot-batch-ingestion-standalone/src/test/java/org/apache/pinot/plugin/ingestion/batch/standalone/SegmentGenerationJobRunnerTest.java b/pinot-plugins/pinot-batch-ingestion/pinot-batch-ingestion-standalone/src/test/java/org/apache/pinot/plugin/ingestion/batch/standalone/SegmentGenerationJobRunnerTest.java
index 2ad2b68..1f920c4 100644
--- a/pinot-plugins/pinot-batch-ingestion/pinot-batch-ingestion-standalone/src/test/java/org/apache/pinot/plugin/ingestion/batch/standalone/SegmentGenerationJobRunnerTest.java
+++ b/pinot-plugins/pinot-batch-ingestion/pinot-batch-ingestion-standalone/src/test/java/org/apache/pinot/plugin/ingestion/batch/standalone/SegmentGenerationJobRunnerTest.java
@@ -42,7 +42,7 @@ import org.testng.Assert;
 import org.testng.annotations.Test;
 
 public class SegmentGenerationJobRunnerTest {
-  
+
   @Test
   public void testSegmentGeneration() throws Exception {
     // TODO use common resource definitions & code shared with Hadoop unit test.
@@ -51,12 +51,12 @@ public class SegmentGenerationJobRunnerTest {
     File testDir = Files.createTempDirectory("testSegmentGeneration-").toFile();
     testDir.delete();
     testDir.mkdirs();
-    
+
     File inputDir = new File(testDir, "input");
     inputDir.mkdirs();
     File inputFile = new File(inputDir, "input.csv");
     FileUtils.writeLines(inputFile, Lists.newArrayList("col1,col2", "value1,1", "value2,2"));
-    
+
     // Create an output directory, with two empty files in it. One we'll overwrite,
     // and one we'll leave alone.
     final String outputFilename = "myTable_OFFLINE_0.tar.gz";
@@ -64,7 +64,7 @@ public class SegmentGenerationJobRunnerTest {
     File outputDir = new File(testDir, "output");
     FileUtils.touch(new File(outputDir, outputFilename));
     FileUtils.touch(new File(outputDir, existingFilename));
-    
+
     // Set up schema file.
     final String schemaName = "mySchema";
     File schemaFile = new File(testDir, "schema");
@@ -74,7 +74,7 @@ public class SegmentGenerationJobRunnerTest {
       .addMetric("col2", DataType.INT)
       .build();
     FileUtils.write(schemaFile, schema.toPrettyJsonString(), StandardCharsets.UTF_8);
-    
+
     // Set up table config file.
     File tableConfigFile = new File(testDir, "tableConfig");
     TableConfig tableConfig = new TableConfigBuilder(TableType.OFFLINE)
@@ -83,38 +83,38 @@ public class SegmentGenerationJobRunnerTest {
       .setNumReplicas(1)
       .build();
     FileUtils.write(tableConfigFile, tableConfig.toJsonString(), StandardCharsets.UTF_8);
-    
+
     SegmentGenerationJobSpec jobSpec = new SegmentGenerationJobSpec();
     jobSpec.setJobType("SegmentCreation");
     jobSpec.setInputDirURI(inputDir.toURI().toString());
     jobSpec.setOutputDirURI(outputDir.toURI().toString());
     jobSpec.setOverwriteOutput(false);
-    
+
     RecordReaderSpec recordReaderSpec = new RecordReaderSpec();
     recordReaderSpec.setDataFormat("csv");
     recordReaderSpec.setClassName(CSVRecordReader.class.getName());
     recordReaderSpec.setConfigClassName(CSVRecordReaderConfig.class.getName());
     jobSpec.setRecordReaderSpec(recordReaderSpec);
-    
+
     TableSpec tableSpec = new TableSpec();
     tableSpec.setTableName("myTable");
     tableSpec.setSchemaURI(schemaFile.toURI().toString());
     tableSpec.setTableConfigURI(tableConfigFile.toURI().toString());
     jobSpec.setTableSpec(tableSpec);
-    
+
     ExecutionFrameworkSpec efSpec = new ExecutionFrameworkSpec();
     efSpec.setName("standalone");
     efSpec.setSegmentGenerationJobRunnerClassName(SegmentGenerationJobRunner.class.getName());
     jobSpec.setExecutionFrameworkSpec(efSpec);
-    
+
     PinotFSSpec pfsSpec = new PinotFSSpec();
     pfsSpec.setScheme("file");
     pfsSpec.setClassName(LocalPinotFS.class.getName());
     jobSpec.setPinotFSSpecs(Collections.singletonList(pfsSpec));
-    
+
     SegmentGenerationJobRunner jobRunner = new SegmentGenerationJobRunner(jobSpec);
     jobRunner.run();
-    
+
     // The output directory should still have the original file in it.
     File oldSegmentFile = new File(outputDir, existingFilename);
     Assert.assertTrue(oldSegmentFile.exists());
@@ -124,7 +124,7 @@ public class SegmentGenerationJobRunnerTest {
     Assert.assertTrue(newSegmentFile.exists());
     Assert.assertTrue(newSegmentFile.isFile());
     Assert.assertTrue(newSegmentFile.length() == 0);
-    
+
     // Now run again, but this time with overwriting of output files, and confirm we got a valid segment file.
     jobSpec.setOverwriteOutput(true);
     jobRunner = new SegmentGenerationJobRunner(jobSpec);
diff --git a/pinot-plugins/pinot-file-system/pinot-adls/src/main/java/org/apache/pinot/plugin/filesystem/AzurePinotFS.java b/pinot-plugins/pinot-file-system/pinot-adls/src/main/java/org/apache/pinot/plugin/filesystem/AzurePinotFS.java
index 84872bf..14a0bef 100644
--- a/pinot-plugins/pinot-file-system/pinot-adls/src/main/java/org/apache/pinot/plugin/filesystem/AzurePinotFS.java
+++ b/pinot-plugins/pinot-file-system/pinot-adls/src/main/java/org/apache/pinot/plugin/filesystem/AzurePinotFS.java
@@ -61,7 +61,6 @@ public class AzurePinotFS extends BasePinotFS {
   public static final String CLIENT_SECRET = "clientSecret";
 
   public AzurePinotFS() {
-
   }
 
   @VisibleForTesting
diff --git a/pinot-plugins/pinot-file-system/pinot-hdfs/src/main/java/org/apache/pinot/plugin/filesystem/HadoopPinotFS.java b/pinot-plugins/pinot-file-system/pinot-hdfs/src/main/java/org/apache/pinot/plugin/filesystem/HadoopPinotFS.java
index 5136c10..2d1064d 100644
--- a/pinot-plugins/pinot-file-system/pinot-hdfs/src/main/java/org/apache/pinot/plugin/filesystem/HadoopPinotFS.java
+++ b/pinot-plugins/pinot-file-system/pinot-hdfs/src/main/java/org/apache/pinot/plugin/filesystem/HadoopPinotFS.java
@@ -55,7 +55,6 @@ public class HadoopPinotFS extends BasePinotFS {
   private org.apache.hadoop.conf.Configuration _hadoopConf;
 
   public HadoopPinotFS() {
-
   }
 
   @Override
diff --git a/pinot-plugins/pinot-input-format/pinot-orc/src/test/java/org/apache/pinot/plugin/inputformat/orc/ORCRecordReaderTest.java b/pinot-plugins/pinot-input-format/pinot-orc/src/test/java/org/apache/pinot/plugin/inputformat/orc/ORCRecordReaderTest.java
index 44ea965..c244d93 100644
--- a/pinot-plugins/pinot-input-format/pinot-orc/src/test/java/org/apache/pinot/plugin/inputformat/orc/ORCRecordReaderTest.java
+++ b/pinot-plugins/pinot-input-format/pinot-orc/src/test/java/org/apache/pinot/plugin/inputformat/orc/ORCRecordReaderTest.java
@@ -1,5 +1,4 @@
 package org.apache.pinot.plugin.inputformat.orc;
-
 /**
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -18,7 +17,6 @@ package org.apache.pinot.plugin.inputformat.orc;
  * specific language governing permissions and limitations
  * under the License.
  */
-
 import java.io.File;
 import java.util.List;
 import java.util.Map;
diff --git a/pinot-plugins/pinot-metrics/pinot-dropwizard/src/main/java/org/apache/pinot/plugin/metrics/dropwizard/DropwizardMetricsFactory.java b/pinot-plugins/pinot-metrics/pinot-dropwizard/src/main/java/org/apache/pinot/plugin/metrics/dropwizard/DropwizardMetricsFactory.java
index 4a20f6f..be218d0 100644
--- a/pinot-plugins/pinot-metrics/pinot-dropwizard/src/main/java/org/apache/pinot/plugin/metrics/dropwizard/DropwizardMetricsFactory.java
+++ b/pinot-plugins/pinot-metrics/pinot-dropwizard/src/main/java/org/apache/pinot/plugin/metrics/dropwizard/DropwizardMetricsFactory.java
@@ -34,7 +34,6 @@ public class DropwizardMetricsFactory implements PinotMetricsFactory {
 
   @Override
   public void init(PinotConfiguration metricsConfiguration) {
-
   }
 
   @Override
diff --git a/pinot-plugins/pinot-metrics/pinot-yammer/src/main/java/org/apache/pinot/plugin/metrics/yammer/YammerMetricsFactory.java b/pinot-plugins/pinot-metrics/pinot-yammer/src/main/java/org/apache/pinot/plugin/metrics/yammer/YammerMetricsFactory.java
index 37b0aef..933b796 100644
--- a/pinot-plugins/pinot-metrics/pinot-yammer/src/main/java/org/apache/pinot/plugin/metrics/yammer/YammerMetricsFactory.java
+++ b/pinot-plugins/pinot-metrics/pinot-yammer/src/main/java/org/apache/pinot/plugin/metrics/yammer/YammerMetricsFactory.java
@@ -34,7 +34,6 @@ public class YammerMetricsFactory implements PinotMetricsFactory {
 
   @Override
   public void init(PinotConfiguration metricsConfiguration) {
-
   }
 
   @Override
diff --git a/pinot-plugins/pinot-stream-ingestion/pinot-kafka-0.9/src/main/java/org/apache/pinot/plugin/stream/kafka09/SimpleConsumerFactory.java b/pinot-plugins/pinot-stream-ingestion/pinot-kafka-0.9/src/main/java/org/apache/pinot/plugin/stream/kafka09/SimpleConsumerFactory.java
index 863cfe2..c4cd66a 100644
--- a/pinot-plugins/pinot-stream-ingestion/pinot-kafka-0.9/src/main/java/org/apache/pinot/plugin/stream/kafka09/SimpleConsumerFactory.java
+++ b/pinot-plugins/pinot-stream-ingestion/pinot-kafka-0.9/src/main/java/org/apache/pinot/plugin/stream/kafka09/SimpleConsumerFactory.java
@@ -26,5 +26,4 @@ package org.apache.pinot.plugin.stream.kafka09;
  */
 @Deprecated
 public class SimpleConsumerFactory extends KafkaConsumerFactory {
-
 }
diff --git a/pinot-plugins/pinot-stream-ingestion/pinot-kafka-base/src/main/java/org/apache/pinot/plugin/stream/kafka/KafkaJSONMessageDecoder.java b/pinot-plugins/pinot-stream-ingestion/pinot-kafka-base/src/main/java/org/apache/pinot/plugin/stream/kafka/KafkaJSONMessageDecoder.java
index 0c9126a..cf12fcc 100644
--- a/pinot-plugins/pinot-stream-ingestion/pinot-kafka-base/src/main/java/org/apache/pinot/plugin/stream/kafka/KafkaJSONMessageDecoder.java
+++ b/pinot-plugins/pinot-stream-ingestion/pinot-kafka-base/src/main/java/org/apache/pinot/plugin/stream/kafka/KafkaJSONMessageDecoder.java
@@ -28,5 +28,4 @@ import org.apache.pinot.plugin.inputformat.json.JSONMessageDecoder;
  */
 @Deprecated
 public class KafkaJSONMessageDecoder extends JSONMessageDecoder {
-
 }
diff --git a/pinot-plugins/pinot-stream-ingestion/pinot-kinesis/src/main/java/org/apache/pinot/plugin/stream/kinesis/KinesisMsgOffsetFactory.java b/pinot-plugins/pinot-stream-ingestion/pinot-kinesis/src/main/java/org/apache/pinot/plugin/stream/kinesis/KinesisMsgOffsetFactory.java
index ed325e4..f745b11 100644
--- a/pinot-plugins/pinot-stream-ingestion/pinot-kinesis/src/main/java/org/apache/pinot/plugin/stream/kinesis/KinesisMsgOffsetFactory.java
+++ b/pinot-plugins/pinot-stream-ingestion/pinot-kinesis/src/main/java/org/apache/pinot/plugin/stream/kinesis/KinesisMsgOffsetFactory.java
@@ -31,7 +31,6 @@ public class KinesisMsgOffsetFactory implements StreamPartitionMsgOffsetFactory
 
   @Override
   public void init(StreamConfig streamConfig) {
-
   }
 
   @Override
diff --git a/pinot-plugins/pinot-stream-ingestion/pinot-pulsar/src/main/java/org/apache/pinot/plugin/stream/pulsar/PulsarStreamLevelConsumer.java b/pinot-plugins/pinot-stream-ingestion/pinot-pulsar/src/main/java/org/apache/pinot/plugin/stream/pulsar/PulsarStreamLevelConsumer.java
index 1de7c0b..60272c6 100644
--- a/pinot-plugins/pinot-stream-ingestion/pinot-pulsar/src/main/java/org/apache/pinot/plugin/stream/pulsar/PulsarStreamLevelConsumer.java
+++ b/pinot-plugins/pinot-stream-ingestion/pinot-pulsar/src/main/java/org/apache/pinot/plugin/stream/pulsar/PulsarStreamLevelConsumer.java
@@ -99,7 +99,6 @@ public class PulsarStreamLevelConsumer implements StreamLevelConsumer {
 
   @Override
   public void commit() {
-
   }
 
   @Override
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ChunkCompressorFactory.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ChunkCompressorFactory.java
index f190e11..b2d06b9 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ChunkCompressorFactory.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ChunkCompressorFactory.java
@@ -30,7 +30,6 @@ public class ChunkCompressorFactory {
 
   // Private constructor to avoid object instantiation
   private ChunkCompressorFactory() {
-
   }
 
   /**
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/LZ4Compressor.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/LZ4Compressor.java
index c11e2c2..35c5470 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/LZ4Compressor.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/LZ4Compressor.java
@@ -36,7 +36,6 @@ class LZ4Compressor implements ChunkCompressor {
   static final LZ4Compressor INSTANCE = new LZ4Compressor();
 
   private LZ4Compressor() {
-
   }
 
   @Override
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ZstandardCompressor.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ZstandardCompressor.java
index f53b3cd..d9f6864 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ZstandardCompressor.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ZstandardCompressor.java
@@ -34,7 +34,6 @@ class ZstandardCompressor implements ChunkCompressor {
   static final ZstandardCompressor INSTANCE = new ZstandardCompressor();
 
   private ZstandardCompressor() {
-
   }
 
   @Override
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ZstandardDecompressor.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ZstandardDecompressor.java
index bd71f05..16b9a09 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ZstandardDecompressor.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/io/compression/ZstandardDecompressor.java
@@ -34,7 +34,6 @@ class ZstandardDecompressor implements ChunkDecompressor {
   static final ZstandardDecompressor INSTANCE = new ZstandardDecompressor();
 
   private ZstandardDecompressor() {
-
   }
 
   @Override
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/segment/creator/impl/SegmentColumnarIndexCreator.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/segment/creator/impl/SegmentColumnarIndexCreator.java
index 080e5f8..8c2e1db 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/segment/creator/impl/SegmentColumnarIndexCreator.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/segment/creator/impl/SegmentColumnarIndexCreator.java
@@ -384,7 +384,7 @@ public class SegmentColumnarIndexCreator implements SegmentCreator {
                 forwardIndexCreator.putString((String) columnValueToIndex);
               } else if (columnValueToIndex instanceof byte[]) {
                 forwardIndexCreator.putBytes((byte[]) columnValueToIndex);
-              } 
+              }
               break;
             default:
               throw new IllegalStateException();
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/startree/v2/builder/MultipleTreesBuilder.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/startree/v2/builder/MultipleTreesBuilder.java
index 68303c2..9cbc18f 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/startree/v2/builder/MultipleTreesBuilder.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/startree/v2/builder/MultipleTreesBuilder.java
@@ -144,8 +144,8 @@ public class MultipleTreesBuilder implements Closeable {
       }
 
       // Save the metadata and index maps to the disk
-      // Commons Configuration 1.10 does not support file path containing '%'. 
-      // Explicitly providing the output stream for the file bypasses the problem.       
+      // Commons Configuration 1.10 does not support file path containing '%'.
+      // Explicitly providing the output stream for the file bypasses the problem.
       try (FileOutputStream fileOutputStream = new FileOutputStream(_metadataProperties.getFile())) {
         _metadataProperties.save(fileOutputStream);
       }
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/startree/v2/store/StarTreeIndexMapUtils.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/startree/v2/store/StarTreeIndexMapUtils.java
index 1ed1fd1..da98506 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/startree/v2/store/StarTreeIndexMapUtils.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/startree/v2/store/StarTreeIndexMapUtils.java
@@ -156,8 +156,8 @@ public class StarTreeIndexMapUtils {
       }
     }
 
-    // Commons Configuration 1.10 does not support file path containing '%'. 
-    // Explicitly providing the output stream for the file bypasses the problem.       
+    // Commons Configuration 1.10 does not support file path containing '%'.
+    // Explicitly providing the output stream for the file bypasses the problem.
     try (FileOutputStream fileOutputStream = new FileOutputStream(configuration.getFile())) {
       configuration.save(fileOutputStream);
     } catch (IOException e) {
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/FSTTraversal.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/FSTTraversal.java
index 4ada83d..457b157 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/FSTTraversal.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/FSTTraversal.java
@@ -44,7 +44,7 @@ public final class FSTTraversal {
    *
    * @param reuse The {@link MatchResult} to reuse.
    * @param sequence Input sequence to look for in the automaton.
-   * @param start Start index in the sequence array. 
+   * @param start Start index in the sequence array.
    * @param length Length of the byte sequence, must be at least 1.
    * @param node The node to start traversal from, typically the {@linkplain FST#getRootNode() root node}.
    *
@@ -96,7 +96,7 @@ public final class FSTTraversal {
    * <code>sequence</code> and starting at node <code>node</code>.
    *
    * @param sequence Input sequence to look for in the automaton.
-   * @param start Start index in the sequence array. 
+   * @param start Start index in the sequence array.
    * @param length Length of the byte sequence, must be at least 1.
    * @param node The node to start traversal from, typically the {@linkplain FST#getRootNode() root node}.
    *
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/StateVisitor.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/StateVisitor.java
index eb8e638..69dd058 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/StateVisitor.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/StateVisitor.java
@@ -26,4 +26,4 @@ package org.apache.pinot.segment.local.utils.nativefst;
  */
 public interface StateVisitor {
   boolean accept(int state);
-}
\ No newline at end of file
+}
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/Automaton.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/Automaton.java
index 715cbce..a3beb42 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/Automaton.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/Automaton.java
@@ -37,7 +37,7 @@ import java.util.Set;
  *      or with a singleton string ({@link #expandSingleton()}) in case
  *      the automaton is known to accept exactly one string.
  *      (Implicitly, all states and transitions of an automaton are reachable from its initial state.)
- * <li> Automata are always reduced (see {@link #reduce()}) 
+ * <li> Automata are always reduced (see {@link #reduce()})
  *      and have no transitions to dead states (see {@link #removeDeadTransitions()}).
  * <li> Automata provided as input to operations are generally assumed to be disjoint.
  * </ul>
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/StringUnionOperations.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/StringUnionOperations.java
index 557044b..7b0dcb2 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/StringUnionOperations.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/StringUnionOperations.java
@@ -25,7 +25,7 @@ import java.util.IdentityHashMap;
 
 
 /**
- * Operations for building minimal deterministic automata from sets of strings. 
+ * Operations for building minimal deterministic automata from sets of strings.
  * The algorithm requires sorted input data, but is very fast (nearly linear with the input size).
  *
  * NOTE: This class is not used today but is a fast way of building automata so is kept for future uses
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/Transition.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/Transition.java
index 09439bb..2b74d71 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/Transition.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/automaton/Transition.java
@@ -22,7 +22,7 @@ import java.io.Serializable;
 
 
 /**
- * <tt>Automaton</tt> transition. 
+ * <tt>Automaton</tt> transition.
  * <p>
  * A transition, which belongs to a source state, consists of a Unicode character interval
  * and a destination state.
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/builder/FSTSerializer.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/builder/FSTSerializer.java
index 0f3fb7d..24d0fff 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/builder/FSTSerializer.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/builder/FSTSerializer.java
@@ -34,7 +34,7 @@ public interface FSTSerializer {
    *
    * @param fst The automaton to serialize.
    * @param os The output stream to serialize to.
-   * @param <T> A subclass of {@link OutputStream}, returned for chaining. 
+   * @param <T> A subclass of {@link OutputStream}, returned for chaining.
    * @return Returns <code>T</code> for chaining.
    * @throws IOException Rethrown if an I/O error occurs.
    */
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/builder/FSTUtils.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/builder/FSTUtils.java
index 44d8ed0..6e63811 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/builder/FSTUtils.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/builder/FSTUtils.java
@@ -115,12 +115,12 @@ final class FSTUtils {
   }
 
   /**
-   * Calculate fan-out ratio (how many nodes have a given number of outgoing arcs).  
+   * Calculate fan-out ratio (how many nodes have a given number of outgoing arcs).
    *
    * @param fst The automaton to calculate fanout for.
    *
    * @return The returned map contains keys for the number of outgoing arcs and
-   * an associated value being the number of nodes with that arc number. 
+   * an associated value being the number of nodes with that arc number.
    */
   public static TreeMap<Integer, Integer> calculateFanOuts(final FST fst) {
     final int[] result = new int[256];
@@ -158,7 +158,7 @@ final class FSTUtils {
    *
    * @param fst The automaton to calculate right language for.
    * @return Returns a map with node identifiers as keys and their right language
-   * counts as associated values. 
+   * counts as associated values.
    */
   public static Int2IntOpenHashMap rightLanguageForAllStates(final FST fst) {
     final Int2IntOpenHashMap numbers = new Int2IntOpenHashMap();
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/mutablefst/utils/MutableFSTUtils.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/mutablefst/utils/MutableFSTUtils.java
index 7f41db5..71fccb5 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/mutablefst/utils/MutableFSTUtils.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/mutablefst/utils/MutableFSTUtils.java
@@ -29,7 +29,6 @@ import org.roaringbitmap.buffer.MutableRoaringBitmap;
 public class MutableFSTUtils {
 
   private MutableFSTUtils() {
-
   }
 
   public static boolean fstEquals(Object thisFstObj,
diff --git a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/utils/RealTimeRegexpMatcher.java b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/utils/RealTimeRegexpMatcher.java
index 9c59d15..1fb1f1e 100644
--- a/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/utils/RealTimeRegexpMatcher.java
+++ b/pinot-segment-local/src/main/java/org/apache/pinot/segment/local/utils/nativefst/utils/RealTimeRegexpMatcher.java
@@ -141,4 +141,4 @@ public class RealTimeRegexpMatcher {
       _pathState.add(node.getLabel());
     }
   }
-}
\ No newline at end of file
+}
diff --git a/pinot-segment-spi/src/main/java/org/apache/pinot/segment/spi/index/IndexingOverrides.java b/pinot-segment-spi/src/main/java/org/apache/pinot/segment/spi/index/IndexingOverrides.java
index 9df4650..273a4e9 100644
--- a/pinot-segment-spi/src/main/java/org/apache/pinot/segment/spi/index/IndexingOverrides.java
+++ b/pinot-segment-spi/src/main/java/org/apache/pinot/segment/spi/index/IndexingOverrides.java
@@ -232,7 +232,7 @@ public class IndexingOverrides {
       ensureReaderPresent();
       return READER_DEFAULTS.newTextIndexReader(file, columnMetadata, textIndexProperties);
     }
-    
+
     private void ensureReaderPresent() {
       if (READER_DEFAULTS == null) {
         throw new UnsupportedOperationException("default implementation not present on classpath");
diff --git a/pinot-segment-spi/src/main/java/org/apache/pinot/segment/spi/index/reader/ForwardIndexReader.java b/pinot-segment-spi/src/main/java/org/apache/pinot/segment/spi/index/reader/ForwardIndexReader.java
index c6b9809..b0d74f1 100644
--- a/pinot-segment-spi/src/main/java/org/apache/pinot/segment/spi/index/reader/ForwardIndexReader.java
+++ b/pinot-segment-spi/src/main/java/org/apache/pinot/segment/spi/index/reader/ForwardIndexReader.java
@@ -412,5 +412,4 @@ public interface ForwardIndexReader<T extends ForwardIndexReaderContext> extends
   default int getBytesMV(int docId, byte[][] valueBuffer, T context) {
     throw new UnsupportedOperationException();
   }
-
 }
diff --git a/pinot-server/src/main/java/org/apache/pinot/server/api/resources/ServerResourceUtils.java b/pinot-server/src/main/java/org/apache/pinot/server/api/resources/ServerResourceUtils.java
index c5ab415..986d67d 100644
--- a/pinot-server/src/main/java/org/apache/pinot/server/api/resources/ServerResourceUtils.java
+++ b/pinot-server/src/main/java/org/apache/pinot/server/api/resources/ServerResourceUtils.java
@@ -32,7 +32,6 @@ public class ServerResourceUtils {
 
   // Disable instantiation.
   private ServerResourceUtils() {
-
   }
 
   public static TableDataManager checkGetTableDataManager(ServerInstance serverInstance, String tableName) {
diff --git a/pinot-server/src/test/java/org/apache/pinot/server/starter/helix/OffsetBasedConsumptionStatusCheckerTest.java b/pinot-server/src/test/java/org/apache/pinot/server/starter/helix/OffsetBasedConsumptionStatusCheckerTest.java
index f717d09..1209bf0 100644
--- a/pinot-server/src/test/java/org/apache/pinot/server/starter/helix/OffsetBasedConsumptionStatusCheckerTest.java
+++ b/pinot-server/src/test/java/org/apache/pinot/server/starter/helix/OffsetBasedConsumptionStatusCheckerTest.java
@@ -248,4 +248,4 @@ public class OffsetBasedConsumptionStatusCheckerTest {
     when(segMngrB0.getCurrentOffset()).thenReturn(new LongMsgOffset(3000));
     assertEquals(statusChecker.getNumConsumingSegmentsNotReachedTheirLatestOffset(), 1);
   }
-}
\ No newline at end of file
+}
diff --git a/pinot-spi/src/main/java/org/apache/pinot/spi/crypt/NoOpPinotCrypter.java b/pinot-spi/src/main/java/org/apache/pinot/spi/crypt/NoOpPinotCrypter.java
index 8b5e799..5ac7616 100644
--- a/pinot-spi/src/main/java/org/apache/pinot/spi/crypt/NoOpPinotCrypter.java
+++ b/pinot-spi/src/main/java/org/apache/pinot/spi/crypt/NoOpPinotCrypter.java
@@ -34,7 +34,6 @@ public class NoOpPinotCrypter implements PinotCrypter {
 
   @Override
   public void init(PinotConfiguration config) {
-
   }
 
   @Override
diff --git a/pinot-spi/src/main/java/org/apache/pinot/spi/crypt/PinotCrypterFactory.java b/pinot-spi/src/main/java/org/apache/pinot/spi/crypt/PinotCrypterFactory.java
index 38d8999..2469f98 100644
--- a/pinot-spi/src/main/java/org/apache/pinot/spi/crypt/PinotCrypterFactory.java
+++ b/pinot-spi/src/main/java/org/apache/pinot/spi/crypt/PinotCrypterFactory.java
@@ -39,7 +39,6 @@ public class PinotCrypterFactory {
 
   // Prevent factory from being instantiated
   private PinotCrypterFactory() {
-
   }
 
   /**
diff --git a/pinot-spi/src/main/java/org/apache/pinot/spi/data/readers/RecordReaderConfig.java b/pinot-spi/src/main/java/org/apache/pinot/spi/data/readers/RecordReaderConfig.java
index 641205e..6bb7153 100644
--- a/pinot-spi/src/main/java/org/apache/pinot/spi/data/readers/RecordReaderConfig.java
+++ b/pinot-spi/src/main/java/org/apache/pinot/spi/data/readers/RecordReaderConfig.java
@@ -19,5 +19,4 @@
 package org.apache.pinot.spi.data.readers;
 
 public interface RecordReaderConfig {
-
 }
diff --git a/pinot-spi/src/main/java/org/apache/pinot/spi/env/CommonsConfigurationUtils.java b/pinot-spi/src/main/java/org/apache/pinot/spi/env/CommonsConfigurationUtils.java
index 13a865a..5d8c881 100644
--- a/pinot-spi/src/main/java/org/apache/pinot/spi/env/CommonsConfigurationUtils.java
+++ b/pinot-spi/src/main/java/org/apache/pinot/spi/env/CommonsConfigurationUtils.java
@@ -49,8 +49,8 @@ public abstract class CommonsConfigurationUtils {
     try {
       PropertiesConfiguration propertiesConfiguration = new PropertiesConfiguration();
 
-      // Commons Configuration 1.10 does not support file path containing '%'. 
-      // Explicitly providing the input stream on load bypasses the problem. 
+      // Commons Configuration 1.10 does not support file path containing '%'.
+      // Explicitly providing the input stream on load bypasses the problem.
       propertiesConfiguration.setFile(file);
       if (file.exists()) {
         propertiesConfiguration.load(new FileInputStream(file));
diff --git a/pinot-spi/src/main/java/org/apache/pinot/spi/env/PinotConfiguration.java b/pinot-spi/src/main/java/org/apache/pinot/spi/env/PinotConfiguration.java
index f6ec539..c075356 100644
--- a/pinot-spi/src/main/java/org/apache/pinot/spi/env/PinotConfiguration.java
+++ b/pinot-spi/src/main/java/org/apache/pinot/spi/env/PinotConfiguration.java
@@ -42,7 +42,7 @@ import org.apache.pinot.spi.utils.Obfuscator;
  * Provides a configuration abstraction for Pinot to decouple services from configuration sources and frameworks.
  * </p>
  * <p>
- * Pinot services may retreived configurations from PinotConfiguration independently from any source of configuration. 
+ * Pinot services may retreived configurations from PinotConfiguration independently from any source of configuration.
  * {@link PinotConfiguration} currently supports configuration loaded from the following sources :
  *
  * <ul>
@@ -121,9 +121,9 @@ public class PinotConfiguration {
   }
 
   /**
-   * Creates a new instance with existing properties provided through a map as well as environment variables. 
-   * Base properties will have priority offers properties defined in environment variables. Keys will be 
-   * sanitized for relaxed binding. See {@link PinotConfiguration} for further details. 
+   * Creates a new instance with existing properties provided through a map as well as environment variables.
+   * Base properties will have priority offers properties defined in environment variables. Keys will be
+   * sanitized for relaxed binding. See {@link PinotConfiguration} for further details.
    *
    * @param baseProperties with highest precedences (e.g. CLI arguments)
    * @param environmentVariables as a {@link Map}. Can be provided with {@link SystemEnvironment}
@@ -133,7 +133,7 @@ public class PinotConfiguration {
   }
 
   /**
-   * Helper constructor to create an instance from configurations found in a PinotFSSpec instance. 
+   * Helper constructor to create an instance from configurations found in a PinotFSSpec instance.
    * Intended for use by Job Runners
    *
    * @param pinotFSSpec
@@ -241,7 +241,7 @@ public class PinotConfiguration {
   }
 
   /**
-   * Creates a new instance of {@link PinotConfiguration} by closing the underlying {@link CompositeConfiguration}. 
+   * Creates a new instance of {@link PinotConfiguration} by closing the underlying {@link CompositeConfiguration}.
    * Useful to mutate configurations {@link PinotConfiguration} without impacting the original configurations.
    *
    *  @return a new {@link PinotConfiguration} instance with a cloned {@link CompositeConfiguration}.
@@ -252,7 +252,7 @@ public class PinotConfiguration {
 
   /**
    * Check if the configuration contains the specified key after being sanitized.
-   * @param key to sanitized and lookup 
+   * @param key to sanitized and lookup
    * @return true if key exists.
    */
   public boolean containsKey(String key) {
@@ -272,7 +272,7 @@ public class PinotConfiguration {
    *
    * If multiple properties exists with the same key, all values will be joined as a comma separated String.
    *
-   * @param name of the property to retrieve a value. Property name will be sanitized. 
+   * @param name of the property to retrieve a value. Property name will be sanitized.
    * @return the property String value. Null if missing.
    */
   public String getProperty(String name) {
@@ -283,7 +283,7 @@ public class PinotConfiguration {
    * Retrieves a boolean value with the given property name. See {@link PinotConfiguration} for supported key naming
    * conventions.
    *
-   * @param name of the property to retrieve a value. Property name will be sanitized. 
+   * @param name of the property to retrieve a value. Property name will be sanitized.
    * @return the property boolean value. Fallback to default value if missing.
    */
   public boolean getProperty(String name, boolean defaultValue) {
@@ -296,7 +296,7 @@ public class PinotConfiguration {
    *
    * @param name of the property to retrieve a value. Property name will be sanitized.
    * @param returnType a class reference of the value type.
-   * @return the typed configuration value. Null if missing. 
+   * @return the typed configuration value. Null if missing.
    */
   public <T> T getProperty(String name, Class<T> returnType) {
     return getProperty(name, null, returnType);
@@ -306,7 +306,7 @@ public class PinotConfiguration {
    * Retrieves a double value with the given property name. See {@link PinotConfiguration} for supported key naming
    * conventions.
    *
-   * @param name of the property to retrieve a value. Property name will be sanitized. 
+   * @param name of the property to retrieve a value. Property name will be sanitized.
    * @return the property double value. Fallback to default value if missing.
    */
   public double getProperty(String name, double defaultValue) {
@@ -317,7 +317,7 @@ public class PinotConfiguration {
    * Retrieves a integer value with the given property name. See {@link PinotConfiguration} for supported key naming
    * conventions.
    *
-   * @param name of the property to retrieve a value. Property name will be sanitized. 
+   * @param name of the property to retrieve a value. Property name will be sanitized.
    * @return the property integer value. Fallback to default value if missing.
    */
   public int getProperty(String name, int defaultValue) {
@@ -328,7 +328,7 @@ public class PinotConfiguration {
    * Retrieves a list of String values with the given property name. See {@link PinotConfiguration} for supported key
    * naming conventions.
    *
-   * @param name of the property to retrieve a list of values. Property name will be sanitized. 
+   * @param name of the property to retrieve a list of values. Property name will be sanitized.
    * @return the property String value. Fallback to the provided default values if no property is found.
    */
   public List<String> getProperty(String name, List<String> defaultValues) {
@@ -341,7 +341,7 @@ public class PinotConfiguration {
    * Retrieves a long value with the given property name. See {@link PinotConfiguration} for supported key naming
    * conventions.
    *
-   * @param name of the property to retrieve a value. Property name will be sanitized. 
+   * @param name of the property to retrieve a value. Property name will be sanitized.
    * @return the property long value. Fallback to default value if missing.
    */
   public long getProperty(String name, long defaultValue) {
@@ -352,7 +352,7 @@ public class PinotConfiguration {
    * Retrieves a String value with the given property name. See {@link PinotConfiguration} for supported key naming
    * conventions.
    *
-   * @param name of the property to retrieve a value. Property name will be sanitized. 
+   * @param name of the property to retrieve a value. Property name will be sanitized.
    * @return the property String value. Fallback to default value if missing.
    */
   public String getProperty(String name, String defaultValue) {
@@ -377,7 +377,7 @@ public class PinotConfiguration {
   }
 
   /**
-   * Returns the raw object stored within the underlying {@link CompositeConfiguration}. 
+   * Returns the raw object stored within the underlying {@link CompositeConfiguration}.
    *
    * See {@link PinotConfiguration} for supported key naming conventions.
    *
@@ -389,7 +389,7 @@ public class PinotConfiguration {
   }
 
   /**
-   * Returns the raw object stored within the underlying {@link CompositeConfiguration}. 
+   * Returns the raw object stored within the underlying {@link CompositeConfiguration}.
    *
    * See {@link PinotConfiguration} for supported key naming conventions.
    *
@@ -426,7 +426,7 @@ public class PinotConfiguration {
 
   /**
    * <p>
-   * Creates a copy of the configuration only containing properties matching a property prefix. 
+   * Creates a copy of the configuration only containing properties matching a property prefix.
    * Changes made on the source {@link PinotConfiguration} will not be available in the subset instance
    * since properties are copied.
    * </p>
@@ -436,7 +436,7 @@ public class PinotConfiguration {
    * </p>
    *
    * @param prefix of the properties to copy. Applies relaxed binding on the properties prefix.
-   * @return a new {@link PinotConfiguration} instance with 
+   * @return a new {@link PinotConfiguration} instance with
    */
   public PinotConfiguration subset(String prefix) {
     return new PinotConfiguration(_configuration.subset(relaxPropertyName(prefix)));
diff --git a/pinot-spi/src/main/java/org/apache/pinot/spi/plugin/PluginClassLoader.java b/pinot-spi/src/main/java/org/apache/pinot/spi/plugin/PluginClassLoader.java
index dda1cf8..5a575f0 100644
--- a/pinot-spi/src/main/java/org/apache/pinot/spi/plugin/PluginClassLoader.java
+++ b/pinot-spi/src/main/java/org/apache/pinot/spi/plugin/PluginClassLoader.java
@@ -37,7 +37,7 @@ public class PluginClassLoader extends URLClassLoader {
   public PluginClassLoader(URL[] urls, ClassLoader parent) {
     super(urls, parent);
     _classLoader = PluginClassLoader.class.getClassLoader();
-    
+
     /**
      * ClassLoader in java9+ does not extend URLClassLoader.
      * If the class is not found in the parent classloader,
@@ -53,7 +53,6 @@ public class PluginClassLoader extends URLClassLoader {
         //this should never happen
         ExceptionUtils.rethrow(e);
       }
-      
       _addUrlMethod.setAccessible(true);
     }
 
diff --git a/pinot-spi/src/main/java/org/apache/pinot/spi/plugin/PluginManager.java b/pinot-spi/src/main/java/org/apache/pinot/spi/plugin/PluginManager.java
index 05e8215..084ffc6 100644
--- a/pinot-spi/src/main/java/org/apache/pinot/spi/plugin/PluginManager.java
+++ b/pinot-spi/src/main/java/org/apache/pinot/spi/plugin/PluginManager.java
@@ -193,8 +193,7 @@ public class PluginManager {
       Collection<File> jarFiles = FileUtils.listFiles(
           new File(pluginsDirectory),
           new String[]{JAR_FILE_EXTENSION},
-          true
-      );
+          true);
       List<String> pluginsToLoad = null;
       if (!StringUtils.isEmpty(pluginsInclude)) {
         pluginsToLoad = Arrays.asList(pluginsInclude.split(";"));
@@ -226,7 +225,6 @@ public class PluginManager {
   }
 
   private void initRecordReaderClassMap() {
-
   }
 
   /**
diff --git a/pinot-spi/src/main/java/org/apache/pinot/spi/stream/OffsetCriteria.java b/pinot-spi/src/main/java/org/apache/pinot/spi/stream/OffsetCriteria.java
index 14cb6a4..f43a7b2 100644
--- a/pinot-spi/src/main/java/org/apache/pinot/spi/stream/OffsetCriteria.java
+++ b/pinot-spi/src/main/java/org/apache/pinot/spi/stream/OffsetCriteria.java
@@ -56,7 +56,6 @@ public class OffsetCriteria {
   private String _offsetString;
 
   private OffsetCriteria() {
-
   }
 
   private void setOffsetType(OffsetType offsetType) {
diff --git a/pinot-spi/src/main/java/org/apache/pinot/spi/stream/PartitionGroupConsumer.java b/pinot-spi/src/main/java/org/apache/pinot/spi/stream/PartitionGroupConsumer.java
index 8e9308e..67c35c1 100644
--- a/pinot-spi/src/main/java/org/apache/pinot/spi/stream/PartitionGroupConsumer.java
+++ b/pinot-spi/src/main/java/org/apache/pinot/spi/stream/PartitionGroupConsumer.java
@@ -40,7 +40,6 @@ public interface PartitionGroupConsumer extends Closeable {
    * @param startOffset Offset (inclusive) at which the consumption should begin
    */
   default void start(StreamPartitionMsgOffset startOffset) {
-
   }
 
   /**
diff --git a/pinot-spi/src/main/java/org/apache/pinot/spi/utils/Obfuscator.java b/pinot-spi/src/main/java/org/apache/pinot/spi/utils/Obfuscator.java
index cd36245..5a71889 100644
--- a/pinot-spi/src/main/java/org/apache/pinot/spi/utils/Obfuscator.java
+++ b/pinot-spi/src/main/java/org/apache/pinot/spi/utils/Obfuscator.java
@@ -106,9 +106,7 @@ public final class Obfuscator {
       } else {
         node = JsonUtils.objectToJsonNode(object);
       }
-
       return toJsonRecursive(node);
-
     } catch (IOException e) {
       throw new RuntimeException(e);
     }
diff --git a/pinot-spi/src/test/java/org/apache/pinot/spi/env/PinotConfigurationTest.java b/pinot-spi/src/test/java/org/apache/pinot/spi/env/PinotConfigurationTest.java
index 188a720..240eb4f 100644
--- a/pinot-spi/src/test/java/org/apache/pinot/spi/env/PinotConfigurationTest.java
+++ b/pinot-spi/src/test/java/org/apache/pinot/spi/env/PinotConfigurationTest.java
@@ -155,11 +155,11 @@ public class PinotConfigurationTest {
     // Tests that config.paths properties provided through environment variables are available.
     Assert.assertEquals(configuration.getProperty("controller.timeout"), "config-path-2-timeout");
 
-    // Tests a priority of a property available in both config files of a config.paths array. 
+    // Tests a priority of a property available in both config files of a config.paths array.
     Assert.assertEquals(configuration.getProperty("controller.config-paths-multi-value-test-1"),
         "config-path-2-config-paths-multi-value-test-1");
 
-    // Tests properties provided through the last config file of a config.paths array. 
+    // Tests properties provided through the last config file of a config.paths array.
     Assert.assertEquals(configuration.getProperty("controller.config-paths-multi-value-test-2"),
         "config-path-3-config-paths-multi-value-test-2");
 
@@ -203,7 +203,7 @@ public class PinotConfigurationTest {
     Assert.assertEquals(pinotConfiguration.getProperty("config.property.2"), "val2");
     Assert.assertEquals(pinotConfiguration.getProperty("config.property.3"), "val3");
 
-    // Asserts no error occurs when no configuration is provided in the spec. 
+    // Asserts no error occurs when no configuration is provided in the spec.
     new PinotConfiguration(new PinotFSSpec());
   }
 
diff --git a/pinot-spi/src/test/java/org/apache/pinot/spi/filesystem/LocalPinotFSTest.java b/pinot-spi/src/test/java/org/apache/pinot/spi/filesystem/LocalPinotFSTest.java
index c4bc5d2..85e7059 100644
--- a/pinot-spi/src/test/java/org/apache/pinot/spi/filesystem/LocalPinotFSTest.java
+++ b/pinot-spi/src/test/java/org/apache/pinot/spi/filesystem/LocalPinotFSTest.java
@@ -210,7 +210,6 @@ public class LocalPinotFSTest {
       localPinotFS.length(firstTempDir.toURI());
       fail();
     } catch (IllegalArgumentException e) {
-
     }
   }
 }
diff --git a/pinot-spi/src/test/java/org/apache/pinot/spi/filesystem/PinotFSTest.java b/pinot-spi/src/test/java/org/apache/pinot/spi/filesystem/PinotFSTest.java
index 9e9cfed..d44925b 100644
--- a/pinot-spi/src/test/java/org/apache/pinot/spi/filesystem/PinotFSTest.java
+++ b/pinot-spi/src/test/java/org/apache/pinot/spi/filesystem/PinotFSTest.java
@@ -145,13 +145,11 @@ public class PinotFSTest {
     @Override
     public void copyToLocalFile(URI srcUri, File dstFile)
         throws Exception {
-
     }
 
     @Override
     public void copyFromLocalFile(File srcFile, URI dstUri)
         throws Exception {
-
     }
 
     @Override
diff --git a/pinot-spi/src/test/resources/TestRecordReader.java b/pinot-spi/src/test/resources/TestRecordReader.java
index 1a37679..02576fa 100644
--- a/pinot-spi/src/test/resources/TestRecordReader.java
+++ b/pinot-spi/src/test/resources/TestRecordReader.java
@@ -68,6 +68,5 @@ public class TestRecordReader implements RecordReader {
   }
 
   public void close() {
-
   }
 }
diff --git a/pinot-spi/src/test/resources/pinot-configuration-1.properties b/pinot-spi/src/test/resources/pinot-configuration-1.properties
index 0f8ff51..297b152 100644
--- a/pinot-spi/src/test/resources/pinot-configuration-1.properties
+++ b/pinot-spi/src/test/resources/pinot-configuration-1.properties
@@ -25,4 +25,4 @@ pinot.server.storage.factory.class.s3=org.apache.pinot.plugin.filesystem.S3Pinot
 pinot.server.segment.fetcher.protocols=file,http,s3
 pinot.server.segment.fetcher.s3.class=org.apache.pinot.common.utils.fetcher.PinotFSSegmentFetcher
 pinot.server.instance.dataDir=/home/ubuntu/pinot/data
-pinot.server.instance.segmentTarDir=/home/ubuntu/pinot/segments
\ No newline at end of file
+pinot.server.instance.segmentTarDir=/home/ubuntu/pinot/segments
diff --git a/pinot-spi/src/test/resources/pinot-configuration-2.properties b/pinot-spi/src/test/resources/pinot-configuration-2.properties
index 27d2e90..43fd17f 100644
--- a/pinot-spi/src/test/resources/pinot-configuration-2.properties
+++ b/pinot-spi/src/test/resources/pinot-configuration-2.properties
@@ -21,4 +21,4 @@ controller.host=config-path-2-controller-host
 controller.port=config-path-2-controller-port
 controller.cluster-name=config-path-2-cluster-name
 controller.timeout=config-path-2-timeout
-controller.config-paths-multi-value-test-1=config-path-2-config-paths-multi-value-test-1
\ No newline at end of file
+controller.config-paths-multi-value-test-1=config-path-2-config-paths-multi-value-test-1
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/AbstractBaseCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/AbstractBaseCommand.java
index 3f651ae..af4db1d 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/AbstractBaseCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/AbstractBaseCommand.java
@@ -35,7 +35,6 @@ public class AbstractBaseCommand {
   }
 
   public AbstractBaseCommand() {
-
   }
 
   public String getName() {
@@ -48,7 +47,6 @@ public class AbstractBaseCommand {
   }
 
   public void printExamples() {
-
   }
 
   public void cleanup() {
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/AutoAddInvertedIndexTool.java b/pinot-tools/src/main/java/org/apache/pinot/tools/AutoAddInvertedIndexTool.java
index 0b14db5..e39eb59 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/AutoAddInvertedIndexTool.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/AutoAddInvertedIndexTool.java
@@ -31,37 +31,37 @@ public class AutoAddInvertedIndexTool extends AbstractBaseCommand implements Com
   @CommandLine.Option(names = {"-clusterName"}, required = true, description = "Pinot cluster name")
   private String _clusterName;
 
-  @CommandLine.Option(names = {"-controllerAddress"}, required = true, 
+  @CommandLine.Option(names = {"-controllerAddress"}, required = true,
       description = "Address of the Pinot controller (host:port)")
   private String _controllerAddress;
 
-  @CommandLine.Option(names = {"-brokerAddress"}, required = true, 
+  @CommandLine.Option(names = {"-brokerAddress"}, required = true,
       description = "Address of the Pinot broker (host:port)")
   private String _brokerAddress;
 
-  @CommandLine.Option(names = {"-strategy"}, required = false, 
+  @CommandLine.Option(names = {"-strategy"}, required = false,
       description = "Strategy to add inverted index (QUERY), default: QUERY")
   private AutoAddInvertedIndex.Strategy _strategy = AutoAddInvertedIndex.Strategy.QUERY;
 
-  @CommandLine.Option(names = {"-mode"}, required = false, 
+  @CommandLine.Option(names = {"-mode"}, required = false,
       description = "Mode to add inverted index (NEW|REMOVE|REFRESH|APPEND), default: NEW")
   private AutoAddInvertedIndex.Mode _mode = AutoAddInvertedIndex.Mode.NEW;
 
-  @CommandLine.Option(names = {"-tableNamePattern"}, required = false, 
+  @CommandLine.Option(names = {"-tableNamePattern"}, required = false,
       description = "Optional table name pattern trigger to add inverted index, default: null (match any table name)")
   private String _tableNamePattern = null;
 
-  @CommandLine.Option(names = {"-tableSizeThreshold"}, required = false, 
+  @CommandLine.Option(names = {"-tableSizeThreshold"}, required = false,
       description = "Optional table size threshold to trigger adding inverted index, default: "
           + AutoAddInvertedIndex.DEFAULT_TABLE_SIZE_THRESHOLD)
   private long _tableSizeThreshold = AutoAddInvertedIndex.DEFAULT_TABLE_SIZE_THRESHOLD;
 
-  @CommandLine.Option(names = {"-cardinalityThreshold"}, required = false, 
+  @CommandLine.Option(names = {"-cardinalityThreshold"}, required = false,
       description = "Optional cardinality threshold to trigger adding inverted index, default: "
           + AutoAddInvertedIndex.DEFAULT_CARDINALITY_THRESHOLD)
   private long _cardinalityThreshold = AutoAddInvertedIndex.DEFAULT_CARDINALITY_THRESHOLD;
 
-  @CommandLine.Option(names = {"-maxNumInvertedIndex"}, required = false, 
+  @CommandLine.Option(names = {"-maxNumInvertedIndex"}, required = false,
       description = "Optional max number of inverted index added, default: "
           + AutoAddInvertedIndex.DEFAULT_MAX_NUM_INVERTED_INDEX_ADDED)
   private int _maxNumInvertedIndex = AutoAddInvertedIndex.DEFAULT_MAX_NUM_INVERTED_INDEX_ADDED;
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/UpdateSegmentState.java b/pinot-tools/src/main/java/org/apache/pinot/tools/UpdateSegmentState.java
index f166707..8ed14b0 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/UpdateSegmentState.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/UpdateSegmentState.java
@@ -54,7 +54,7 @@ public class UpdateSegmentState extends AbstractBaseCommand implements Command {
   @CommandLine.Option(names = {"-tenantName"}, required = false, description = "Name of tenant.")
   private String _tenantName;
 
-  @CommandLine.Option(names = {"-tableName"}, required = false, 
+  @CommandLine.Option(names = {"-tableName"}, required = false,
       description = "Name of the table (e.g. foo_table_OFFLINE).")
   private String _tableName;
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/ValidateTableRetention.java b/pinot-tools/src/main/java/org/apache/pinot/tools/ValidateTableRetention.java
index 80acf8c..4f6cce9 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/ValidateTableRetention.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/ValidateTableRetention.java
@@ -31,11 +31,11 @@ public class ValidateTableRetention extends AbstractBaseCommand implements Comma
   @CommandLine.Option(names = {"-clusterName"}, required = true, description = "Pinot cluster name")
   private String _clusterName;
 
-  @CommandLine.Option(names = {"-tableNamePattern"}, required = false, 
+  @CommandLine.Option(names = {"-tableNamePattern"}, required = false,
       description = "Optional table name pattern trigger to add inverted index, default: null (match any table name)")
   private String _tableNamePattern = null;
 
-  @CommandLine.Option(names = {"-durationInDaysThreshold"}, required = false, 
+  @CommandLine.Option(names = {"-durationInDaysThreshold"}, required = false,
       description = "Optional duration in days threshold to log a warning for table with too large retention time,"
           + " default: " + TableRetentionValidator.DEFAULT_DURATION_IN_DAYS_THRESHOLD)
   private long _durationInDaysThreshold = TableRetentionValidator.DEFAULT_DURATION_IN_DAYS_THRESHOLD;
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/AddSchemaCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/AddSchemaCommand.java
index 95d618d..83fe31e 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/AddSchemaCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/AddSchemaCommand.java
@@ -89,7 +89,6 @@ public class AddSchemaCommand extends AbstractBaseAdminCommand implements Comman
 
   @Override
   public void cleanup() {
-
   }
 
   public AddSchemaCommand setControllerHost(String controllerHost) {
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/AnonymizeDataCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/AnonymizeDataCommand.java
index 3c9f3c9..b120e45 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/AnonymizeDataCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/AnonymizeDataCommand.java
@@ -40,7 +40,7 @@ public class AnonymizeDataCommand extends AbstractBaseAdminCommand implements Co
           + "whether the tool should extract the filter columns, generate data or generate queries")
   private String _action;
 
-  @CommandLine.Option(names = {"-inputSegmentsDir"}, 
+  @CommandLine.Option(names = {"-inputSegmentsDir"},
       description = "Absolute path of directory containing Pinot table segments")
   private String _inputSegmentsDir;
 
@@ -54,7 +54,7 @@ public class AnonymizeDataCommand extends AbstractBaseAdminCommand implements Co
   @CommandLine.Option(names = {"-tableName"}, description = "Table name to use for generating queries")
   private String _tableName;
 
-  @CommandLine.Option(names = {"-queryDir"}, 
+  @CommandLine.Option(names = {"-queryDir"},
       description = "Absolute path of directory containing the original query file and where the generated query file"
           + " will be written into")
   private String _queryDir;
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/BootstrapTableCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/BootstrapTableCommand.java
index 8a947c6..a6accd2 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/BootstrapTableCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/BootstrapTableCommand.java
@@ -113,7 +113,6 @@ public class BootstrapTableCommand extends AbstractBaseAdminCommand implements C
 
   @Override
   public void cleanup() {
-
   }
 
   @Override
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ChangeNumReplicasCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ChangeNumReplicasCommand.java
index c33c579..e420392 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ChangeNumReplicasCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ChangeNumReplicasCommand.java
@@ -35,7 +35,7 @@ public class ChangeNumReplicasCommand extends AbstractBaseAdminCommand implement
   @CommandLine.Option(names = {"-clusterName"}, required = false, description = "Pinot cluster name.")
   private String _clusterName = "PinotCluster";
 
-  @CommandLine.Option(names = {"-tableName"}, required = true, 
+  @CommandLine.Option(names = {"-tableName"}, required = true,
       description = "Table name to rebalance (e.g. myTable_OFFLINE)")
   private String _tableName;
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ChangeTableState.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ChangeTableState.java
index 8a89b59..d098935 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ChangeTableState.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ChangeTableState.java
@@ -114,6 +114,5 @@ public class ChangeTableState extends AbstractBaseAdminCommand implements Comman
 
   @Override
   public void cleanup() {
-
   }
 }
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/CreateSegmentCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/CreateSegmentCommand.java
index 70bcae9..4263f4b 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/CreateSegmentCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/CreateSegmentCommand.java
@@ -74,7 +74,7 @@ public class CreateSegmentCommand extends AbstractBaseAdminCommand implements Co
   @CommandLine.Option(names = {"-readerConfigFile"}, description = "Config file for record reader.")
   private String _readerConfigFile;
 
-  @CommandLine.Option(names = {"-retry"}, 
+  @CommandLine.Option(names = {"-retry"},
       description = "Number of retries if encountered any segment creation failure, default is 0.")
   private int _retry = 0;
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/DeleteClusterCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/DeleteClusterCommand.java
index e229d6d..7099e9a 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/DeleteClusterCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/DeleteClusterCommand.java
@@ -61,7 +61,6 @@ public class DeleteClusterCommand extends AbstractBaseAdminCommand implements Co
 
   @Override
   public void cleanup() {
-
   }
 
   public DeleteClusterCommand setClusterName(String clusterName) {
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/GenerateDataCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/GenerateDataCommand.java
index b5cc1a8..d869b1b 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/GenerateDataCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/GenerateDataCommand.java
@@ -64,7 +64,7 @@ public class GenerateDataCommand extends AbstractBaseAdminCommand implements Com
   @CommandLine.Option(names = {"-schemaFile"}, required = true, description = "File containing schema for data.")
   private String _schemaFile = null;
 
-  @CommandLine.Option(names = {"-schemaAnnotationFile"}, required = false, 
+  @CommandLine.Option(names = {"-schemaAnnotationFile"}, required = false,
       description = "File containing dim/metrics for columns.")
   private String _schemaAnnFile;
 
@@ -108,7 +108,6 @@ public class GenerateDataCommand extends AbstractBaseAdminCommand implements Com
 
   @Override
   public void cleanup() {
-
   }
 
   @Override
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ImportDataCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ImportDataCommand.java
index b2edc3d..3a4a8c3 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ImportDataCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ImportDataCommand.java
@@ -85,7 +85,7 @@ public class ImportDataCommand extends AbstractBaseAdminCommand implements Comma
   @CommandLine.Option(names = {"-authToken"}, required = false, description = "Http auth token.")
   private String _authToken;
 
-  @CommandLine.Option(names = {"-tempDir"}, 
+  @CommandLine.Option(names = {"-tempDir"},
       description = "Temporary directory used to hold data during segment creation.")
   private String _tempDir = new File(FileUtils.getTempDirectory(), getClass().getSimpleName()).getAbsolutePath();
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/MoveReplicaGroup.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/MoveReplicaGroup.java
index dc4076c..2c72d5a 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/MoveReplicaGroup.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/MoveReplicaGroup.java
@@ -88,7 +88,7 @@ public class MoveReplicaGroup extends AbstractBaseAdminCommand implements Comman
       description = "Zookeeper cluster path(Ex: /pinot")
   private String _zkPath;
 
-  @CommandLine.Option(names = {"-exec"}, required = false, 
+  @CommandLine.Option(names = {"-exec"}, required = false,
       description = "Execute replica group move. dryRun(default) if not specified")
   private boolean _exec = false;
 
@@ -121,7 +121,6 @@ public class MoveReplicaGroup extends AbstractBaseAdminCommand implements Comman
 
   @Override
   public void cleanup() {
-
   }
 
   public boolean execute()
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/OfflineSegmentIntervalCheckerCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/OfflineSegmentIntervalCheckerCommand.java
index ab73bb9..cf0aaba 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/OfflineSegmentIntervalCheckerCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/OfflineSegmentIntervalCheckerCommand.java
@@ -56,7 +56,7 @@ public class OfflineSegmentIntervalCheckerCommand extends AbstractBaseAdminComma
   @CommandLine.Option(names = {"-clusterName"}, required = true, description = "Helix cluster name")
   private String _clusterName;
 
-  @CommandLine.Option(names = {"-tableNames"}, 
+  @CommandLine.Option(names = {"-tableNames"},
       description = "Comma separated list of tables to check for invalid segment intervals")
   private String _tableNames;
 
@@ -80,7 +80,6 @@ public class OfflineSegmentIntervalCheckerCommand extends AbstractBaseAdminComma
 
   @Override
   public void cleanup() {
-
   }
 
   @Override
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/OperateClusterConfigCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/OperateClusterConfigCommand.java
index 266dcda..35fe6db 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/OperateClusterConfigCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/OperateClusterConfigCommand.java
@@ -58,7 +58,7 @@ public class OperateClusterConfigCommand extends AbstractBaseAdminCommand implem
   @CommandLine.Option(names = {"-config"}, description = "Cluster config to operate.")
   private String _config;
 
-  @CommandLine.Option(names = {"-operation"}, required = true, 
+  @CommandLine.Option(names = {"-operation"}, required = true,
       description = "Operation to take for Cluster config, currently support GET/ADD/UPDATE/DELETE.")
   private String _operation;
 
@@ -89,7 +89,6 @@ public class OperateClusterConfigCommand extends AbstractBaseAdminCommand implem
 
   @Override
   public void cleanup() {
-
   }
 
   @Override
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/PostQueryCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/PostQueryCommand.java
index f78764a..686ddbc 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/PostQueryCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/PostQueryCommand.java
@@ -79,7 +79,6 @@ public class PostQueryCommand extends AbstractBaseAdminCommand implements Comman
 
   @Override
   public void cleanup() {
-
   }
 
   @Override
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/RealtimeProvisioningHelperCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/RealtimeProvisioningHelperCommand.java
index 26185c8..975d70f 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/RealtimeProvisioningHelperCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/RealtimeProvisioningHelperCommand.java
@@ -59,36 +59,36 @@ public class RealtimeProvisioningHelperCommand extends AbstractBaseAdminCommand
   @CommandLine.Option(names = {"-tableConfigFile"}, required = true)
   private String _tableConfigFile;
 
-  @CommandLine.Option(names = {"-numPartitions"}, required = true, 
+  @CommandLine.Option(names = {"-numPartitions"}, required = true,
       description = "number of stream partitions for the table")
   private int _numPartitions;
 
-  @CommandLine.Option(names = {"-retentionHours"}, 
+  @CommandLine.Option(names = {"-retentionHours"},
       description = "Number of recent hours queried most often" + "\n\t(-pushFrequency is ignored)")
   private int _retentionHours;
 
-  @CommandLine.Option(names = {"-pushFrequency"}, 
+  @CommandLine.Option(names = {"-pushFrequency"},
       description = "Frequency with which offline table pushes happen, if this is a hybrid table"
           + "\n\t(hourly,daily,weekly,monthly). Do not specify if realtime-only table")
   private String _pushFrequency;
 
-  @CommandLine.Option(names = {"-numHosts"}, 
+  @CommandLine.Option(names = {"-numHosts"},
       description = "number of hosts as comma separated values (default 2,4,6,8,10,12,14,16)")
   private String _numHosts = "2,4,6,8,10,12,14,16";
 
-  @CommandLine.Option(names = {"-numHours"}, 
+  @CommandLine.Option(names = {"-numHours"},
       description = "number of hours to consume as comma separated values (default 2,3,4,5,6,7,8,9,10,11,12)")
   private String _numHours = "2,3,4,5,6,7,8,9,10,11,12";
 
-  @CommandLine.Option(names = {"-sampleCompletedSegmentDir"}, required = false, 
+  @CommandLine.Option(names = {"-sampleCompletedSegmentDir"}, required = false,
       description = "Consume from the topic for n hours and provide the path of the segment dir after it completes")
   private String _sampleCompletedSegmentDir;
 
-  @CommandLine.Option(names = {"-schemaWithMetadataFile"}, required = false, 
+  @CommandLine.Option(names = {"-schemaWithMetadataFile"}, required = false,
       description = "Schema file with extra information on each column describing characteristics of data")
   private String _schemaWithMetadataFile;
 
-  @CommandLine.Option(names = {"-numRows"}, required = false, 
+  @CommandLine.Option(names = {"-numRows"}, required = false,
       description = "Number of rows to be generated based on schema with metadata file")
   private int _numRows;
 
@@ -96,7 +96,7 @@ public class RealtimeProvisioningHelperCommand extends AbstractBaseAdminCommand
       + "ingested on any one stream partition (assumed all partitions are uniform)")
   private int _ingestionRate;
 
-  @CommandLine.Option(names = {"-maxUsableHostMemory"}, required = false, 
+  @CommandLine.Option(names = {"-maxUsableHostMemory"}, required = false,
       description = "Maximum memory per host that can be used for pinot data (e.g. 250G, 100M). Default 48g")
   private String _maxUsableHostMemory = "48G";
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/RebalanceTableCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/RebalanceTableCommand.java
index 7bf342b..6f15c86 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/RebalanceTableCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/RebalanceTableCommand.java
@@ -41,38 +41,38 @@ public class RebalanceTableCommand extends AbstractBaseAdminCommand implements C
   @CommandLine.Option(names = {"-clusterName"}, required = true, description = "Name of the Pinot cluster")
   private String _clusterName;
 
-  @CommandLine.Option(names = {"-tableName"}, required = true, 
+  @CommandLine.Option(names = {"-tableName"}, required = true,
       description = "Name of the table to rebalance (with type suffix, e.g. myTable_OFFLINE)")
   private String _tableNameWithType;
 
-  @CommandLine.Option(names = {"-dryRun"}, 
+  @CommandLine.Option(names = {"-dryRun"},
       description = "Whether to rebalance table in dry-run mode (just log the target assignment without applying"
           + " changes to the cluster, false by default)")
   private boolean _dryRun = false;
 
-  @CommandLine.Option(names = {"-reassignInstances"}, 
+  @CommandLine.Option(names = {"-reassignInstances"},
       description = "Whether to reassign instances before reassigning segments (false by default)")
   private boolean _reassignInstances = false;
 
-  @CommandLine.Option(names = {"-includeConsuming"}, 
+  @CommandLine.Option(names = {"-includeConsuming"},
       description = "Whether to reassign CONSUMING segments for real-time table (false by default)")
   private boolean _includeConsuming = false;
 
-  @CommandLine.Option(names = {"-bootstrap"}, 
+  @CommandLine.Option(names = {"-bootstrap"},
       description = "Whether to rebalance table in bootstrap mode (regardless of minimum segment movement, reassign"
           + " all segments in a round-robin fashion as if adding new segments to an empty table, false by default)")
   private boolean _bootstrap = false;
 
-  @CommandLine.Option(names = {"-downtime"}, 
+  @CommandLine.Option(names = {"-downtime"},
       description = "Whether to allow downtime for the rebalance (false by default)")
   private boolean _downtime = false;
 
-  @CommandLine.Option(names = {"-minAvailableReplicas"}, 
+  @CommandLine.Option(names = {"-minAvailableReplicas"},
       description = "For no-downtime rebalance, minimum number of replicas to keep alive during rebalance, or maximum "
           + "number of replicas allowed to be unavailable if value is negative (1 by default)")
   private int _minAvailableReplicas = 1;
 
-  @CommandLine.Option(names = {"-bestEfforts"}, 
+  @CommandLine.Option(names = {"-bestEfforts"},
       description = "Whether to use best-efforts to rebalance (not fail the rebalance when the no-downtime contract"
           + " cannot be achieved, false by default)")
   private boolean _bestEfforts = false;
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartBrokerCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartBrokerCommand.java
index 30f005b..b42e3ab 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartBrokerCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartBrokerCommand.java
@@ -108,7 +108,6 @@ public class StartBrokerCommand extends AbstractBaseAdminCommand implements Comm
 
   @Override
   public void cleanup() {
-
   }
 
   @Override
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartControllerCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartControllerCommand.java
index ad98f5a..43fa1bf 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartControllerCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartControllerCommand.java
@@ -51,7 +51,7 @@ public class StartControllerCommand extends AbstractBaseAdminCommand implements
   @CommandLine.Option(names = {"-controllerHost"}, required = false, description = "host name for controller.")
   private String _controllerHost;
 
-  @CommandLine.Option(names = {"-controllerPort"}, required = false, 
+  @CommandLine.Option(names = {"-controllerPort"}, required = false,
       description = "Port number to start the controller at.")
   private String _controllerPort = DEFAULT_CONTROLLER_PORT;
 
@@ -168,7 +168,6 @@ public class StartControllerCommand extends AbstractBaseAdminCommand implements
 
   @Override
   public void cleanup() {
-
   }
 
   @Override
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartServerCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartServerCommand.java
index 66d40dc..0e67737 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartServerCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StartServerCommand.java
@@ -51,14 +51,14 @@ public class StartServerCommand extends AbstractBaseAdminCommand implements Comm
   @CommandLine.Option(names = {"-serverPort"}, required = false, description = "Port number to start the server at.")
   private int _serverPort = CommonConstants.Helix.DEFAULT_SERVER_NETTY_PORT;
 
-  @CommandLine.Option(names = {"-serverAdminPort"}, required = false, 
+  @CommandLine.Option(names = {"-serverAdminPort"}, required = false,
       description = "Port number to serve the server admin API at.")
   private int _serverAdminPort = CommonConstants.Server.DEFAULT_ADMIN_API_PORT;
 
   @CommandLine.Option(names = {"-dataDir"}, required = false, description = "Path to directory containing data.")
   private String _dataDir = PinotConfigUtils.TMP_DIR + "data/pinotServerData";
 
-  @CommandLine.Option(names = {"-segmentDir"}, required = false, 
+  @CommandLine.Option(names = {"-segmentDir"}, required = false,
       description = "Path to directory containing segments.")
   private String _segmentDir = PinotConfigUtils.TMP_DIR + "data/pinotSegments";
 
@@ -176,7 +176,6 @@ public class StartServerCommand extends AbstractBaseAdminCommand implements Comm
 
   @Override
   public void cleanup() {
-
   }
 
   @Override
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StopProcessCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StopProcessCommand.java
index d54001a..65ecaaa 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StopProcessCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StopProcessCommand.java
@@ -211,7 +211,6 @@ public class StopProcessCommand extends AbstractBaseAdminCommand implements Comm
 
   @Override
   public void cleanup() {
-
   }
 
   private boolean stopProcess(String fileName)
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StreamAvroIntoKafkaCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StreamAvroIntoKafkaCommand.java
index 08355c2..8eb2c06 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StreamAvroIntoKafkaCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StreamAvroIntoKafkaCommand.java
@@ -64,11 +64,11 @@ public class StreamAvroIntoKafkaCommand extends AbstractBaseAdminCommand impleme
   @CommandLine.Option(names = {"-zkAddress"}, required = false, description = "Address of Zookeeper.")
   private String _zkAddress = "localhost:2181";
 
-  @CommandLine.Option(names = {"-outputFormat"}, required = false, 
+  @CommandLine.Option(names = {"-outputFormat"}, required = false,
       description = "Data format to produce to Kafka, supported: json(default) and avro")
   private String _outputFormat = "json";
 
-  @CommandLine.Option(names = {"-millisBetweenMessages"}, required = false, 
+  @CommandLine.Option(names = {"-millisBetweenMessages"}, required = false,
       description = "Delay in milliseconds between messages (default 1000 ms)")
   private String _millisBetweenMessages = "1000";
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StreamGitHubEventsCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StreamGitHubEventsCommand.java
index 1053728..269281d 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StreamGitHubEventsCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/StreamGitHubEventsCommand.java
@@ -36,14 +36,14 @@ public class StreamGitHubEventsCommand extends AbstractBaseAdminCommand implemen
   @CommandLine.Option(names = {"-personalAccessToken"}, required = true, description = "GitHub personal access token.")
   private String _personalAccessToken;
 
-  @CommandLine.Option(names = {"-kafkaBrokerList"}, 
+  @CommandLine.Option(names = {"-kafkaBrokerList"},
       description = "Kafka broker list of the kafka cluster to produce events.")
   private String _kafkaBrokerList = KafkaStarterUtils.DEFAULT_KAFKA_BROKER;
 
   @CommandLine.Option(names = {"-topic"}, required = true, description = "Name of kafka topic to publish events.")
   private String _topic;
 
-  @CommandLine.Option(names = {"-eventType"}, 
+  @CommandLine.Option(names = {"-eventType"},
       description = "Type of GitHub event. Supported types - pullRequestMergedEvent")
   private String _eventType = PULL_REQUEST_MERGED_EVENT_TYPE;
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/UploadSegmentCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/UploadSegmentCommand.java
index faa4533..9a1af3c 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/UploadSegmentCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/UploadSegmentCommand.java
@@ -91,7 +91,6 @@ public class UploadSegmentCommand extends AbstractBaseAdminCommand implements Co
 
   @Override
   public void cleanup() {
-
   }
 
   @Override
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ValidateConfigCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ValidateConfigCommand.java
index a62a2c0..950587f 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ValidateConfigCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/ValidateConfigCommand.java
@@ -66,14 +66,14 @@ public class ValidateConfigCommand extends AbstractBaseCommand implements Comman
   @CommandLine.Option(names = {"-tableConfig"}, required = false, description = "Validate the table config")
   private boolean _validateTableConfig;
 
-  @CommandLine.Option(names = {"-tableNames"}, required = false, 
+  @CommandLine.Option(names = {"-tableNames"}, required = false,
       description = "Space separated table names to be validated (default to validate ALL)")
   private String _tableNames;
 
   @CommandLine.Option(names = {"-schema"}, required = false, description = "Validate the schema")
   private boolean _validateSchema;
 
-  @CommandLine.Option(names = {"-schemaNames"}, required = false, 
+  @CommandLine.Option(names = {"-schemaNames"}, required = false,
       description = "Space separated schema names to be validated (default to validate ALL)")
   private String _schemaNames;
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/VerifyClusterStateCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/VerifyClusterStateCommand.java
index 32fff62..8246a09 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/VerifyClusterStateCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/VerifyClusterStateCommand.java
@@ -35,7 +35,7 @@ public class VerifyClusterStateCommand extends AbstractBaseAdminCommand implemen
   @CommandLine.Option(names = {"-clusterName"}, required = false, description = "Pinot cluster name.")
   private String _clusterName = "PinotCluster";
 
-  @CommandLine.Option(names = {"-tableName"}, required = false, 
+  @CommandLine.Option(names = {"-tableName"}, required = false,
       description = "Table name to check the state (e.g. myTable_OFFLINE).")
   private String _tableName;
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/VerifySegmentState.java b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/VerifySegmentState.java
index 6da8806..18b00c4 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/VerifySegmentState.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/admin/command/VerifySegmentState.java
@@ -43,7 +43,7 @@ public class VerifySegmentState extends AbstractBaseCommand implements Command {
   @CommandLine.Option(names = {"-clusterName"}, required = true, description = "Helix cluster name")
   String _clusterName;
 
-  @CommandLine.Option(names = {"-tablePrefix"}, required = false, 
+  @CommandLine.Option(names = {"-tablePrefix"}, required = false,
       description = "Table name prefix. (Ex: myTable, my or myTable_OFFLINE)")
   String _tablePrefix = "";
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/filesystem/PinotFSBenchmarkRunner.java b/pinot-tools/src/main/java/org/apache/pinot/tools/filesystem/PinotFSBenchmarkRunner.java
index 31eef12..8aef127 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/filesystem/PinotFSBenchmarkRunner.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/filesystem/PinotFSBenchmarkRunner.java
@@ -34,26 +34,26 @@ public class PinotFSBenchmarkRunner extends AbstractBaseCommand implements Comma
       description = "Test mode. (ALL|LISTFILES|READWRITE|DELETE|RENAME)")
   private String _mode;
 
-  @CommandLine.Option(names = {"-pinotFSConfigFile"}, required = true, 
+  @CommandLine.Option(names = {"-pinotFSConfigFile"}, required = true,
       description = "Path for PinotFS configuration file")
   private String _pinotFSConfigFile;
 
-  @CommandLine.Option(names = {"-baseDirectoryUri"}, required = true, 
+  @CommandLine.Option(names = {"-baseDirectoryUri"}, required = true,
       description = "Temp dir path for running benchmark against. e.g. file:///path/to/test, abfss://host/path...")
   private String _baseDirectoryUri;
 
   @CommandLine.Option(names = {"-localTempDir"}, required = false, description = "Local temp directory for benchmark.")
   private String _localTempDir;
 
-  @CommandLine.Option(names = {"-numSegmentsForListTest"}, required = false, 
+  @CommandLine.Option(names = {"-numSegmentsForListTest"}, required = false,
       description = "The number of segments to create before running listFiles test.")
   private Integer _numSegmentsForListTest;
 
-  @CommandLine.Option(names = {"-dataSizeInMBsForCopyTest"}, required = false, 
+  @CommandLine.Option(names = {"-dataSizeInMBsForCopyTest"}, required = false,
       description = "Data size in MB for copy test. (e.g. 1024 = 1GB)")
   private Integer _dataSizeInMBsForCopyTest;
 
-  @CommandLine.Option(names = {"-numOps"}, required = false, 
+  @CommandLine.Option(names = {"-numOps"}, required = false,
       description = "The number of trials of operations when running a benchmark.")
   private Integer _numOps;
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/perf/PerfBenchmarkRunner.java b/pinot-tools/src/main/java/org/apache/pinot/tools/perf/PerfBenchmarkRunner.java
index e8b895f..c692ad2 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/perf/PerfBenchmarkRunner.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/perf/PerfBenchmarkRunner.java
@@ -42,41 +42,41 @@ public class PerfBenchmarkRunner extends AbstractBaseCommand implements Command
       description = "Mode of the PerfBenchmarkRunner (startAll|startAllButServer|startServerWithPreLoadedSegments).")
   private String _mode;
 
-  @CommandLine.Option(names = {"-dataDir"}, required = false, 
+  @CommandLine.Option(names = {"-dataDir"}, required = false,
       description = "Path to directory containing un-tarred segments.")
   private String _dataDir;
 
-  @CommandLine.Option(names = {"-tempDir"}, required = false, 
+  @CommandLine.Option(names = {"-tempDir"}, required = false,
       description = "Path to temporary directory to start the cluster")
   private String _tempDir = "/tmp/";
 
   @CommandLine.Option(names = {"-loadMode"}, required = false, description = "Load mode of the segments (HEAP|MMAP).")
   private String _loadMode = "HEAP";
 
-  @CommandLine.Option(names = {"-segmentFormatVersion"}, required = false, 
+  @CommandLine.Option(names = {"-segmentFormatVersion"}, required = false,
       description = "Segment format version to be loaded (v1|v3).")
   private String _segmentFormatVersion;
 
   @CommandLine.Option(names = {"-batchLoad"}, required = false, description = "Batch load multiple tables.")
   private boolean _isBatchLoad;
 
-  @CommandLine.Option(names = {"-numThreads"}, required = false, 
+  @CommandLine.Option(names = {"-numThreads"}, required = false,
       description = "Number of threads for batch load (default 10).")
   private int _numThreads = 10;
 
-  @CommandLine.Option(names = {"-timeoutInSeconds"}, required = false, 
+  @CommandLine.Option(names = {"-timeoutInSeconds"}, required = false,
       description = "Timeout in seconds for batch load (default 60).")
   private int _timeoutInSeconds = 60;
 
-  @CommandLine.Option(names = {"-tableNames"}, required = false, 
+  @CommandLine.Option(names = {"-tableNames"}, required = false,
       description = "Comma separated table names with types to be loaded (non-batch load).")
   private String _tableNames;
 
-  @CommandLine.Option(names = {"-invertedIndexColumns"}, required = false, 
+  @CommandLine.Option(names = {"-invertedIndexColumns"}, required = false,
       description = "Comma separated inverted index columns to be created (non-batch load).")
   private String _invertedIndexColumns;
 
-  @CommandLine.Option(names = {"-bloomFilterColumns"}, required = false, 
+  @CommandLine.Option(names = {"-bloomFilterColumns"}, required = false,
       description = "Comma separated bloom filter columns to be created (non-batch load).")
   private String _bloomFilterColumns;
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/perf/QueryRunner.java b/pinot-tools/src/main/java/org/apache/pinot/tools/perf/QueryRunner.java
index 485d598..d0a2535 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/perf/QueryRunner.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/perf/QueryRunner.java
@@ -53,7 +53,7 @@ public class QueryRunner extends AbstractBaseCommand implements Command {
   private static final long NANO_DELTA = (long) 5E5;
   private static final String CLIENT_TIME_STATISTICS = "CLIENT TIME STATISTICS";
 
-  @CommandLine.Option(names = {"-mode"}, required = true, 
+  @CommandLine.Option(names = {"-mode"}, required = true,
       description = "Mode of query runner (singleThread|multiThreads|targetQPS|increasingQPS).")
   private String _mode;
   @CommandLine.Option(names = {"-queryFile"}, required = true, description = "Path to query file.")
@@ -64,26 +64,26 @@ public class QueryRunner extends AbstractBaseCommand implements Command {
   @CommandLine.Option(names = {"-queryCount"}, required = false,
       description = "Number of queries to run (default 0 = all).")
   private int _queryCount = 0;
-  @CommandLine.Option(names = {"-numTimesToRunQueries"}, required = false, 
+  @CommandLine.Option(names = {"-numTimesToRunQueries"}, required = false,
       description = "Number of times to run all queries in the query file, 0 means infinite times (default 1).")
   private int _numTimesToRunQueries = 1;
-  @CommandLine.Option(names = {"-reportIntervalMs"}, required = false, 
+  @CommandLine.Option(names = {"-reportIntervalMs"}, required = false,
       description = "Interval in milliseconds to report simple statistics (default 3000).")
   private int _reportIntervalMs = 3000;
-  @CommandLine.Option(names = {"-numIntervalsToReportAndClearStatistics"}, required = false, 
+  @CommandLine.Option(names = {"-numIntervalsToReportAndClearStatistics"}, required = false,
       description = "Number of report intervals to report detailed statistics and clear them,"
           + " 0 means never (default 10).")
   private int _numIntervalsToReportAndClearStatistics = 10;
-  @CommandLine.Option(names = {"-numThreads"}, required = false, 
+  @CommandLine.Option(names = {"-numThreads"}, required = false,
       description = "Number of threads sending queries for multiThreads, targetQPS and increasingQPS mode (default 5). "
           + "This can be used to simulate multiple clients sending queries concurrently.")
   private int _numThreads = 5;
-  @CommandLine.Option(names = {"-startQPS"}, required = false, 
+  @CommandLine.Option(names = {"-startQPS"}, required = false,
       description = "Start QPS for targetQPS and increasingQPS mode")
   private double _startQPS;
   @CommandLine.Option(names = {"-deltaQPS"}, required = false, description = "Delta QPS for increasingQPS mode.")
   private double _deltaQPS;
-  @CommandLine.Option(names = {"-numIntervalsToIncreaseQPS"}, required = false, 
+  @CommandLine.Option(names = {"-numIntervalsToIncreaseQPS"}, required = false,
       description = "Number of report intervals to increase QPS for increasingQPS mode (default 10).")
   private int _numIntervalsToIncreaseQPS = 10;
   @CommandLine.Option(names = {"-brokerHost"}, required = false, description = "Broker host name (default localhost).")
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/segment/converter/PinotSegmentConvertCommand.java b/pinot-tools/src/main/java/org/apache/pinot/tools/segment/converter/PinotSegmentConvertCommand.java
index 133b325..46aee12 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/segment/converter/PinotSegmentConvertCommand.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/segment/converter/PinotSegmentConvertCommand.java
@@ -53,21 +53,21 @@ public class PinotSegmentConvertCommand extends AbstractBaseCommand implements C
   @CommandLine.Option(names = {"-outputDir"}, required = true, description = "Path to output directory.")
   private String _outputDir;
 
-  @CommandLine.Option(names = {"-outputFormat"}, required = true, 
+  @CommandLine.Option(names = {"-outputFormat"}, required = true,
       description = "Format to convert to (AVRO/CSV/JSON).")
   private String _outputFormat;
 
   @CommandLine.Option(names = {"-csvDelimiter"}, required = false, description = "CSV delimiter (default ',').")
   private char _csvDelimiter = ',';
 
-  @CommandLine.Option(names = {"-csvListDelimiter"}, required = false, 
+  @CommandLine.Option(names = {"-csvListDelimiter"}, required = false,
       description = "CSV List delimiter for multi-value columns (default ';').")
   private char _csvListDelimiter = ';';
 
   @CommandLine.Option(names = {"-csvWithHeader"}, required = false, description = "Print CSV Header (default false).")
   private boolean _csvWithHeader;
 
-  @CommandLine.Option(names = {"-overwrite"}, required = false, 
+  @CommandLine.Option(names = {"-overwrite"}, required = false,
       description = "Overwrite the existing file (default false).")
   private boolean _overwrite;
 
diff --git a/pinot-tools/src/main/java/org/apache/pinot/tools/streams/AirlineDataStream.java b/pinot-tools/src/main/java/org/apache/pinot/tools/streams/AirlineDataStream.java
index 67ae201..d0824e0 100644
--- a/pinot-tools/src/main/java/org/apache/pinot/tools/streams/AirlineDataStream.java
+++ b/pinot-tools/src/main/java/org/apache/pinot/tools/streams/AirlineDataStream.java
@@ -83,7 +83,6 @@ public class AirlineDataStream {
     properties.put("request.required.acks", "1");
 
     return StreamDataProvider.getStreamDataProducer(KafkaStarterUtils.KAFKA_PRODUCER_CLASS_NAME, properties);
-
   }
 
   public void shutdown() {

---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@pinot.apache.org
For additional commands, e-mail: commits-help@pinot.apache.org