You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pinot.apache.org by su...@apache.org on 2019/01/08 22:38:52 UTC

[incubator-pinot] branch master updated: Update license header (#3664)

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

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


The following commit(s) were added to refs/heads/master by this push:
     new 46ad4f9  Update license header (#3664)
46ad4f9 is described below

commit 46ad4f95996e77da8b516535daa8be4d89c09d36
Author: Sunitha Beeram <sb...@linkedin.com>
AuthorDate: Tue Jan 8 14:38:45 2019 -0800

    Update license header (#3664)
    
    * Update license header
    
    * Address review comments - Update excludes
    
    * Address review comments - add license header for autogenerated code as well
---
 .codecov.yml                                       | 25 ++++++++------
 .travis_install.sh                                 | 25 ++++++++------
 .travis_test.sh                                    | 25 ++++++++------
 contrib/pinot-druid-benchmark/pom.xml              | 25 ++++++++------
 contrib/pinot-druid-benchmark/run_benchmark.sh     | 25 ++++++++------
 .../linkedin/pinotdruidbenchmark/DataMerger.java   | 25 ++++++++------
 .../pinotdruidbenchmark/DataSeparator.java         | 25 ++++++++------
 .../pinotdruidbenchmark/DruidResponseTime.java     | 25 ++++++++------
 .../pinotdruidbenchmark/DruidThroughput.java       | 25 ++++++++------
 .../pinotdruidbenchmark/PinotResponseTime.java     | 25 ++++++++------
 .../pinotdruidbenchmark/PinotThroughput.java       | 25 ++++++++------
 docs/conf.py                                       | 25 ++++++++------
 docs/make.bat                                      | 25 ++++++++------
 license.header                                     | 16 +++++++++
 pinot-api/pom.xml                                  | 25 ++++++++------
 .../linkedin/pinot/client/AbstractResultSet.java   | 25 ++++++++------
 .../pinot/client/AggregationResultSet.java         | 25 ++++++++------
 .../com/linkedin/pinot/client/BrokerResponse.java  | 25 ++++++++------
 .../com/linkedin/pinot/client/BrokerSelector.java  | 25 ++++++++------
 .../java/com/linkedin/pinot/client/Connection.java | 25 ++++++++------
 .../linkedin/pinot/client/ConnectionFactory.java   | 25 ++++++++------
 .../pinot/client/DynamicBrokerSelector.java        | 25 ++++++++------
 .../linkedin/pinot/client/ExternalViewReader.java  | 25 ++++++++------
 .../linkedin/pinot/client/GroupByResultSet.java    | 25 ++++++++------
 .../client/JsonAsyncHttpPinotClientTransport.java  | 25 ++++++++------
 .../JsonAsyncHttpPinotClientTransportFactory.java  | 25 ++++++++------
 .../pinot/client/PinotClientException.java         | 25 ++++++++------
 .../pinot/client/PinotClientTransport.java         | 25 ++++++++------
 .../pinot/client/PinotClientTransportFactory.java  | 25 ++++++++------
 .../linkedin/pinot/client/PreparedStatement.java   | 25 ++++++++------
 .../java/com/linkedin/pinot/client/ResultSet.java  | 25 ++++++++------
 .../com/linkedin/pinot/client/ResultSetGroup.java  | 25 ++++++++------
 .../linkedin/pinot/client/SelectionResultSet.java  | 25 ++++++++------
 .../pinot/client/SimpleBrokerSelector.java         | 25 ++++++++------
 .../java/com/linkedin/pinot/client/TextTable.java  | 25 ++++++++------
 .../com/linkedin/pinot/client/package-info.java    | 29 ++++++++--------
 .../pinot/client/ConnectionFactoryTest.java        | 25 ++++++++------
 .../pinot/client/PreparedStatementTest.java        | 25 ++++++++------
 .../linkedin/pinot/client/ResultSetGroupTest.java  | 25 ++++++++------
 pinot-azure-filesystem/pom.xml                     | 25 ++++++++------
 .../linkedin/pinot/filesystem/AzurePinotFS.java    | 25 ++++++++------
 .../pinot/filesystem/test/AzurePinotFSTest.java    | 25 ++++++++------
 .../datalake/store/MockADLFileInputStream.java     | 25 ++++++++------
 pinot-broker/pom.xml                               | 25 ++++++++------
 .../linkedin/pinot/broker/api/AccessControl.java   | 25 ++++++++------
 .../pinot/broker/api/RequestStatistics.java        | 26 ++++++++-------
 .../pinot/broker/api/RequesterIdentity.java        | 25 ++++++++------
 .../broker/api/resources/PinotBrokerDebug.java     | 25 ++++++++------
 .../api/resources/PinotBrokerHealthCheck.java      | 25 ++++++++------
 .../broker/api/resources/PinotClientRequest.java   | 25 ++++++++------
 .../pinot/broker/broker/AccessControlFactory.java  | 25 ++++++++------
 .../broker/AllowAllAccessControlFactory.java       | 25 ++++++++------
 .../broker/broker/BrokerAdminApiApplication.java   | 25 ++++++++------
 .../pinot/broker/broker/BrokerServerBuilder.java   | 25 ++++++++------
 ...okerResourceOnlineOfflineStateModelFactory.java | 25 ++++++++------
 .../broker/broker/helix/ClusterChangeMediator.java | 25 ++++++++------
 .../broker/helix/DefaultHelixBrokerConfig.java     | 25 ++++++++------
 .../broker/broker/helix/HelixBrokerStarter.java    | 25 ++++++++------
 .../helix/LiveInstancesChangeListenerImpl.java     | 25 ++++++++------
 .../TimeboundaryRefreshMessageHandlerFactory.java  | 25 ++++++++------
 .../broker/pruner/PartitionZKMetadataPruner.java   | 25 ++++++++------
 .../pinot/broker/pruner/SegmentPrunerContext.java  | 25 ++++++++------
 .../broker/pruner/SegmentZKMetadataPruner.java     | 25 ++++++++------
 .../pruner/SegmentZKMetadataPrunerProvider.java    | 25 ++++++++------
 .../pruner/SegmentZKMetadataPrunerService.java     | 25 ++++++++------
 .../pinot/broker/queryquota/HitCounter.java        | 25 ++++++++------
 .../pinot/broker/queryquota/QueryQuotaConfig.java  | 25 ++++++++------
 .../broker/queryquota/TableQueryQuotaManager.java  | 25 ++++++++------
 .../requesthandler/BaseBrokerRequestHandler.java   | 25 ++++++++------
 .../requesthandler/BrokerRequestHandler.java       | 25 ++++++++------
 .../requesthandler/BrokerRequestOptimizer.java     | 25 ++++++++------
 .../ConnectionPoolBrokerRequestHandler.java        | 25 ++++++++------
 .../FilterQueryOptimizerRequest.java               | 25 ++++++++------
 .../requesthandler/FilterQueryTreeOptimizer.java   | 25 ++++++++------
 ...enNestedPredicatesFilterQueryTreeOptimizer.java | 25 ++++++++------
 ...ualitiesToInClauseFilterQueryTreeOptimizer.java | 25 ++++++++------
 .../broker/requesthandler/OptimizationFlags.java   | 25 ++++++++------
 .../broker/requesthandler/RangeMergeOptimizer.java | 25 ++++++++------
 .../SingleConnectionBrokerRequestHandler.java      | 25 ++++++++------
 .../pinot/broker/routing/CfgBasedRouting.java      | 25 ++++++++------
 .../routing/HelixExternalViewBasedRouting.java     | 25 ++++++++------
 .../HelixExternalViewBasedTimeBoundaryService.java | 25 ++++++++------
 .../pinot/broker/routing/RoutingTable.java         | 25 ++++++++------
 .../broker/routing/RoutingTableBuilderFactory.java | 25 ++++++++------
 .../broker/routing/RoutingTableLookupRequest.java  | 25 ++++++++------
 .../pinot/broker/routing/TimeBoundaryService.java  | 25 ++++++++------
 .../builder/BalancedRandomRoutingTableBuilder.java | 25 ++++++++------
 .../BasePartitionAwareRoutingTableBuilder.java     | 25 ++++++++------
 .../routing/builder/BaseRoutingTableBuilder.java   | 25 ++++++++------
 .../builder/DefaultOfflineRoutingTableBuilder.java | 25 ++++++++------
 .../DefaultRealtimeRoutingTableBuilder.java        | 25 ++++++++------
 .../builder/GeneratorBasedRoutingTableBuilder.java | 25 ++++++++------
 .../HighLevelConsumerBasedRoutingTableBuilder.java | 25 ++++++++------
 .../builder/LargeClusterRoutingTableBuilder.java   | 25 ++++++++------
 .../LowLevelConsumerRoutingTableBuilder.java       | 25 ++++++++------
 .../builder/LowLevelRoutingTableBuilderUtil.java   | 25 ++++++++------
 .../PartitionAwareOfflineRoutingTableBuilder.java  | 25 ++++++++------
 .../PartitionAwareRealtimeRoutingTableBuilder.java | 25 ++++++++------
 .../routing/builder/RoutingTableBuilder.java       | 25 ++++++++------
 .../builder/RoutingTableInstancePruner.java        | 25 ++++++++------
 .../routing/selector/MergedSegmentSelector.java    | 25 ++++++++------
 .../broker/routing/selector/SegmentSelector.java   | 25 ++++++++------
 .../routing/selector/SegmentSelectorProvider.java  | 25 ++++++++------
 .../pinot/broker/broker/BrokerTestUtils.java       | 25 ++++++++------
 .../EmptyBrokerOnlineOfflineStateModelFactory.java | 25 ++++++++------
 ...EmptySegmentOnlineOfflineStateModelFactory.java | 25 ++++++++------
 .../broker/broker/HelixBrokerStarterTest.java      | 25 ++++++++------
 .../broker/broker/HelixBrokerStarterUtilsTest.java | 25 ++++++++------
 .../broker/pruner/SegmentZKMetadataPrunerTest.java | 25 ++++++++------
 .../pinot/broker/queryquota/HitCounterTest.java    | 25 ++++++++------
 .../queryquota/TableQueryQuotaManagerTest.java     | 25 ++++++++------
 .../broker/requesthandler/FilterOptimizerTest.java | 25 ++++++++------
 ...tiesToInClauseFilterQueryTreeOptimizerTest.java | 25 ++++++++------
 .../requesthandler/OptimizationFlagsTest.java      | 25 ++++++++------
 .../requesthandler/RangeMergeOptimizerTest.java    | 25 ++++++++------
 .../broker/routing/RandomRoutingTableTest.java     | 25 ++++++++------
 .../pinot/broker/routing/RoutingTableTest.java     | 25 ++++++++------
 .../broker/routing/TimeBoundaryServiceTest.java    | 25 ++++++++------
 .../BalancedRandomRoutingTableBuilderTest.java     | 25 ++++++++------
 .../HighLevelConsumerRoutingTableBuilderTest.java  | 25 ++++++++------
 .../LargeClusterRoutingTableBuilderTest.java       | 25 ++++++++------
 .../LowLevelConsumerRoutingTableBuilderTest.java   | 25 ++++++++------
 ...rtitionAwareOfflineRoutingTableBuilderTest.java | 25 ++++++++------
 ...titionAwareRealtimeRoutingTableBuilderTest.java | 25 ++++++++------
 .../builder/RoutingTableBuilderTestUtil.java       | 25 ++++++++------
 .../selector/MergedSegmentSelectorTest.java        | 25 ++++++++------
 .../pinot/broker/util/FakePropertyStore.java       | 25 ++++++++------
 pinot-common/pom.xml                               | 25 ++++++++------
 .../antlr4/com/linkedin/pinot/pql/parsers/PQL2.g4  | 25 ++++++++------
 .../main/java/com/linkedin/pinot/common/Utils.java | 25 ++++++++------
 .../config/AdjustTableNameChildKeyTransformer.java | 25 ++++++++------
 .../pinot/common/config/ChildKeyHandler.java       | 25 ++++++++------
 .../pinot/common/config/ChildKeyTransformer.java   | 25 ++++++++------
 .../pinot/common/config/ColumnPartitionConfig.java | 25 ++++++++------
 .../config/ColumnPartitionMapChildKeyHandler.java  | 25 ++++++++------
 .../pinot/common/config/CombinedConfig.java        | 25 ++++++++------
 .../pinot/common/config/CombinedConfigLoader.java  | 25 ++++++++------
 ...CombinedConfigSeparatorChildKeyTransformer.java | 25 ++++++++------
 .../linkedin/pinot/common/config/ConfigDoc.java    | 25 ++++++++------
 .../linkedin/pinot/common/config/ConfigKey.java    | 25 ++++++++------
 .../common/config/ConfigNodeLifecycleAware.java    | 25 ++++++++------
 .../linkedin/pinot/common/config/Deserializer.java | 25 ++++++++------
 .../com/linkedin/pinot/common/config/Duration.java | 25 ++++++++------
 .../linkedin/pinot/common/config/DurationDsl.java  | 25 ++++++++------
 .../pinot/common/config/IndexingConfig.java        | 25 ++++++++------
 .../common/config/NamedListChildKeyHandler.java    | 25 ++++++++------
 .../linkedin/pinot/common/config/NestedConfig.java | 25 ++++++++------
 .../pinot/common/config/OfflineTagConfig.java      | 25 ++++++++------
 .../pinot/common/config/PinotTaskConfig.java       | 25 ++++++++------
 .../linkedin/pinot/common/config/QuotaConfig.java  | 25 ++++++++------
 .../pinot/common/config/RealtimeTagConfig.java     | 25 ++++++++------
 .../config/RemapTableTypesChildKeyTransformer.java | 25 ++++++++------
 .../common/config/ReplicaGroupStrategyConfig.java  | 25 ++++++++------
 .../pinot/common/config/RoutingConfig.java         | 25 ++++++++------
 .../common/config/SegmentPartitionConfig.java      | 25 ++++++++------
 .../SegmentsValidationAndRetentionConfig.java      | 25 ++++++++------
 .../linkedin/pinot/common/config/Serializer.java   | 25 ++++++++------
 .../common/config/SimpleMapChildKeyHandler.java    | 25 ++++++++------
 .../linkedin/pinot/common/config/SingleKeyDsl.java | 25 ++++++++------
 .../pinot/common/config/StarTreeIndexConfig.java   | 25 ++++++++------
 .../common/config/StreamConsumptionConfig.java     | 25 ++++++++------
 .../linkedin/pinot/common/config/TableConfig.java  | 25 ++++++++------
 .../pinot/common/config/TableCustomConfig.java     | 25 ++++++++------
 .../pinot/common/config/TableNameBuilder.java      | 25 ++++++++------
 .../pinot/common/config/TableTaskConfig.java       | 25 ++++++++------
 .../linkedin/pinot/common/config/TagConfig.java    | 25 ++++++++------
 .../linkedin/pinot/common/config/TagNameUtils.java | 25 ++++++++------
 .../pinot/common/config/TagOverrideConfig.java     | 25 ++++++++------
 .../config/TaskConfigMapChildKeyHandler.java       | 25 ++++++++------
 .../com/linkedin/pinot/common/config/Tenant.java   | 25 ++++++++------
 .../linkedin/pinot/common/config/TenantConfig.java | 25 ++++++++------
 .../common/config/TypedMapChildKeyHandler.java     | 25 ++++++++------
 .../pinot/common/config/UseChildKeyHandler.java    | 25 ++++++++------
 .../common/config/UseChildKeyTransformers.java     | 25 ++++++++------
 .../com/linkedin/pinot/common/config/UseDsl.java   | 25 ++++++++------
 .../pinot/common/data/DateTimeFieldSpec.java       | 25 ++++++++------
 .../data/DateTimeFieldSpecChildKeyHandler.java     | 25 ++++++++------
 .../common/data/DateTimeFormatPatternSpec.java     | 25 ++++++++------
 .../pinot/common/data/DateTimeFormatSpec.java      | 25 ++++++++------
 .../pinot/common/data/DateTimeFormatUnitSpec.java  | 25 ++++++++------
 .../pinot/common/data/DateTimeGranularitySpec.java | 25 ++++++++------
 .../pinot/common/data/DimensionFieldSpec.java      | 25 ++++++++------
 .../data/DimensionFieldSpecChildKeyHandler.java    | 25 ++++++++------
 .../com/linkedin/pinot/common/data/FieldSpec.java  | 25 ++++++++------
 .../pinot/common/data/MetricFieldSpec.java         | 25 ++++++++------
 .../data/MetricFieldSpecChildKeyHandler.java       | 25 ++++++++------
 .../com/linkedin/pinot/common/data/RowEvent.java   | 25 ++++++++------
 .../com/linkedin/pinot/common/data/Schema.java     | 25 ++++++++------
 .../com/linkedin/pinot/common/data/Segment.java    | 25 ++++++++------
 .../pinot/common/data/StarTreeIndexSpec.java       | 25 ++++++++------
 .../linkedin/pinot/common/data/TimeFieldSpec.java  | 25 ++++++++------
 .../pinot/common/data/TimeGranularitySpec.java     | 25 ++++++++------
 .../common/exception/HttpErrorStatusException.java | 25 ++++++++------
 .../common/exception/InvalidConfigException.java   | 25 ++++++++------
 .../pinot/common/exception/QueryException.java     | 25 ++++++++------
 .../common/exception/TableNotFoundException.java   | 25 ++++++++------
 .../pinot/common/http/MultiGetRequest.java         | 25 ++++++++------
 .../pinot/common/lineage/SegmentGroup.java         | 25 ++++++++------
 .../pinot/common/lineage/SegmentMergeLineage.java  | 25 ++++++++------
 .../lineage/SegmentMergeLineageAccessHelper.java   | 25 ++++++++------
 .../common/messages/SegmentRefreshMessage.java     | 25 ++++++++------
 .../common/messages/SegmentReloadMessage.java      | 25 ++++++++------
 .../messages/TimeboundaryRefreshMessage.java       | 25 ++++++++------
 .../linkedin/pinot/common/metadata/ZKMetadata.java | 25 ++++++++------
 .../pinot/common/metadata/ZKMetadataProvider.java  | 25 ++++++++------
 .../metadata/instance/InstanceZKMetadata.java      | 25 ++++++++------
 .../metadata/segment/ColumnPartitionMetadata.java  | 25 ++++++++------
 .../segment/LLCRealtimeSegmentZKMetadata.java      | 25 ++++++++------
 .../metadata/segment/OfflineSegmentZKMetadata.java | 25 ++++++++------
 .../segment/RealtimeSegmentZKMetadata.java         | 25 ++++++++------
 .../metadata/segment/SegmentPartitionMetadata.java | 25 ++++++++------
 .../common/metadata/segment/SegmentZKMetadata.java | 25 ++++++++------
 .../SegmentZKMetadataCustomMapModifier.java        | 25 ++++++++------
 .../pinot/common/metrics/AbstractMetrics.java      | 25 ++++++++------
 .../pinot/common/metrics/AggregatedCounter.java    | 25 ++++++++------
 .../pinot/common/metrics/AggregatedHistogram.java  | 25 ++++++++------
 .../pinot/common/metrics/AggregatedLongGauge.java  | 25 ++++++++------
 .../pinot/common/metrics/AggregatedMeter.java      | 25 ++++++++------
 .../common/metrics/AggregatedMetricsRegistry.java  | 25 ++++++++------
 .../linkedin/pinot/common/metrics/BrokerGauge.java | 25 ++++++++------
 .../linkedin/pinot/common/metrics/BrokerMeter.java | 25 ++++++++------
 .../pinot/common/metrics/BrokerMetrics.java        | 25 ++++++++------
 .../pinot/common/metrics/BrokerQueryPhase.java     | 25 ++++++++------
 .../linkedin/pinot/common/metrics/BrokerTimer.java | 25 ++++++++------
 .../pinot/common/metrics/ControllerGauge.java      | 25 ++++++++------
 .../pinot/common/metrics/ControllerMeter.java      | 25 ++++++++------
 .../pinot/common/metrics/ControllerMetrics.java    | 25 ++++++++------
 .../pinot/common/metrics/ControllerTimer.java      | 25 ++++++++------
 ...eporterMetricsRegistryRegistrationListener.java | 25 ++++++++------
 .../pinot/common/metrics/LatencyMetric.java        | 25 ++++++++------
 .../pinot/common/metrics/MetricsHelper.java        | 25 ++++++++------
 .../MetricsRegistryRegistrationListener.java       | 25 ++++++++------
 .../linkedin/pinot/common/metrics/ServerGauge.java | 25 ++++++++------
 .../linkedin/pinot/common/metrics/ServerMeter.java | 25 ++++++++------
 .../pinot/common/metrics/ServerMetrics.java        | 25 ++++++++------
 .../pinot/common/metrics/ServerQueryPhase.java     | 25 ++++++++------
 .../linkedin/pinot/common/metrics/ServerTimer.java | 25 ++++++++------
 .../pinot/common/metrics/ValidationMetrics.java    | 25 ++++++++------
 .../common/partition/PartitionAssignment.java      | 25 ++++++++------
 .../partition/ReplicaGroupPartitionAssignment.java | 25 ++++++++------
 .../ReplicaGroupPartitionAssignmentGenerator.java  | 25 ++++++++------
 .../StreamPartitionAssignmentGenerator.java        | 25 ++++++++------
 .../protocols/SegmentCompletionProtocol.java       | 25 ++++++++------
 .../linkedin/pinot/common/query/ReduceService.java | 25 ++++++++------
 .../pinot/common/query/ReduceServiceRegistry.java  | 25 ++++++++------
 .../pinot/common/request/AggregationInfo.java      | 18 ++++++++++
 .../pinot/common/request/BrokerRequest.java        | 18 ++++++++++
 .../pinot/common/request/FilterOperator.java       | 18 ++++++++++
 .../linkedin/pinot/common/request/FilterQuery.java | 18 ++++++++++
 .../pinot/common/request/FilterQueryMap.java       | 18 ++++++++++
 .../com/linkedin/pinot/common/request/GroupBy.java | 18 ++++++++++
 .../pinot/common/request/HavingFilterQuery.java    | 18 ++++++++++
 .../pinot/common/request/HavingFilterQueryMap.java | 18 ++++++++++
 .../pinot/common/request/InstanceRequest.java      | 18 ++++++++++
 .../linkedin/pinot/common/request/QuerySource.java | 18 ++++++++++
 .../linkedin/pinot/common/request/QueryType.java   | 18 ++++++++++
 .../linkedin/pinot/common/request/Selection.java   | 18 ++++++++++
 .../pinot/common/request/SelectionSort.java        | 18 ++++++++++
 .../request/transform/TransformExpressionTree.java | 25 ++++++++------
 .../pinot/common/response/BrokerResponse.java      | 25 ++++++++------
 .../common/response/BrokerResponseFactory.java     | 25 ++++++++------
 .../pinot/common/response/ProcessingException.java | 18 ++++++++++
 .../pinot/common/response/ServerInstance.java      | 25 ++++++++------
 .../common/response/broker/AggregationResult.java  | 25 ++++++++------
 .../response/broker/BrokerResponseNative.java      | 25 ++++++++------
 .../common/response/broker/GroupByResult.java      | 25 ++++++++------
 .../response/broker/QueryProcessingException.java  | 25 ++++++++------
 .../common/response/broker/SelectionResults.java   | 25 ++++++++------
 .../common/restlet/resources/RebalanceResult.java  | 25 ++++++++------
 .../common/restlet/resources/ResourceUtils.java    | 25 ++++++++------
 .../common/restlet/resources/SegmentSizeInfo.java  | 25 ++++++++------
 .../common/restlet/resources/TableSegments.java    | 25 ++++++++------
 .../common/restlet/resources/TableSizeInfo.java    | 25 ++++++++------
 .../pinot/common/restlet/resources/TablesList.java | 25 ++++++++------
 .../linkedin/pinot/common/segment/ReadMode.java    | 25 ++++++++------
 .../pinot/common/segment/SegmentMetadata.java      | 25 ++++++++------
 .../pinot/common/segment/StarTreeMetadata.java     | 25 ++++++++------
 .../common/segment/fetcher/HdfsSegmentFetcher.java | 25 ++++++++------
 .../common/segment/fetcher/HttpSegmentFetcher.java | 25 ++++++++------
 .../segment/fetcher/HttpsSegmentFetcher.java       | 25 ++++++++------
 .../segment/fetcher/LocalFileSegmentFetcher.java   | 25 ++++++++------
 .../pinot/common/segment/fetcher/NoOpFetcher.java  | 25 ++++++++------
 .../segment/fetcher/PinotFSSegmentFetcher.java     | 25 ++++++++------
 .../common/segment/fetcher/SegmentFetcher.java     | 25 ++++++++------
 .../segment/fetcher/SegmentFetcherFactory.java     | 25 ++++++++------
 .../common/utils/ClientSSLContextGenerator.java    | 26 ++++++++-------
 .../pinot/common/utils/CommonConstants.java        | 25 ++++++++------
 .../linkedin/pinot/common/utils/DataSchema.java    | 25 ++++++++------
 .../com/linkedin/pinot/common/utils/DataSize.java  | 25 ++++++++------
 .../com/linkedin/pinot/common/utils/DataTable.java | 25 ++++++++------
 .../linkedin/pinot/common/utils/EqualityUtils.java | 25 ++++++++------
 .../common/utils/FileUploadDownloadClient.java     | 25 ++++++++------
 .../com/linkedin/pinot/common/utils/FileUtils.java | 25 ++++++++------
 .../pinot/common/utils/HLCSegmentName.java         | 25 ++++++++------
 .../com/linkedin/pinot/common/utils/HashUtil.java  | 25 ++++++++------
 .../pinot/common/utils/KafkaStarterUtils.java      | 25 ++++++++------
 .../pinot/common/utils/LLCSegmentName.java         | 25 ++++++++------
 .../com/linkedin/pinot/common/utils/LLCUtils.java  | 25 ++++++++------
 .../com/linkedin/pinot/common/utils/LogUtils.java  | 25 ++++++++------
 .../pinot/common/utils/NamedThreadFactory.java     | 18 ++++++++++
 .../com/linkedin/pinot/common/utils/NetUtil.java   | 25 ++++++++------
 .../com/linkedin/pinot/common/utils/Pairs.java     | 25 ++++++++------
 .../pinot/common/utils/PrimitiveArrayUtils.java    | 25 ++++++++------
 .../linkedin/pinot/common/utils/SchemaUtils.java   | 25 ++++++++------
 .../linkedin/pinot/common/utils/SegmentName.java   | 25 ++++++++------
 .../linkedin/pinot/common/utils/ServerType.java    | 25 ++++++++------
 .../linkedin/pinot/common/utils/ServiceStatus.java | 25 ++++++++------
 .../pinot/common/utils/SimpleHttpResponse.java     | 25 ++++++++------
 .../linkedin/pinot/common/utils/StringUtil.java    | 25 ++++++++------
 .../pinot/common/utils/TarGzCompressionUtils.java  | 25 ++++++++------
 .../linkedin/pinot/common/utils/TenantRole.java    | 25 ++++++++------
 .../com/linkedin/pinot/common/utils/ZkStarter.java | 25 ++++++++------
 .../pinot/common/utils/helix/HelixHelper.java      | 25 ++++++++------
 .../PinotHelixPropertyStoreZnRecordProvider.java   | 25 ++++++++------
 .../pinot/common/utils/primitive/ByteArray.java    | 25 ++++++++------
 .../common/utils/request/FilterQueryTree.java      | 25 ++++++++------
 .../common/utils/request/HavingQueryTree.java      | 25 ++++++++------
 .../pinot/common/utils/request/QueryTree.java      | 25 ++++++++------
 .../pinot/common/utils/request/RequestUtils.java   | 25 ++++++++------
 .../utils/retry/AttemptFailureException.java       | 25 ++++++++------
 .../utils/retry/AttemptsExceededException.java     | 25 ++++++++------
 .../pinot/common/utils/retry/BaseRetryPolicy.java  | 25 ++++++++------
 .../utils/retry/ExponentialBackoffRetryPolicy.java | 25 ++++++++------
 .../common/utils/retry/FixedDelayRetryPolicy.java  | 25 ++++++++------
 .../common/utils/retry/NoDelayRetryPolicy.java     | 25 ++++++++------
 .../utils/retry/RetriableOperationException.java   | 25 ++++++++------
 .../pinot/common/utils/retry/RetryPolicies.java    | 25 ++++++++------
 .../pinot/common/utils/retry/RetryPolicy.java      | 25 ++++++++------
 .../pinot/common/utils/time/TimeConverter.java     | 25 ++++++++------
 .../pinot/common/utils/time/TimeUtils.java         | 25 ++++++++------
 .../common/utils/webhdfs/WebHdfsV1Client.java      | 25 ++++++++------
 .../pinot/pql/parsers/AbstractCompiler.java        | 25 ++++++++------
 .../pinot/pql/parsers/Pql2AstListener.java         | 25 ++++++++------
 .../pql/parsers/Pql2CompilationException.java      | 25 ++++++++------
 .../linkedin/pinot/pql/parsers/Pql2Compiler.java   | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/AstNode.java        | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/BaseAstNode.java    | 25 ++++++++------
 .../parsers/pql2/ast/BetweenPredicateAstNode.java  | 25 ++++++++------
 .../pql/parsers/pql2/ast/BinaryMathOpAstNode.java  | 25 ++++++++------
 .../parsers/pql2/ast/BooleanOperatorAstNode.java   | 25 ++++++++------
 .../pql2/ast/ComparisonPredicateAstNode.java       | 25 ++++++++------
 .../ast/ExpressionParenthesisGroupAstNode.java     | 25 ++++++++------
 .../pql2/ast/FloatingPointLiteralAstNode.java      | 25 ++++++++------
 .../pql/parsers/pql2/ast/FunctionCallAstNode.java  | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/GroupByAstNode.java | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/HavingAstNode.java  | 25 ++++++++------
 .../pql/parsers/pql2/ast/IdentifierAstNode.java    | 25 ++++++++------
 .../pql/parsers/pql2/ast/InPredicateAstNode.java   | 25 ++++++++------
 .../parsers/pql2/ast/IntegerLiteralAstNode.java    | 25 ++++++++------
 .../pql/parsers/pql2/ast/IsPredicateAstNode.java   | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/LimitAstNode.java   | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/LiteralAstNode.java | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/OptionAstNode.java  | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/OptionsAstNode.java | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/OrderByAstNode.java | 25 ++++++++------
 .../parsers/pql2/ast/OrderByExpressionAstNode.java | 25 ++++++++------
 .../pql/parsers/pql2/ast/OutputColumnAstNode.java  | 25 ++++++++------
 .../parsers/pql2/ast/OutputColumnListAstNode.java  | 25 ++++++++------
 .../pql/parsers/pql2/ast/PredicateAstNode.java     | 25 ++++++++------
 .../pql/parsers/pql2/ast/PredicateListAstNode.java | 25 ++++++++------
 .../pql2/ast/PredicateParenthesisGroupAstNode.java | 25 ++++++++------
 .../pql2/ast/RegexpLikePredicateAstNode.java       | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/SelectAstNode.java  | 25 ++++++++------
 .../parsers/pql2/ast/StarColumnListAstNode.java    | 25 ++++++++------
 .../parsers/pql2/ast/StarExpressionAstNode.java    | 25 ++++++++------
 .../pql/parsers/pql2/ast/StringLiteralAstNode.java | 25 ++++++++------
 .../pql/parsers/pql2/ast/TableNameAstNode.java     | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/TopAstNode.java     | 25 ++++++++------
 .../pinot/pql/parsers/pql2/ast/WhereAstNode.java   | 25 ++++++++------
 .../com/linkedin/pinot/pql/parsers/utils/Pair.java | 25 ++++++++------
 .../main/java/com/linkedin/pinot/serde/SerDe.java  | 25 ++++++++------
 .../com/linkedin/pinot/startree/hll/HllConfig.java | 25 ++++++++------
 .../linkedin/pinot/startree/hll/HllConstants.java  | 25 ++++++++------
 .../linkedin/pinot/startree/hll/HllSizeUtils.java  | 25 ++++++++------
 .../pinot/common/config/IndexingConfigTest.java    | 25 ++++++++------
 .../pinot/common/config/QuotaConfigTest.java       | 25 ++++++++------
 .../pinot/common/config/TableConfigTest.java       | 25 ++++++++------
 .../pinot/common/config/TagOverrideConfigTest.java | 25 ++++++++------
 .../linkedin/pinot/common/config/TenantTest.java   | 25 ++++++++------
 .../common/config/TestConfigSerialization.java     | 25 ++++++++------
 .../pinot/common/data/DateTimeFormatSpecTest.java  | 25 ++++++++------
 .../common/data/DateTimeGranularitySpecTest.java   | 25 ++++++++------
 .../linkedin/pinot/common/data/FieldSpecTest.java  | 25 ++++++++------
 .../com/linkedin/pinot/common/data/SchemaTest.java | 25 ++++++++------
 .../pinot/common/http/MultiGetRequestTest.java     | 25 ++++++++------
 .../common/lineage/SegmentMergeLineageTest.java    | 25 ++++++++------
 .../common/metadata/InstanceZKMetadataTest.java    | 25 ++++++++------
 .../metadata/MetadataEqualsHashCodeTest.java       | 25 ++++++++------
 .../pinot/common/metadata/MetadataUtils.java       | 25 ++++++++------
 .../common/metadata/SegmentZKMetadataTest.java     | 25 ++++++++------
 .../pinot/common/metrics/MetricsHelperTest.java    | 25 ++++++++------
 .../common/partition/IdealStateBuilderUtil.java    | 25 ++++++++------
 .../StreamPartitionAssignmentGeneratorTest.java    | 25 ++++++++------
 .../pinot/common/query/gen/AvroQueryGenerator.java | 25 ++++++++------
 .../transform/TransformExpressionTreeTest.java     | 25 ++++++++------
 .../segment/fetcher/SegmentFetcherFactoryTest.java | 25 ++++++++------
 .../pinot/common/utils/DataSchemaTest.java         | 25 ++++++++------
 .../linkedin/pinot/common/utils/DataSizeTest.java  | 25 ++++++++------
 .../pinot/common/utils/EqualityUtilsTest.java      | 25 ++++++++------
 .../common/utils/FileUploadDownloadClientTest.java | 25 ++++++++------
 .../pinot/common/utils/SegmentNameBuilderTest.java | 25 ++++++++------
 .../pinot/common/utils/ServiceStatusTest.java      | 25 ++++++++------
 .../pinot/common/utils/StringUtilTest.java         | 25 ++++++++------
 .../common/utils/TarGzCompressionUtilsTest.java    | 25 ++++++++------
 .../com/linkedin/pinot/common/utils/UtilsTest.java | 25 ++++++++------
 .../pinot/common/utils/retry/RetryPolicyTest.java  | 25 ++++++++------
 .../pinot/common/utils/time/TimeConverterTest.java | 25 ++++++++------
 .../pinot/pql/parsers/Pql2CompilerTest.java        | 25 ++++++++------
 .../request/BrokerRequestSerializationTest.java    | 25 ++++++++------
 .../pinot/request/BrokerResponseNativeTest.java    | 25 ++++++++------
 pinot-common/src/thrift/request.thrift             | 25 ++++++++------
 pinot-common/src/thrift/response.thrift            | 25 ++++++++------
 pinot-controller/pom.xml                           | 25 ++++++++------
 .../linkedin/pinot/controller/ControllerConf.java  | 25 ++++++++------
 .../controller/ControllerLeadershipManager.java    | 26 ++++++++-------
 .../pinot/controller/ControllerStarter.java        | 25 ++++++++------
 .../controller/LeadershipChangeSubscriber.java     | 25 ++++++++------
 .../pinot/controller/api/CallableHttpGet.java      | 25 ++++++++------
 .../api/ControllerAdminApiApplication.java         | 25 ++++++++------
 .../pinot/controller/api/access/AccessControl.java | 25 ++++++++------
 .../api/access/AccessControlFactory.java           | 25 ++++++++------
 .../api/access/AllowAllAccessFactory.java          | 25 ++++++++------
 .../api/events/DefaultMetadataEventNotifier.java   | 25 ++++++++------
 .../DefaultMetadataEventNotifierFactory.java       | 25 ++++++++------
 .../api/events/MetadataEventNotifier.java          | 25 ++++++++------
 .../api/events/MetadataEventNotifierFactory.java   | 25 ++++++++------
 .../controller/api/events/SchemaEventType.java     | 25 ++++++++------
 .../pinot/controller/api/pojos/Instance.java       | 25 ++++++++------
 .../pinot/controller/api/resources/Constants.java  | 25 ++++++++------
 .../resources/ControllerApplicationException.java  | 25 ++++++++------
 .../api/resources/ControllerResponseFilter.java    | 25 ++++++++------
 .../api/resources/FileUploadPathProvider.java      | 25 ++++++++------
 .../controller/api/resources/HeaderAdder.java      | 25 ++++++++------
 .../InvalidControllerConfigException.java          | 25 ++++++++------
 .../resources/LLCSegmentCompletionHandlers.java    | 25 ++++++++------
 .../api/resources/LandingPageHandler.java          | 25 ++++++++------
 .../api/resources/PinotControllerHealthCheck.java  | 25 ++++++++------
 .../resources/PinotControllerResponseFilter.java   | 25 ++++++++------
 .../resources/PinotInstanceRestletResource.java    | 25 ++++++++------
 .../api/resources/PinotSchemaRestletResource.java  | 25 ++++++++------
 .../api/resources/PinotSegmentRestletResource.java | 25 ++++++++------
 .../PinotSegmentUploadRestletResource.java         | 25 ++++++++------
 .../resources/PinotTableConfigRestletResource.java | 25 ++++++++------
 .../api/resources/PinotTableIndexingConfigs.java   | 25 ++++++++------
 .../api/resources/PinotTableInstances.java         | 25 ++++++++------
 .../api/resources/PinotTableMetadataConfigs.java   | 25 ++++++++------
 .../api/resources/PinotTableRestletResource.java   | 25 ++++++++------
 .../controller/api/resources/PinotTableSchema.java | 25 ++++++++------
 .../api/resources/PinotTableSegmentConfigs.java    | 25 ++++++++------
 .../api/resources/PinotTableTenantConfigs.java     | 25 ++++++++------
 .../api/resources/PinotTaskRestletResource.java    | 25 ++++++++------
 .../api/resources/PinotTenantRestletResource.java  | 25 ++++++++------
 .../api/resources/PinotVersionRestletResource.java | 25 ++++++++------
 .../controller/api/resources/PqlQueryResource.java | 25 ++++++++------
 .../api/resources/ServerTableSizeReader.java       | 25 ++++++++------
 .../pinot/controller/api/resources/StateType.java  | 25 ++++++++------
 .../api/resources/StringResultResponse.java        | 25 ++++++++------
 .../controller/api/resources/SuccessResponse.java  | 25 ++++++++------
 .../pinot/controller/api/resources/TableSize.java  | 25 ++++++++------
 .../pinot/controller/api/resources/TableViews.java | 25 ++++++++------
 .../resources/WebApplicationExceptionMapper.java   | 25 ++++++++------
 .../controller/api/upload/SegmentValidator.java    | 25 ++++++++------
 .../pinot/controller/api/upload/ZKOperator.java    | 25 ++++++++------
 .../helix/ControllerRequestBuilderUtil.java        | 25 ++++++++------
 .../helix/ControllerRequestURLBuilder.java         | 25 ++++++++------
 .../EmptyBrokerOnlineOfflineStateModelFactory.java | 25 ++++++++------
 ...EmptySegmentOnlineOfflineStateModelFactory.java | 25 ++++++++------
 .../controller/helix/SegmentStatusChecker.java     | 25 ++++++++------
 ...erResourceOnlineOfflineStateModelGenerator.java | 25 ++++++++------
 .../helix/core/PinotHelixResourceManager.java      | 25 ++++++++------
 ...lixSegmentOnlineOfflineStateModelGenerator.java | 25 ++++++++------
 .../helix/core/PinotResourceManagerResponse.java   | 25 ++++++++------
 .../helix/core/PinotTableIdealStateBuilder.java    | 25 ++++++++------
 .../helix/core/SegmentDeletionManager.java         | 25 ++++++++------
 .../controller/helix/core/TableRebalancer.java     | 25 ++++++++------
 .../helix/core/minion/ClusterInfoProvider.java     | 25 ++++++++------
 .../core/minion/PinotHelixTaskResourceManager.java | 25 ++++++++------
 .../helix/core/minion/PinotTaskManager.java        | 25 ++++++++------
 .../generator/ConvertToRawIndexTaskGenerator.java  | 25 ++++++++------
 .../core/minion/generator/PinotTaskGenerator.java  | 25 ++++++++------
 .../minion/generator/TaskGeneratorRegistry.java    | 25 ++++++++------
 .../core/minion/generator/TaskGeneratorUtils.java  | 25 ++++++++------
 .../core/periodictask/ControllerPeriodicTask.java  | 25 ++++++++------
 .../ControllerPeriodicTaskScheduler.java           | 26 ++++++++-------
 .../realtime/PinotLLCRealtimeSegmentManager.java   | 25 ++++++++------
 .../core/realtime/PinotRealtimeSegmentManager.java | 25 ++++++++------
 .../core/realtime/SegmentCompletionManager.java    | 25 ++++++++------
 .../helix/core/realtime/TableConfigCache.java      | 25 ++++++++------
 .../segment/CommittingSegmentDescriptor.java       | 25 ++++++++------
 .../segment/DefaultFlushThresholdUpdater.java      | 25 ++++++++------
 .../segment/FlushThresholdUpdateManager.java       | 25 ++++++++------
 .../realtime/segment/FlushThresholdUpdater.java    | 25 ++++++++------
 .../SegmentSizeBasedFlushThresholdUpdater.java     | 25 ++++++++------
 .../rebalance/DefaultRebalanceSegmentStrategy.java | 25 ++++++++------
 .../core/rebalance/RebalanceSegmentStrategy.java   | 25 ++++++++------
 .../rebalance/RebalanceSegmentStrategyFactory.java | 25 ++++++++------
 .../rebalance/RebalanceUserConfigConstants.java    | 25 ++++++++------
 .../ReplicaGroupRebalanceSegmentStrategy.java      | 25 ++++++++------
 .../core/relocation/RealtimeSegmentRelocator.java  | 25 ++++++++------
 .../helix/core/retention/RetentionManager.java     | 25 ++++++++------
 .../core/retention/strategy/RetentionStrategy.java | 25 ++++++++------
 .../retention/strategy/TimeRetentionStrategy.java  | 25 ++++++++------
 .../BalanceNumSegmentAssignmentStrategy.java       | 25 ++++++++------
 .../core/sharding/BucketizedSegmentStrategy.java   | 25 ++++++++------
 .../core/sharding/RandomAssignmentStrategy.java    | 25 ++++++++------
 .../ReplicaGroupSegmentAssignmentStrategy.java     | 25 ++++++++------
 .../core/sharding/SegmentAssignmentStrategy.java   | 25 ++++++++------
 .../sharding/SegmentAssignmentStrategyEnum.java    | 25 ++++++++------
 .../sharding/SegmentAssignmentStrategyFactory.java | 25 ++++++++------
 .../helix/core/util/HelixSetupUtils.java           | 25 ++++++++------
 .../helix/core/util/ZKMetadataUtils.java           | 25 ++++++++------
 .../controller/helix/starter/HelixConfig.java      | 25 ++++++++------
 .../controller/util/AutoAddInvertedIndex.java      | 25 ++++++++------
 .../controller/util/SegmentCompletionUtils.java    | 25 ++++++++------
 .../controller/util/TableRetentionValidator.java   | 25 ++++++++------
 .../pinot/controller/util/TableSizeReader.java     | 25 ++++++++------
 .../controller/validation/StorageQuotaChecker.java | 25 ++++++++------
 .../controller/validation/ValidationManager.java   | 25 ++++++++------
 .../api/resources/AccessControlTest.java           | 25 ++++++++------
 .../api/resources/FileUploadPathProviderTest.java  | 25 ++++++++------
 .../api/resources/PinotFileUploadTest.java         | 25 ++++++++------
 .../PinotInstanceRestletResourceTest.java          | 25 ++++++++------
 .../resources/PinotSchemaRestletResourceTest.java  | 25 ++++++++------
 .../resources/PinotSegmentRestletResourceTest.java | 25 ++++++++------
 .../resources/PinotTableRestletResourceTest.java   | 25 ++++++++------
 .../resources/PinotTenantRestletResourceTest.java  | 25 ++++++++------
 .../SegmentCompletionProtocolDeserTest.java        | 25 ++++++++------
 .../api/resources/SegmentCompletionUtilsTest.java  | 25 ++++++++------
 .../api/resources/ServerTableSizeReaderTest.java   | 25 ++++++++------
 .../api/resources/TableSizeReaderTest.java         | 25 ++++++++------
 .../controller/api/resources/TableViewsTest.java   | 25 ++++++++------
 .../helix/ControllerInstanceToggleTest.java        | 25 ++++++++------
 .../controller/helix/ControllerSentinelTestV2.java | 25 ++++++++------
 .../controller/helix/ControllerTenantTest.java     | 25 ++++++++------
 .../pinot/controller/helix/ControllerTest.java     | 25 ++++++++------
 .../pinot/controller/helix/HelixHelperTest.java    | 25 ++++++++------
 .../controller/helix/PinotResourceManagerTest.java | 25 ++++++++------
 .../controller/helix/SegmentStatusCheckerTest.java | 25 ++++++++------
 .../helix/core/PinotHelixResourceManagerTest.java  | 25 ++++++++------
 .../periodictask/ControllerPeriodicTaskTest.java   | 25 ++++++++------
 .../PinotLLCRealtimeSegmentManagerTest.java        | 25 ++++++++------
 .../helix/core/realtime/SegmentCompletionTest.java | 25 ++++++++------
 .../segment/FlushThresholdUpdaterTest.java         | 25 ++++++++------
 .../rebalance/DefaultRebalanceStrategyTest.java    | 25 ++++++++------
 .../ReplicaGroupRebalanceStrategyTest.java         | 25 ++++++++------
 .../relocation/RealtimeSegmentRelocatorTest.java   | 25 ++++++++------
 .../helix/core/retention/RetentionManagerTest.java | 25 ++++++++------
 .../strategy/TimeRetentionStrategyTest.java        | 25 ++++++++------
 .../sharding/SegmentAssignmentStrategyTest.java    | 25 ++++++++------
 .../core/util/SegmentDeletionManagerTest.java      | 25 ++++++++------
 .../helix/core/util/TableRebalancerTest.java       | 25 ++++++++------
 .../controller/utils/ReplicaGroupTestUtils.java    | 25 ++++++++------
 .../controller/utils/SegmentMetadataMockUtils.java | 25 ++++++++------
 .../validation/StorageQuotaCheckerTest.java        | 25 ++++++++------
 .../validation/ValidationManagerTest.java          | 25 ++++++++------
 pinot-core/pom.xml                                 | 25 ++++++++------
 .../com/linkedin/pinot/core/bloom/BloomFilter.java | 25 ++++++++------
 .../linkedin/pinot/core/bloom/BloomFilterType.java | 25 ++++++++------
 .../linkedin/pinot/core/bloom/BloomFilterUtil.java | 25 ++++++++------
 .../pinot/core/bloom/GuavaOnHeapBloomFilter.java   | 25 ++++++++------
 .../core/bloom/SegmentBloomFilterFactory.java      | 25 ++++++++------
 .../pinot/core/common/BaseBlockValSet.java         | 25 ++++++++------
 .../java/com/linkedin/pinot/core/common/Block.java | 25 ++++++++------
 .../pinot/core/common/BlockDocIdIterator.java      | 25 ++++++++------
 .../linkedin/pinot/core/common/BlockDocIdSet.java  | 25 ++++++++------
 .../pinot/core/common/BlockDocIdValueIterator.java | 25 ++++++++------
 .../pinot/core/common/BlockDocIdValueSet.java      | 25 ++++++++------
 .../linkedin/pinot/core/common/BlockMetadata.java  | 25 ++++++++------
 .../pinot/core/common/BlockMultiValIterator.java   | 25 ++++++++------
 .../pinot/core/common/BlockSingleValIterator.java  | 25 ++++++++------
 .../pinot/core/common/BlockValIterator.java        | 25 ++++++++------
 .../linkedin/pinot/core/common/BlockValSet.java    | 25 ++++++++------
 .../com/linkedin/pinot/core/common/Constants.java  | 25 ++++++++------
 .../linkedin/pinot/core/common/DataBlockCache.java | 25 ++++++++------
 .../linkedin/pinot/core/common/DataFetcher.java    | 25 ++++++++------
 .../com/linkedin/pinot/core/common/DataSource.java | 25 ++++++++------
 .../pinot/core/common/DataSourceMetadata.java      | 25 ++++++++------
 .../pinot/core/common/MinionConstants.java         | 25 ++++++++------
 .../pinot/core/common/ObjectSerDeUtils.java        | 25 ++++++++------
 .../com/linkedin/pinot/core/common/Operator.java   | 25 ++++++++------
 .../com/linkedin/pinot/core/common/Predicate.java  | 25 ++++++++------
 .../core/common/datatable/DataTableBuilder.java    | 25 ++++++++------
 .../core/common/datatable/DataTableFactory.java    | 25 ++++++++------
 .../core/common/datatable/DataTableImplV2.java     | 25 ++++++++------
 .../core/common/datatable/DataTableUtils.java      | 25 ++++++++------
 .../core/common/predicate/BaseInPredicate.java     | 25 ++++++++------
 .../pinot/core/common/predicate/EqPredicate.java   | 25 ++++++++------
 .../pinot/core/common/predicate/InPredicate.java   | 25 ++++++++------
 .../pinot/core/common/predicate/NEqPredicate.java  | 25 ++++++++------
 .../core/common/predicate/NotInPredicate.java      | 25 ++++++++------
 .../core/common/predicate/RangePredicate.java      | 25 ++++++++------
 .../core/common/predicate/RegexpLikePredicate.java | 25 ++++++++------
 .../pinot/core/crypt/NoOpPinotCrypter.java         | 25 ++++++++------
 .../linkedin/pinot/core/crypt/PinotCrypter.java    | 25 ++++++++------
 .../pinot/core/crypt/PinotCrypterFactory.java      | 25 ++++++++------
 .../com/linkedin/pinot/core/data/GenericRow.java   | 25 ++++++++------
 .../core/data/aggregator/AvgValueAggregator.java   | 25 ++++++++------
 .../core/data/aggregator/CountValueAggregator.java | 25 ++++++++------
 .../DistinctCountHLLValueAggregator.java           | 25 ++++++++------
 .../core/data/aggregator/MaxValueAggregator.java   | 25 ++++++++------
 .../aggregator/MinMaxRangeValueAggregator.java     | 25 ++++++++------
 .../core/data/aggregator/MinValueAggregator.java   | 25 ++++++++------
 .../aggregator/PercentileEstValueAggregator.java   | 25 ++++++++------
 .../PercentileTDigestValueAggregator.java          | 25 ++++++++------
 .../core/data/aggregator/SumValueAggregator.java   | 25 ++++++++------
 .../core/data/aggregator/ValueAggregator.java      | 25 ++++++++------
 .../data/aggregator/ValueAggregatorFactory.java    | 25 ++++++++------
 .../data/function/FunctionExpressionEvaluator.java | 25 ++++++++------
 .../pinot/core/data/function/FunctionInfo.java     | 25 ++++++++------
 .../pinot/core/data/function/FunctionInvoker.java  | 25 ++++++++------
 .../pinot/core/data/function/FunctionRegistry.java | 25 ++++++++------
 .../core/data/manager/BaseTableDataManager.java    | 25 ++++++++------
 .../core/data/manager/InstanceDataManager.java     | 25 ++++++++------
 .../core/data/manager/SegmentDataManager.java      | 25 ++++++++------
 .../pinot/core/data/manager/TableDataManager.java  | 25 ++++++++------
 .../manager/config/InstanceDataManagerConfig.java  | 25 ++++++++------
 .../manager/config/TableDataManagerConfig.java     | 25 ++++++++------
 .../offline/ImmutableSegmentDataManager.java       | 25 ++++++++------
 .../manager/offline/OfflineTableDataManager.java   | 25 ++++++++------
 .../manager/offline/TableDataManagerProvider.java  | 25 ++++++++------
 .../realtime/HLRealtimeSegmentDataManager.java     | 25 ++++++++------
 .../realtime/LLRealtimeSegmentDataManager.java     | 25 ++++++++------
 .../realtime/RealtimeSegmentDataManager.java       | 25 ++++++++------
 .../manager/realtime/RealtimeTableDataManager.java | 25 ++++++++------
 .../realtime/SegmentBuildTimeLeaseExtender.java    | 25 ++++++++------
 .../core/data/manager/realtime/TimerService.java   | 25 ++++++++------
 .../data/partition/ByteArrayPartitionFunction.java | 25 ++++++++------
 .../data/partition/ModuloPartitionFunction.java    | 25 ++++++++------
 .../data/partition/MurmurPartitionFunction.java    | 25 ++++++++------
 .../core/data/partition/PartitionFunction.java     | 25 ++++++++------
 .../data/partition/PartitionFunctionFactory.java   | 25 ++++++++------
 .../pinot/core/data/readers/AvroRecordReader.java  | 25 ++++++++------
 .../pinot/core/data/readers/CSVRecordReader.java   | 25 ++++++++------
 .../core/data/readers/CSVRecordReaderConfig.java   | 25 ++++++++------
 .../pinot/core/data/readers/FileFormat.java        | 25 ++++++++------
 .../core/data/readers/GenericRowRecordReader.java  | 25 ++++++++------
 .../pinot/core/data/readers/JSONRecordReader.java  | 25 ++++++++------
 .../readers/MultiplePinotSegmentRecordReader.java  | 25 ++++++++------
 .../data/readers/PinotSegmentColumnReader.java     | 25 ++++++++------
 .../data/readers/PinotSegmentRecordReader.java     | 25 ++++++++------
 .../pinot/core/data/readers/RecordReader.java      | 25 ++++++++------
 .../core/data/readers/RecordReaderConfig.java      | 25 ++++++++------
 .../core/data/readers/RecordReaderFactory.java     | 25 ++++++++------
 .../pinot/core/data/readers/RecordReaderUtils.java | 25 ++++++++------
 .../core/data/readers/ThriftRecordReader.java      | 25 ++++++++------
 .../data/readers/ThriftRecordReaderConfig.java     | 25 ++++++++------
 .../core/data/readers/sort/PinotSegmentSorter.java | 25 ++++++++------
 .../core/data/readers/sort/SegmentSorter.java      | 25 ++++++++------
 .../recordtransformer/CompoundTransformer.java     | 25 ++++++++------
 .../recordtransformer/DataTypeTransformer.java     | 25 ++++++++------
 .../recordtransformer/ExpressionTransformer.java   | 25 ++++++++------
 .../core/data/recordtransformer/PinotDataType.java | 25 ++++++++------
 .../data/recordtransformer/RecordTransformer.java  | 25 ++++++++------
 .../recordtransformer/SanitationTransformer.java   | 25 ++++++++------
 .../data/recordtransformer/TimeTransformer.java    | 25 ++++++++------
 .../pinot/core/indexsegment/IndexSegment.java      | 25 ++++++++------
 .../pinot/core/indexsegment/IndexSegmentUtils.java | 25 ++++++++------
 .../generator/SegmentGeneratorConfig.java          | 25 ++++++++------
 .../indexsegment/generator/SegmentVersion.java     | 25 ++++++++------
 .../indexsegment/immutable/ImmutableSegment.java   | 25 ++++++++------
 .../immutable/ImmutableSegmentImpl.java            | 25 ++++++++------
 .../immutable/ImmutableSegmentLoader.java          | 25 ++++++++------
 .../core/indexsegment/mutable/MutableSegment.java  | 25 ++++++++------
 .../indexsegment/mutable/MutableSegmentImpl.java   | 25 ++++++++------
 .../pinot/core/io/compression/ChunkCompressor.java | 25 ++++++++------
 .../io/compression/ChunkCompressorFactory.java     | 25 ++++++++------
 .../core/io/compression/ChunkDecompressor.java     | 25 ++++++++------
 .../core/io/compression/PassThroughCompressor.java | 25 ++++++++------
 .../io/compression/PassThroughDecompressor.java    | 25 ++++++++------
 .../core/io/compression/SnappyCompressor.java      | 25 ++++++++------
 .../core/io/compression/SnappyDecompressor.java    | 25 ++++++++------
 .../reader/BaseSingleColumnMultiValueReader.java   | 25 ++++++++------
 .../reader/BaseSingleColumnSingleValueReader.java  | 25 ++++++++------
 .../pinot/core/io/reader/DataFileReader.java       | 25 ++++++++------
 .../pinot/core/io/reader/ReaderContext.java        | 25 ++++++++------
 .../io/reader/SingleColumnMultiValueReader.java    | 25 ++++++++------
 .../io/reader/SingleColumnSingleValueReader.java   | 25 ++++++++------
 .../io/reader/SingleValueMultiColumnReader.java    | 25 ++++++++------
 .../core/io/reader/impl/ChunkReaderContext.java    | 25 ++++++++------
 .../impl/FixedByteSingleValueMultiColReader.java   | 25 ++++++++------
 .../io/reader/impl/UnSortedValueReaderContext.java | 25 ++++++++------
 .../reader/impl/v1/BaseChunkSingleValueReader.java | 25 ++++++++------
 .../reader/impl/v1/FixedBitMultiValueReader.java   | 25 ++++++++------
 .../reader/impl/v1/FixedBitSingleValueReader.java  | 25 ++++++++------
 .../impl/v1/FixedByteChunkSingleValueReader.java   | 25 ++++++++------
 .../core/io/reader/impl/v1/SortedIndexReader.java  | 25 ++++++++------
 .../io/reader/impl/v1/SortedIndexReaderImpl.java   | 25 ++++++++------
 .../impl/v1/VarByteChunkSingleValueReader.java     | 25 ++++++++------
 .../BaseSingleColumnMultiValueReaderWriter.java    | 25 ++++++++------
 .../BaseSingleColumnSingleValueReaderWriter.java   | 25 ++++++++------
 .../BaseSingleValueMultiColumnReaderWriter.java    | 25 ++++++++------
 .../readerwriter/PinotDataBufferMemoryManager.java | 25 ++++++++------
 .../RealtimeIndexOffHeapMemoryManager.java         | 25 ++++++++------
 ...ixedByteSingleColumnMultiValueReaderWriter.java | 25 ++++++++------
 ...xedByteSingleColumnSingleValueReaderWriter.java | 25 ++++++++------
 ...ixedByteSingleValueMultiColumnReaderWriter.java | 25 ++++++++------
 .../io/util/DictionaryDelegatingValueReader.java   | 26 ++++++++-------
 .../core/io/util/FixedBitIntReaderWriter.java      | 25 ++++++++------
 .../core/io/util/FixedByteValueReaderWriter.java   | 25 ++++++++------
 .../pinot/core/io/util/PinotDataBitSet.java        | 25 ++++++++------
 .../linkedin/pinot/core/io/util/ValueReader.java   | 25 ++++++++------
 .../pinot/core/io/writer/DataFileWriter.java       | 25 ++++++++------
 .../io/writer/SingleColumnMultiValueWriter.java    | 25 ++++++++------
 .../io/writer/SingleColumnSingleValueWriter.java   | 25 ++++++++------
 .../io/writer/SingleValueMultiColumnWriter.java    | 25 ++++++++------
 .../core/io/writer/impl/DirectMemoryManager.java   | 25 ++++++++------
 .../impl/FixedByteSingleValueMultiColWriter.java   | 25 ++++++++------
 .../core/io/writer/impl/MmapMemoryManager.java     | 25 ++++++++------
 .../writer/impl/MutableOffHeapByteArrayStore.java  | 25 ++++++++------
 .../core/io/writer/impl/OffHeapStringStore.java    | 29 ++++++++--------
 .../writer/impl/v1/BaseChunkSingleValueWriter.java | 25 ++++++++------
 .../writer/impl/v1/FixedBitMultiValueWriter.java   | 25 ++++++++------
 .../writer/impl/v1/FixedBitSingleValueWriter.java  | 25 ++++++++------
 .../impl/v1/FixedByteChunkSingleValueWriter.java   | 25 ++++++++------
 .../impl/v1/VarByteChunkSingleValueWriter.java     | 25 ++++++++------
 .../core/metadata/DefaultMetadataExtractor.java    | 25 ++++++++------
 .../pinot/core/metadata/MetadataExtractor.java     | 25 ++++++++------
 .../core/metadata/MetadataExtractorFactory.java    | 25 ++++++++------
 .../pinot/core/minion/BackfillDateTimeColumn.java  | 25 ++++++++------
 .../pinot/core/minion/RawIndexConverter.java       | 25 ++++++++------
 .../pinot/core/minion/SegmentConverter.java        | 25 ++++++++------
 .../linkedin/pinot/core/minion/SegmentPurger.java  | 25 ++++++++------
 .../minion/rollup/MergeRollupSegmentConverter.java | 25 ++++++++------
 .../pinot/core/minion/rollup/MergeType.java        | 25 ++++++++------
 .../core/minion/rollup/RollupRecordAggregator.java | 25 ++++++++------
 .../rollup/aggregate/MaxValueAggregator.java       | 25 ++++++++------
 .../rollup/aggregate/SumValueAggregator.java       | 25 ++++++++------
 .../minion/rollup/aggregate/ValueAggregator.java   | 25 ++++++++------
 .../rollup/aggregate/ValueAggregatorFactory.java   | 25 ++++++++------
 .../minion/segment/DefaultRecordPartitioner.java   | 25 ++++++++------
 .../core/minion/segment/MapperRecordReader.java    | 25 ++++++++------
 .../core/minion/segment/RecordAggregator.java      | 25 ++++++++------
 .../core/minion/segment/RecordPartitioner.java     | 25 ++++++++------
 .../core/minion/segment/RecordTransformer.java     | 25 ++++++++------
 .../core/minion/segment/ReducerRecordReader.java   | 25 ++++++++------
 .../linkedin/pinot/core/operator/BaseOperator.java | 25 ++++++++------
 .../core/operator/CombineGroupByOperator.java      | 25 ++++++++------
 .../pinot/core/operator/CombineOperator.java       | 25 ++++++++------
 .../pinot/core/operator/DocIdSetOperator.java      | 25 ++++++++------
 .../pinot/core/operator/ExecutionStatistics.java   | 25 ++++++++------
 .../core/operator/InstanceResponseOperator.java    | 25 ++++++++------
 .../pinot/core/operator/ProjectionOperator.java    | 25 ++++++++------
 .../core/operator/blocks/BlockMetadataImpl.java    | 25 ++++++++------
 .../pinot/core/operator/blocks/DocIdSetBlock.java  | 25 ++++++++------
 .../core/operator/blocks/EmptyFilterBlock.java     | 25 ++++++++------
 .../pinot/core/operator/blocks/FilterBlock.java    | 25 ++++++++------
 .../operator/blocks/InstanceResponseBlock.java     | 25 ++++++++------
 .../operator/blocks/IntermediateResultsBlock.java  | 25 ++++++++------
 .../core/operator/blocks/MultiValueBlock.java      | 25 ++++++++------
 .../core/operator/blocks/ProjectionBlock.java      | 25 ++++++++------
 .../core/operator/blocks/SingleValueBlock.java     | 25 ++++++++------
 .../pinot/core/operator/blocks/TransformBlock.java | 25 ++++++++------
 .../operator/dociditerators/AndDocIdIterator.java  | 25 ++++++++------
 .../dociditerators/ArrayBasedDocIdIterator.java    | 25 ++++++++------
 .../dociditerators/BitmapDocIdIterator.java        | 25 ++++++++------
 .../dociditerators/EmptyBlockDocIdIterator.java    | 25 ++++++++------
 .../dociditerators/IndexBasedDocIdIterator.java    | 25 ++++++++------
 .../dociditerators/MVScanDocIdIterator.java        | 25 ++++++++------
 .../operator/dociditerators/OrDocIdIterator.java   | 25 ++++++++------
 .../RangelessBitmapDocIdIterator.java              | 25 ++++++++------
 .../dociditerators/SVScanDocIdIterator.java        | 25 ++++++++------
 .../dociditerators/ScanBasedDocIdIterator.java     | 25 ++++++++------
 .../dociditerators/SizeBasedDocIdIterator.java     | 25 ++++++++------
 .../dociditerators/SortedDocIdIterator.java        | 25 ++++++++------
 .../core/operator/docidsets/AndBlockDocIdSet.java  | 25 ++++++++------
 .../operator/docidsets/ArrayBasedDocIdSet.java     | 25 ++++++++------
 .../core/operator/docidsets/BitmapDocIdSet.java    | 25 ++++++++------
 .../docidsets/EmptyFilterBlockDocIdSet.java        | 25 ++++++++------
 .../operator/docidsets/FilterBlockDocIdSet.java    | 25 ++++++++------
 .../core/operator/docidsets/OrBlockDocIdSet.java   | 25 ++++++++------
 .../docidsets/ScanBasedMultiValueDocIdSet.java     | 25 ++++++++------
 .../docidsets/ScanBasedSingleValueDocIdSet.java    | 25 ++++++++------
 .../core/operator/docidsets/SizeBasedDocIdSet.java | 25 ++++++++------
 .../core/operator/docidsets/SortedDocIdSet.java    | 25 ++++++++------
 .../core/operator/docidsets/StarTreeDocIdSet.java  | 25 ++++++++------
 .../docvaliterators/MultiValueIterator.java        | 25 ++++++++------
 .../docvaliterators/SingleValueIterator.java       | 25 ++++++++------
 .../core/operator/docvalsets/MultiValueSet.java    | 25 ++++++++------
 .../operator/docvalsets/ProjectionBlockValSet.java | 25 ++++++++------
 .../core/operator/docvalsets/SingleValueSet.java   | 25 ++++++++------
 .../operator/docvalsets/TransformBlockValSet.java  | 25 ++++++++------
 .../core/operator/filter/AndFilterOperator.java    | 25 ++++++++------
 .../core/operator/filter/BaseFilterOperator.java   | 25 ++++++++------
 .../operator/filter/BitmapBasedFilterOperator.java | 25 ++++++++------
 .../core/operator/filter/EmptyFilterOperator.java  | 25 ++++++++------
 .../core/operator/filter/FilterOperatorUtils.java  | 25 ++++++++------
 .../pinot/core/operator/filter/IntRanges.java      | 25 ++++++++------
 .../operator/filter/MatchAllFilterOperator.java    | 25 ++++++++------
 .../core/operator/filter/OrFilterOperator.java     | 25 ++++++++------
 .../operator/filter/ScanBasedFilterOperator.java   | 25 ++++++++------
 .../SortedInvertedIndexBasedFilterOperator.java    | 25 ++++++++------
 .../BaseDictionaryBasedPredicateEvaluator.java     | 25 ++++++++------
 .../filter/predicate/BasePredicateEvaluator.java   | 25 ++++++++------
 .../BaseRawValueBasedPredicateEvaluator.java       | 25 ++++++++------
 .../predicate/EqualsPredicateEvaluatorFactory.java | 25 ++++++++------
 .../predicate/InPredicateEvaluatorFactory.java     | 25 ++++++++------
 .../NotEqualsPredicateEvaluatorFactory.java        | 25 ++++++++------
 .../predicate/NotInPredicateEvaluatorFactory.java  | 25 ++++++++------
 .../filter/predicate/PredicateEvaluator.java       | 25 ++++++++------
 .../predicate/PredicateEvaluatorProvider.java      | 25 ++++++++------
 .../predicate/RangePredicateEvaluatorFactory.java  | 25 ++++++++------
 .../RegexpLikePredicateEvaluatorFactory.java       | 25 ++++++++------
 .../operator/query/AggregationGroupByOperator.java | 25 ++++++++------
 .../core/operator/query/AggregationOperator.java   | 25 ++++++++------
 .../query/DictionaryBasedAggregationOperator.java  | 25 ++++++++------
 .../operator/query/EmptySelectionOperator.java     | 25 ++++++++------
 .../query/MetadataBasedAggregationOperator.java    | 25 ++++++++------
 .../core/operator/query/SelectionOnlyOperator.java | 25 ++++++++------
 .../operator/query/SelectionOrderByOperator.java   | 25 ++++++++------
 .../core/operator/transform/TransformOperator.java | 25 ++++++++------
 .../transform/TransformResultMetadata.java         | 25 ++++++++------
 .../function/AdditionTransformFunction.java        | 25 ++++++++------
 .../transform/function/BaseTransformFunction.java  | 25 ++++++++------
 .../DateTimeConversionTransformFunction.java       | 25 ++++++++------
 .../function/DivisionTransformFunction.java        | 25 ++++++++------
 .../function/IdentifierTransformFunction.java      | 25 ++++++++------
 .../function/LiteralTransformFunction.java         | 25 ++++++++------
 .../function/MultiplicationTransformFunction.java  | 25 ++++++++------
 .../function/SubtractionTransformFunction.java     | 25 ++++++++------
 .../function/TimeConversionTransformFunction.java  | 25 ++++++++------
 .../transform/function/TransformFunction.java      | 25 ++++++++------
 .../function/TransformFunctionFactory.java         | 25 ++++++++------
 .../function/ValueInTransformFunction.java         | 25 ++++++++------
 .../transform/transformer/DataTransformer.java     | 25 ++++++++------
 .../datetime/BaseDateTimeTransformer.java          | 25 ++++++++------
 .../datetime/DateTimeTransformerFactory.java       | 25 ++++++++------
 .../datetime/EpochToEpochTransformer.java          | 25 ++++++++------
 .../datetime/EpochToSDFTransformer.java            | 25 ++++++++------
 .../datetime/SDFToEpochTransformer.java            | 25 ++++++++------
 .../transformer/datetime/SDFToSDFTransformer.java  | 25 ++++++++------
 .../timeunit/CustomTimeUnitTransformer.java        | 25 ++++++++------
 .../timeunit/JavaTimeUnitTransformer.java          | 25 ++++++++------
 .../transformer/timeunit/TimeUnitTransformer.java  | 25 ++++++++------
 .../timeunit/TimeUnitTransformerFactory.java       | 25 ++++++++------
 .../pinot/core/periodictask/BasePeriodicTask.java  | 25 ++++++++------
 .../pinot/core/periodictask/PeriodicTask.java      | 25 ++++++++------
 .../core/periodictask/PeriodicTaskScheduler.java   | 25 ++++++++------
 .../core/plan/AggregationFunctionInitializer.java  | 25 ++++++++------
 .../core/plan/AggregationGroupByPlanNode.java      | 25 ++++++++------
 .../pinot/core/plan/AggregationPlanNode.java       | 25 ++++++++------
 .../linkedin/pinot/core/plan/CombinePlanNode.java  | 25 ++++++++------
 .../plan/DictionaryBasedAggregationPlanNode.java   | 25 ++++++++------
 .../linkedin/pinot/core/plan/DocIdSetPlanNode.java | 25 ++++++++------
 .../linkedin/pinot/core/plan/FilterPlanNode.java   | 25 ++++++++------
 .../linkedin/pinot/core/plan/GlobalPlanImplV0.java | 25 ++++++++------
 .../pinot/core/plan/InstanceResponsePlanNode.java  | 25 ++++++++------
 .../plan/MetadataBasedAggregationPlanNode.java     | 25 ++++++++------
 .../java/com/linkedin/pinot/core/plan/Plan.java    | 25 ++++++++------
 .../com/linkedin/pinot/core/plan/PlanNode.java     | 25 ++++++++------
 .../pinot/core/plan/ProjectionPlanNode.java        | 25 ++++++++------
 .../pinot/core/plan/SelectionPlanNode.java         | 25 ++++++++------
 .../pinot/core/plan/TransformPlanNode.java         | 25 ++++++++------
 .../core/plan/maker/BrokerRequestPreProcessor.java | 25 ++++++++------
 .../core/plan/maker/InstancePlanMakerImplV2.java   | 25 ++++++++------
 .../linkedin/pinot/core/plan/maker/PlanMaker.java  | 25 ++++++++------
 .../query/aggregation/AggregationExecutor.java     | 25 ++++++++------
 .../aggregation/AggregationFunctionContext.java    | 25 ++++++++------
 .../query/aggregation/AggregationResultHolder.java | 25 ++++++++------
 .../aggregation/DefaultAggregationExecutor.java    | 25 ++++++++------
 .../aggregation/DoubleAggregationResultHolder.java | 25 ++++++++------
 .../aggregation/ObjectAggregationResultHolder.java | 25 ++++++++------
 .../aggregation/function/AggregationFunction.java  | 25 ++++++++------
 .../function/AggregationFunctionFactory.java       | 25 ++++++++------
 .../function/AggregationFunctionType.java          | 25 ++++++++------
 .../function/AggregationFunctionUtils.java         | 25 ++++++++------
 .../function/AggregationFunctionVisitorBase.java   | 25 ++++++++------
 .../function/AvgAggregationFunction.java           | 25 ++++++++------
 .../function/AvgMVAggregationFunction.java         | 25 ++++++++------
 .../function/CountAggregationFunction.java         | 25 ++++++++------
 .../function/CountMVAggregationFunction.java       | 25 ++++++++------
 .../function/DistinctCountAggregationFunction.java | 25 ++++++++------
 .../DistinctCountHLLAggregationFunction.java       | 25 ++++++++------
 .../DistinctCountHLLMVAggregationFunction.java     | 25 ++++++++------
 .../DistinctCountMVAggregationFunction.java        | 25 ++++++++------
 .../function/FastHLLAggregationFunction.java       | 25 ++++++++------
 .../function/MaxAggregationFunction.java           | 25 ++++++++------
 .../function/MaxMVAggregationFunction.java         | 25 ++++++++------
 .../function/MinAggregationFunction.java           | 25 ++++++++------
 .../function/MinMVAggregationFunction.java         | 25 ++++++++------
 .../function/MinMaxRangeAggregationFunction.java   | 25 ++++++++------
 .../function/MinMaxRangeMVAggregationFunction.java | 25 ++++++++------
 .../function/PercentileAggregationFunction.java    | 25 ++++++++------
 .../function/PercentileEstAggregationFunction.java | 25 ++++++++------
 .../PercentileEstMVAggregationFunction.java        | 25 ++++++++------
 .../function/PercentileMVAggregationFunction.java  | 25 ++++++++------
 .../PercentileTDigestAggregationFunction.java      | 25 ++++++++------
 .../PercentileTDigestMVAggregationFunction.java    | 25 ++++++++------
 .../function/SumAggregationFunction.java           | 25 ++++++++------
 .../function/SumMVAggregationFunction.java         | 25 ++++++++------
 .../aggregation/function/customobject/AvgPair.java | 25 ++++++++------
 .../function/customobject/MinMaxRangePair.java     | 25 ++++++++------
 .../function/customobject/QuantileDigest.java      | 25 ++++++++------
 .../groupby/AggregationGroupByResult.java          | 25 ++++++++------
 .../groupby/AggregationGroupByTrimmingService.java | 25 ++++++++------
 .../groupby/DefaultGroupByExecutor.java            | 25 ++++++++------
 .../groupby/DictionaryBasedGroupKeyGenerator.java  | 25 ++++++++------
 .../groupby/DoubleGroupByResultHolder.java         | 25 ++++++++------
 .../query/aggregation/groupby/GroupByExecutor.java | 25 ++++++++------
 .../aggregation/groupby/GroupByResultHolder.java   | 25 ++++++++------
 .../aggregation/groupby/GroupKeyGenerator.java     | 25 ++++++++------
 .../NoDictionaryMultiColumnGroupKeyGenerator.java  | 25 ++++++++------
 .../NoDictionarySingleColumnGroupKeyGenerator.java | 25 ++++++++------
 .../groupby/ObjectGroupByResultHolder.java         | 25 ++++++++------
 .../groupby/utils/BaseValueToIdMap.java            | 25 ++++++++------
 .../aggregation/groupby/utils/DoubleToIdMap.java   | 25 ++++++++------
 .../aggregation/groupby/utils/FloatToIdMap.java    | 25 ++++++++------
 .../aggregation/groupby/utils/IntToIdMap.java      | 25 ++++++++------
 .../aggregation/groupby/utils/LongToIdMap.java     | 25 ++++++++------
 .../aggregation/groupby/utils/StringToIdMap.java   | 25 ++++++++------
 .../aggregation/groupby/utils/ValueToIdMap.java    | 25 ++++++++------
 .../groupby/utils/ValueToIdMapFactory.java         | 25 ++++++++------
 .../core/query/config/QueryExecutorConfig.java     | 25 ++++++++------
 .../core/query/config/QueryPlannerConfig.java      | 25 ++++++++------
 .../core/query/config/SegmentPrunerConfig.java     | 25 ++++++++------
 .../query/exception/BadQueryRequestException.java  | 25 ++++++++------
 .../pinot/core/query/executor/QueryExecutor.java   | 25 ++++++++------
 .../query/executor/ServerQueryExecutorV1Impl.java  | 25 ++++++++------
 .../core/query/pruner/AbstractSegmentPruner.java   | 25 ++++++++------
 .../query/pruner/ColumnValueSegmentPruner.java     | 25 ++++++++------
 .../core/query/pruner/DataSchemaSegmentPruner.java | 25 ++++++++------
 .../core/query/pruner/PartitionSegmentPruner.java  | 25 ++++++++------
 .../pinot/core/query/pruner/SegmentPruner.java     | 25 ++++++++------
 .../core/query/pruner/SegmentPrunerProvider.java   | 25 ++++++++------
 .../core/query/pruner/SegmentPrunerService.java    | 25 ++++++++------
 .../core/query/pruner/ValidSegmentPruner.java      | 25 ++++++++------
 .../pinot/core/query/reduce/BetweenComparison.java | 25 ++++++++------
 .../core/query/reduce/BrokerReduceService.java     | 25 ++++++++------
 .../pinot/core/query/reduce/CombineService.java    | 25 ++++++++------
 .../core/query/reduce/ComparisonFunction.java      | 25 ++++++++------
 .../pinot/core/query/reduce/EqualComparison.java   | 25 ++++++++------
 .../core/query/reduce/GreaterEqualComparison.java  | 25 ++++++++------
 .../core/query/reduce/GreaterThanComparison.java   | 25 ++++++++------
 .../query/reduce/HavingClauseComparisonTree.java   | 25 ++++++++------
 .../core/query/reduce/InAndNotInComparison.java    | 25 ++++++++------
 .../core/query/reduce/LessEqualComparison.java     | 25 ++++++++------
 .../core/query/reduce/LessThanComparison.java      | 25 ++++++++------
 .../core/query/reduce/NotEqualComparison.java      | 25 ++++++++------
 .../core/query/request/ServerQueryRequest.java     | 25 ++++++++------
 .../core/query/request/context/TimerContext.java   | 25 ++++++++------
 .../query/scheduler/AbstractSchedulerGroup.java    | 25 ++++++++------
 .../query/scheduler/MultiLevelPriorityQueue.java   | 25 ++++++++------
 .../query/scheduler/OutOfCapacityException.java    | 25 ++++++++------
 .../core/query/scheduler/PriorityScheduler.java    | 25 ++++++++------
 .../pinot/core/query/scheduler/QueryScheduler.java | 25 ++++++++------
 .../query/scheduler/QuerySchedulerFactory.java     | 25 ++++++++------
 .../pinot/core/query/scheduler/SchedulerGroup.java | 25 ++++++++------
 .../query/scheduler/SchedulerGroupAccountant.java  | 25 ++++++++------
 .../query/scheduler/SchedulerGroupFactory.java     | 25 ++++++++------
 .../core/query/scheduler/SchedulerGroupMapper.java | 25 ++++++++------
 .../query/scheduler/SchedulerPriorityQueue.java    | 25 ++++++++------
 .../query/scheduler/SchedulerQueryContext.java     | 25 ++++++++------
 .../query/scheduler/TableBasedGroupMapper.java     | 25 ++++++++------
 .../query/scheduler/fcfs/BoundedFCFSScheduler.java | 25 ++++++++------
 .../query/scheduler/fcfs/FCFSQueryScheduler.java   | 25 ++++++++------
 .../query/scheduler/fcfs/FCFSSchedulerGroup.java   | 25 ++++++++------
 .../resources/BoundedAccountingExecutor.java       | 25 ++++++++------
 .../resources/PolicyBasedResourceManager.java      | 25 ++++++++------
 .../scheduler/resources/QueryExecutorService.java  | 25 ++++++++------
 .../scheduler/resources/ResourceLimitPolicy.java   | 25 ++++++++------
 .../query/scheduler/resources/ResourceManager.java | 25 ++++++++------
 .../resources/UnboundedResourceManager.java        | 25 ++++++++------
 .../tokenbucket/TokenPriorityScheduler.java        | 25 ++++++++------
 .../scheduler/tokenbucket/TokenSchedulerGroup.java | 25 ++++++++------
 .../core/query/selection/SelectionFetcher.java     | 25 ++++++++------
 .../query/selection/SelectionOperatorService.java  | 25 ++++++++------
 .../query/selection/SelectionOperatorUtils.java    | 25 ++++++++------
 .../comparator/CompositeDocIdValComparator.java    | 25 ++++++++------
 .../comparator/DocIdDoubleValComparator.java       | 25 ++++++++------
 .../comparator/DocIdFloatValComparator.java        | 25 ++++++++------
 .../comparator/DocIdIntValComparator.java          | 25 ++++++++------
 .../comparator/DocIdLongValComparator.java         | 25 ++++++++------
 .../selection/comparator/IDocIdValComparator.java  | 25 ++++++++------
 .../DoubleArraySelectionColumnIterator.java        | 25 ++++++++------
 .../iterator/DoubleSelectionColumnIterator.java    | 25 ++++++++------
 .../FloatArraySelectionColumnIterator.java         | 25 ++++++++------
 .../iterator/FloatSelectionColumnIterator.java     | 25 ++++++++------
 .../iterator/IntArraySelectionColumnIterator.java  | 25 ++++++++------
 .../iterator/IntSelectionColumnIterator.java       | 25 ++++++++------
 .../iterator/LongArraySelectionColumnIterator.java | 25 ++++++++------
 .../iterator/LongSelectionColumnIterator.java      | 25 ++++++++------
 .../iterator/SelectionColumnIterator.java          | 25 ++++++++------
 .../SelectionMultiValueColumnIterator.java         | 25 ++++++++------
 ...SelectionSingleValueColumnWithDictIterator.java | 25 ++++++++------
 .../StringArraySelectionColumnIterator.java        | 25 ++++++++------
 .../iterator/StringSelectionColumnIterator.java    | 25 ++++++++------
 .../com/linkedin/pinot/core/query/utils/Pair.java  | 25 ++++++++------
 .../linkedin/pinot/core/query/utils/TrieNode.java  | 25 ++++++++------
 .../converter/RealtimeSegmentConverter.java        | 25 ++++++++------
 .../converter/RealtimeSegmentRecordReader.java     | 25 ++++++++------
 .../converter/stats/RealtimeColumnStatistics.java  | 25 ++++++++------
 .../stats/RealtimeNoDictionaryColStatistics.java   | 25 ++++++++------
 .../RealtimeSegmentSegmentCreationDataSource.java  | 25 ++++++++------
 .../stats/RealtimeSegmentStatsContainer.java       | 25 ++++++++------
 .../core/realtime/impl/RealtimeSegmentConfig.java  | 25 ++++++++------
 .../realtime/impl/RealtimeSegmentStatsHistory.java | 25 ++++++++------
 .../dictionary/BaseOffHeapMutableDictionary.java   | 25 ++++++++------
 .../dictionary/BaseOnHeapMutableDictionary.java    | 25 ++++++++------
 .../dictionary/BytesOffHeapMutableDictionary.java  | 25 ++++++++------
 .../dictionary/BytesOnHeapMutableDictionary.java   | 25 ++++++++------
 .../dictionary/DoubleOffHeapMutableDictionary.java | 25 ++++++++------
 .../dictionary/DoubleOnHeapMutableDictionary.java  | 25 ++++++++------
 .../dictionary/FloatOffHeapMutableDictionary.java  | 25 ++++++++------
 .../dictionary/FloatOnHeapMutableDictionary.java   | 25 ++++++++------
 .../dictionary/IntOffHeapMutableDictionary.java    | 25 ++++++++------
 .../dictionary/IntOnHeapMutableDictionary.java     | 25 ++++++++------
 .../dictionary/LongOffHeapMutableDictionary.java   | 25 ++++++++------
 .../dictionary/LongOnHeapMutableDictionary.java    | 25 ++++++++------
 .../impl/dictionary/MutableDictionary.java         | 25 ++++++++------
 .../impl/dictionary/MutableDictionaryFactory.java  | 25 ++++++++------
 .../dictionary/StringOffHeapMutableDictionary.java | 25 ++++++++------
 .../dictionary/StringOnHeapMutableDictionary.java  | 25 ++++++++------
 .../invertedindex/RealtimeInvertedIndexReader.java | 25 ++++++++------
 .../impl/kafka/AvroRecordToPinotRowGenerator.java  | 25 ++++++++------
 .../realtime/impl/kafka/ConsumerAndIterator.java   | 25 ++++++++------
 .../impl/kafka/KafkaAvroMessageDecoder.java        | 25 ++++++++------
 .../realtime/impl/kafka/KafkaBrokerWrapper.java    | 25 ++++++++------
 .../impl/kafka/KafkaConnectionHandler.java         | 25 ++++++++------
 .../realtime/impl/kafka/KafkaConsumerFactory.java  | 25 ++++++++------
 .../realtime/impl/kafka/KafkaConsumerManager.java  | 25 ++++++++------
 .../impl/kafka/KafkaHighLevelStreamConfig.java     | 25 ++++++++------
 .../impl/kafka/KafkaJSONMessageDecoder.java        | 25 ++++++++------
 .../impl/kafka/KafkaLowLevelStreamConfig.java      | 25 ++++++++------
 .../impl/kafka/KafkaPartitionLevelConsumer.java    | 25 ++++++++------
 .../impl/kafka/KafkaSimpleConsumerFactory.java     | 25 ++++++++------
 .../impl/kafka/KafkaSimpleConsumerFactoryImpl.java | 25 ++++++++------
 .../impl/kafka/KafkaStreamConfigProperties.java    | 25 ++++++++------
 .../impl/kafka/KafkaStreamLevelConsumer.java       | 25 ++++++++------
 .../impl/kafka/KafkaStreamMetadataProvider.java    | 25 ++++++++------
 .../realtime/impl/kafka/SimpleConsumerFactory.java | 25 ++++++++------
 .../impl/kafka/SimpleConsumerMessageBatch.java     | 25 ++++++++------
 .../ConsumingSegmentAssignmentStrategy.java        | 25 ++++++++------
 .../segment/RealtimeSegmentAssignmentStrategy.java | 25 ++++++++------
 .../pinot/core/realtime/stream/MessageBatch.java   | 25 ++++++++------
 .../pinot/core/realtime/stream/OffsetCriteria.java | 25 ++++++++------
 .../realtime/stream/PartitionCountFetcher.java     | 25 ++++++++------
 .../realtime/stream/PartitionLevelConsumer.java    | 25 ++++++++------
 .../stream/PartitionLevelStreamConfig.java         | 25 ++++++++------
 .../realtime/stream/PartitionOffsetFetcher.java    | 25 ++++++++------
 .../stream/PermanentConsumerException.java         | 25 ++++++++------
 .../pinot/core/realtime/stream/StreamConfig.java   | 25 ++++++++------
 .../realtime/stream/StreamConfigProperties.java    | 25 ++++++++------
 .../realtime/stream/StreamConsumerFactory.java     | 25 ++++++++------
 .../stream/StreamConsumerFactoryProvider.java      | 25 ++++++++------
 .../realtime/stream/StreamDecoderProvider.java     | 25 ++++++++------
 .../core/realtime/stream/StreamLevelConsumer.java  | 25 ++++++++------
 .../core/realtime/stream/StreamMessageDecoder.java | 25 ++++++++------
 .../realtime/stream/StreamMetadataProvider.java    | 25 ++++++++------
 .../stream/TransientConsumerException.java         | 25 ++++++++------
 .../creator/BaseSingleValueRawIndexCreator.java    | 25 ++++++++------
 .../segment/creator/ColumnIndexCreationInfo.java   | 25 ++++++++------
 .../core/segment/creator/ColumnStatistics.java     | 25 ++++++++------
 .../core/segment/creator/ForwardIndexCreator.java  | 25 ++++++++------
 .../core/segment/creator/ForwardIndexType.java     | 25 ++++++++------
 .../core/segment/creator/InvertedIndexCreator.java | 25 ++++++++------
 .../core/segment/creator/InvertedIndexType.java    | 25 ++++++++------
 .../creator/MultiValueForwardIndexCreator.java     | 25 ++++++++------
 .../RecordReaderSegmentCreationDataSource.java     | 25 ++++++++------
 .../segment/creator/SegmentCreationDataSource.java | 25 ++++++++------
 .../pinot/core/segment/creator/SegmentCreator.java | 25 ++++++++------
 .../creator/SegmentIndexCreationDriver.java        | 25 ++++++++------
 .../segment/creator/SegmentIndexCreationInfo.java  | 25 ++++++++------
 .../creator/SegmentPreIndexStatsCollector.java     | 25 ++++++++------
 .../creator/SegmentPreIndexStatsContainer.java     | 25 ++++++++------
 .../creator/SingleValueForwardIndexCreator.java    | 25 ++++++++------
 .../creator/SingleValueRawIndexCreator.java        | 25 ++++++++------
 .../core/segment/creator/StatsCollectorConfig.java | 25 ++++++++------
 .../creator/impl/SegmentColumnarIndexCreator.java  | 25 ++++++++------
 .../creator/impl/SegmentCreationDriverFactory.java | 25 ++++++++------
 .../creator/impl/SegmentDictionaryCreator.java     | 25 ++++++++------
 .../impl/SegmentIndexCreationDriverImpl.java       | 25 ++++++++------
 .../core/segment/creator/impl/V1Constants.java     | 25 ++++++++------
 .../creator/impl/bloom/BloomFilterCreator.java     | 25 ++++++++------
 .../fwd/MultiValueUnsortedForwardIndexCreator.java | 25 ++++++++------
 .../fwd/SingleValueFixedByteRawIndexCreator.java   | 25 ++++++++------
 .../fwd/SingleValueSortedForwardIndexCreator.java  | 25 ++++++++------
 .../SingleValueUnsortedForwardIndexCreator.java    | 25 ++++++++------
 .../fwd/SingleValueVarByteRawIndexCreator.java     | 25 ++++++++------
 .../inv/OffHeapBitmapInvertedIndexCreator.java     | 25 ++++++++------
 .../impl/inv/OnHeapBitmapInvertedIndexCreator.java | 25 ++++++++------
 .../stats/AbstractColumnStatisticsCollector.java   | 25 ++++++++------
 .../stats/BytesColumnPredIndexStatsCollector.java  | 25 ++++++++------
 .../stats/DoubleColumnPreIndexStatsCollector.java  | 25 ++++++++------
 .../stats/FloatColumnPreIndexStatsCollector.java   | 25 ++++++++------
 .../stats/IntColumnPreIndexStatsCollector.java     | 25 ++++++++------
 .../stats/LongColumnPreIndexStatsCollector.java    | 25 ++++++++------
 .../stats/SegmentPreIndexStatsCollectorImpl.java   | 25 ++++++++------
 .../stats/StringColumnPreIndexStatsCollector.java  | 25 ++++++++------
 .../pinot/core/segment/index/ColumnMetadata.java   | 25 ++++++++------
 .../core/segment/index/SegmentMetadataImpl.java    | 25 ++++++++------
 .../segment/index/column/ColumnIndexContainer.java | 25 ++++++++------
 .../index/column/PhysicalColumnIndexContainer.java | 25 ++++++++------
 .../index/converter/SegmentFormatConverter.java    | 25 ++++++++------
 .../converter/SegmentFormatConverterFactory.java   | 25 ++++++++------
 .../converter/SegmentV1V2ToV3FormatConverter.java  | 25 ++++++++------
 .../index/data/source/ColumnDataSource.java        | 25 ++++++++------
 .../segment/index/loader/IndexLoadingConfig.java   | 25 ++++++++------
 .../core/segment/index/loader/LoaderUtils.java     | 25 ++++++++------
 .../segment/index/loader/SegmentPreProcessor.java  | 25 ++++++++------
 .../index/loader/V3RemoveIndexException.java       | 25 ++++++++------
 .../loader/bloomfilter/BloomFilterHandler.java     | 25 ++++++++------
 .../ColumnMinMaxValueGenerator.java                | 25 ++++++++------
 .../ColumnMinMaxValueGeneratorMode.java            | 25 ++++++++------
 .../defaultcolumn/BaseDefaultColumnHandler.java    | 25 ++++++++------
 .../loader/defaultcolumn/DefaultColumnHandler.java | 25 ++++++++------
 .../defaultcolumn/DefaultColumnHandlerFactory.java | 25 ++++++++------
 .../defaultcolumn/DefaultColumnStatistics.java     | 26 ++++++++-------
 .../defaultcolumn/V1DefaultColumnHandler.java      | 25 ++++++++------
 .../defaultcolumn/V3DefaultColumnHandler.java      | 25 ++++++++------
 .../loader/invertedindex/InvertedIndexHandler.java | 25 ++++++++------
 .../core/segment/index/readers/BaseDictionary.java | 25 ++++++++------
 .../index/readers/BitmapInvertedIndexReader.java   | 25 ++++++++------
 .../segment/index/readers/BloomFilterReader.java   | 25 ++++++++------
 .../segment/index/readers/BytesDictionary.java     | 25 ++++++++------
 .../core/segment/index/readers/Dictionary.java     | 25 ++++++++------
 .../segment/index/readers/DoubleDictionary.java    | 25 ++++++++------
 .../segment/index/readers/FloatDictionary.java     | 25 ++++++++------
 .../index/readers/ImmutableDictionaryReader.java   | 25 ++++++++------
 .../core/segment/index/readers/IntDictionary.java  | 25 ++++++++------
 .../segment/index/readers/InvertedIndexReader.java | 25 ++++++++------
 .../core/segment/index/readers/LongDictionary.java | 25 ++++++++------
 .../segment/index/readers/OnHeapDictionary.java    | 25 ++++++++------
 .../index/readers/OnHeapDoubleDictionary.java      | 25 ++++++++------
 .../index/readers/OnHeapFloatDictionary.java       | 25 ++++++++------
 .../segment/index/readers/OnHeapIntDictionary.java | 25 ++++++++------
 .../index/readers/OnHeapLongDictionary.java        | 25 ++++++++------
 .../index/readers/OnHeapStringDictionary.java      | 25 ++++++++------
 .../segment/index/readers/StringDictionary.java    | 25 ++++++++------
 .../core/segment/memory/BasePinotLBuffer.java      | 25 ++++++++------
 .../pinot/core/segment/memory/PinotByteBuffer.java | 25 ++++++++------
 .../pinot/core/segment/memory/PinotDataBuffer.java | 25 ++++++++------
 .../segment/memory/PinotNativeOrderLBuffer.java    | 25 ++++++++------
 .../segment/memory/PinotNonNativeOrderLBuffer.java | 25 ++++++++------
 .../segment/name/DefaultSegmentNameGenerator.java  | 25 ++++++++------
 .../name/NormalizedDateSegmentNameGenerator.java   | 25 ++++++++------
 .../core/segment/name/SegmentNameGenerator.java    | 25 ++++++++------
 .../core/segment/store/ColumnIndexDirectory.java   | 25 ++++++++------
 .../pinot/core/segment/store/ColumnIndexType.java  | 25 ++++++++------
 .../core/segment/store/FilePerIndexDirectory.java  | 25 ++++++++------
 .../pinot/core/segment/store/IndexEntry.java       | 25 ++++++++------
 .../pinot/core/segment/store/IndexKey.java         | 25 ++++++++------
 .../pinot/core/segment/store/SegmentDirectory.java | 25 ++++++++------
 .../core/segment/store/SegmentDirectoryPaths.java  | 25 ++++++++------
 .../segment/store/SegmentLocalFSDirectory.java     | 25 ++++++++------
 .../segment/store/SingleFileIndexDirectory.java    | 25 ++++++++------
 .../virtualcolumn/BaseVirtualColumnProvider.java   | 25 ++++++++------
 .../virtualcolumn/DocIdVirtualColumnProvider.java  | 25 ++++++++------
 .../HostNameVirtualColumnProvider.java             | 25 ++++++++------
 .../IntSingleValueDataFileReader.java              | 25 ++++++++------
 .../SegmentNameVirtualColumnProvider.java          | 25 ++++++++------
 .../SingleStringVirtualColumnProvider.java         | 25 ++++++++------
 .../virtualcolumn/VirtualColumnContext.java        | 25 ++++++++------
 .../virtualcolumn/VirtualColumnIndexContainer.java | 25 ++++++++------
 .../virtualcolumn/VirtualColumnProvider.java       | 25 ++++++++------
 .../VirtualColumnProviderFactory.java              | 25 ++++++++------
 .../core/segment/virtualcolumn/package-info.java   | 25 ++++++++------
 .../pinot/core/startree/DimensionBuffer.java       | 25 ++++++++------
 .../linkedin/pinot/core/startree/MetricBuffer.java | 25 ++++++++------
 .../pinot/core/startree/OffHeapStarTree.java       | 25 ++++++++------
 .../core/startree/OffHeapStarTreeBuilder.java      | 25 ++++++++------
 .../pinot/core/startree/OffHeapStarTreeNode.java   | 25 ++++++++------
 .../com/linkedin/pinot/core/startree/StarTree.java | 25 ++++++++------
 .../pinot/core/startree/StarTreeBuilder.java       | 25 ++++++++------
 .../pinot/core/startree/StarTreeBuilderConfig.java | 25 ++++++++------
 .../pinot/core/startree/StarTreeBuilderUtils.java  | 25 ++++++++------
 .../pinot/core/startree/StarTreeDataTable.java     | 25 ++++++++------
 .../linkedin/pinot/core/startree/StarTreeNode.java | 25 ++++++++------
 .../pinot/core/startree/StarTreeUtils.java         | 25 ++++++++------
 .../executor/StarTreeAggregationExecutor.java      | 25 ++++++++------
 .../startree/executor/StarTreeGroupByExecutor.java | 25 ++++++++------
 .../linkedin/pinot/core/startree/hll/HllUtil.java  | 25 ++++++++------
 .../startree/operator/StarTreeFilterOperator.java  | 25 ++++++++------
 .../startree/plan/StarTreeDocIdSetPlanNode.java    | 25 ++++++++------
 .../core/startree/plan/StarTreeFilterPlanNode.java | 25 ++++++++------
 .../startree/plan/StarTreeProjectionPlanNode.java  | 25 ++++++++------
 .../startree/plan/StarTreeTransformPlanNode.java   | 25 ++++++++------
 .../startree/v2/AggregationFunctionColumnPair.java | 25 ++++++++------
 .../pinot/core/startree/v2/StarTreeV2.java         | 25 ++++++++------
 .../core/startree/v2/StarTreeV2Constants.java      | 25 ++++++++------
 .../pinot/core/startree/v2/StarTreeV2Metadata.java | 25 ++++++++------
 .../startree/v2/builder/BaseSingleTreeBuilder.java | 25 ++++++++------
 .../startree/v2/builder/MultipleTreesBuilder.java  | 25 ++++++++------
 .../v2/builder/OffHeapSingleTreeBuilder.java       | 25 ++++++++------
 .../v2/builder/OnHeapSingleTreeBuilder.java        | 25 ++++++++------
 .../startree/v2/builder/SingleTreeBuilder.java     | 25 ++++++++------
 .../startree/v2/builder/StarTreeIndexCombiner.java | 25 ++++++++------
 .../v2/builder/StarTreeV2BuilderConfig.java        | 25 ++++++++------
 .../v2/store/StarTreeDimensionDataSource.java      | 25 ++++++++------
 .../startree/v2/store/StarTreeIndexContainer.java  | 25 ++++++++------
 .../startree/v2/store/StarTreeIndexMapUtils.java   | 25 ++++++++------
 .../startree/v2/store/StarTreeLoaderUtils.java     | 25 ++++++++------
 .../v2/store/StarTreeMetricDataSource.java         | 25 ++++++++------
 .../pinot/core/transport/AsyncQueryResponse.java   | 25 ++++++++------
 .../pinot/core/transport/DataTableHandler.java     | 25 ++++++++------
 .../linkedin/pinot/core/transport/QueryRouter.java | 25 ++++++++------
 .../com/linkedin/pinot/core/transport/Server.java  | 25 ++++++++------
 .../pinot/core/transport/ServerChannels.java       | 25 ++++++++------
 .../pinot/core/transport/ServerResponse.java       | 25 ++++++++------
 .../linkedin/pinot/core/util/ArrayCopyUtils.java   | 25 ++++++++------
 .../com/linkedin/pinot/core/util/AvroUtils.java    | 25 ++++++++------
 .../pinot/core/util/BaseIndexedPriorityQueue.java  | 25 ++++++++------
 .../com/linkedin/pinot/core/util/CrcUtils.java     | 25 ++++++++------
 .../linkedin/pinot/core/util/FixedIntArray.java    | 25 ++++++++------
 .../pinot/core/util/FixedIntArrayOffHeapIdMap.java | 25 ++++++++------
 .../java/com/linkedin/pinot/core/util/IdMap.java   | 25 ++++++++------
 .../core/util/IntDoubleIndexedPriorityQueue.java   | 25 ++++++++------
 .../core/util/IntObjectIndexedPriorityQueue.java   | 25 ++++++++------
 .../com/linkedin/pinot/core/util/SizeUtil.java     | 25 ++++++++------
 .../pinot/core/util/SortedRangeIntersection.java   | 25 ++++++++------
 .../pinot/core/util/trace/TraceCallable.java       | 25 ++++++++------
 .../pinot/core/util/trace/TraceContext.java        | 25 ++++++++------
 .../pinot/core/util/trace/TraceRunnable.java       | 25 ++++++++------
 .../server/realtime/ControllerLeaderLocator.java   | 25 ++++++++------
 .../ServerSegmentCompletionProtocolHandler.java    | 25 ++++++++------
 .../pinot/core/common/DataFetcherTest.java         | 25 ++++++++------
 .../pinot/core/common/ObjectSerDeUtilsTest.java    | 25 ++++++++------
 .../core/common/RealtimeNoDictionaryTest.java      | 25 ++++++++------
 .../core/common/datatable/DataTableSerDeTest.java  | 25 ++++++++------
 .../core/common/docidsets/BitmapDocIdSetTest.java  | 25 ++++++++------
 .../core/common/docidsets/SortedDocIdSetTest.java  | 25 ++++++++------
 .../pinot/core/crypt/PinotCrypterFactoryTest.java  | 25 ++++++++------
 .../function/FunctionExpressionEvaluatorTest.java  | 25 ++++++++------
 .../data/manager/BaseTableDataManagerTest.java     | 25 ++++++++------
 .../realtime/LLRealtimeSegmentDataManagerTest.java | 25 ++++++++------
 .../core/data/partition/PartitionFunctionTest.java | 25 ++++++++------
 .../readers/BackfillDateTimeRecordReaderTest.java  | 25 ++++++++------
 .../core/data/readers/CSVRecordReaderTest.java     | 25 ++++++++------
 .../core/data/readers/JSONRecordReaderTest.java    | 25 ++++++++------
 .../MultiplePinotSegmentRecordReaderTest.java      | 25 ++++++++------
 .../data/readers/PinotSegmentRecordReaderTest.java | 25 ++++++++------
 .../pinot/core/data/readers/PinotSegmentUtil.java  | 25 ++++++++------
 .../pinot/core/data/readers/RecordReaderTest.java  | 25 ++++++++------
 .../core/data/readers/ThriftRecordReaderTest.java  | 25 ++++++++------
 .../pinot/core/data/readers/ThriftSampleData.java  | 25 ++++++++------
 .../data/recordtransformer/PinotDataTypeTest.java  | 25 ++++++++------
 .../recordtransformer/RecordTransformerTest.java   | 25 ++++++++------
 .../recordtransformer/TimeTransformerTest.java     | 25 ++++++++------
 .../MutableSegmentImplAggregateMetricsTest.java    | 25 ++++++++------
 .../mutable/MutableSegmentImplTest.java            | 25 ++++++++------
 .../mutable/MutableSegmentImplTestUtils.java       | 25 ++++++++------
 .../pinot/core/io/util/PinotDataBitSetTest.java    | 25 ++++++++------
 .../impl/MmapMemoryManagerFileCleanupTest.java     | 25 ++++++++------
 .../core/io/writer/impl/MmapMemoryManagerTest.java | 25 ++++++++------
 .../impl/MutableOffHeapByteArrayStoreTest.java     | 25 ++++++++------
 .../io/writer/impl/OffHeapStringStoreTest.java     | 25 ++++++++------
 .../metadata/MetadataExtractorFactoryTest.java     | 25 ++++++++------
 .../minion/MergeRollupSegmentConverterTest.java    | 25 ++++++++------
 .../pinot/core/minion/SegmentConverterTest.java    | 25 ++++++++------
 .../pinot/core/minion/SegmentPurgerTest.java       | 25 ++++++++------
 .../dociditerators/BitmapDocIdIteratorTest.java    | 25 ++++++++------
 .../RealtimeSingleValueIteratorTest.java           | 25 ++++++++------
 .../operator/filter/AndFilterOperatorTest.java     | 25 ++++++++------
 .../operator/filter/FilterOperatorUtilsTest.java   | 25 ++++++++------
 .../pinot/core/operator/filter/IntRangesTest.java  | 25 ++++++++------
 .../core/operator/filter/OrFilterOperatorTest.java | 25 ++++++++------
 .../core/operator/filter/TestFilterOperator.java   | 25 ++++++++------
 .../function/AdditionTransformFunctionTest.java    | 25 ++++++++------
 .../function/BaseTransformFunctionTest.java        | 25 ++++++++------
 .../DateTimeConversionTransformFunctionTest.java   | 25 ++++++++------
 .../function/DivisionTransformFunctionTest.java    | 25 ++++++++------
 .../MultiplicationTransformFunctionTest.java       | 25 ++++++++------
 .../function/SubtractionTransformFunctionTest.java | 25 ++++++++------
 .../TimeConversionTransformFunctionTest.java       | 25 ++++++++------
 .../function/ValueInTransformFunctionTest.java     | 25 ++++++++------
 .../datetime/DateTimeConverterTest.java            | 25 ++++++++------
 .../timeunit/TimeUnitTransformerTest.java          | 25 ++++++++------
 .../periodictask/PeriodicTaskSchedulerTest.java    | 25 ++++++++------
 .../pinot/core/plan/CombinePlanNodeTest.java       | 25 ++++++++------
 ...adataAndDictionaryAggregationPlanMakerTest.java | 25 ++++++++------
 .../pinot/core/predicate/InPredicateTest.java      | 25 ++++++++------
 .../NoDictionaryEqualsPredicateEvaluatorsTest.java | 25 ++++++++------
 .../NoDictionaryInPredicateEvaluatorTest.java      | 25 ++++++++------
 .../NoDictionaryRangePredicateEvaluatorTest.java   | 25 ++++++++------
 .../predicate/PredicateEvaluatorTestUtils.java     | 25 ++++++++------
 ...ngeOfflineDictionaryPredicateEvaluatorTest.java | 25 ++++++++------
 .../function/AggregationFunctionFactoryTest.java   | 25 ++++++++------
 .../function/AggregationFunctionTypeTest.java      | 25 ++++++++------
 .../scheduler/MultiLevelPriorityQueueTest.java     | 25 ++++++++------
 .../query/scheduler/PrioritySchedulerTest.java     | 25 ++++++++------
 .../pinot/core/query/scheduler/TestHelper.java     | 25 ++++++++------
 .../core/query/scheduler/TestSchedulerGroup.java   | 25 ++++++++------
 .../query/scheduler/TestSchedulerGroupFactory.java | 25 ++++++++------
 .../scheduler/fcfs/FCFSSchedulerGroupTest.java     | 25 ++++++++------
 .../resources/BoundedAccountingExecutorTest.java   | 25 ++++++++------
 .../scheduler/resources/ResourceManagerTest.java   | 25 ++++++++------
 .../resources/UnboundedResourceManagerTest.java    | 25 ++++++++------
 .../tokenbucket/TokenSchedulerGroupTest.java       | 25 ++++++++------
 .../impl/RealtimeSegmentStatsHistoryTest.java      | 25 ++++++++------
 .../impl/dictionary/DictionaryPerfRunner.java      | 25 ++++++++------
 .../impl/dictionary/MultiValueDictionaryTest.java  | 25 ++++++++------
 .../impl/dictionary/MutableDictionaryTest.java     | 25 ++++++++------
 .../kafka/AvroRecordToPinotRowGeneratorTest.java   | 25 ++++++++------
 .../impl/kafka/KafkaLowLevelStreamConfigTest.java  | 25 ++++++++------
 .../kafka/KafkaPartitionLevelConsumerTest.java     | 25 ++++++++------
 .../ConsumingSegmentAssignmentStrategyTest.java    | 25 ++++++++------
 .../stream/MetadataEqualsHashCodeTest.java         | 25 ++++++++------
 .../core/realtime/stream/OffsetCriteriaTest.java   | 25 ++++++++------
 .../core/realtime/stream/StreamConfigTest.java     | 25 ++++++++------
 .../core/segment/index/ColumnMetadataTest.java     | 25 ++++++++------
 .../segment/index/SegmentMetadataImplTest.java     | 25 ++++++++------
 .../SegmentV1V2ToV3FormatConverterTest.java        | 25 ++++++++------
 .../index/creator/BloomFilterCreatorTest.java      | 25 ++++++++------
 .../segment/index/creator/RawIndexCreatorTest.java | 25 ++++++++------
 .../SegmentGenerationWithBytesTypeTest.java        | 25 ++++++++------
 .../SegmentGenerationWithTimeColumnTest.java       | 25 ++++++++------
 .../index/creator/SegmentPartitionTest.java        | 25 ++++++++------
 .../core/segment/index/loader/LoaderTest.java      | 25 ++++++++------
 .../core/segment/index/loader/LoaderUtilsTest.java | 25 ++++++++------
 .../index/loader/SegmentPreProcessorTest.java      | 25 ++++++++------
 .../readers/ImmutableDictionaryReaderTest.java     | 25 ++++++++------
 .../core/segment/memory/PinotDataBufferTest.java   | 25 ++++++++------
 .../name/DefaultSegmentNameGeneratorTest.java      | 25 ++++++++------
 .../NormalizedDateSegmentNameGeneratorTest.java    | 25 ++++++++------
 .../store/ColumnIndexDirectoryTestHelper.java      | 25 ++++++++------
 .../segment/store/FilePerIndexDirectoryTest.java   | 25 ++++++++------
 .../segment/store/SegmentDirectoryPathsTest.java   | 25 ++++++++------
 .../segment/store/SegmentLocalFSDirectoryTest.java | 25 ++++++++------
 .../store/SingleFileIndexDirectoryTest.java        | 25 ++++++++------
 .../pinot/core/startree/BaseStarTreeIndexTest.java | 25 ++++++++------
 .../core/startree/OffHeapStarTreeBuilderTest.java  | 25 ++++++++------
 .../pinot/core/startree/StarTreeDataTableTest.java | 25 ++++++++------
 .../startree/StarTreeIndexTestSegmentHelper.java   | 25 ++++++++------
 .../pinot/core/startree/SumStarTreeIndexTest.java  | 25 ++++++++------
 .../pinot/core/startree/TestStarTreeMetadata.java  | 25 ++++++++------
 .../pinot/core/startree/hll/HllFieldSizeTest.java  | 25 ++++++++------
 .../core/startree/hll/HllIndexCreationTest.java    | 25 ++++++++------
 .../core/startree/hll/HllStarTreeIndexTest.java    | 25 ++++++++------
 .../core/startree/hll/HllTypeConversionTest.java   | 25 ++++++++------
 .../OffHeapStarTreeBuilderWithHllFieldTest.java    | 25 ++++++++------
 .../hll/SegmentWithHllIndexCreateHelper.java       | 25 ++++++++------
 .../v2/AggregationFunctionColumnPairTest.java      | 25 ++++++++------
 .../pinot/core/startree/v2/AvgStarTreeV2Test.java  | 25 ++++++++------
 .../pinot/core/startree/v2/BaseStarTreeV2Test.java | 25 ++++++++------
 .../core/startree/v2/CountStarTreeV2Test.java      | 25 ++++++++------
 .../v2/DistinctCountHLLStarTreeV2Test.java         | 25 ++++++++------
 .../pinot/core/startree/v2/MaxStarTreeV2Test.java  | 25 ++++++++------
 .../startree/v2/MinMaxRangeStarTreeV2Test.java     | 25 ++++++++------
 .../pinot/core/startree/v2/MinStarTreeV2Test.java  | 25 ++++++++------
 .../startree/v2/PercentileEstStarTreeV2Test.java   | 25 ++++++++------
 .../v2/PercentileTDigestStarTreeV2Test.java        | 25 ++++++++------
 .../v2/PreAggregatedAvgStarTreeV2Test.java         | 25 ++++++++------
 ...reAggregatedDistinctCountHLLStarTreeV2Test.java | 25 ++++++++------
 .../v2/PreAggregatedMinMaxRangeStarTreeV2Test.java | 25 ++++++++------
 .../PreAggregatedPercentileEstStarTreeV2Test.java  | 25 ++++++++------
 ...eAggregatedPercentileTDigestStarTreeV2Test.java | 25 ++++++++------
 .../pinot/core/startree/v2/SumStarTreeV2Test.java  | 25 ++++++++------
 .../linkedin/pinot/core/transport/DummyServer.java | 25 ++++++++------
 .../pinot/core/transport/QueryRouterTest.java      | 25 ++++++++------
 .../pinot/core/util/ArrayCopyUtilsTest.java        | 25 ++++++++------
 .../com/linkedin/pinot/core/util/CrcUtilsTest.java | 25 ++++++++------
 .../pinot/core/util/DoubleComparisonUtil.java      | 25 ++++++++------
 .../core/util/SortedRangeIntersectionTest.java     | 25 ++++++++------
 .../pinot/core/util/trace/TraceContextTest.java    | 25 ++++++++------
 .../pinot/index/persist/AvroDataPublisherTest.java | 25 ++++++++------
 .../pinot/index/reader/FileReaderTestUtils.java    | 25 ++++++++------
 .../pinot/index/reader/FixedBitMultiValueTest.java | 25 ++++++++------
 .../FixedByteWidthRowColDataFileReaderTest.java    | 25 ++++++++------
 .../index/reader/SortedForwardIndexReaderTest.java | 25 ++++++++------
 .../FixedByteChunkSingleValueReaderWriteTest.java  | 25 ++++++++------
 ...ByteSingleColumnMultiValueReaderWriterTest.java | 25 ++++++++------
 ...yteSingleColumnSingleValueReaderWriterTest.java | 25 ++++++++------
 ...ByteSingleValueMultiColumnReaderWriterTest.java | 25 ++++++++------
 .../VarByteChunkSingleValueReaderWriteTest.java    | 25 ++++++++------
 .../FixedByteWidthRowColDataFileWriterTest.java    | 25 ++++++++------
 .../pinot/queries/BaseMultiValueQueriesTest.java   | 25 ++++++++------
 .../linkedin/pinot/queries/BaseQueriesTest.java    | 25 ++++++++------
 .../pinot/queries/BaseSingleValueQueriesTest.java  | 25 ++++++++------
 .../linkedin/pinot/queries/FastHllQueriesTest.java | 25 ++++++++------
 ...nerSegmentAggregationMultiValueQueriesTest.java | 25 ++++++++------
 ...erSegmentAggregationSingleValueQueriesTest.java | 25 ++++++++------
 ...InnerSegmentSelectionMultiValueQueriesTest.java | 25 ++++++++------
 ...nnerSegmentSelectionSingleValueQueriesTest.java | 25 ++++++++------
 ...terSegmentAggregationMultiValueQueriesTest.java | 25 ++++++++------
 ...erSegmentAggregationSingleValueQueriesTest.java | 25 ++++++++------
 .../queries/PercentileTDigestMVQueriesTest.java    | 25 ++++++++------
 .../queries/PercentileTDigestQueriesTest.java      | 25 ++++++++------
 .../linkedin/pinot/queries/QueriesTestUtils.java   | 25 ++++++++------
 .../DefaultAggregationExecutorTest.java            | 25 ++++++++------
 .../DoubleAggregationResultHolderTest.java         | 25 ++++++++------
 .../AggregationGroupByTrimmingServiceTest.java     | 25 ++++++++------
 .../DictionaryBasedGroupKeyGeneratorTest.java      | 25 ++++++++------
 .../groupby/DoubleGroupByResultHolderTest.java     | 25 ++++++++------
 .../groupby/NoDictionaryGroupKeyGeneratorTest.java | 25 ++++++++------
 .../pinot/query/executor/QueryExecutorTest.java    | 25 ++++++++------
 .../query/pruner/ColumnValueSegmentPrunerTest.java | 25 ++++++++------
 .../selection/SelectionOperatorServiceTest.java    | 25 ++++++++------
 .../converter/RealtimeSegmentConverterTest.java    | 25 ++++++++------
 .../pinot/reduce/HavingClauseComparisonTests.java  | 25 ++++++++------
 .../v1/creator/BitmapInvertedIndexCreatorTest.java | 25 ++++++++------
 .../v1/creator/BitmapInvertedIndexTest.java        | 25 ++++++++------
 .../pinot/segments/v1/creator/BlocksTest.java      | 25 ++++++++------
 .../segments/v1/creator/DictionariesTest.java      | 25 ++++++++------
 .../v1/creator/FixedIntArrayIdMapTest.java         | 25 ++++++++------
 .../pinot/segments/v1/creator/IntArraysTest.java   | 25 ++++++++------
 .../v1/creator/OnHeapDictionariesTest.java         | 25 ++++++++------
 .../segments/v1/creator/SegmentTestUtils.java      | 25 ++++++++------
 .../realtime/ControllerLeaderLocatorTest.java      | 25 ++++++++------
 .../util/IntDoubleIndexedPriorityQueueTest.java    | 25 ++++++++------
 .../util/IntObjectIndexedPriorityQueueTest.java    | 25 ++++++++------
 .../java/com/linkedin/pinot/util/TestUtils.java    | 25 ++++++++------
 pinot-core/testng.xml                              | 25 ++++++++------
 pinot-distribution/pinot-assembly.xml              | 25 ++++++++------
 pinot-distribution/pom.xml                         | 25 ++++++++------
 pinot-filesystem/pom.xml                           | 25 ++++++++------
 .../linkedin/pinot/filesystem/LocalPinotFS.java    | 25 ++++++++------
 .../com/linkedin/pinot/filesystem/PinotFS.java     | 25 ++++++++------
 .../linkedin/pinot/filesystem/PinotFSFactory.java  | 26 ++++++++-------
 .../pinot/filesystem/LocalPinotFSTest.java         | 25 ++++++++------
 .../pinot/filesystem/PinotFSFactoryTest.java       | 25 ++++++++------
 pinot-hadoop-filesystem/pom.xml                    | 25 ++++++++------
 .../linkedin/pinot/filesystem/HadoopPinotFS.java   | 25 ++++++++------
 pinot-hadoop/pom.xml                               | 25 ++++++++------
 .../pinot/hadoop/PinotHadoopJobLauncher.java       | 25 ++++++++------
 .../com/linkedin/pinot/hadoop/io/FileHandler.java  | 25 ++++++++------
 .../pinot/hadoop/io/JsonPinotOutputFormat.java     | 25 ++++++++------
 .../pinot/hadoop/io/PinotOutputFormat.java         | 25 ++++++++------
 .../com/linkedin/pinot/hadoop/io/PinotRecord.java  | 25 ++++++++------
 .../pinot/hadoop/io/PinotRecordSerialization.java  | 25 ++++++++------
 .../pinot/hadoop/io/PinotRecordWriter.java         | 25 ++++++++------
 .../pinot/hadoop/job/ControllerRestApi.java        | 25 ++++++++------
 .../pinot/hadoop/job/JobConfigConstants.java       | 25 ++++++++------
 .../pinot/hadoop/job/SegmentCreationJob.java       | 25 ++++++++------
 .../pinot/hadoop/job/SegmentTarPushJob.java        | 25 ++++++++------
 .../pinot/hadoop/job/SegmentUriPushJob.java        | 25 ++++++++------
 .../mapper/HadoopSegmentCreationMapReduceJob.java  | 25 ++++++++------
 .../linkedin/pinot/hadoop/utils/PushLocation.java  | 26 ++++++++-------
 .../pinot/hadoop/io/PinotOutputFormatTest.java     | 25 ++++++++------
 pinot-integration-tests/pom.xml                    | 25 ++++++++------
 ...umSegmentAssignmentStrategyIntegrationTest.java | 25 ++++++++------
 .../tests/BaseClusterIntegrationTest.java          | 25 ++++++++------
 .../tests/BaseClusterIntegrationTestSet.java       | 25 ++++++++------
 .../tests/ChaosMonkeyIntegrationTest.java          | 25 ++++++++------
 .../tests/ClusterIntegrationTestUtils.java         | 25 ++++++++------
 .../pinot/integration/tests/ClusterTest.java       | 25 ++++++++------
 ...vertToRawIndexMinionClusterIntegrationTest.java | 25 ++++++++------
 .../DeleteAPIHybridClusterIntegrationTest.java     | 25 ++++++++------
 ...lakyConsumerRealtimeClusterIntegrationTest.java | 25 ++++++++------
 ...mentBuildPushOfflineClusterIntegrationTest.java | 25 ++++++++------
 .../tests/HybridClusterIntegrationTest.java        | 25 ++++++++------
 ...ridClusterIntegrationTestCommandLineRunner.java | 25 ++++++++------
 .../tests/LLCRealtimeClusterIntegrationTest.java   | 25 ++++++++------
 ...CRealtimeClusterSplitCommitIntegrationTest.java | 25 ++++++++------
 ...onaryAggregationPlanClusterIntegrationTest.java | 25 ++++++++------
 .../MultiNodesOfflineClusterIntegrationTest.java   | 25 ++++++++------
 .../tests/NewConfigApplyIntegrationTest.java       | 26 ++++++++-------
 .../tests/OfflineClusterIntegrationTest.java       | 25 ++++++++------
 .../tests/PinotURIUploadIntegrationTest.java       | 25 ++++++++------
 .../pinot/integration/tests/QueryGenerator.java    | 25 ++++++++------
 .../tests/RealtimeClusterIntegrationTest.java      | 25 ++++++++------
 .../tests/SegmentCompletionIntegrationTests.java   | 25 ++++++++------
 .../tests/SimpleMinionClusterIntegrationTest.java  | 25 ++++++++------
 .../tests/StarTreeClusterIntegrationTest.java      | 25 ++++++++------
 .../tests/StarTreeV2ClusterIntegrationTest.java    | 25 ++++++++------
 .../tests/UploadRefreshDeleteIntegrationTest.java  | 25 ++++++++------
 pinot-minion/pom.xml                               | 25 ++++++++------
 .../com/linkedin/pinot/minion/MinionContext.java   | 25 ++++++++------
 .../com/linkedin/pinot/minion/MinionStarter.java   | 25 ++++++++------
 .../minion/events/DefaultMinionEventObserver.java  | 25 ++++++++------
 .../events/DefaultMinionEventObserverFactory.java  | 25 ++++++++------
 .../events/EventObserverFactoryRegistry.java       | 25 ++++++++------
 .../pinot/minion/events/MinionEventObserver.java   | 25 ++++++++------
 .../minion/events/MinionEventObserverFactory.java  | 25 ++++++++------
 .../pinot/minion/exception/FatalException.java     | 25 ++++++++------
 .../minion/exception/TaskCancelledException.java   | 25 ++++++++------
 .../BaseMultipleSegmentsConversionExecutor.java    | 25 ++++++++------
 .../BaseSingleSegmentConversionExecutor.java       | 25 ++++++++------
 .../pinot/minion/executor/BaseTaskExecutor.java    | 25 ++++++++------
 .../executor/ConvertToRawIndexTaskExecutor.java    | 25 ++++++++------
 .../ConvertToRawIndexTaskExecutorFactory.java      | 25 ++++++++------
 .../pinot/minion/executor/PinotTaskExecutor.java   | 25 ++++++++------
 .../minion/executor/PinotTaskExecutorFactory.java  | 25 ++++++++------
 .../pinot/minion/executor/PurgeTaskExecutor.java   | 25 ++++++++------
 .../minion/executor/PurgeTaskExecutorFactory.java  | 25 ++++++++------
 .../minion/executor/SegmentConversionResult.java   | 25 ++++++++------
 .../minion/executor/SegmentConversionUtils.java    | 25 ++++++++------
 .../executor/TaskExecutorFactoryRegistry.java      | 25 ++++++++------
 .../linkedin/pinot/minion/metrics/MinionGauge.java | 25 ++++++++------
 .../linkedin/pinot/minion/metrics/MinionMeter.java | 25 ++++++++------
 .../pinot/minion/metrics/MinionMetrics.java        | 25 ++++++++------
 .../pinot/minion/metrics/MinionQueryPhase.java     | 25 ++++++++------
 .../linkedin/pinot/minion/metrics/MinionTimer.java | 25 ++++++++------
 .../minion/taskfactory/TaskFactoryRegistry.java    | 25 ++++++++------
 .../minion/executor/PurgeTaskExecutorTest.java     | 25 ++++++++------
 pinot-perf/pom.xml                                 | 25 ++++++++------
 .../linkedin/pinot/perf/BenchmarkDictionary.java   | 25 ++++++++------
 .../pinot/perf/BenchmarkDictionaryCreation.java    | 25 ++++++++------
 .../perf/BenchmarkFixedIntArrayOffHeapIdMap.java   | 25 ++++++++------
 .../perf/BenchmarkOffHeapDictionaryMemory.java     | 25 ++++++++------
 .../pinot/perf/BenchmarkOfflineIndexReader.java    | 25 ++++++++------
 .../pinot/perf/BenchmarkOrDocIdIterator.java       | 25 ++++++++------
 .../linkedin/pinot/perf/BenchmarkQueryEngine.java  | 25 ++++++++------
 .../perf/BenchmarkRealtimeConsumptionSpeed.java    | 25 ++++++++------
 .../pinot/perf/BenchmarkStringDictionary.java      | 25 ++++++++------
 .../com/linkedin/pinot/perf/DictionaryDumper.java  | 25 ++++++++------
 .../pinot/perf/ForwardIndexWriterBenchmark.java    | 25 ++++++++------
 .../com/linkedin/pinot/perf/RawIndexBenchmark.java | 25 ++++++++------
 .../linkedin/pinot/perf/RealtimeStressTest.java    | 25 ++++++++------
 .../pinot/perf/StringDictionaryPerfTest.java       | 25 ++++++++------
 pinot-server/pom.xml                               | 25 ++++++++------
 .../api/resources/DefaultExceptionMapper.java      | 25 ++++++++------
 .../pinot/server/api/resources/ErrorInfo.java      | 25 ++++++++------
 .../pinot/server/api/resources/ErrorResponse.java  | 25 ++++++++------
 .../server/api/resources/HealthCheckResource.java  | 25 ++++++++------
 .../server/api/resources/MmapDebugResource.java    | 25 ++++++++------
 .../server/api/resources/SchedulerResource.java    | 25 ++++++++------
 .../server/api/resources/TableSizeResource.java    | 25 ++++++++------
 .../pinot/server/api/resources/TablesResource.java | 25 ++++++++------
 .../pinot/server/conf/NettyServerConfig.java       | 25 ++++++++------
 .../com/linkedin/pinot/server/conf/ServerConf.java | 25 ++++++++------
 .../server/request/ScheduledRequestHandler.java    | 25 ++++++++------
 .../pinot/server/starter/ServerBuilder.java        | 25 ++++++++------
 .../pinot/server/starter/ServerInstance.java       | 25 ++++++++------
 .../server/starter/helix/AdminApiApplication.java  | 25 ++++++++------
 .../helix/DefaultHelixStarterServerConfig.java     | 25 ++++++++------
 .../starter/helix/HelixInstanceDataManager.java    | 25 ++++++++------
 .../helix/HelixInstanceDataManagerConfig.java      | 25 ++++++++------
 .../server/starter/helix/HelixServerStarter.java   | 25 ++++++++------
 .../starter/helix/SegmentFetcherAndLoader.java     | 25 ++++++++------
 .../pinot/server/starter/helix/SegmentLocks.java   | 25 ++++++++------
 .../helix/SegmentMessageHandlerFactory.java        | 25 ++++++++------
 .../SegmentOnlineOfflineStateModelFactory.java     | 25 ++++++++------
 .../server/api/resources/BaseResourceTest.java     | 25 ++++++++------
 .../api/resources/TableSizeResourceTest.java       | 25 ++++++++------
 .../server/api/resources/TablesResourceTest.java   | 25 ++++++++------
 .../realtime/RealtimeTableDataManagerTest.java     | 25 ++++++++------
 .../request/ScheduledRequestHandlerTest.java       | 25 ++++++++------
 .../pinot/server/util/SegmentTestUtils.java        | 25 ++++++++------
 pinot-style.xml                                    | 25 ++++++++------
 pinot-tools/pom.xml                                | 25 ++++++++------
 .../linkedin/pinot/tools/AbstractBaseCommand.java  | 25 ++++++++------
 .../pinot/tools/AutoAddInvertedIndexTool.java      | 25 ++++++++------
 .../linkedin/pinot/tools/ClusterStateVerifier.java | 25 ++++++++------
 .../java/com/linkedin/pinot/tools/Command.java     | 25 ++++++++------
 .../com/linkedin/pinot/tools/HybridQuickstart.java | 25 ++++++++------
 .../pinot/tools/PinotIdealstateChanger.java        | 26 ++++++++-------
 .../pinot/tools/PinotNumReplicaChanger.java        | 25 ++++++++------
 .../pinot/tools/PinotSegmentRebalancer.java        | 25 ++++++++------
 .../linkedin/pinot/tools/PinotToolLauncher.java    | 25 ++++++++------
 .../com/linkedin/pinot/tools/PinotZKChanger.java   | 25 ++++++++------
 .../java/com/linkedin/pinot/tools/Quickstart.java  | 25 ++++++++------
 .../pinot/tools/QuickstartTableRequest.java        | 25 ++++++++------
 .../linkedin/pinot/tools/RealtimeQuickStart.java   | 25 ++++++++------
 .../com/linkedin/pinot/tools/SegmentDumpTool.java  | 25 ++++++++------
 .../java/com/linkedin/pinot/tools/SpeedTest.java   | 25 ++++++++------
 .../linkedin/pinot/tools/StarTreeIndexViewer.java  | 25 ++++++++------
 .../linkedin/pinot/tools/UpdateSegmentState.java   | 25 ++++++++------
 .../pinot/tools/ValidateTableRetention.java        | 25 ++++++++------
 .../pinot/tools/admin/PinotAdministrator.java      | 25 ++++++++------
 .../linkedin/pinot/tools/admin/PinotBroker.java    | 25 ++++++++------
 .../pinot/tools/admin/PinotController.java         | 25 ++++++++------
 .../linkedin/pinot/tools/admin/PinotServer.java    | 25 ++++++++------
 .../admin/command/AbstractBaseAdminCommand.java    | 25 ++++++++------
 .../tools/admin/command/AddSchemaCommand.java      | 25 ++++++++------
 .../pinot/tools/admin/command/AddTableCommand.java | 25 ++++++++------
 .../tools/admin/command/AddTenantCommand.java      | 25 ++++++++------
 .../admin/command/ApplyTableConfigCommand.java     | 25 ++++++++------
 .../admin/command/AvroSchemaToPinotSchema.java     | 25 ++++++++------
 .../command/BackfillDateTimeColumnCommand.java     | 25 ++++++++------
 .../admin/command/ChangeNumReplicasCommand.java    | 25 ++++++++------
 .../tools/admin/command/ChangeTableState.java      | 25 ++++++++------
 .../tools/admin/command/CreateSegmentCommand.java  | 25 ++++++++------
 .../tools/admin/command/DeleteClusterCommand.java  | 25 ++++++++------
 .../tools/admin/command/GenerateDataCommand.java   | 25 ++++++++------
 .../tools/admin/command/MoveReplicaGroup.java      | 25 ++++++++------
 .../tools/admin/command/PostQueryCommand.java      | 25 ++++++++------
 .../tools/admin/command/QuickstartRunner.java      | 25 ++++++++------
 .../command/RealtimeProvisioningHelperCommand.java | 25 ++++++++------
 .../tools/admin/command/RebalanceTableCommand.java | 25 ++++++++------
 .../admin/command/ShowClusterInfoCommand.java      | 25 ++++++++------
 .../tools/admin/command/StartBrokerCommand.java    | 25 ++++++++------
 .../admin/command/StartControllerCommand.java      | 25 ++++++++------
 .../tools/admin/command/StartKafkaCommand.java     | 25 ++++++++------
 .../tools/admin/command/StartServerCommand.java    | 25 ++++++++------
 .../tools/admin/command/StartZookeeperCommand.java | 25 ++++++++------
 .../tools/admin/command/StopProcessCommand.java    | 25 ++++++++------
 .../admin/command/StreamAvroIntoKafkaCommand.java  | 25 ++++++++------
 .../tools/admin/command/UploadSegmentCommand.java  | 25 ++++++++------
 .../tools/admin/command/ValidateConfigCommand.java | 25 ++++++++------
 .../admin/command/VerifyClusterStateCommand.java   | 25 ++++++++------
 .../tools/admin/command/VerifySegmentState.java    | 25 ++++++++------
 .../pinot/tools/backfill/BackfillSegmentUtils.java | 25 ++++++++------
 .../tools/config/validator/SchemaValidator.java    | 25 ++++++++------
 .../config/validator/TableConfigValidator.java     | 25 ++++++++------
 .../pinot/tools/data/generator/AvroWriter.java     | 25 ++++++++------
 .../pinot/tools/data/generator/DataGenerator.java  | 25 ++++++++------
 .../tools/data/generator/DataGeneratorSpec.java    | 25 ++++++++------
 .../pinot/tools/data/generator/Generator.java      | 25 ++++++++------
 .../tools/data/generator/GeneratorFactory.java     | 25 ++++++++------
 .../tools/data/generator/NumberGenerator.java      | 25 ++++++++------
 .../tools/data/generator/RangeDoubleGenerator.java | 25 ++++++++------
 .../tools/data/generator/RangeFloatGenerator.java  | 25 ++++++++------
 .../tools/data/generator/RangeIntGenerator.java    | 25 ++++++++------
 .../tools/data/generator/RangeLongGenerator.java   | 25 ++++++++------
 .../tools/data/generator/SchemaAnnotation.java     | 25 ++++++++------
 .../tools/data/generator/StringGenerator.java      | 25 ++++++++------
 .../pinot/tools/perf/PerfBenchmarkDriver.java      | 25 ++++++++------
 .../pinot/tools/perf/PerfBenchmarkDriverConf.java  | 25 ++++++++------
 .../pinot/tools/perf/PerfBenchmarkRunner.java      | 25 ++++++++------
 .../com/linkedin/pinot/tools/perf/QueryRunner.java | 25 ++++++++------
 .../pinot/tools/perf/ZookeeperLauncher.java        | 25 ++++++++------
 .../tools/query/comparison/ClusterStarter.java     | 25 ++++++++------
 .../tools/query/comparison/QueryComparison.java    | 25 ++++++++------
 .../query/comparison/QueryComparisonConfig.java    | 25 ++++++++------
 .../query/comparison/SegmentInfoProvider.java      | 25 ++++++++------
 .../query/comparison/StarQueryComparison.java      | 25 ++++++++------
 .../query/comparison/StarTreeQueryGenerator.java   | 25 ++++++++------
 .../tools/query/comparison/StatsGenerator.java     | 25 ++++++++------
 .../realtime/provisioning/MemoryEstimator.java     | 25 ++++++++------
 .../pinot/tools/scan/query/Aggregation.java        | 25 ++++++++------
 .../pinot/tools/scan/query/AggregationFunc.java    | 25 ++++++++------
 .../tools/scan/query/AggregationFuncFactory.java   | 25 ++++++++------
 .../pinot/tools/scan/query/AvgFunction.java        | 25 ++++++++------
 .../pinot/tools/scan/query/CountFunction.java      | 25 ++++++++------
 .../tools/scan/query/DistinctCountFunction.java    | 25 ++++++++------
 .../tools/scan/query/EqualsPredicateFilter.java    | 25 ++++++++------
 .../pinot/tools/scan/query/GroupByOperator.java    | 25 ++++++++------
 .../pinot/tools/scan/query/InPredicateFilter.java  | 25 ++++++++------
 .../pinot/tools/scan/query/MaxFunction.java        | 25 ++++++++------
 .../pinot/tools/scan/query/MinFunction.java        | 25 ++++++++------
 .../tools/scan/query/MinMaxRangeFunction.java      | 25 ++++++++------
 .../tools/scan/query/NotInPredicateFilter.java     | 25 ++++++++------
 .../pinot/tools/scan/query/NotPredicateFilter.java | 25 ++++++++------
 .../pinot/tools/scan/query/PredicateFilter.java    | 25 ++++++++------
 .../pinot/tools/scan/query/Projection.java         | 25 ++++++++------
 .../pinot/tools/scan/query/QueryResponse.java      | 25 ++++++++------
 .../tools/scan/query/RangePredicateFilter.java     | 25 ++++++++------
 .../pinot/tools/scan/query/ResultTable.java        | 25 ++++++++------
 .../tools/scan/query/ScanBasedQueryProcessor.java  | 25 ++++++++------
 .../tools/scan/query/SegmentQueryProcessor.java    | 25 ++++++++------
 .../linkedin/pinot/tools/scan/query/Selection.java | 25 ++++++++------
 .../pinot/tools/scan/query/SumFunction.java        | 25 ++++++++------
 .../com/linkedin/pinot/tools/scan/query/Utils.java | 25 ++++++++------
 .../converter/ColumnarToStarTreeConverter.java     | 25 ++++++++------
 .../converter/DictionaryToRawIndexConverter.java   | 25 ++++++++------
 .../converter/PinotSegmentConvertCommand.java      | 25 ++++++++------
 .../segment/converter/PinotSegmentConverter.java   | 25 ++++++++------
 .../converter/PinotSegmentToAvroConverter.java     | 25 ++++++++------
 .../converter/PinotSegmentToCsvConverter.java      | 25 ++++++++------
 .../converter/PinotSegmentToJsonConverter.java     | 25 ++++++++------
 .../segment/converter/SegmentMergeCommand.java     | 25 ++++++++------
 .../pinot/tools/streams/AirlineDataStream.java     | 25 ++++++++------
 .../pinot/tools/streams/MeetupRsvpStream.java      | 25 ++++++++------
 pinot-transport/pom.xml                            | 25 ++++++++------
 .../common/AbstractCompositeListenableFuture.java  | 25 ++++++++------
 .../transport/common/AsyncResponseFuture.java      | 25 ++++++++------
 .../linkedin/pinot/transport/common/Callback.java  | 25 ++++++++------
 .../pinot/transport/common/Cancellable.java        | 25 ++++++++------
 .../pinot/transport/common/CompositeFuture.java    | 25 ++++++++------
 .../pinot/transport/common/LinkedDequeue.java      | 25 ++++++++------
 .../linkedin/pinot/transport/common/NoneType.java  | 25 ++++++++------
 .../pinot/transport/common/SelectingFuture.java    | 25 ++++++++------
 .../transport/common/ServerResponseFuture.java     | 25 ++++++++------
 .../pinot/transport/conf/TransportClientConf.java  | 25 ++++++++------
 .../transport/config/ConnectionPoolConfig.java     | 25 ++++++++------
 .../transport/config/PerTableRoutingConfig.java    | 25 ++++++++------
 .../pinot/transport/config/RoutingTableConfig.java | 25 ++++++++------
 .../pinot/transport/config/ThreadPoolConfig.java   | 25 ++++++++------
 .../transport/metrics/AggregatedPoolStats.java     | 25 ++++++++------
 .../metrics/AggregatedTransportClientMetrics.java  | 25 ++++++++------
 .../metrics/AggregatedTransportServerMetrics.java  | 25 ++++++++------
 .../pinot/transport/metrics/AsyncPoolStats.java    | 25 ++++++++------
 .../transport/metrics/NettyClientMetrics.java      | 25 ++++++++------
 .../transport/metrics/NettyServerMetrics.java      | 25 ++++++++------
 .../pinot/transport/metrics/PoolStats.java         | 25 ++++++++------
 .../pinot/transport/metrics/PoolStatsProvider.java | 25 ++++++++------
 .../transport/metrics/TransportClientMetrics.java  | 25 ++++++++------
 .../transport/metrics/TransportServerMetrics.java  | 25 ++++++++------
 .../transport/netty/NettyClientConnection.java     | 25 ++++++++------
 .../pinot/transport/netty/NettyServer.java         | 25 ++++++++------
 .../transport/netty/NettyTCPClientConnection.java  | 25 ++++++++------
 .../pinot/transport/netty/NettyTCPServer.java      | 25 ++++++++------
 .../netty/PooledNettyClientResourceManager.java    | 25 ++++++++------
 .../linkedin/pinot/transport/pool/AsyncPool.java   | 25 ++++++++------
 .../pinot/transport/pool/AsyncPoolImpl.java        | 25 ++++++++------
 .../pool/AsyncPoolResourceManagerAdapter.java      | 25 ++++++++------
 .../linkedin/pinot/transport/pool/KeyedPool.java   | 25 ++++++++------
 .../pinot/transport/pool/KeyedPoolImpl.java        | 25 ++++++++------
 .../transport/pool/PooledResourceManager.java      | 25 ++++++++------
 .../transport/pool/SizeLimitExceededException.java | 25 ++++++++------
 .../transport/scattergather/ScatterGather.java     | 25 ++++++++------
 .../transport/scattergather/ScatterGatherImpl.java | 25 ++++++++------
 .../scattergather/ScatterGatherRequest.java        | 25 ++++++++------
 .../scattergather/ScatterGatherStats.java          | 25 ++++++++------
 .../test/java/com/linkedin/pinot/Checkable.java    | 25 ++++++++------
 .../test/java/com/linkedin/pinot/TestUtils.java    | 25 ++++++++------
 .../transport/common/CompositeFutureTest.java      | 25 ++++++++------
 .../pinot/transport/common/ResponseFutureTest.java | 25 ++++++++------
 .../transport/common/SelectingFutureTest.java      | 25 ++++++++------
 .../pinot/transport/common/ServerInstanceTest.java | 25 ++++++++------
 .../transport/netty/NettyCloseChannelTest.java     | 25 ++++++++------
 .../NettySingleConnectionIntegrationTest.java      | 25 ++++++++------
 .../pinot/transport/netty/NettyTestUtils.java      | 25 ++++++++------
 .../transport/perf/ScatterGatherPerfClient.java    | 25 ++++++++------
 .../transport/perf/ScatterGatherPerfServer.java    | 25 ++++++++------
 .../transport/perf/ScatterGatherPerfTester.java    | 25 ++++++++------
 .../pool/AsyncPoolResourceManagerAdapterTest.java  | 25 ++++++++------
 .../pinot/transport/pool/KeyedPoolImplTest.java    | 25 ++++++++------
 .../transport/scattergather/ScatterGatherTest.java | 25 ++++++++------
 pom.xml                                            | 39 +++++++++-------------
 1698 files changed, 23839 insertions(+), 18529 deletions(-)

diff --git a/.codecov.yml b/.codecov.yml
index 7dd6f06..c0e4b9b 100644
--- a/.codecov.yml
+++ b/.codecov.yml
@@ -1,17 +1,20 @@
 #
-# Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
 #
-# Licensed under the Apache License, Version 2.0 (the "License");
-# you may not use this file except in compliance with the License.
-# You may obtain a copy of the License at
+#   http://www.apache.org/licenses/LICENSE-2.0
 #
-#         http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
 #
 
 coverage:
diff --git a/.travis_install.sh b/.travis_install.sh
index 56668d9..995ce1f 100755
--- a/.travis_install.sh
+++ b/.travis_install.sh
@@ -1,18 +1,21 @@
 #!/bin/bash -x
 #
-# Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
 #
-# Licensed under the Apache License, Version 2.0 (the "License");
-# you may not use this file except in compliance with the License.
-# You may obtain a copy of the License at
+#   http://www.apache.org/licenses/LICENSE-2.0
 #
-#         http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
 #
 
 # Ignore changes not related to pinot code
diff --git a/.travis_test.sh b/.travis_test.sh
index 46c875a..2c65f03 100755
--- a/.travis_test.sh
+++ b/.travis_test.sh
@@ -1,18 +1,21 @@
 #!/bin/bash -x
 #
-# Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
 #
-# Licensed under the Apache License, Version 2.0 (the "License");
-# you may not use this file except in compliance with the License.
-# You may obtain a copy of the License at
+#   http://www.apache.org/licenses/LICENSE-2.0
 #
-#         http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
 #
 
 # ThirdEye related changes
diff --git a/contrib/pinot-druid-benchmark/pom.xml b/contrib/pinot-druid-benchmark/pom.xml
index 2ef6659..1f919aa 100644
--- a/contrib/pinot-druid-benchmark/pom.xml
+++ b/contrib/pinot-druid-benchmark/pom.xml
@@ -1,19 +1,22 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
 
-    Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
 
-    Licensed under the Apache License, Version 2.0 (the "License");
-    you may not use this file except in compliance with the License.
-    You may obtain a copy of the License at
+      http://www.apache.org/licenses/LICENSE-2.0
 
-            http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
 
 -->
 <project xmlns="http://maven.apache.org/POM/4.0.0"
diff --git a/contrib/pinot-druid-benchmark/run_benchmark.sh b/contrib/pinot-druid-benchmark/run_benchmark.sh
index d9ad86e..e51669e 100755
--- a/contrib/pinot-druid-benchmark/run_benchmark.sh
+++ b/contrib/pinot-druid-benchmark/run_benchmark.sh
@@ -1,18 +1,21 @@
 #!/bin/bash
 #
-# Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
 #
-# Licensed under the Apache License, Version 2.0 (the "License");
-# you may not use this file except in compliance with the License.
-# You may obtain a copy of the License at
+#   http://www.apache.org/licenses/LICENSE-2.0
 #
-#         http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
 #
 
 
diff --git a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DataMerger.java b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DataMerger.java
index 820e29e..4849e6e 100644
--- a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DataMerger.java
+++ b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DataMerger.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinotdruidbenchmark;
 
diff --git a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DataSeparator.java b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DataSeparator.java
index d161ab5..6e6f735 100644
--- a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DataSeparator.java
+++ b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DataSeparator.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinotdruidbenchmark;
 
diff --git a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DruidResponseTime.java b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DruidResponseTime.java
index 6827dd6..06caf2e 100644
--- a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DruidResponseTime.java
+++ b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DruidResponseTime.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinotdruidbenchmark;
 
diff --git a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DruidThroughput.java b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DruidThroughput.java
index 4f29f0e..789db27 100644
--- a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DruidThroughput.java
+++ b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/DruidThroughput.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinotdruidbenchmark;
 
diff --git a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/PinotResponseTime.java b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/PinotResponseTime.java
index bc57638..32c2499 100644
--- a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/PinotResponseTime.java
+++ b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/PinotResponseTime.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinotdruidbenchmark;
 
diff --git a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/PinotThroughput.java b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/PinotThroughput.java
index 7a10025..c50f61f 100644
--- a/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/PinotThroughput.java
+++ b/contrib/pinot-druid-benchmark/src/main/java/com/linkedin/pinotdruidbenchmark/PinotThroughput.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinotdruidbenchmark;
 
diff --git a/docs/conf.py b/docs/conf.py
index 1cf24c1..7f6d5d2 100644
--- a/docs/conf.py
+++ b/docs/conf.py
@@ -1,17 +1,20 @@
 #
-# Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
 #
-# Licensed under the Apache License, Version 2.0 (the "License");
-# you may not use this file except in compliance with the License.
-# You may obtain a copy of the License at
+#   http://www.apache.org/licenses/LICENSE-2.0
 #
-#         http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
 #
 
 # -*- coding: utf-8 -*-
diff --git a/docs/make.bat b/docs/make.bat
index 3fd420a..319060e 100644
--- a/docs/make.bat
+++ b/docs/make.bat
@@ -1,17 +1,20 @@
 @REM
-@REM Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+@REM Licensed to the Apache Software Foundation (ASF) under one
+@REM or more contributor license agreements.  See the NOTICE file
+@REM distributed with this work for additional information
+@REM regarding copyright ownership.  The ASF licenses this file
+@REM to you under the Apache License, Version 2.0 (the
+@REM "License"); you may not use this file except in compliance
+@REM with the License.  You may obtain a copy of the License at
 @REM
-@REM Licensed under the Apache License, Version 2.0 (the "License");
-@REM you may not use this file except in compliance with the License.
-@REM You may obtain a copy of the License at
+@REM   http://www.apache.org/licenses/LICENSE-2.0
 @REM
-@REM         http://www.apache.org/licenses/LICENSE-2.0
-@REM
-@REM Unless required by applicable law or agreed to in writing, software
-@REM distributed under the License is distributed on an "AS IS" BASIS,
-@REM WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-@REM See the License for the specific language governing permissions and
-@REM limitations under the License.
+@REM Unless required by applicable law or agreed to in writing,
+@REM software distributed under the License is distributed on an
+@REM "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+@REM KIND, either express or implied.  See the License for the
+@REM specific language governing permissions and limitations
+@REM under the License.
 @REM
 
 @ECHO OFF
diff --git a/license.header b/license.header
new file mode 100644
index 0000000..60b675e
--- /dev/null
+++ b/license.header
@@ -0,0 +1,16 @@
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
diff --git a/pinot-api/pom.xml b/pinot-api/pom.xml
index 97ab0d9..9dc3304 100644
--- a/pinot-api/pom.xml
+++ b/pinot-api/pom.xml
@@ -1,19 +1,22 @@
 <?xml version="1.0"?>
 <!--
 
-    Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
 
-    Licensed under the Apache License, Version 2.0 (the "License");
-    you may not use this file except in compliance with the License.
-    You may obtain a copy of the License at
+      http://www.apache.org/licenses/LICENSE-2.0
 
-            http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
 
 -->
 <project xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd" xmlns="http://maven.apache.org/POM/4.0.0"
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/AbstractResultSet.java b/pinot-api/src/main/java/com/linkedin/pinot/client/AbstractResultSet.java
index 4902561..6a3fda6 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/AbstractResultSet.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/AbstractResultSet.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/AggregationResultSet.java b/pinot-api/src/main/java/com/linkedin/pinot/client/AggregationResultSet.java
index e21ee95..18934f6 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/AggregationResultSet.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/AggregationResultSet.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/BrokerResponse.java b/pinot-api/src/main/java/com/linkedin/pinot/client/BrokerResponse.java
index 28ca8b8..cd81e7b 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/BrokerResponse.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/BrokerResponse.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/BrokerSelector.java b/pinot-api/src/main/java/com/linkedin/pinot/client/BrokerSelector.java
index 4878a25..5968344 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/BrokerSelector.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/BrokerSelector.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/Connection.java b/pinot-api/src/main/java/com/linkedin/pinot/client/Connection.java
index 263f036..236c34f 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/Connection.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/Connection.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/ConnectionFactory.java b/pinot-api/src/main/java/com/linkedin/pinot/client/ConnectionFactory.java
index 48cf7ac..f4cd8db 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/ConnectionFactory.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/ConnectionFactory.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/DynamicBrokerSelector.java b/pinot-api/src/main/java/com/linkedin/pinot/client/DynamicBrokerSelector.java
index ed7fff4..4a6ab26 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/DynamicBrokerSelector.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/DynamicBrokerSelector.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/ExternalViewReader.java b/pinot-api/src/main/java/com/linkedin/pinot/client/ExternalViewReader.java
index 576d848..157d061 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/ExternalViewReader.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/ExternalViewReader.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/GroupByResultSet.java b/pinot-api/src/main/java/com/linkedin/pinot/client/GroupByResultSet.java
index de7272b..a510aad 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/GroupByResultSet.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/GroupByResultSet.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/JsonAsyncHttpPinotClientTransport.java b/pinot-api/src/main/java/com/linkedin/pinot/client/JsonAsyncHttpPinotClientTransport.java
index 65be8e8..f91c8cd 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/JsonAsyncHttpPinotClientTransport.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/JsonAsyncHttpPinotClientTransport.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/JsonAsyncHttpPinotClientTransportFactory.java b/pinot-api/src/main/java/com/linkedin/pinot/client/JsonAsyncHttpPinotClientTransportFactory.java
index ba35d34..e5c0e55 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/JsonAsyncHttpPinotClientTransportFactory.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/JsonAsyncHttpPinotClientTransportFactory.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientException.java b/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientException.java
index da72af9..f43818c 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientException.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientException.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientTransport.java b/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientTransport.java
index 2c19fb8..c54e091 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientTransport.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientTransport.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientTransportFactory.java b/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientTransportFactory.java
index 226e9cd..efbcd25 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientTransportFactory.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/PinotClientTransportFactory.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/PreparedStatement.java b/pinot-api/src/main/java/com/linkedin/pinot/client/PreparedStatement.java
index e3f5b0b..1406cba 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/PreparedStatement.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/PreparedStatement.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/ResultSet.java b/pinot-api/src/main/java/com/linkedin/pinot/client/ResultSet.java
index 56f0dfc..e8051fd 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/ResultSet.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/ResultSet.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/ResultSetGroup.java b/pinot-api/src/main/java/com/linkedin/pinot/client/ResultSetGroup.java
index 0c28448..248ef19 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/ResultSetGroup.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/ResultSetGroup.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/SelectionResultSet.java b/pinot-api/src/main/java/com/linkedin/pinot/client/SelectionResultSet.java
index cd63ef5..d26f41c 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/SelectionResultSet.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/SelectionResultSet.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/SimpleBrokerSelector.java b/pinot-api/src/main/java/com/linkedin/pinot/client/SimpleBrokerSelector.java
index 97004e2..fb89488 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/SimpleBrokerSelector.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/SimpleBrokerSelector.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/TextTable.java b/pinot-api/src/main/java/com/linkedin/pinot/client/TextTable.java
index bc3a2bd..67c5875 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/TextTable.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/TextTable.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/main/java/com/linkedin/pinot/client/package-info.java b/pinot-api/src/main/java/com/linkedin/pinot/client/package-info.java
index b7e1183..ac22e3f 100644
--- a/pinot-api/src/main/java/com/linkedin/pinot/client/package-info.java
+++ b/pinot-api/src/main/java/com/linkedin/pinot/client/package-info.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 /**
  * This package contains the Pinot client API.
diff --git a/pinot-api/src/test/java/com/linkedin/pinot/client/ConnectionFactoryTest.java b/pinot-api/src/test/java/com/linkedin/pinot/client/ConnectionFactoryTest.java
index b8a1a38..705f2a6 100644
--- a/pinot-api/src/test/java/com/linkedin/pinot/client/ConnectionFactoryTest.java
+++ b/pinot-api/src/test/java/com/linkedin/pinot/client/ConnectionFactoryTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/test/java/com/linkedin/pinot/client/PreparedStatementTest.java b/pinot-api/src/test/java/com/linkedin/pinot/client/PreparedStatementTest.java
index 8e6a3fe..365ca3c 100644
--- a/pinot-api/src/test/java/com/linkedin/pinot/client/PreparedStatementTest.java
+++ b/pinot-api/src/test/java/com/linkedin/pinot/client/PreparedStatementTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-api/src/test/java/com/linkedin/pinot/client/ResultSetGroupTest.java b/pinot-api/src/test/java/com/linkedin/pinot/client/ResultSetGroupTest.java
index 471e340..892cd7a 100644
--- a/pinot-api/src/test/java/com/linkedin/pinot/client/ResultSetGroupTest.java
+++ b/pinot-api/src/test/java/com/linkedin/pinot/client/ResultSetGroupTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.client;
 
diff --git a/pinot-azure-filesystem/pom.xml b/pinot-azure-filesystem/pom.xml
index c003ef6..2080d4d 100644
--- a/pinot-azure-filesystem/pom.xml
+++ b/pinot-azure-filesystem/pom.xml
@@ -1,19 +1,22 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
 
-    Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
 
-    Licensed under the Apache License, Version 2.0 (the "License");
-    you may not use this file except in compliance with the License.
-    You may obtain a copy of the License at
+      http://www.apache.org/licenses/LICENSE-2.0
 
-            http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
 
 -->
 <project xmlns="http://maven.apache.org/POM/4.0.0"
diff --git a/pinot-azure-filesystem/src/main/java/com/linkedin/pinot/filesystem/AzurePinotFS.java b/pinot-azure-filesystem/src/main/java/com/linkedin/pinot/filesystem/AzurePinotFS.java
index 796d4a0..34c2e80 100644
--- a/pinot-azure-filesystem/src/main/java/com/linkedin/pinot/filesystem/AzurePinotFS.java
+++ b/pinot-azure-filesystem/src/main/java/com/linkedin/pinot/filesystem/AzurePinotFS.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.filesystem;
 
diff --git a/pinot-azure-filesystem/src/test/java/com/linkedin/pinot/filesystem/test/AzurePinotFSTest.java b/pinot-azure-filesystem/src/test/java/com/linkedin/pinot/filesystem/test/AzurePinotFSTest.java
index 73dfeff..b4bcff3 100644
--- a/pinot-azure-filesystem/src/test/java/com/linkedin/pinot/filesystem/test/AzurePinotFSTest.java
+++ b/pinot-azure-filesystem/src/test/java/com/linkedin/pinot/filesystem/test/AzurePinotFSTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.filesystem.test;
 
diff --git a/pinot-azure-filesystem/src/test/java/com/microsoft/azure/datalake/store/MockADLFileInputStream.java b/pinot-azure-filesystem/src/test/java/com/microsoft/azure/datalake/store/MockADLFileInputStream.java
index f7eefbe3..53b5192 100644
--- a/pinot-azure-filesystem/src/test/java/com/microsoft/azure/datalake/store/MockADLFileInputStream.java
+++ b/pinot-azure-filesystem/src/test/java/com/microsoft/azure/datalake/store/MockADLFileInputStream.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.microsoft.azure.datalake.store;
 
diff --git a/pinot-broker/pom.xml b/pinot-broker/pom.xml
index c9ae051..d975197 100644
--- a/pinot-broker/pom.xml
+++ b/pinot-broker/pom.xml
@@ -1,19 +1,22 @@
 <?xml version="1.0"?>
 <!--
 
-    Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
 
-    Licensed under the Apache License, Version 2.0 (the "License");
-    you may not use this file except in compliance with the License.
-    You may obtain a copy of the License at
+      http://www.apache.org/licenses/LICENSE-2.0
 
-            http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
 
 -->
 <project xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd" xmlns="http://maven.apache.org/POM/4.0.0"
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/AccessControl.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/AccessControl.java
index 0ead0c5..b315693 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/AccessControl.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/AccessControl.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.api;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/RequestStatistics.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/RequestStatistics.java
index f6feb4d..a4c0556 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/RequestStatistics.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/RequestStatistics.java
@@ -1,19 +1,21 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-
 package com.linkedin.pinot.broker.api;
 
 import com.linkedin.pinot.common.response.BrokerResponse;
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/RequesterIdentity.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/RequesterIdentity.java
index 3667d05..e1fed0d 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/RequesterIdentity.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/RequesterIdentity.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.api;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotBrokerDebug.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotBrokerDebug.java
index be88743..cfac240 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotBrokerDebug.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotBrokerDebug.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.api.resources;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotBrokerHealthCheck.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotBrokerHealthCheck.java
index 1ab61dc..b2bdae8 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotBrokerHealthCheck.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotBrokerHealthCheck.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.api.resources;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotClientRequest.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotClientRequest.java
index eccd43a..354d420 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotClientRequest.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/api/resources/PinotClientRequest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.api.resources;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/AccessControlFactory.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/AccessControlFactory.java
index 2034db2..7181549 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/AccessControlFactory.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/AccessControlFactory.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/AllowAllAccessControlFactory.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/AllowAllAccessControlFactory.java
index 11add6a..c8ebf51 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/AllowAllAccessControlFactory.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/AllowAllAccessControlFactory.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/BrokerAdminApiApplication.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/BrokerAdminApiApplication.java
index edbe8b3..f0e70af 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/BrokerAdminApiApplication.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/BrokerAdminApiApplication.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/BrokerServerBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/BrokerServerBuilder.java
index c1e2d59..e1b85a8 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/BrokerServerBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/BrokerServerBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/BrokerResourceOnlineOfflineStateModelFactory.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/BrokerResourceOnlineOfflineStateModelFactory.java
index fd8ec83..71e247e 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/BrokerResourceOnlineOfflineStateModelFactory.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/BrokerResourceOnlineOfflineStateModelFactory.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker.helix;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/ClusterChangeMediator.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/ClusterChangeMediator.java
index cfb0906..9be0d0b 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/ClusterChangeMediator.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/ClusterChangeMediator.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker.helix;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/DefaultHelixBrokerConfig.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/DefaultHelixBrokerConfig.java
index b2b184c..911ed48 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/DefaultHelixBrokerConfig.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/DefaultHelixBrokerConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker.helix;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/HelixBrokerStarter.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/HelixBrokerStarter.java
index ac7e6de..e3cc6c6 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/HelixBrokerStarter.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/HelixBrokerStarter.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker.helix;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/LiveInstancesChangeListenerImpl.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/LiveInstancesChangeListenerImpl.java
index 3d5a9f5..c05affb 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/LiveInstancesChangeListenerImpl.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/LiveInstancesChangeListenerImpl.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker.helix;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/TimeboundaryRefreshMessageHandlerFactory.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/TimeboundaryRefreshMessageHandlerFactory.java
index 63b26a5..214bdf2 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/TimeboundaryRefreshMessageHandlerFactory.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/broker/helix/TimeboundaryRefreshMessageHandlerFactory.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker.helix;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/PartitionZKMetadataPruner.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/PartitionZKMetadataPruner.java
index 8f88eea..d65ed66 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/PartitionZKMetadataPruner.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/PartitionZKMetadataPruner.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.pruner;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentPrunerContext.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentPrunerContext.java
index 78121f2..e3c5732 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentPrunerContext.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentPrunerContext.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.pruner;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPruner.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPruner.java
index a40af44..748d4cc 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPruner.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPruner.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.pruner;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerProvider.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerProvider.java
index 59dd975..25b4a47 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerProvider.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerProvider.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.pruner;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerService.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerService.java
index c3b85c6..6be47b4 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerService.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerService.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.pruner;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/HitCounter.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/HitCounter.java
index e9af98d..54fdf57 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/HitCounter.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/HitCounter.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.queryquota;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/QueryQuotaConfig.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/QueryQuotaConfig.java
index b667596..6ead5e8 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/QueryQuotaConfig.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/QueryQuotaConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.queryquota;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/TableQueryQuotaManager.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/TableQueryQuotaManager.java
index a15bfae..8877dbe 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/TableQueryQuotaManager.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/queryquota/TableQueryQuotaManager.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.queryquota;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BaseBrokerRequestHandler.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BaseBrokerRequestHandler.java
index e12afcc..ea8eb0e 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BaseBrokerRequestHandler.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BaseBrokerRequestHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BrokerRequestHandler.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BrokerRequestHandler.java
index 6310a20..dd3337f 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BrokerRequestHandler.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BrokerRequestHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BrokerRequestOptimizer.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BrokerRequestOptimizer.java
index 6ce4b15..47acffc 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BrokerRequestOptimizer.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/BrokerRequestOptimizer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/ConnectionPoolBrokerRequestHandler.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/ConnectionPoolBrokerRequestHandler.java
index ef46895..fc87f6d 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/ConnectionPoolBrokerRequestHandler.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/ConnectionPoolBrokerRequestHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FilterQueryOptimizerRequest.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FilterQueryOptimizerRequest.java
index 43061ad..3d9660d 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FilterQueryOptimizerRequest.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FilterQueryOptimizerRequest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FilterQueryTreeOptimizer.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FilterQueryTreeOptimizer.java
index 924bbe7..74030fe 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FilterQueryTreeOptimizer.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FilterQueryTreeOptimizer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FlattenNestedPredicatesFilterQueryTreeOptimizer.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FlattenNestedPredicatesFilterQueryTreeOptimizer.java
index edb6d5f..0efdcfa 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FlattenNestedPredicatesFilterQueryTreeOptimizer.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/FlattenNestedPredicatesFilterQueryTreeOptimizer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/MultipleOrEqualitiesToInClauseFilterQueryTreeOptimizer.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/MultipleOrEqualitiesToInClauseFilterQueryTreeOptimizer.java
index 1f767e3..099d1ec 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/MultipleOrEqualitiesToInClauseFilterQueryTreeOptimizer.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/MultipleOrEqualitiesToInClauseFilterQueryTreeOptimizer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/OptimizationFlags.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/OptimizationFlags.java
index ea2282b..db75f8a 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/OptimizationFlags.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/OptimizationFlags.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/RangeMergeOptimizer.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/RangeMergeOptimizer.java
index 2204d32..0afc56b 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/RangeMergeOptimizer.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/RangeMergeOptimizer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/SingleConnectionBrokerRequestHandler.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/SingleConnectionBrokerRequestHandler.java
index 73c8040..f7002cf 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/SingleConnectionBrokerRequestHandler.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/requesthandler/SingleConnectionBrokerRequestHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/CfgBasedRouting.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/CfgBasedRouting.java
index e62aec3..8aa1147 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/CfgBasedRouting.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/CfgBasedRouting.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/HelixExternalViewBasedRouting.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/HelixExternalViewBasedRouting.java
index 840c06a..7aa07d8 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/HelixExternalViewBasedRouting.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/HelixExternalViewBasedRouting.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/HelixExternalViewBasedTimeBoundaryService.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/HelixExternalViewBasedTimeBoundaryService.java
index 87faa94..997247d 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/HelixExternalViewBasedTimeBoundaryService.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/HelixExternalViewBasedTimeBoundaryService.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTable.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTable.java
index 10c665e..d62d542 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTable.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTable.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTableBuilderFactory.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTableBuilderFactory.java
index ddae509..7ef2f78 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTableBuilderFactory.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTableBuilderFactory.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTableLookupRequest.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTableLookupRequest.java
index fc7ecaf..7028a89 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTableLookupRequest.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/RoutingTableLookupRequest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/TimeBoundaryService.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/TimeBoundaryService.java
index d68f85e..d0aec08 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/TimeBoundaryService.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/TimeBoundaryService.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BalancedRandomRoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BalancedRandomRoutingTableBuilder.java
index 471d74e..01f1259 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BalancedRandomRoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BalancedRandomRoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BasePartitionAwareRoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BasePartitionAwareRoutingTableBuilder.java
index fe15602..dc88c1e 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BasePartitionAwareRoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BasePartitionAwareRoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BaseRoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BaseRoutingTableBuilder.java
index 6b7993a..0783abe 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BaseRoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/BaseRoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/DefaultOfflineRoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/DefaultOfflineRoutingTableBuilder.java
index 2ed57c4..c1eda37 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/DefaultOfflineRoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/DefaultOfflineRoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/DefaultRealtimeRoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/DefaultRealtimeRoutingTableBuilder.java
index 72a9a79..061d016 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/DefaultRealtimeRoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/DefaultRealtimeRoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/GeneratorBasedRoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/GeneratorBasedRoutingTableBuilder.java
index e6939eb..be29b8b 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/GeneratorBasedRoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/GeneratorBasedRoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/HighLevelConsumerBasedRoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/HighLevelConsumerBasedRoutingTableBuilder.java
index 21d746a..40dd9df 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/HighLevelConsumerBasedRoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/HighLevelConsumerBasedRoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LargeClusterRoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LargeClusterRoutingTableBuilder.java
index 164e603..d0f1b45 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LargeClusterRoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LargeClusterRoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LowLevelConsumerRoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LowLevelConsumerRoutingTableBuilder.java
index de62b6b..baf8fc1 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LowLevelConsumerRoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LowLevelConsumerRoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LowLevelRoutingTableBuilderUtil.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LowLevelRoutingTableBuilderUtil.java
index bff16eb..d34161a 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LowLevelRoutingTableBuilderUtil.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/LowLevelRoutingTableBuilderUtil.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareOfflineRoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareOfflineRoutingTableBuilder.java
index 6bf2df1..c7c37bc 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareOfflineRoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareOfflineRoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareRealtimeRoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareRealtimeRoutingTableBuilder.java
index 0ac3017..8d4ca27 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareRealtimeRoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareRealtimeRoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/RoutingTableBuilder.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/RoutingTableBuilder.java
index d27546a..9457d3d 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/RoutingTableBuilder.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/RoutingTableBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/RoutingTableInstancePruner.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/RoutingTableInstancePruner.java
index 6ef173e..fe423ba 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/RoutingTableInstancePruner.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/builder/RoutingTableInstancePruner.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/MergedSegmentSelector.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/MergedSegmentSelector.java
index 7d74146..622fea7 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/MergedSegmentSelector.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/MergedSegmentSelector.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.selector;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/SegmentSelector.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/SegmentSelector.java
index 9114c31..a2c801a 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/SegmentSelector.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/SegmentSelector.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.selector;
 
diff --git a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/SegmentSelectorProvider.java b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/SegmentSelectorProvider.java
index 502ddfd..2156783 100644
--- a/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/SegmentSelectorProvider.java
+++ b/pinot-broker/src/main/java/com/linkedin/pinot/broker/routing/selector/SegmentSelectorProvider.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.selector;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/BrokerTestUtils.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/BrokerTestUtils.java
index fcc6dba..dbef75f 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/BrokerTestUtils.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/BrokerTestUtils.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/EmptyBrokerOnlineOfflineStateModelFactory.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/EmptyBrokerOnlineOfflineStateModelFactory.java
index ac67673..a473fba 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/EmptyBrokerOnlineOfflineStateModelFactory.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/EmptyBrokerOnlineOfflineStateModelFactory.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/EmptySegmentOnlineOfflineStateModelFactory.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/EmptySegmentOnlineOfflineStateModelFactory.java
index 2f9dcff..0eca71e 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/EmptySegmentOnlineOfflineStateModelFactory.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/EmptySegmentOnlineOfflineStateModelFactory.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/HelixBrokerStarterTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/HelixBrokerStarterTest.java
index 38f26e5..4545c61 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/HelixBrokerStarterTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/HelixBrokerStarterTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/HelixBrokerStarterUtilsTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/HelixBrokerStarterUtilsTest.java
index e2556ca..325e8ee 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/HelixBrokerStarterUtilsTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/broker/HelixBrokerStarterUtilsTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.broker;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerTest.java
index d629329..83c904c 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/pruner/SegmentZKMetadataPrunerTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.pruner;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/queryquota/HitCounterTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/queryquota/HitCounterTest.java
index 88c5c16..d7d353a 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/queryquota/HitCounterTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/queryquota/HitCounterTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.queryquota;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/queryquota/TableQueryQuotaManagerTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/queryquota/TableQueryQuotaManagerTest.java
index 374dbb9..c154a61 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/queryquota/TableQueryQuotaManagerTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/queryquota/TableQueryQuotaManagerTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.queryquota;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/FilterOptimizerTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/FilterOptimizerTest.java
index 8d0aaae..85d1b9d 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/FilterOptimizerTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/FilterOptimizerTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/MultipleOrEqualitiesToInClauseFilterQueryTreeOptimizerTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/MultipleOrEqualitiesToInClauseFilterQueryTreeOptimizerTest.java
index af77f7e..ad8df61 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/MultipleOrEqualitiesToInClauseFilterQueryTreeOptimizerTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/MultipleOrEqualitiesToInClauseFilterQueryTreeOptimizerTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/OptimizationFlagsTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/OptimizationFlagsTest.java
index c6bf769..c27a266 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/OptimizationFlagsTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/OptimizationFlagsTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/RangeMergeOptimizerTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/RangeMergeOptimizerTest.java
index cd0dbf3..b8e4078 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/RangeMergeOptimizerTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/requesthandler/RangeMergeOptimizerTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.requesthandler;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/RandomRoutingTableTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/RandomRoutingTableTest.java
index 7ea2149..411feed 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/RandomRoutingTableTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/RandomRoutingTableTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/RoutingTableTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/RoutingTableTest.java
index 3413711..cf2c232 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/RoutingTableTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/RoutingTableTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/TimeBoundaryServiceTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/TimeBoundaryServiceTest.java
index 078535b..922ec74 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/TimeBoundaryServiceTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/TimeBoundaryServiceTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/BalancedRandomRoutingTableBuilderTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/BalancedRandomRoutingTableBuilderTest.java
index 46ca40c..a41f375 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/BalancedRandomRoutingTableBuilderTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/BalancedRandomRoutingTableBuilderTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/HighLevelConsumerRoutingTableBuilderTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/HighLevelConsumerRoutingTableBuilderTest.java
index c2ef4e4..51d0f1e 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/HighLevelConsumerRoutingTableBuilderTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/HighLevelConsumerRoutingTableBuilderTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/LargeClusterRoutingTableBuilderTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/LargeClusterRoutingTableBuilderTest.java
index ee599e6..ab9d6a0 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/LargeClusterRoutingTableBuilderTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/LargeClusterRoutingTableBuilderTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/LowLevelConsumerRoutingTableBuilderTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/LowLevelConsumerRoutingTableBuilderTest.java
index 0ebefb2..8242ecb 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/LowLevelConsumerRoutingTableBuilderTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/LowLevelConsumerRoutingTableBuilderTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareOfflineRoutingTableBuilderTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareOfflineRoutingTableBuilderTest.java
index 5a44a28..20ee440 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareOfflineRoutingTableBuilderTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareOfflineRoutingTableBuilderTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareRealtimeRoutingTableBuilderTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareRealtimeRoutingTableBuilderTest.java
index 7890b1b..3b91b28 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareRealtimeRoutingTableBuilderTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/PartitionAwareRealtimeRoutingTableBuilderTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/RoutingTableBuilderTestUtil.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/RoutingTableBuilderTestUtil.java
index c50bb8f..9fc6ea9 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/RoutingTableBuilderTestUtil.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/builder/RoutingTableBuilderTestUtil.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.builder;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/selector/MergedSegmentSelectorTest.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/selector/MergedSegmentSelectorTest.java
index 2edc891..202eb74 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/selector/MergedSegmentSelectorTest.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/routing/selector/MergedSegmentSelectorTest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.routing.selector;
 
diff --git a/pinot-broker/src/test/java/com/linkedin/pinot/broker/util/FakePropertyStore.java b/pinot-broker/src/test/java/com/linkedin/pinot/broker/util/FakePropertyStore.java
index 70e5310..41e4893 100644
--- a/pinot-broker/src/test/java/com/linkedin/pinot/broker/util/FakePropertyStore.java
+++ b/pinot-broker/src/test/java/com/linkedin/pinot/broker/util/FakePropertyStore.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.broker.util;
 
diff --git a/pinot-common/pom.xml b/pinot-common/pom.xml
index 95e4fc8..46b8ded 100644
--- a/pinot-common/pom.xml
+++ b/pinot-common/pom.xml
@@ -1,19 +1,22 @@
 <?xml version="1.0"?>
 <!--
 
-    Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
 
-    Licensed under the Apache License, Version 2.0 (the "License");
-    you may not use this file except in compliance with the License.
-    You may obtain a copy of the License at
+      http://www.apache.org/licenses/LICENSE-2.0
 
-            http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
 
 -->
 <project xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd"
diff --git a/pinot-common/src/main/antlr4/com/linkedin/pinot/pql/parsers/PQL2.g4 b/pinot-common/src/main/antlr4/com/linkedin/pinot/pql/parsers/PQL2.g4
index 1716d0f..5086182 100644
--- a/pinot-common/src/main/antlr4/com/linkedin/pinot/pql/parsers/PQL2.g4
+++ b/pinot-common/src/main/antlr4/com/linkedin/pinot/pql/parsers/PQL2.g4
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 grammar PQL2;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/Utils.java b/pinot-common/src/main/java/com/linkedin/pinot/common/Utils.java
index 7a8706a..f1052df 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/Utils.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/Utils.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/AdjustTableNameChildKeyTransformer.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/AdjustTableNameChildKeyTransformer.java
index 76a3fbd..b26c240 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/AdjustTableNameChildKeyTransformer.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/AdjustTableNameChildKeyTransformer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ChildKeyHandler.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ChildKeyHandler.java
index ee6d72f..3eb854f 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ChildKeyHandler.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ChildKeyHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ChildKeyTransformer.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ChildKeyTransformer.java
index ff118de..6ac3140 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ChildKeyTransformer.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ChildKeyTransformer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ColumnPartitionConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ColumnPartitionConfig.java
index a4b4bff..ce39dfe 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ColumnPartitionConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ColumnPartitionConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ColumnPartitionMapChildKeyHandler.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ColumnPartitionMapChildKeyHandler.java
index cf098c2..4f85029 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ColumnPartitionMapChildKeyHandler.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ColumnPartitionMapChildKeyHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfig.java
index 8cb5203..756d0cd 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfigLoader.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfigLoader.java
index de887a1..616e27d 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfigLoader.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfigLoader.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfigSeparatorChildKeyTransformer.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfigSeparatorChildKeyTransformer.java
index f8fef31..5325ffb 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfigSeparatorChildKeyTransformer.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/CombinedConfigSeparatorChildKeyTransformer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigDoc.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigDoc.java
index f183b1d..2583699 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigDoc.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigDoc.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigKey.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigKey.java
index 0de6134..1a1194f 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigKey.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigKey.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigNodeLifecycleAware.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigNodeLifecycleAware.java
index 34ccbe2..d4ce459 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigNodeLifecycleAware.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ConfigNodeLifecycleAware.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/Deserializer.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/Deserializer.java
index c667366..f06b7f3 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/Deserializer.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/Deserializer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/Duration.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/Duration.java
index 0075955..089852a 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/Duration.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/Duration.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/DurationDsl.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/DurationDsl.java
index 00070ba..c9c54c2 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/DurationDsl.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/DurationDsl.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/IndexingConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/IndexingConfig.java
index c3a45900..327e113 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/IndexingConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/IndexingConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/NamedListChildKeyHandler.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/NamedListChildKeyHandler.java
index 30dc547..9084b13 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/NamedListChildKeyHandler.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/NamedListChildKeyHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/NestedConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/NestedConfig.java
index c65607f..656a775 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/NestedConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/NestedConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/OfflineTagConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/OfflineTagConfig.java
index 9d3d694..4575066 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/OfflineTagConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/OfflineTagConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/PinotTaskConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/PinotTaskConfig.java
index 115fb01..091dcfc 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/PinotTaskConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/PinotTaskConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/QuotaConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/QuotaConfig.java
index 6782c1f..bfa2fb5 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/QuotaConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/QuotaConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/RealtimeTagConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/RealtimeTagConfig.java
index 7646284..17a4a67 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/RealtimeTagConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/RealtimeTagConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/RemapTableTypesChildKeyTransformer.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/RemapTableTypesChildKeyTransformer.java
index 8863f16..f09f732 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/RemapTableTypesChildKeyTransformer.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/RemapTableTypesChildKeyTransformer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ReplicaGroupStrategyConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ReplicaGroupStrategyConfig.java
index 978cbba..4de9d24 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/ReplicaGroupStrategyConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/ReplicaGroupStrategyConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/RoutingConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/RoutingConfig.java
index b0d75d0..f948868 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/RoutingConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/RoutingConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/SegmentPartitionConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/SegmentPartitionConfig.java
index 9adba1c..967039d 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/SegmentPartitionConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/SegmentPartitionConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/SegmentsValidationAndRetentionConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/SegmentsValidationAndRetentionConfig.java
index d2f06bb..a7f0d3d 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/SegmentsValidationAndRetentionConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/SegmentsValidationAndRetentionConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/Serializer.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/Serializer.java
index 9ca3fde..fc04190 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/Serializer.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/Serializer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/SimpleMapChildKeyHandler.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/SimpleMapChildKeyHandler.java
index 6201bdf..ed38f4d 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/SimpleMapChildKeyHandler.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/SimpleMapChildKeyHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/SingleKeyDsl.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/SingleKeyDsl.java
index 5ff4c06..aa8674f 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/SingleKeyDsl.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/SingleKeyDsl.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/StarTreeIndexConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/StarTreeIndexConfig.java
index 5526bb7..06ebabf 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/StarTreeIndexConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/StarTreeIndexConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/StreamConsumptionConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/StreamConsumptionConfig.java
index 26f5061..ff37c4d 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/StreamConsumptionConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/StreamConsumptionConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableConfig.java
index 373f369..3d24d27 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableCustomConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableCustomConfig.java
index 0aaff6f..e888c52 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableCustomConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableCustomConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableNameBuilder.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableNameBuilder.java
index 94eca7b..3f1bfd8 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableNameBuilder.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableNameBuilder.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableTaskConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableTaskConfig.java
index 5cfae9d..7fc554e 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableTaskConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TableTaskConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagConfig.java
index f71b451..e02cabf 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagNameUtils.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagNameUtils.java
index 4ea07d8..fc82050 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagNameUtils.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagNameUtils.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagOverrideConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagOverrideConfig.java
index 0482ec2..b14480a 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagOverrideConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TagOverrideConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TaskConfigMapChildKeyHandler.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TaskConfigMapChildKeyHandler.java
index 32058dd..b4ac8f5 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TaskConfigMapChildKeyHandler.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TaskConfigMapChildKeyHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/Tenant.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/Tenant.java
index 3db6183..02c9e92 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/Tenant.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/Tenant.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TenantConfig.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TenantConfig.java
index ec7311f..ba717f5 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TenantConfig.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TenantConfig.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TypedMapChildKeyHandler.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TypedMapChildKeyHandler.java
index 7aceddb..7b0ce30 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/TypedMapChildKeyHandler.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/TypedMapChildKeyHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseChildKeyHandler.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseChildKeyHandler.java
index 325a317..152830a 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseChildKeyHandler.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseChildKeyHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseChildKeyTransformers.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseChildKeyTransformers.java
index e5d45fe..af44f14 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseChildKeyTransformers.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseChildKeyTransformers.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseDsl.java b/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseDsl.java
index 85d8855..f680162 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseDsl.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/config/UseDsl.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.config;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFieldSpec.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFieldSpec.java
index c4c1497..ace21c6 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFieldSpec.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFieldSpec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFieldSpecChildKeyHandler.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFieldSpecChildKeyHandler.java
index 0d1ad6b..34722cc 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFieldSpecChildKeyHandler.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFieldSpecChildKeyHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatPatternSpec.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatPatternSpec.java
index 7cd9ffe..ec9e029 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatPatternSpec.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatPatternSpec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatSpec.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatSpec.java
index c5e1c65..4e2aa9c 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatSpec.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatSpec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatUnitSpec.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatUnitSpec.java
index 2a3d1bd..93d58df 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatUnitSpec.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeFormatUnitSpec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeGranularitySpec.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeGranularitySpec.java
index 5f00a07..773f956 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeGranularitySpec.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DateTimeGranularitySpec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DimensionFieldSpec.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DimensionFieldSpec.java
index 96b8d82..970a896 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DimensionFieldSpec.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DimensionFieldSpec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DimensionFieldSpecChildKeyHandler.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DimensionFieldSpecChildKeyHandler.java
index 25be4be..188e020 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/DimensionFieldSpecChildKeyHandler.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/DimensionFieldSpecChildKeyHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/FieldSpec.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/FieldSpec.java
index f80d356..d61b1be 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/FieldSpec.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/FieldSpec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/MetricFieldSpec.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/MetricFieldSpec.java
index 5037dce..3e52a33 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/MetricFieldSpec.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/MetricFieldSpec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/MetricFieldSpecChildKeyHandler.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/MetricFieldSpecChildKeyHandler.java
index cbfde64..9b0ebb3 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/MetricFieldSpecChildKeyHandler.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/MetricFieldSpecChildKeyHandler.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/RowEvent.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/RowEvent.java
index 256e8ce..a9a0d7e 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/RowEvent.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/RowEvent.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/Schema.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/Schema.java
index f2e6a0c..9566eaa 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/Schema.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/Schema.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/Segment.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/Segment.java
index 712e269..5b5985e 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/Segment.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/Segment.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/StarTreeIndexSpec.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/StarTreeIndexSpec.java
index 67f6880..15b1b9e 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/StarTreeIndexSpec.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/StarTreeIndexSpec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/TimeFieldSpec.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/TimeFieldSpec.java
index dc0bf4c..adbe577 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/TimeFieldSpec.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/TimeFieldSpec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/data/TimeGranularitySpec.java b/pinot-common/src/main/java/com/linkedin/pinot/common/data/TimeGranularitySpec.java
index dad159d..8ec74cb 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/data/TimeGranularitySpec.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/data/TimeGranularitySpec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.data;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/exception/HttpErrorStatusException.java b/pinot-common/src/main/java/com/linkedin/pinot/common/exception/HttpErrorStatusException.java
index e377927..4e05371 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/exception/HttpErrorStatusException.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/exception/HttpErrorStatusException.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.exception;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/exception/InvalidConfigException.java b/pinot-common/src/main/java/com/linkedin/pinot/common/exception/InvalidConfigException.java
index ca60ce3..7744df1 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/exception/InvalidConfigException.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/exception/InvalidConfigException.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.exception;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/exception/QueryException.java b/pinot-common/src/main/java/com/linkedin/pinot/common/exception/QueryException.java
index 0cdfc85..4de49b9 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/exception/QueryException.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/exception/QueryException.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.exception;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/exception/TableNotFoundException.java b/pinot-common/src/main/java/com/linkedin/pinot/common/exception/TableNotFoundException.java
index 17dbe50..0786a15 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/exception/TableNotFoundException.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/exception/TableNotFoundException.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.exception;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/http/MultiGetRequest.java b/pinot-common/src/main/java/com/linkedin/pinot/common/http/MultiGetRequest.java
index 7e40de0..76366d0 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/http/MultiGetRequest.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/http/MultiGetRequest.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.http;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentGroup.java b/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentGroup.java
index fb28ac1..1ca4057 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentGroup.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentGroup.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.lineage;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentMergeLineage.java b/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentMergeLineage.java
index 3df8aa9..ee83370 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentMergeLineage.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentMergeLineage.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.lineage;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentMergeLineageAccessHelper.java b/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentMergeLineageAccessHelper.java
index 848d7b8..07420ca 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentMergeLineageAccessHelper.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/lineage/SegmentMergeLineageAccessHelper.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.lineage;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/messages/SegmentRefreshMessage.java b/pinot-common/src/main/java/com/linkedin/pinot/common/messages/SegmentRefreshMessage.java
index bba257f..2532163 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/messages/SegmentRefreshMessage.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/messages/SegmentRefreshMessage.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.messages;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/messages/SegmentReloadMessage.java b/pinot-common/src/main/java/com/linkedin/pinot/common/messages/SegmentReloadMessage.java
index 938dfa8..f87ccb1 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/messages/SegmentReloadMessage.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/messages/SegmentReloadMessage.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.messages;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/messages/TimeboundaryRefreshMessage.java b/pinot-common/src/main/java/com/linkedin/pinot/common/messages/TimeboundaryRefreshMessage.java
index cc1b7c9..594c549 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/messages/TimeboundaryRefreshMessage.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/messages/TimeboundaryRefreshMessage.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.messages;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/ZKMetadata.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/ZKMetadata.java
index 746dbbc..22b3d52 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/ZKMetadata.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/ZKMetadata.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metadata;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/ZKMetadataProvider.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/ZKMetadataProvider.java
index e9d6b63..711a7d4 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/ZKMetadataProvider.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/ZKMetadataProvider.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metadata;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/instance/InstanceZKMetadata.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/instance/InstanceZKMetadata.java
index 8680e2a..f9adbbf 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/instance/InstanceZKMetadata.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/instance/InstanceZKMetadata.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metadata.instance;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/ColumnPartitionMetadata.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/ColumnPartitionMetadata.java
index 941f2b2..b77e29a 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/ColumnPartitionMetadata.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/ColumnPartitionMetadata.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metadata.segment;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/LLCRealtimeSegmentZKMetadata.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/LLCRealtimeSegmentZKMetadata.java
index cf3e90b..797ef25 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/LLCRealtimeSegmentZKMetadata.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/LLCRealtimeSegmentZKMetadata.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metadata.segment;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/OfflineSegmentZKMetadata.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/OfflineSegmentZKMetadata.java
index 0e78436..34c6804 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/OfflineSegmentZKMetadata.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/OfflineSegmentZKMetadata.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metadata.segment;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/RealtimeSegmentZKMetadata.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/RealtimeSegmentZKMetadata.java
index 4a11681..a644d26 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/RealtimeSegmentZKMetadata.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/RealtimeSegmentZKMetadata.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metadata.segment;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentPartitionMetadata.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentPartitionMetadata.java
index d9fb77e..86eb506 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentPartitionMetadata.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentPartitionMetadata.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metadata.segment;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentZKMetadata.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentZKMetadata.java
index c997eac..08d0c03 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentZKMetadata.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentZKMetadata.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metadata.segment;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentZKMetadataCustomMapModifier.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentZKMetadataCustomMapModifier.java
index b8f02ba..84b8c0c 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentZKMetadataCustomMapModifier.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metadata/segment/SegmentZKMetadataCustomMapModifier.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metadata.segment;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AbstractMetrics.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AbstractMetrics.java
index d7c6b8a..86f5eec 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AbstractMetrics.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AbstractMetrics.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedCounter.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedCounter.java
index a3682ac..4afc93a 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedCounter.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedCounter.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedHistogram.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedHistogram.java
index 5615ef0..926c839 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedHistogram.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedHistogram.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedLongGauge.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedLongGauge.java
index df89580..f0dd89e 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedLongGauge.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedLongGauge.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedMeter.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedMeter.java
index b367fac..670e824 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedMeter.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedMeter.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedMetricsRegistry.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedMetricsRegistry.java
index bafe78e..7f77b56 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedMetricsRegistry.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/AggregatedMetricsRegistry.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerGauge.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerGauge.java
index 65f6519..501d5da 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerGauge.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerGauge.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerMeter.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerMeter.java
index 78b9264..dfcc538 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerMeter.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerMeter.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerMetrics.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerMetrics.java
index df79b4b..667ddd4 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerMetrics.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerMetrics.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerQueryPhase.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerQueryPhase.java
index 3655786..d2ace35 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerQueryPhase.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerQueryPhase.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerTimer.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerTimer.java
index 4bdfd52..f041f46 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerTimer.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/BrokerTimer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerGauge.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerGauge.java
index 157d326..891a161 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerGauge.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerGauge.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerMeter.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerMeter.java
index 5163700..070bf78 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerMeter.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerMeter.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerMetrics.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerMetrics.java
index df11638..3d54ed1 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerMetrics.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerMetrics.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerTimer.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerTimer.java
index d312b33..4a87f5c 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerTimer.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/ControllerTimer.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/JmxReporterMetricsRegistryRegistrationListener.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/JmxReporterMetricsRegistryRegistrationListener.java
index 11e8536..afdf4c0 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/JmxReporterMetricsRegistryRegistrationListener.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/JmxReporterMetricsRegistryRegistrationListener.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/LatencyMetric.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/LatencyMetric.java
index 98539ec..75190ff 100644
--- a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/LatencyMetric.java
+++ b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/LatencyMetric.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014-2018 LinkedIn Corp. (pinot-core@linkedin.com)
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *   http://www.apache.org/licenses/LICENSE-2.0
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.linkedin.pinot.common.metrics;
 
diff --git a/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/MetricsHelper.java b/pinot-common/src/main/java/com/linkedin/pinot/common/metrics/MetricsHelper.java
... 52791 lines suppressed ...


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