You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@druid.apache.org by gi...@apache.org on 2018/07/11 16:55:24 UTC

[incubator-druid] branch master updated: Update license headers. (#5976)

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

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


The following commit(s) were added to refs/heads/master by this push:
     new 04ea3c9  Update license headers. (#5976)
04ea3c9 is described below

commit 04ea3c9f8c1f5ea34b023217bd709509ace4d30d
Author: Gian Merlino <gi...@gmail.com>
AuthorDate: Wed Jul 11 09:55:18 2018 -0700

    Update license headers. (#5976)
    
    * Update license headers.
    
    For compliance with http://www.apache.org/legal/src-headers.html.
    
    * More license adjustments.
    
    * Fix mistakenly edited package line.
---
 api/pom.xml                                        | 34 +++++++++++-----------
 .../main/java/io/druid/cli/CliCommandCreator.java  | 12 ++++----
 .../druid/data/input/ByteBufferInputRowParser.java | 12 ++++----
 .../main/java/io/druid/data/input/Committer.java   | 12 ++++----
 .../main/java/io/druid/data/input/Firehose.java    | 12 ++++----
 .../java/io/druid/data/input/FirehoseFactory.java  | 12 ++++----
 .../io/druid/data/input/FirehoseFactoryV2.java     | 12 ++++----
 .../main/java/io/druid/data/input/FirehoseV2.java  | 12 ++++----
 .../main/java/io/druid/data/input/InputRow.java    | 12 ++++----
 .../java/io/druid/data/input/MapBasedInputRow.java | 12 ++++----
 .../main/java/io/druid/data/input/MapBasedRow.java | 12 ++++----
 api/src/main/java/io/druid/data/input/Row.java     | 12 ++++----
 api/src/main/java/io/druid/data/input/Rows.java    | 12 ++++----
 .../impl/AbstractTextFilesFirehoseFactory.java     | 12 ++++----
 .../io/druid/data/input/impl/CSVParseSpec.java     | 12 ++++----
 .../druid/data/input/impl/DelimitedParseSpec.java  | 12 ++++----
 .../io/druid/data/input/impl/DimensionSchema.java  | 12 ++++----
 .../io/druid/data/input/impl/DimensionsSpec.java   | 12 ++++----
 .../data/input/impl/DoubleDimensionSchema.java     | 12 ++++----
 .../data/input/impl/FileIteratingFirehose.java     | 12 ++++----
 .../data/input/impl/FloatDimensionSchema.java      | 12 ++++----
 .../io/druid/data/input/impl/InputRowParser.java   | 12 ++++----
 .../data/input/impl/JSONLowercaseParseSpec.java    | 12 ++++----
 .../io/druid/data/input/impl/JSONParseSpec.java    | 12 ++++----
 .../druid/data/input/impl/JavaScriptParseSpec.java | 12 ++++----
 .../druid/data/input/impl/LongDimensionSchema.java | 12 ++++----
 .../druid/data/input/impl/MapInputRowParser.java   | 12 ++++----
 .../data/input/impl/NewSpatialDimensionSchema.java | 12 ++++----
 .../druid/data/input/impl/NoopInputRowParser.java  | 12 ++++----
 .../java/io/druid/data/input/impl/ParseSpec.java   | 12 ++++----
 .../io/druid/data/input/impl/RegexParseSpec.java   | 12 ++++----
 .../data/input/impl/SpatialDimensionSchema.java    | 12 ++++----
 .../java/io/druid/data/input/impl/SqlFirehose.java | 12 ++++----
 .../data/input/impl/StringDimensionSchema.java     | 12 ++++----
 .../data/input/impl/StringInputRowParser.java      | 12 ++++----
 .../data/input/impl/TimeAndDimsParseSpec.java      | 12 ++++----
 .../io/druid/data/input/impl/TimestampSpec.java    | 12 ++++----
 .../data/input/impl/prefetch/CacheManager.java     | 12 ++++----
 .../data/input/impl/prefetch/FetchedFile.java      | 12 ++++----
 .../io/druid/data/input/impl/prefetch/Fetcher.java | 12 ++++----
 .../data/input/impl/prefetch/FileFetcher.java      | 12 ++++----
 .../data/input/impl/prefetch/JsonIterator.java     | 12 ++++----
 .../input/impl/prefetch/ObjectOpenFunction.java    | 12 ++++----
 .../data/input/impl/prefetch/OpenedObject.java     | 12 ++++----
 .../data/input/impl/prefetch/PrefetchConfig.java   | 12 ++++----
 .../impl/prefetch/PrefetchSqlFirehoseFactory.java  | 12 ++++----
 .../PrefetchableTextFilesFirehoseFactory.java      | 12 ++++----
 .../input/impl/prefetch/RetryingInputStream.java   | 12 ++++----
 .../druid/data/input/impl/prefetch/SqlFetcher.java | 12 ++++----
 api/src/main/java/io/druid/guice/Binders.java      | 12 ++++----
 .../java/io/druid/guice/ConditionalMultibind.java  | 12 ++++----
 .../java/io/druid/guice/DruidGuiceExtensions.java  | 12 ++++----
 api/src/main/java/io/druid/guice/DruidScopes.java  | 12 ++++----
 api/src/main/java/io/druid/guice/Jerseys.java      | 12 ++++----
 .../java/io/druid/guice/JsonConfigProvider.java    | 12 ++++----
 .../main/java/io/druid/guice/JsonConfigurator.java | 12 ++++----
 api/src/main/java/io/druid/guice/KeyHolder.java    | 12 ++++----
 .../main/java/io/druid/guice/LazySingleton.java    | 12 ++++----
 .../main/java/io/druid/guice/LifecycleModule.java  | 12 ++++----
 .../main/java/io/druid/guice/LifecycleScope.java   | 12 ++++----
 .../main/java/io/druid/guice/ManageLifecycle.java  | 12 ++++----
 .../java/io/druid/guice/ManageLifecycleLast.java   | 12 ++++----
 api/src/main/java/io/druid/guice/PolyBind.java     | 12 ++++----
 .../main/java/io/druid/guice/SupplierProvider.java | 12 ++++----
 .../druid/guice/annotations/EscalatedGlobal.java   | 12 ++++----
 .../java/io/druid/guice/annotations/Global.java    | 12 ++++----
 .../io/druid/guice/annotations/JSR311Resource.java | 12 ++++----
 .../main/java/io/druid/guice/annotations/Json.java | 12 ++++----
 .../main/java/io/druid/guice/annotations/Self.java | 12 ++++----
 .../java/io/druid/guice/annotations/Smile.java     | 12 ++++----
 .../main/java/io/druid/indexer/IngestionState.java | 12 ++++----
 .../java/io/druid/indexer/RunnerTaskState.java     | 12 ++++----
 api/src/main/java/io/druid/indexer/TaskInfo.java   | 12 ++++----
 .../main/java/io/druid/indexer/TaskLocation.java   | 12 ++++----
 .../java/io/druid/indexer/TaskMetricsGetter.java   | 12 ++++----
 .../java/io/druid/indexer/TaskMetricsUtils.java    | 12 ++++----
 api/src/main/java/io/druid/indexer/TaskState.java  | 12 ++++----
 api/src/main/java/io/druid/indexer/TaskStatus.java | 12 ++++----
 .../main/java/io/druid/indexer/TaskStatusPlus.java | 12 ++++----
 .../java/io/druid/initialization/DruidModule.java  | 12 ++++----
 .../druid/jackson/CommaListJoinDeserializer.java   | 12 ++++----
 .../io/druid/jackson/CommaListJoinSerializer.java  | 12 ++++----
 .../main/java/io/druid/js/JavaScriptConfig.java    | 12 ++++----
 .../java/io/druid/query/SegmentDescriptor.java     | 12 ++++----
 .../main/java/io/druid/segment/SegmentUtils.java   | 12 ++++----
 .../druid/segment/loading/DataSegmentArchiver.java | 12 ++++----
 .../druid/segment/loading/DataSegmentFinder.java   | 12 ++++----
 .../druid/segment/loading/DataSegmentKiller.java   | 12 ++++----
 .../io/druid/segment/loading/DataSegmentMover.java | 12 ++++----
 .../druid/segment/loading/DataSegmentPusher.java   | 12 ++++----
 .../java/io/druid/segment/loading/LoadSpec.java    | 12 ++++----
 .../segment/loading/NoopDataSegmentPusher.java     | 12 ++++----
 .../segment/loading/SegmentLoadingException.java   | 12 ++++----
 .../io/druid/segment/loading/URIDataPuller.java    | 12 ++++----
 .../main/java/io/druid/tasklogs/NoopTaskLogs.java  | 12 ++++----
 .../main/java/io/druid/tasklogs/TaskLogKiller.java | 12 ++++----
 .../main/java/io/druid/tasklogs/TaskLogPusher.java | 12 ++++----
 .../java/io/druid/tasklogs/TaskLogStreamer.java    | 12 ++++----
 api/src/main/java/io/druid/tasklogs/TaskLogs.java  | 12 ++++----
 .../main/java/io/druid/timeline/DataSegment.java   | 12 ++++----
 .../java/io/druid/timeline/DataSegmentUtils.java   | 12 ++++----
 .../main/java/io/druid/timeline/PruneLoadSpec.java | 12 ++++----
 .../io/druid/timeline/partition/NoneShardSpec.java | 12 ++++----
 .../druid/timeline/partition/PartitionChunk.java   | 12 ++++----
 .../io/druid/timeline/partition/ShardSpec.java     | 12 ++++----
 .../druid/timeline/partition/ShardSpecLookup.java  | 12 ++++----
 .../partition/SingleElementPartitionChunk.java     | 12 ++++----
 .../main/java/io/druid/utils/CircularBuffer.java   | 12 ++++----
 .../main/java/io/druid/utils/CompressionUtils.java | 12 ++++----
 api/src/main/java/io/druid/utils/Runnables.java    | 12 ++++----
 api/src/test/java/io/druid/TestObjectMapper.java   | 12 ++++----
 .../java/io/druid/data/input/MapBasedRowTest.java  | 12 ++++----
 .../io/druid/data/input/impl/CSVParseSpecTest.java | 12 ++++----
 .../data/input/impl/DelimitedParseSpecTest.java    | 12 ++++----
 .../druid/data/input/impl/DimensionSchemaTest.java | 12 ++++----
 .../data/input/impl/DimensionsSpecSerdeTest.java   | 12 ++++----
 .../data/input/impl/FileIteratingFirehoseTest.java | 12 ++++----
 .../data/input/impl/InputRowParserSerdeTest.java   | 12 ++++----
 .../input/impl/JSONLowercaseParseSpecTest.java     | 12 ++++----
 .../druid/data/input/impl/JSONParseSpecTest.java   | 12 ++++----
 .../io/druid/data/input/impl/JSONPathSpecTest.java | 12 ++++----
 .../data/input/impl/JavaScriptParseSpecTest.java   | 12 ++++----
 .../data/input/impl/NoopInputRowParserTest.java    | 12 ++++----
 .../io/druid/data/input/impl/ParseSpecTest.java    | 12 ++++----
 .../druid/data/input/impl/RegexParseSpecTest.java  | 12 ++++----
 .../io/druid/data/input/impl/SqlFirehoseTest.java  | 12 ++++----
 .../data/input/impl/StringInputRowParserTest.java  | 12 ++++----
 .../data/input/impl/TimeAndDimsParseSpecTest.java  | 12 ++++----
 .../druid/data/input/impl/TimestampSpecTest.java   | 12 ++++----
 .../data/input/impl/prefetch/JsonIteratorTest.java | 12 ++++----
 .../PrefetchableTextFilesFirehoseFactoryTest.java  | 12 ++++----
 .../impl/prefetch/RetryingInputStreamTest.java     | 12 ++++----
 .../io/druid/guice/ConditionalMultibindTest.java   | 12 ++++----
 .../java/io/druid/guice/JsonConfiguratorTest.java  | 12 ++++----
 api/src/test/java/io/druid/guice/PolyBindTest.java | 12 ++++----
 .../java/io/druid/indexer/TaskStatusPlusTest.java  | 12 ++++----
 .../JacksonExtremeDoubleValuesSerdeTest.java       | 12 ++++----
 .../java/io/druid/js/JavaScriptConfigTest.java     | 12 ++++----
 .../java/io/druid/segment/SegmentUtilsTest.java    | 12 ++++----
 .../segment/loading/NoopDataSegmentArchiver.java   | 12 ++++----
 .../segment/loading/NoopDataSegmentKiller.java     | 12 ++++----
 .../segment/loading/NoopDataSegmentMover.java      | 12 ++++----
 .../java/io/druid/timeline/DataSegmentTest.java    | 12 ++++----
 .../io/druid/timeline/DataSegmentUtilsTest.java    | 12 ++++----
 .../timeline/partition/NoneShardSpecTest.java      | 12 ++++----
 api/src/test/resources/log4j2.xml                  |  4 +--
 aws-common/pom.xml                                 | 26 +++++++++--------
 .../java/io/druid/common/aws/AWSClientConfig.java  | 12 ++++----
 .../io/druid/common/aws/AWSCredentialsConfig.java  | 12 ++++----
 .../io/druid/common/aws/AWSCredentialsUtils.java   | 12 ++++----
 .../io/druid/common/aws/AWSEndpointConfig.java     | 12 ++++----
 .../java/io/druid/common/aws/AWSProxyConfig.java   | 12 ++++----
 .../ConfigDrivenAwsCredentialsConfigProvider.java  | 12 ++++----
 .../common/aws/FileSessionCredentialsProvider.java | 12 ++++----
 .../aws/LazyFileSessionCredentialsProvider.java    | 12 ++++----
 .../druid/common/aws/AWSCredentialsConfigTest.java | 12 ++++----
 benchmarks/pom.xml                                 | 34 +++++++++++-----------
 .../benchmark/BasicAuthUserMapSerdeBenchmark.java  | 12 ++++----
 .../druid/benchmark/BitmapIterationBenchmark.java  | 12 ++++----
 .../io/druid/benchmark/BoundFilterBenchmark.java   | 12 ++++----
 .../benchmark/CompressedColumnarIntsBenchmark.java | 12 ++++----
 .../CompressedVSizeColumnarMultiIntsBenchmark.java | 12 ++++----
 .../benchmark/ConciseComplementBenchmark.java      | 12 ++++----
 .../druid/benchmark/ConsistentHasherBenchmark.java | 12 ++++----
 .../DimensionPredicateFilterBenchmark.java         | 12 ++++----
 .../benchmark/ExpressionAggregationBenchmark.java  | 12 ++++----
 .../benchmark/ExpressionSelectorBenchmark.java     | 12 ++++----
 .../druid/benchmark/FilterPartitionBenchmark.java  | 12 ++++----
 .../benchmark/FilteredAggregatorBenchmark.java     | 12 ++++----
 .../io/druid/benchmark/FlattenJSONBenchmark.java   | 12 ++++----
 .../druid/benchmark/FlattenJSONBenchmarkUtil.java  | 12 ++++----
 .../druid/benchmark/FloatCompressionBenchmark.java | 12 ++++----
 .../FloatCompressionBenchmarkFileGenerator.java    | 12 ++++----
 .../druid/benchmark/GenericIndexedBenchmark.java   | 12 ++++----
 .../benchmark/GroupByTypeInterfaceBenchmark.java   | 12 ++++----
 .../IncrementalIndexRowTypeBenchmark.java          | 12 ++++----
 .../io/druid/benchmark/LikeFilterBenchmark.java    | 12 ++++----
 .../io/druid/benchmark/LoadStatusBenchmark.java    | 12 ++++----
 .../druid/benchmark/LongCompressionBenchmark.java  | 12 ++++----
 .../LongCompressionBenchmarkFileGenerator.java     | 12 ++++----
 .../io/druid/benchmark/MergeSequenceBenchmark.java | 12 ++++----
 .../io/druid/benchmark/RegexMatchBenchmark.java    | 12 ++++----
 .../druid/benchmark/RendezvousHasherBenchmark.java | 12 ++++----
 .../benchmark/StupidPoolConcurrencyBenchmark.java  | 12 ++++----
 .../io/druid/benchmark/TimeParseBenchmark.java     | 12 ++++----
 .../benchmark/TopNTypeInterfaceBenchmark.java      | 12 ++++----
 .../io/druid/benchmark/VSizeSerdeBenchmark.java    | 12 ++++----
 .../benchmark/datagen/BenchmarkColumnSchema.java   | 12 ++++----
 .../datagen/BenchmarkColumnValueGenerator.java     | 12 ++++----
 .../benchmark/datagen/BenchmarkDataGenerator.java  | 12 ++++----
 .../benchmark/datagen/BenchmarkSchemaInfo.java     | 12 ++++----
 .../druid/benchmark/datagen/BenchmarkSchemas.java  | 12 ++++----
 .../datagen/EnumeratedTreeDistribution.java        | 12 ++++----
 .../datagen/RealRoundingDistribution.java          | 12 ++++----
 .../druid/benchmark/datagen/SegmentGenerator.java  | 12 ++++----
 .../benchmark/datagen/SequentialDistribution.java  | 12 ++++----
 .../indexing/IncrementalIndexReadBenchmark.java    | 12 ++++----
 .../indexing/IndexIngestionBenchmark.java          | 12 ++++----
 .../benchmark/indexing/IndexMergeBenchmark.java    | 12 ++++----
 .../benchmark/indexing/IndexPersistBenchmark.java  | 12 ++++----
 .../io/druid/benchmark/query/GroupByBenchmark.java | 12 ++++----
 .../druid/benchmark/query/QueryBenchmarkUtil.java  | 12 ++++----
 .../io/druid/benchmark/query/SearchBenchmark.java  | 12 ++++----
 .../io/druid/benchmark/query/SelectBenchmark.java  | 12 ++++----
 .../benchmark/query/SerializingQueryRunner.java    | 12 ++++----
 .../io/druid/benchmark/query/SqlBenchmark.java     | 12 ++++----
 .../druid/benchmark/query/TimeseriesBenchmark.java | 12 ++++----
 .../io/druid/benchmark/query/TopNBenchmark.java    | 12 ++++----
 .../CachingCostBalancerStrategyBenchmark.java      | 12 ++++----
 .../coordinator/CostBalancerStrategyBenchmark.java | 12 ++++----
 .../NewestSegmentFirstPolicyBenchmark.java         | 12 ++++----
 .../benchmark/BenchmarkDataGeneratorTest.java      | 12 ++++----
 .../benchmark/FlattenJSONBenchmarkUtilTest.java    | 12 ++++----
 ci/travis_script_integration.sh                    | 14 ++++-----
 codestyle/LICENSE.txt                              | 14 ++++-----
 codestyle/checkstyle-suppressions.xml              | 22 +++++++-------
 codestyle/checkstyle.xml                           | 20 ++++++-------
 common/pom.xml                                     | 26 +++++++++--------
 .../annotations/EverythingIsNonnullByDefault.java  | 12 ++++----
 .../druid/annotations/SubclassesMustBePublic.java  | 12 ++++----
 .../SubclassesMustBePublicAnnotationProcessor.java | 12 ++++----
 .../druid/annotations/UsedByJUnitParamsRunner.java | 12 ++++----
 .../io/druid/annotations/UsedInGeneratedCode.java  | 12 ++++----
 .../src/main/java/io/druid/audit/AuditEntry.java   | 12 ++++----
 common/src/main/java/io/druid/audit/AuditInfo.java | 12 ++++----
 .../src/main/java/io/druid/audit/AuditManager.java | 12 ++++----
 .../java/io/druid/collections/BlockingPool.java    | 12 ++++----
 .../io/druid/collections/CombiningIterable.java    | 12 ++++----
 .../io/druid/collections/CombiningIterator.java    | 12 ++++----
 .../io/druid/collections/DefaultBlockingPool.java  | 12 ++++----
 .../io/druid/collections/DummyBlockingPool.java    | 12 ++++----
 .../io/druid/collections/DummyNonBlockingPool.java | 12 ++++----
 .../java/io/druid/collections/NonBlockingPool.java | 12 ++++----
 .../io/druid/collections/OrderedMergeIterator.java | 12 ++++----
 .../io/druid/collections/OrderedMergeSequence.java | 12 ++++----
 .../ReferenceCountingResourceHolder.java           | 12 ++++----
 .../main/java/io/druid/collections/Releaser.java   | 12 ++++----
 .../java/io/druid/collections/ResourceHolder.java  | 12 ++++----
 .../io/druid/collections/SerializablePair.java     | 12 ++++----
 .../main/java/io/druid/collections/StupidPool.java | 12 ++++----
 .../io/druid/collections/StupidResourceHolder.java | 12 ++++----
 .../java/io/druid/common/config/ConfigManager.java | 12 ++++----
 .../druid/common/config/ConfigManagerConfig.java   | 12 ++++----
 .../java/io/druid/common/config/ConfigSerde.java   | 12 ++++----
 .../druid/common/config/JacksonConfigManager.java  | 12 ++++----
 .../java/io/druid/common/config/Log4jShutdown.java | 12 ++++----
 .../java/io/druid/common/config/NullHandling.java  | 12 ++++----
 .../common/config/NullValueHandlingConfig.java     | 12 ++++----
 .../io/druid/common/guava/CombiningSequence.java   | 12 ++++----
 .../java/io/druid/common/guava/DSuppliers.java     | 12 ++++----
 .../java/io/druid/common/guava/GuavaUtils.java     | 12 ++++----
 .../io/druid/common/guava/SettableSupplier.java    | 12 ++++----
 .../druid/common/guava/ThreadRenamingCallable.java | 12 ++++----
 .../druid/common/guava/ThreadRenamingRunnable.java | 12 ++++----
 .../main/java/io/druid/common/utils/ByteUtils.java | 12 ++++----
 .../java/io/druid/common/utils/IntArrayUtils.java  | 12 ++++----
 .../main/java/io/druid/common/utils/PropUtils.java | 12 ++++----
 .../io/druid/common/utils/SerializerUtils.java     | 12 ++++----
 .../druid/common/utils/ServletResourceUtils.java   | 12 ++++----
 .../java/io/druid/common/utils/SocketUtil.java     | 12 ++++----
 .../main/java/io/druid/common/utils/UUIDUtils.java | 12 ++++----
 .../main/java/io/druid/common/utils/VMUtils.java   | 12 ++++----
 .../java/io/druid/concurrent/LifecycleLock.java    | 12 ++++----
 .../io/druid/concurrent/TaskThreadPriority.java    | 12 ++++----
 .../druid/data/SearchableVersionedDataFinder.java  | 12 ++++----
 .../main/java/io/druid/guice/ConfigProvider.java   | 12 ++++----
 .../java/io/druid/guice/DruidSecondaryModule.java  | 12 ++++----
 .../druid/guice/GuiceAnnotationIntrospector.java   | 12 ++++----
 .../java/io/druid/guice/GuiceInjectableValues.java | 12 ++++----
 .../io/druid/guice/JacksonConfigManagerModule.java | 12 ++++----
 .../java/io/druid/guice/JacksonConfigProvider.java | 12 ++++----
 .../src/main/java/io/druid/guice/ListProvider.java | 12 ++++----
 common/src/main/java/io/druid/indexer/Jobby.java   | 12 ++++----
 .../indexer/MetadataStorageUpdaterJobHandler.java  | 12 ++++----
 .../java/io/druid/io/ByteBufferInputStream.java    | 12 ++++----
 common/src/main/java/io/druid/io/Channels.java     | 12 ++++----
 .../io/druid/io/ZeroCopyByteArrayOutputStream.java | 12 ++++----
 common/src/main/java/io/druid/math/expr/Evals.java | 12 ++++----
 common/src/main/java/io/druid/math/expr/Expr.java  | 12 ++++----
 .../src/main/java/io/druid/math/expr/ExprEval.java | 12 ++++----
 .../java/io/druid/math/expr/ExprListenerImpl.java  | 12 ++++----
 .../java/io/druid/math/expr/ExprMacroTable.java    | 12 ++++----
 .../src/main/java/io/druid/math/expr/ExprType.java | 12 ++++----
 .../src/main/java/io/druid/math/expr/Function.java | 12 ++++----
 .../src/main/java/io/druid/math/expr/Parser.java   | 12 ++++----
 .../io/druid/metadata/DefaultPasswordProvider.java | 12 ++++----
 .../io/druid/metadata/EntryExistsException.java    | 12 ++++----
 .../EnvironmentVariablePasswordProvider.java       | 12 ++++----
 .../java/io/druid/metadata/MetadataCASUpdate.java  | 12 ++++----
 .../metadata/MetadataStorageActionHandler.java     | 12 ++++----
 .../MetadataStorageActionHandlerFactory.java       | 12 ++++----
 .../MetadataStorageActionHandlerTypes.java         | 12 ++++----
 .../druid/metadata/MetadataStorageConnector.java   | 12 ++++----
 .../metadata/MetadataStorageConnectorConfig.java   | 12 ++++----
 .../metadata/MetadataStorageTablesConfig.java      | 12 ++++----
 .../java/io/druid/metadata/PasswordProvider.java   | 12 ++++----
 .../java/io/druid/timeline/LogicalSegment.java     | 12 ++++----
 .../java/io/druid/timeline/TimelineLookup.java     | 12 ++++----
 .../io/druid/timeline/TimelineObjectHolder.java    | 12 ++++----
 .../druid/timeline/VersionedIntervalTimeline.java  | 12 ++++----
 .../partition/ImmutablePartitionHolder.java        | 12 ++++----
 .../timeline/partition/IntegerPartitionChunk.java  | 12 ++++----
 .../timeline/partition/LinearPartitionChunk.java   | 12 ++++----
 .../timeline/partition/NumberedPartitionChunk.java | 12 ++++----
 .../druid/timeline/partition/PartitionHolder.java  | 12 ++++----
 .../timeline/partition/StringPartitionChunk.java   | 12 ++++----
 common/src/main/resources/log4j2.debug.xml         |  4 +--
 common/src/main/resources/log4j2.xml               | 26 +++++++++--------
 .../io/druid/collections/BlockingPoolTest.java     | 12 ++++----
 .../druid/collections/CombiningIterableTest.java   | 12 ++++----
 .../druid/collections/CombiningIteratorTest.java   | 12 ++++----
 .../java/io/druid/collections/IteratorShell.java   | 12 ++++----
 .../collections/OrderedMergeIteratorTest.java      | 12 ++++----
 .../collections/OrderedMergeSequenceTest.java      | 12 ++++----
 .../ReferenceCountingResourceHolderTest.java       | 12 ++++----
 .../io/druid/collections/SerializablePairTest.java | 12 ++++----
 .../java/io/druid/collections/StupidPoolTest.java  | 12 ++++----
 .../collections/StupidResourceHolderTest.java      | 12 ++++----
 .../druid/common/guava/CombiningSequenceTest.java  | 12 ++++----
 .../io/druid/common/guava/ComplexSequenceTest.java | 12 ++++----
 .../java/io/druid/common/guava/GuavaUtilsTest.java | 12 ++++----
 .../io/druid/common/utils/IntArrayUtilsTest.java   | 12 ++++----
 .../java/io/druid/common/utils/JodaUtilsTest.java  | 12 ++++----
 .../test/java/io/druid/common/utils/LogTest.java   | 12 ++++----
 .../java/io/druid/common/utils/PropUtilsTest.java  | 12 ++++----
 .../io/druid/common/utils/SerializerUtilsTest.java | 12 ++++----
 .../common/utils/ServletResourceUtilsTest.java     | 12 ++++----
 .../java/io/druid/common/utils/SocketUtilTest.java | 12 ++++----
 .../io/druid/common/utils/StringUtilsTest.java     | 12 ++++----
 .../java/io/druid/common/utils/UUIDUtilsTest.java  | 12 ++++----
 .../java/io/druid/common/utils/VMUtilsTest.java    | 12 ++++----
 .../test/java/io/druid/concurrent/ExecsTest.java   | 12 ++++----
 .../io/druid/concurrent/LifecycleLockTest.java     | 12 ++++----
 .../java/io/druid/guice/LifecycleScopeTest.java    | 12 ++++----
 .../src/test/java/io/druid/math/expr/EvalTest.java | 12 ++++----
 .../test/java/io/druid/math/expr/FunctionTest.java | 12 ++++----
 .../test/java/io/druid/math/expr/ParserTest.java   | 12 ++++----
 .../metadata/DefaultPasswordProviderTest.java      | 12 ++++----
 .../EnvironmentVariablePasswordProviderTest.java   | 12 ++++----
 .../MetadataStorageConnectorConfigTest.java        | 12 ++++----
 .../timeline/VersionedIntervalTimelineTest.java    | 12 ++++----
 .../partition/IntegerPartitionChunkTest.java       | 12 ++++----
 .../partition/StringPartitionChunkTest.java        | 12 ++++----
 distribution/pom.xml                               | 26 +++++++++--------
 distribution/src/assembly/assembly.xml             | 26 +++++++++--------
 docs/_includes/page_footer.html                    | 26 +++++++++--------
 docs/_includes/page_header.html                    | 26 +++++++++--------
 docs/_includes/site_head.html                      | 26 +++++++++--------
 docs/_layouts/doc_page.html                        | 26 +++++++++--------
 docs/index.html                                    | 26 +++++++++--------
 druid_intellij_formatting.xml                      | 19 ++++++++++++
 eclipse_formatting.xml                             | 26 +++++++++--------
 examples/bin/jconsole.sh                           |  4 +--
 .../druid/_common/common.runtime.properties        | 12 ++++----
 examples/conf-quickstart/druid/_common/log4j2.xml  | 34 +++++++++++-----------
 .../druid/broker/runtime.properties                | 19 ++++++++++++
 .../druid/coordinator/runtime.properties           | 19 ++++++++++++
 .../druid/historical/runtime.properties            | 19 ++++++++++++
 .../druid/middleManager/runtime.properties         | 19 ++++++++++++
 .../druid/overlord/runtime.properties              | 19 ++++++++++++
 .../conf/druid/_common/common.runtime.properties   | 12 ++++----
 examples/conf/druid/_common/log4j2.xml             | 19 ++++++++++++
 examples/conf/druid/broker/runtime.properties      | 19 ++++++++++++
 examples/conf/druid/coordinator/runtime.properties | 19 ++++++++++++
 examples/conf/druid/historical/runtime.properties  | 19 ++++++++++++
 .../conf/druid/middleManager/runtime.properties    | 19 ++++++++++++
 examples/conf/druid/overlord/runtime.properties    | 19 ++++++++++++
 examples/pom.xml                                   | 26 +++++++++--------
 .../io/druid/examples/ExamplesDruidModule.java     | 12 ++++----
 .../twitter/TwitterSpritzerFirehoseFactory.java    | 12 ++++----
 extendedset/pom.xml                                | 12 ++++----
 .../io/druid/extendedset/intset/BitIterator.java   | 12 ++++----
 .../druid/extendedset/intset/EmptyIntIterator.java | 12 ++++----
 .../extendedset/intset/ImmutableConciseSet.java    | 31 +++++++++++---------
 .../ImmutableConciseSetIntersectionTest.java       | 12 ++++----
 .../intset/ImmutableConciseSetTest.java            | 31 +++++++++++---------
 extensions-contrib/ambari-metrics-emitter/pom.xml  | 32 ++++++++++----------
 .../ambari/metrics/AmbariMetricsEmitter.java       | 12 ++++----
 .../ambari/metrics/AmbariMetricsEmitterConfig.java | 12 ++++----
 .../ambari/metrics/AmbariMetricsEmitterModule.java | 12 ++++----
 .../metrics/DruidToTimelineMetricConverter.java    | 12 ++++----
 .../metrics/SendAllTimelineEventConverter.java     | 12 ++++----
 ...hiteListBasedDruidToTimelineEventConverter.java | 12 ++++----
 .../metrics/AmbariMetricsEmitterConfigTest.java    | 12 ++++----
 .../DruidToWhiteListBasedConverterTest.java        | 12 ++++----
 ...ListBasedDruidToTimelineEventConverterTest.java | 12 ++++----
 extensions-contrib/azure-extensions/pom.xml        | 32 ++++++++++----------
 .../java/io/druid/firehose/azure/AzureBlob.java    | 12 ++++----
 .../azure/StaticAzureBlobStoreFirehoseFactory.java | 12 ++++----
 .../io/druid/storage/azure/AzureAccountConfig.java | 12 ++++----
 .../io/druid/storage/azure/AzureByteSource.java    | 12 ++++----
 .../storage/azure/AzureDataSegmentKiller.java      | 12 ++++----
 .../storage/azure/AzureDataSegmentPuller.java      | 12 ++++----
 .../storage/azure/AzureDataSegmentPusher.java      | 12 ++++----
 .../java/io/druid/storage/azure/AzureLoadSpec.java | 12 ++++----
 .../java/io/druid/storage/azure/AzureStorage.java  | 12 ++++----
 .../storage/azure/AzureStorageDruidModule.java     | 12 ++++----
 .../java/io/druid/storage/azure/AzureTaskLogs.java | 12 ++++----
 .../druid/storage/azure/AzureTaskLogsConfig.java   | 12 ++++----
 .../java/io/druid/storage/azure/AzureUtils.java    | 12 ++++----
 .../StaticAzureBlobStoreFirehoseFactoryTest.java   | 12 ++++----
 .../druid/storage/azure/AzureByteSourceTest.java   | 12 ++++----
 .../storage/azure/AzureDataSegmentKillerTest.java  | 12 ++++----
 .../storage/azure/AzureDataSegmentPullerTest.java  | 12 ++++----
 .../storage/azure/AzureDataSegmentPusherTest.java  | 12 ++++----
 .../io/druid/storage/azure/AzureTaskLogsTest.java  | 12 ++++----
 .../io/druid/storage/azure/AzureTestUtils.java     | 12 ++++----
 extensions-contrib/cassandra-storage/pom.xml       | 32 ++++++++++----------
 .../cassandra/CassandraDataSegmentConfig.java      | 12 ++++----
 .../cassandra/CassandraDataSegmentPuller.java      | 12 ++++----
 .../cassandra/CassandraDataSegmentPusher.java      | 12 ++++----
 .../storage/cassandra/CassandraDruidModule.java    | 12 ++++----
 .../druid/storage/cassandra/CassandraLoadSpec.java | 12 ++++----
 .../druid/storage/cassandra/CassandraStorage.java  | 12 ++++----
 extensions-contrib/cloudfiles-extensions/pom.xml   | 32 ++++++++++----------
 .../druid/firehose/cloudfiles/CloudFilesBlob.java  | 12 ++++----
 .../cloudfiles/CloudFilesFirehoseDruidModule.java  | 12 ++++----
 .../StaticCloudFilesFirehoseFactory.java           | 12 ++++----
 .../cloudfiles/CloudFilesAccountConfig.java        | 12 ++++----
 .../storage/cloudfiles/CloudFilesByteSource.java   | 12 ++++----
 .../cloudfiles/CloudFilesDataSegmentPuller.java    | 12 ++++----
 .../cloudfiles/CloudFilesDataSegmentPusher.java    | 12 ++++----
 .../CloudFilesDataSegmentPusherConfig.java         | 12 ++++----
 .../storage/cloudfiles/CloudFilesLoadSpec.java     | 12 ++++----
 .../druid/storage/cloudfiles/CloudFilesObject.java | 12 ++++----
 .../cloudfiles/CloudFilesObjectApiProxy.java       | 12 ++++----
 .../cloudfiles/CloudFilesStorageDruidModule.java   | 12 ++++----
 .../druid/storage/cloudfiles/CloudFilesUtils.java  | 12 ++++----
 .../services/io.druid.initialization.DruidModule   |  6 ++--
 .../StaticCloudFilesFirehoseFactoryTest.java       | 12 ++++----
 .../cloudfiles/CloudFilesByteSourceTest.java       | 12 ++++----
 .../CloudFilesDataSegmentPusherTest.java           | 12 ++++----
 .../cloudfiles/CloudFilesObjectApiProxyTest.java   | 12 ++++----
 extensions-contrib/distinctcount/pom.xml           | 32 ++++++++++----------
 .../aggregation/distinctcount/BitMapFactory.java   | 12 ++++----
 .../distinctcount/ConciseBitMapFactory.java        | 12 ++++----
 .../distinctcount/DistinctCountAggregator.java     | 12 ++++----
 .../DistinctCountAggregatorFactory.java            | 12 ++++----
 .../DistinctCountBufferAggregator.java             | 12 ++++----
 .../distinctcount/DistinctCountDruidModule.java    | 12 ++++----
 .../EmptyDistinctCountAggregator.java              | 12 ++++----
 .../EmptyDistinctCountBufferAggregator.java        | 12 ++++----
 .../distinctcount/JavaBitMapFactory.java           | 12 ++++----
 .../distinctcount/RoaringBitMapFactory.java        | 12 ++++----
 .../DistinctCountGroupByQueryTest.java             | 12 ++++----
 .../DistinctCountTimeseriesQueryTest.java          | 12 ++++----
 .../distinctcount/DistinctCountTopNQueryTest.java  | 12 ++++----
 extensions-contrib/druid-rocketmq/pom.xml          | 32 ++++++++++----------
 .../firehose/rocketmq/RocketMQDruidModule.java     | 12 ++++----
 .../firehose/rocketmq/RocketMQFirehoseFactory.java | 12 ++++----
 extensions-contrib/google-extensions/pom.xml       | 32 ++++++++++----------
 .../java/io/druid/firehose/google/GoogleBlob.java  | 12 ++++----
 .../StaticGoogleBlobStoreFirehoseFactory.java      | 12 ++++----
 .../druid/storage/google/GoogleAccountConfig.java  | 12 ++++----
 .../io/druid/storage/google/GoogleByteSource.java  | 12 ++++----
 .../storage/google/GoogleDataSegmentFinder.java    | 12 ++++----
 .../storage/google/GoogleDataSegmentKiller.java    | 12 ++++----
 .../storage/google/GoogleDataSegmentPuller.java    | 12 ++++----
 .../storage/google/GoogleDataSegmentPusher.java    | 12 ++++----
 .../io/druid/storage/google/GoogleLoadSpec.java    | 12 ++++----
 .../io/druid/storage/google/GoogleStorage.java     | 12 ++++----
 .../storage/google/GoogleStorageDruidModule.java   | 12 ++++----
 .../io/druid/storage/google/GoogleTaskLogs.java    | 12 ++++----
 .../druid/storage/google/GoogleTaskLogsConfig.java | 12 ++++----
 .../java/io/druid/storage/google/GoogleUtils.java  | 12 ++++----
 .../services/io.druid.initialization.DruidModule   |  4 +--
 .../StaticGoogleBlobStoreFirehoseFactoryTest.java  | 12 ++++----
 .../druid/storage/google/GoogleByteSourceTest.java | 12 ++++----
 .../google/GoogleDataSegmentFinderTest.java        | 12 ++++----
 .../google/GoogleDataSegmentKillerTest.java        | 12 ++++----
 .../google/GoogleDataSegmentPullerTest.java        | 12 ++++----
 .../google/GoogleDataSegmentPusherTest.java        | 12 ++++----
 .../druid/storage/google/GoogleTaskLogsTest.java   | 12 ++++----
 .../io/druid/storage/google/GoogleUtilsTest.java   | 12 ++++----
 extensions-contrib/graphite-emitter/pom.xml        | 32 ++++++++++----------
 .../graphite/DruidToGraphiteEventConverter.java    | 12 ++++----
 .../io/druid/emitter/graphite/GraphiteEmitter.java | 12 ++++----
 .../emitter/graphite/GraphiteEmitterConfig.java    | 12 ++++----
 .../emitter/graphite/GraphiteEmitterModule.java    | 12 ++++----
 .../io/druid/emitter/graphite/GraphiteEvent.java   | 12 ++++----
 .../graphite/SendAllGraphiteEventConverter.java    | 12 ++++----
 .../emitter/graphite/WhiteListBasedConverter.java  | 12 ++++----
 .../DruidToWhiteListBasedConverterTest.java        | 12 ++++----
 .../graphite/GraphiteEmitterConfigTest.java        | 12 ++++----
 .../graphite/WhiteListBasedConverterTest.java      | 12 ++++----
 extensions-contrib/influx-extensions/pom.xml       | 32 ++++++++++----------
 .../data/input/influx/InfluxExtensionsModule.java  | 12 ++++----
 .../druid/data/input/influx/InfluxParseSpec.java   | 12 ++++----
 .../io/druid/data/input/influx/InfluxParser.java   | 12 ++++----
 .../druid/data/input/influx/InfluxParserTest.java  | 12 ++++----
 .../kafka-eight-simpleConsumer/pom.xml             | 32 ++++++++++----------
 .../kafka/KafkaEightSimpleConsumerDruidModule.java | 12 ++++----
 .../KafkaEightSimpleConsumerFirehoseFactory.java   | 12 ++++----
 .../druid/firehose/kafka/KafkaSimpleConsumer.java  | 12 ++++----
 .../services/io.druid.initialization.DruidModule   |  4 +--
 extensions-contrib/kafka-emitter/pom.xml           | 32 ++++++++++----------
 .../java/io/druid/emitter/kafka/KafkaEmitter.java  | 12 ++++----
 .../io/druid/emitter/kafka/KafkaEmitterConfig.java | 12 ++++----
 .../io/druid/emitter/kafka/KafkaEmitterModule.java | 12 ++++----
 .../kafka/MemoryBoundLinkedBlockingQueue.java      | 12 ++++----
 .../emitter/kafka/KafkaEmitterConfigTest.java      | 12 ++++----
 .../materialized-view-maintenance/pom.xml          | 12 ++++----
 .../DerivativeDataSourceMetadata.java              | 12 ++++----
 .../MaterializedViewMaintenanceDruidModule.java    | 12 ++++----
 .../MaterializedViewSupervisor.java                | 12 ++++----
 .../MaterializedViewSupervisorReport.java          | 12 ++++----
 .../MaterializedViewSupervisorSpec.java            | 12 ++++----
 .../MaterializedViewTaskConfig.java                | 12 ++++----
 .../MaterializedViewSupervisorSpecTest.java        | 12 ++++----
 .../MaterializedViewSupervisorTest.java            | 12 ++++----
 .../materialized-view-selection/pom.xml            | 12 ++++----
 .../materializedview/DataSourceOptimizer.java      | 12 ++++----
 .../DataSourceOptimizerMonitor.java                | 12 ++++----
 .../materializedview/DataSourceOptimizerStats.java | 12 ++++----
 .../materializedview/DerivativeDataSource.java     | 12 ++++----
 .../DerivativeDataSourceManager.java               | 12 ++++----
 .../materializedview/MaterializedViewConfig.java   | 12 ++++----
 .../materializedview/MaterializedViewQuery.java    | 12 ++++----
 .../MaterializedViewQueryQueryToolChest.java       | 12 ++++----
 .../MaterializedViewQueryRunner.java               | 12 ++++----
 .../MaterializedViewSelectionDruidModule.java      | 12 ++++----
 .../materializedview/MaterializedViewUtils.java    | 12 ++++----
 .../materializedview/DatasourceOptimizerTest.java  | 12 ++++----
 .../MaterializedViewQueryTest.java                 | 12 ++++----
 .../MaterializedViewUtilsTest.java                 | 12 ++++----
 extensions-contrib/opentsdb-emitter/pom.xml        |  4 +--
 .../io/druid/emitter/opentsdb/EventConverter.java  | 12 ++++----
 .../io/druid/emitter/opentsdb/OpentsdbEmitter.java | 12 ++++----
 .../emitter/opentsdb/OpentsdbEmitterConfig.java    | 12 ++++----
 .../emitter/opentsdb/OpentsdbEmitterModule.java    | 12 ++++----
 .../io/druid/emitter/opentsdb/OpentsdbEvent.java   | 12 ++++----
 .../io/druid/emitter/opentsdb/OpentsdbSender.java  | 12 ++++----
 .../druid/emitter/opentsdb/EventConverterTest.java | 12 ++++----
 .../opentsdb/OpentsdbEmitterConfigTest.java        | 12 ++++----
 .../druid/emitter/opentsdb/OpentsdbEventTest.java  | 12 ++++----
 .../druid/emitter/opentsdb/OpentsdbSenderTest.java | 12 ++++----
 extensions-contrib/orc-extensions/pom.xml          | 26 +++++++++--------
 .../druid/data/input/orc/OrcExtensionsModule.java  | 12 ++++----
 .../data/input/orc/OrcHadoopInputRowParser.java    | 12 ++++----
 .../data/input/orc/DruidOrcInputFormatTest.java    | 12 ++++----
 .../input/orc/OrcHadoopInputRowParserTest.java     | 12 ++++----
 .../data/input/orc/OrcIndexGeneratorJobTest.java   | 12 ++++----
 extensions-contrib/parquet-extensions/pom.xml      | 19 ++++++++++++
 .../input/parquet/DruidParquetInputFormat.java     | 12 ++++----
 .../data/input/parquet/GenericRecordAsMap.java     | 12 ++++----
 .../input/parquet/ParquetExtensionsModule.java     | 12 ++++----
 .../input/parquet/ParquetHadoopInputRowParser.java | 12 ++++----
 .../parquet/avro/DruidParquetReadSupport.java      | 12 ++++----
 .../data/input/parquet/DruidParquetInputTest.java  | 12 ++++----
 extensions-contrib/rabbitmq/pom.xml                | 32 ++++++++++----------
 .../rabbitmq/JacksonifiedConnectionFactory.java    | 12 ++++----
 .../firehose/rabbitmq/RabbitMQDruidModule.java     | 12 ++++----
 .../firehose/rabbitmq/RabbitMQFirehoseConfig.java  | 12 ++++----
 .../firehose/rabbitmq/RabbitMQFirehoseFactory.java | 12 ++++----
 .../rabbitmq/RabbitMQFirehoseFactoryTest.java      | 12 ++++----
 .../examples/rabbitmq/RabbitMQProducerMain.java    | 12 ++++----
 extensions-contrib/redis-cache/pom.xml             |  4 +--
 .../java/io/druid/client/cache/RedisCache.java     | 12 ++++----
 .../io/druid/client/cache/RedisCacheConfig.java    | 12 ++++----
 .../io/druid/client/cache/RedisCacheProvider.java  | 12 ++++----
 .../io/druid/client/cache/RedisDruidModule.java    | 12 ++++----
 .../java/io/druid/client/cache/RedisCacheTest.java | 12 ++++----
 .../sqlserver-metadata-storage/pom.xml             | 26 +++++++++--------
 .../storage/sqlserver/SQLServerConnector.java      | 12 ++++----
 .../sqlserver/SQLServerMetadataStorageModule.java  | 12 ++++----
 .../sqlserver/CustomStatementRewriterTest.java     | 12 ++++----
 .../storage/sqlserver/SQLServerConnectorTest.java  | 12 ++++----
 extensions-contrib/statsd-emitter/pom.xml          | 32 ++++++++++----------
 .../druid/emitter/statsd/DimensionConverter.java   | 12 ++++----
 .../io/druid/emitter/statsd/StatsDEmitter.java     | 12 ++++----
 .../druid/emitter/statsd/StatsDEmitterConfig.java  | 12 ++++----
 .../druid/emitter/statsd/StatsDEmitterModule.java  | 12 ++++----
 .../java/io/druid/emitter/statsd/StatsDMetric.java | 12 ++++----
 .../src/test/java/DimensionConverterTest.java      | 12 ++++----
 .../src/test/java/StatsDEmitterTest.java           | 12 ++++----
 extensions-contrib/thrift-extensions/pom.xml       | 19 ++++++++++++
 .../data/input/thrift/ThriftDeserialization.java   | 12 ++++----
 .../data/input/thrift/ThriftExtensionsModule.java  | 12 ++++----
 .../data/input/thrift/ThriftInputRowParser.java    | 12 ++++----
 .../input/thrift/ThriftInputRowParserTest.java     | 12 ++++----
 extensions-contrib/time-min-max/pom.xml            | 32 ++++++++++----------
 .../query/aggregation/TimestampAggregator.java     | 12 ++++----
 .../aggregation/TimestampAggregatorFactory.java    | 12 ++++----
 .../aggregation/TimestampBufferAggregator.java     | 12 ++++----
 .../aggregation/TimestampMaxAggregatorFactory.java | 12 ++++----
 .../aggregation/TimestampMinAggregatorFactory.java | 12 ++++----
 .../query/aggregation/TimestampMinMaxModule.java   | 12 ++++----
 .../TimestampAggregationSelectTest.java            | 12 ++++----
 .../TimestampGroupByAggregationTest.java           | 12 ++++----
 .../aggregation/TimestampMinMaxAggregatorTest.java | 12 ++++----
 extensions-contrib/virtual-columns/pom.xml         | 32 ++++++++++----------
 .../druid/segment/DruidVirtualColumnsModule.java   | 12 ++++----
 .../java/io/druid/segment/MapVirtualColumn.java    | 12 ++++----
 .../io/druid/segment/MapVirtualColumnTest.java     | 12 ++++----
 extensions-core/avro-extensions/pom.xml            | 32 ++++++++++----------
 .../druid/data/input/AvroHadoopInputRowParser.java | 12 ++++----
 .../druid/data/input/AvroStreamInputRowParser.java | 12 ++++----
 .../io/druid/data/input/avro/AvroBytesDecoder.java | 12 ++++----
 .../data/input/avro/AvroExtensionsModule.java      | 12 ++++----
 .../druid/data/input/avro/AvroFlattenerMaker.java  | 12 ++++----
 .../io/druid/data/input/avro/AvroParseSpec.java    | 12 ++++----
 .../java/io/druid/data/input/avro/AvroParsers.java | 12 ++++----
 .../data/input/avro/AvroValueInputFormat.java      | 12 ++++----
 .../data/input/avro/AvroValueRecordReader.java     | 12 ++++----
 .../data/input/avro/GenericAvroJsonProvider.java   | 12 ++++----
 .../input/avro/GenericAvroMappingProvider.java     | 12 ++++----
 .../input/avro/InlineSchemaAvroBytesDecoder.java   | 12 ++++----
 .../input/avro/InlineSchemasAvroBytesDecoder.java  | 12 ++++----
 .../avro/SchemaRegistryBasedAvroBytesDecoder.java  | 12 ++++----
 .../avro/SchemaRepoBasedAvroBytesDecoder.java      | 12 ++++----
 .../Avro1124RESTRepositoryClientWrapper.java       | 12 ++++----
 .../schemarepo/Avro1124SubjectAndIdConverter.java  | 12 ++++----
 .../input/schemarepo/SubjectAndIdConverter.java    | 12 ++++----
 .../data/input/AvroHadoopInputRowParserTest.java   | 12 ++++----
 .../data/input/AvroStreamInputRowParserTest.java   | 12 ++++----
 .../avro/InlineSchemaAvroBytesDecoderTest.java     | 12 ++++----
 .../avro/InlineSchemasAvroBytesDecoderTest.java    | 12 ++++----
 .../SchemaRegistryBasedAvroBytesDecoderTest.java   | 12 ++++----
 extensions-core/datasketches/pom.xml               | 14 ++++-----
 .../quantiles/DoublesSketchAggregatorFactory.java  | 12 ++++----
 .../quantiles/DoublesSketchBuildAggregator.java    | 12 ++++----
 .../DoublesSketchBuildBufferAggregator.java        | 12 ++++----
 .../quantiles/DoublesSketchComplexMetricSerde.java | 12 ++++----
 .../quantiles/DoublesSketchJsonSerializer.java     | 12 ++++----
 .../quantiles/DoublesSketchMergeAggregator.java    | 12 ++++----
 .../DoublesSketchMergeAggregatorFactory.java       | 12 ++++----
 .../DoublesSketchMergeBufferAggregator.java        | 12 ++++----
 .../quantiles/DoublesSketchModule.java             | 12 ++++----
 .../quantiles/DoublesSketchNoOpAggregator.java     | 12 ++++----
 .../DoublesSketchNoOpBufferAggregator.java         | 12 ++++----
 .../quantiles/DoublesSketchObjectStrategy.java     | 12 ++++----
 .../quantiles/DoublesSketchOperations.java         | 12 ++++----
 .../DoublesSketchToHistogramPostAggregator.java    | 12 ++++----
 .../DoublesSketchToQuantilePostAggregator.java     | 12 ++++----
 .../DoublesSketchToQuantilesPostAggregator.java    | 12 ++++----
 .../DoublesSketchToStringPostAggregator.java       | 12 ++++----
 .../datasketches/theta/SketchAggregator.java       | 12 ++++----
 .../theta/SketchAggregatorFactory.java             | 12 ++++----
 .../datasketches/theta/SketchBufferAggregator.java | 12 ++++----
 .../theta/SketchBuildComplexMetricSerde.java       | 12 ++++----
 .../theta/SketchConstantPostAggregator.java        | 12 ++++----
 .../theta/SketchEstimatePostAggregator.java        | 12 ++++----
 .../theta/SketchEstimateWithErrorBounds.java       | 12 ++++----
 .../datasketches/theta/SketchHolder.java           | 12 ++++----
 .../theta/SketchHolderJsonSerializer.java          | 12 ++++----
 .../theta/SketchMergeAggregatorFactory.java        | 12 ++++----
 .../theta/SketchMergeComplexMetricSerde.java       | 12 ++++----
 .../datasketches/theta/SketchModule.java           | 12 ++++----
 .../datasketches/theta/SketchObjectStrategy.java   | 12 ++++----
 .../theta/SketchSetPostAggregator.java             | 12 ++++----
 .../datasketches/theta/SynchronizedUnion.java      | 12 ++++----
 .../theta/oldapi/OldApiSketchModule.java           | 12 ++++----
 .../oldapi/OldSketchBuildAggregatorFactory.java    | 12 ++++----
 .../oldapi/OldSketchEstimatePostAggregator.java    | 12 ++++----
 .../oldapi/OldSketchMergeAggregatorFactory.java    | 12 ++++----
 .../theta/oldapi/OldSketchSetPostAggregator.java   | 12 ++++----
 .../ArrayOfDoublesSketchAggregatorFactory.java     | 12 ++++----
 .../tuple/ArrayOfDoublesSketchBuildAggregator.java | 12 ++++----
 .../ArrayOfDoublesSketchBuildBufferAggregator.java | 12 ++++----
 ...rrayOfDoublesSketchBuildComplexMetricSerde.java | 12 ++++----
 .../tuple/ArrayOfDoublesSketchJsonSerializer.java  | 12 ++++----
 .../tuple/ArrayOfDoublesSketchMergeAggregator.java | 12 ++++----
 .../ArrayOfDoublesSketchMergeBufferAggregator.java | 12 ++++----
 ...rrayOfDoublesSketchMergeComplexMetricSerde.java | 12 ++++----
 .../tuple/ArrayOfDoublesSketchModule.java          | 12 ++++----
 .../ArrayOfDoublesSketchMultiPostAggregator.java   | 12 ++++----
 .../tuple/ArrayOfDoublesSketchNoOpAggregator.java  | 12 ++++----
 .../ArrayOfDoublesSketchNoOpBufferAggregator.java  | 12 ++++----
 .../tuple/ArrayOfDoublesSketchObjectStrategy.java  | 12 ++++----
 .../tuple/ArrayOfDoublesSketchOperations.java      | 12 ++++----
 .../tuple/ArrayOfDoublesSketchPostAggregator.java  | 12 ++++----
 .../ArrayOfDoublesSketchSetOpPostAggregator.java   | 12 ++++----
 .../ArrayOfDoublesSketchTTestPostAggregator.java   | 12 ++++----
 ...lesSketchToEstimateAndBoundsPostAggregator.java | 12 ++++----
 ...rayOfDoublesSketchToEstimatePostAggregator.java | 12 ++++----
 .../ArrayOfDoublesSketchToMeansPostAggregator.java | 12 ++++----
 ...yOfDoublesSketchToNumEntriesPostAggregator.java | 12 ++++----
 ...ublesSketchToQuantilesSketchPostAggregator.java | 12 ++++----
 ...ArrayOfDoublesSketchToStringPostAggregator.java | 12 ++++----
 ...ayOfDoublesSketchToVariancesPostAggregator.java | 12 ++++----
 .../ArrayOfDoublesSketchUnaryPostAggregator.java   | 12 ++++----
 .../quantiles/DoublesSketchAggregatorTest.java     | 12 ++++----
 .../datasketches/quantiles/GenerateTestData.java   | 12 ++++----
 ...ouperUsingSketchMergeAggregatorFactoryTest.java | 12 ++++----
 .../datasketches/theta/SketchAggregationTest.java  | 12 ++++----
 .../theta/SketchAggregationWithSimpleDataTest.java | 12 ++++----
 .../theta/SketchEstimateWithErrorBoundsTest.java   | 12 ++++----
 .../theta/oldapi/OldApiSketchAggregationTest.java  | 12 ++++----
 .../tuple/ArrayOfDoublesSketchAggregationTest.java | 12 ++++----
 ...rrayOfDoublesSketchSetOpPostAggregatorTest.java | 12 ++++----
 ...rrayOfDoublesSketchTTestPostAggregatorTest.java | 12 ++++----
 ...ketchToEstimateAndBoundsPostAggregatorTest.java | 12 ++++----
 ...fDoublesSketchToEstimatePostAggregatorTest.java | 12 ++++----
 ...ayOfDoublesSketchToMeansPostAggregatorTest.java | 12 ++++----
 ...oublesSketchToNumEntriesPostAggregatorTest.java | 12 ++++----
 ...sSketchToQuantilesSketchPostAggregatorTest.java | 12 ++++----
 ...yOfDoublesSketchToStringPostAggregatorTest.java | 12 ++++----
 ...DoublesSketchToVariancesPostAggregatorTest.java | 12 ++++----
 .../datasketches/tuple/GenerateTestData.java       | 12 ++++----
 extensions-core/druid-basic-security/pom.xml       | 26 +++++++++--------
 .../security/basic/BasicAuthCommonCacheConfig.java | 12 ++++----
 .../io/druid/security/basic/BasicAuthDBConfig.java | 12 ++++----
 .../io/druid/security/basic/BasicAuthUtils.java    | 12 ++++----
 .../basic/BasicSecurityDBResourceException.java    | 12 ++++----
 .../security/basic/BasicSecurityDruidModule.java   | 12 ++++----
 .../basic/BasicSecurityResourceFilter.java         | 12 ++++----
 .../druid/security/basic/CommonCacheNotifier.java  | 12 ++++----
 .../authentication/BasicHTTPAuthenticator.java     | 12 ++++----
 .../basic/authentication/BasicHTTPEscalator.java   | 12 ++++----
 .../authentication/BytesFullResponseHandler.java   | 12 ++++----
 .../authentication/BytesFullResponseHolder.java    | 12 ++++----
 .../db/cache/BasicAuthenticatorCacheManager.java   | 12 ++++----
 .../db/cache/BasicAuthenticatorCacheNotifier.java  | 12 ++++----
 ...CoordinatorBasicAuthenticatorCacheNotifier.java | 12 ++++----
 ...natorPollingBasicAuthenticatorCacheManager.java | 12 ++++----
 ...oragePollingBasicAuthenticatorCacheManager.java | 12 ++++----
 .../BasicAuthenticatorMetadataStorageUpdater.java  | 12 ++++----
 ...orBasicAuthenticatorMetadataStorageUpdater.java | 12 ++++----
 .../endpoint/BasicAuthenticatorResource.java       | 12 ++++----
 .../BasicAuthenticatorResourceHandler.java         | 12 ++++----
 ...ordinatorBasicAuthenticatorResourceHandler.java | 12 ++++----
 .../DefaultBasicAuthenticatorResourceHandler.java  | 12 ++++----
 .../entity/BasicAuthenticatorCredentialUpdate.java | 12 ++++----
 .../entity/BasicAuthenticatorCredentials.java      | 12 ++++----
 .../entity/BasicAuthenticatorUser.java             | 12 ++++----
 .../entity/BasicAuthenticatorUserMapBundle.java    | 12 ++++----
 .../authorization/BasicRoleBasedAuthorizer.java    | 12 ++++----
 .../db/cache/BasicAuthorizerCacheManager.java      | 12 ++++----
 .../db/cache/BasicAuthorizerCacheNotifier.java     | 12 ++++----
 .../CoordinatorBasicAuthorizerCacheNotifier.java   | 12 ++++----
 ...rdinatorPollingBasicAuthorizerCacheManager.java | 12 ++++----
 ...aStoragePollingBasicAuthorizerCacheManager.java | 12 ++++----
 .../BasicAuthorizerMetadataStorageUpdater.java     | 12 ++++----
 ...natorBasicAuthorizerMetadataStorageUpdater.java | 12 ++++----
 .../endpoint/BasicAuthorizerResource.java          | 12 ++++----
 .../endpoint/BasicAuthorizerResourceHandler.java   | 12 ++++----
 .../CoordinatorBasicAuthorizerResourceHandler.java | 12 ++++----
 .../DefaultBasicAuthorizerResourceHandler.java     | 12 ++++----
 .../entity/BasicAuthorizerPermission.java          | 12 ++++----
 .../authorization/entity/BasicAuthorizerRole.java  | 12 ++++----
 .../entity/BasicAuthorizerRoleFull.java            | 12 ++++----
 .../entity/BasicAuthorizerRoleMapBundle.java       | 12 ++++----
 .../authorization/entity/BasicAuthorizerUser.java  | 12 ++++----
 .../entity/BasicAuthorizerUserFull.java            | 12 ++++----
 .../entity/BasicAuthorizerUserMapBundle.java       | 12 ++++----
 .../basic/authorization/entity/UserAndRoleMap.java | 12 ++++----
 .../java/io/druid/security/BasicAuthUtilsTest.java | 12 ++++----
 .../authentication/BasicHTTPAuthenticatorTest.java | 12 ++++----
 ...sicAuthenticatorMetadataStorageUpdaterTest.java | 12 ++++----
 .../CoordinatorBasicAuthenticatorResourceTest.java | 12 ++++----
 .../NoopBasicAuthenticatorCacheNotifier.java       | 12 ++++----
 .../BasicRoleBasedAuthorizerTest.java              | 12 ++++----
 ...rBasicAuthorizerMetadataStorageUpdaterTest.java | 12 ++++----
 .../CoordinatorBasicAuthorizerResourceTest.java    | 12 ++++----
 .../NoopBasicAuthorizerCacheNotifier.java          | 12 ++++----
 extensions-core/druid-kerberos/pom.xml             | 14 ++++-----
 .../DruidKerberosAuthenticationHandler.java        | 12 ++++----
 .../security/kerberos/DruidKerberosModule.java     | 12 ++++----
 .../druid/security/kerberos/DruidKerberosUtil.java | 12 ++++----
 .../security/kerberos/KerberosAuthenticator.java   | 12 ++++----
 .../druid/security/kerberos/KerberosEscalator.java | 12 ++++----
 .../security/kerberos/KerberosHttpClient.java      | 12 ++++----
 .../security/kerberos/ResponseCookieHandler.java   | 12 ++++----
 .../RetryIfUnauthorizedResponseHandler.java        | 12 ++++----
 .../security/kerberos/RetryResponseHolder.java     | 12 ++++----
 .../src/test/resources/test.runtime.properties     | 19 ++++++++++++
 extensions-core/hdfs-storage/pom.xml               | 26 +++++++++--------
 .../druid/storage/hdfs/HdfsDataSegmentFinder.java  | 12 ++++----
 .../druid/storage/hdfs/HdfsDataSegmentKiller.java  | 12 ++++----
 .../druid/storage/hdfs/HdfsDataSegmentPuller.java  | 12 ++++----
 .../druid/storage/hdfs/HdfsDataSegmentPusher.java  | 12 ++++----
 .../storage/hdfs/HdfsDataSegmentPusherConfig.java  | 12 ++++----
 .../hdfs/HdfsFileTimestampVersionFinder.java       | 12 ++++----
 .../io/druid/storage/hdfs/HdfsKerberosConfig.java  | 12 ++++----
 .../java/io/druid/storage/hdfs/HdfsLoadSpec.java   | 12 ++++----
 .../storage/hdfs/HdfsStorageAuthentication.java    | 12 ++++----
 .../druid/storage/hdfs/HdfsStorageDruidModule.java | 12 ++++----
 .../druid/storage/hdfs/tasklog/HdfsTaskLogs.java   | 12 ++++----
 .../storage/hdfs/tasklog/HdfsTaskLogsConfig.java   | 12 ++++----
 .../java/org/apache/hadoop/fs/HadoopFsWrapper.java | 12 ++++----
 .../indexing/common/tasklogs/HdfsTaskLogsTest.java | 12 ++++----
 .../segment/loading/HdfsDataSegmentFinderTest.java | 12 ++++----
 .../HdfsFileTimestampVersionFinderTest.java        | 12 ++++----
 .../storage/hdfs/HdfsDataSegmentKillerTest.java    | 12 ++++----
 .../storage/hdfs/HdfsDataSegmentPullerTest.java    | 12 ++++----
 .../storage/hdfs/HdfsDataSegmentPusherTest.java    | 12 ++++----
 .../druid/storage/hdfs/HdfsKerberosConfigTest.java | 12 ++++----
 extensions-core/histogram/pom.xml                  | 26 +++++++++--------
 .../histogram/ApproximateHistogram.java            | 12 ++++----
 .../histogram/ApproximateHistogramAggregator.java  | 12 ++++----
 .../ApproximateHistogramAggregatorFactory.java     | 12 ++++----
 .../ApproximateHistogramBufferAggregator.java      | 12 ++++----
 .../histogram/ApproximateHistogramDruidModule.java | 12 ++++----
 .../ApproximateHistogramFoldingAggregator.java     | 12 ++++----
 ...proximateHistogramFoldingAggregatorFactory.java | 12 ++++----
 ...pproximateHistogramFoldingBufferAggregator.java | 12 ++++----
 .../ApproximateHistogramFoldingSerde.java          | 12 ++++----
 .../ApproximateHistogramPostAggregator.java        | 12 ++++----
 .../query/aggregation/histogram/ArrayUtils.java    | 12 ++++----
 .../histogram/BucketsPostAggregator.java           | 12 ++++----
 .../histogram/CustomBucketsPostAggregator.java     | 12 ++++----
 .../histogram/EqualBucketsPostAggregator.java      | 12 ++++----
 .../query/aggregation/histogram/Histogram.java     | 12 ++++----
 .../aggregation/histogram/MaxPostAggregator.java   | 12 ++++----
 .../aggregation/histogram/MinPostAggregator.java   | 12 ++++----
 .../histogram/QuantilePostAggregator.java          | 12 ++++----
 .../query/aggregation/histogram/Quantiles.java     | 12 ++++----
 .../histogram/QuantilesPostAggregator.java         | 12 ++++----
 .../histogram/sql/QuantileSqlAggregator.java       | 12 ++++----
 .../ApproximateHistogramAggregationTest.java       | 12 ++++----
 .../ApproximateHistogramAggregatorTest.java        | 12 ++++----
 .../ApproximateHistogramErrorBenchmark.java        | 12 ++++----
 .../ApproximateHistogramFoldingSerdeTest.java      | 12 ++++----
 .../ApproximateHistogramGroupByQueryTest.java      | 12 ++++----
 .../ApproximateHistogramPostAggregatorTest.java    | 12 ++++----
 .../histogram/ApproximateHistogramTest.java        | 12 ++++----
 .../ApproximateHistogramTopNQueryTest.java         | 12 ++++----
 .../query/aggregation/histogram/QuantilesTest.java | 12 ++++----
 .../histogram/sql/QuantileSqlAggregatorTest.java   | 12 ++++----
 extensions-core/kafka-eight/pom.xml                | 26 +++++++++--------
 .../firehose/kafka/KafkaEightDruidModule.java      | 12 ++++----
 .../firehose/kafka/KafkaEightFirehoseFactory.java  | 12 ++++----
 extensions-core/kafka-extraction-namespace/pom.xml |  4 +--
 .../lookup/KafkaExtractionNamespaceModule.java     | 12 ++++----
 .../query/lookup/KafkaLookupExtractorFactory.java  | 12 ++++----
 .../KafkaLookupExtractorIntrospectionHandler.java  | 12 ++++----
 .../services/io.druid.initialization.DruidModule   |  4 +--
 .../lookup/KafkaLookupExtractorFactoryTest.java    | 12 ++++----
 .../query/lookup/TestKafkaExtractionCluster.java   | 12 ++++----
 .../src/test/resources/log4j2.xml                  |  4 +--
 extensions-core/kafka-indexing-service/pom.xml     | 12 ++++----
 .../IncrementalPublishingKafkaIndexTaskRunner.java | 12 ++++----
 .../indexing/kafka/KafkaDataSourceMetadata.java    | 12 ++++----
 .../io/druid/indexing/kafka/KafkaIOConfig.java     | 12 ++++----
 .../io/druid/indexing/kafka/KafkaIndexTask.java    | 12 ++++----
 .../druid/indexing/kafka/KafkaIndexTaskClient.java | 12 ++++----
 .../kafka/KafkaIndexTaskClientFactory.java         | 12 ++++----
 .../druid/indexing/kafka/KafkaIndexTaskModule.java | 12 ++++----
 .../druid/indexing/kafka/KafkaIndexTaskRunner.java | 12 ++++----
 .../io/druid/indexing/kafka/KafkaPartitions.java   | 12 ++++----
 .../io/druid/indexing/kafka/KafkaTuningConfig.java | 12 ++++----
 .../indexing/kafka/LegacyKafkaIndexTaskRunner.java | 12 ++++----
 .../indexing/kafka/supervisor/KafkaSupervisor.java | 12 ++++----
 .../kafka/supervisor/KafkaSupervisorIOConfig.java  | 12 ++++----
 .../supervisor/KafkaSupervisorReportPayload.java   | 12 ++++----
 .../kafka/supervisor/KafkaSupervisorSpec.java      | 12 ++++----
 .../supervisor/KafkaSupervisorTuningConfig.java    | 12 ++++----
 .../indexing/kafka/supervisor/TaskReportData.java  | 12 ++++----
 .../kafka/KafkaDataSourceMetadataTest.java         | 12 ++++----
 .../io/druid/indexing/kafka/KafkaIOConfigTest.java | 12 ++++----
 .../indexing/kafka/KafkaIndexTaskClientTest.java   | 12 ++++----
 .../druid/indexing/kafka/KafkaIndexTaskTest.java   | 12 ++++----
 .../indexing/kafka/KafkaTuningConfigTest.java      | 12 ++++----
 .../supervisor/KafkaSupervisorIOConfigTest.java    | 12 ++++----
 .../kafka/supervisor/KafkaSupervisorTest.java      | 12 ++++----
 .../KafkaSupervisorTuningConfigTest.java           | 12 ++++----
 .../io/druid/indexing/kafka/test/TestBroker.java   | 12 ++++----
 extensions-core/lookups-cached-global/pom.xml      |  4 +--
 .../java/io/druid/data/input/MapPopulator.java     | 12 ++++----
 .../lookup/NamespaceLookupExtractorFactory.java    | 12 ++++----
 .../lookup/NamespaceLookupIntrospectHandler.java   | 12 ++++----
 .../query/lookup/namespace/CacheGenerator.java     | 12 ++++----
 .../lookup/namespace/ExtractionNamespace.java      | 12 ++++----
 .../lookup/namespace/JdbcExtractionNamespace.java  | 12 ++++----
 .../namespace/StaticMapExtractionNamespace.java    | 12 ++++----
 .../lookup/namespace/UriExtractionNamespace.java   | 12 ++++----
 .../lookup/namespace/JdbcCacheGenerator.java       | 12 ++++----
 .../namespace/NamespaceExtractionConfig.java       | 12 ++++----
 .../namespace/NamespaceExtractionModule.java       | 12 ++++----
 .../lookup/namespace/StaticMapCacheGenerator.java  | 12 ++++----
 .../server/lookup/namespace/UriCacheGenerator.java | 12 ++++----
 .../lookup/namespace/cache/CacheHandler.java       | 12 ++++----
 .../server/lookup/namespace/cache/CacheProxy.java  | 12 ++++----
 .../lookup/namespace/cache/CacheScheduler.java     | 12 ++++----
 .../cache/NamespaceExtractionCacheManager.java     | 12 ++++----
 .../OffHeapNamespaceExtractionCacheManager.java    | 12 ++++----
 .../OnHeapNamespaceExtractionCacheManager.java     | 12 ++++----
 .../services/io.druid.initialization.DruidModule   |  4 +--
 .../NamespaceLookupExtractorFactoryTest.java       | 12 ++++----
 .../lookup/namespace/JSONFlatDataParserTest.java   | 12 ++++----
 .../StaticMapExtractionNamespaceTest.java          | 12 ++++----
 .../namespace/UriExtractionNamespaceTest.java      | 12 ++++----
 .../namespace/NamespacedExtractorModuleTest.java   | 12 ++++----
 .../namespace/StaticMapCacheGeneratorTest.java     | 12 ++++----
 .../lookup/namespace/UriCacheGeneratorTest.java    | 12 ++++----
 .../lookup/namespace/cache/CacheSchedulerTest.java | 12 ++++----
 .../cache/JdbcExtractionNamespaceTest.java         | 12 ++++----
 .../NamespaceExtractionCacheManagersTest.java      | 12 ++++----
 ...OffHeapNamespaceExtractionCacheManagerTest.java | 12 ++++----
 .../OnHeapNamespaceExtractionCacheManagerTest.java | 12 ++++----
 extensions-core/lookups-cached-single/pom.xml      | 12 ++++----
 .../java/io/druid/server/lookup/DataFetcher.java   | 12 ++++----
 .../java/io/druid/server/lookup/LoadingLookup.java | 12 ++++----
 .../druid/server/lookup/LoadingLookupFactory.java  | 12 ++++----
 .../server/lookup/LookupExtractionModule.java      | 12 ++++----
 .../java/io/druid/server/lookup/PollingLookup.java | 12 ++++----
 .../druid/server/lookup/PollingLookupFactory.java  | 12 ++++----
 .../server/lookup/cache/loading/LoadingCache.java  | 12 ++++----
 .../lookup/cache/loading/LookupCacheStats.java     | 12 ++++----
 .../lookup/cache/loading/OffHeapLoadingCache.java  | 12 ++++----
 .../lookup/cache/loading/OnHeapLoadingCache.java   | 12 ++++----
 .../lookup/cache/polling/OffHeapPollingCache.java  | 12 ++++----
 .../lookup/cache/polling/OnHeapPollingCache.java   | 12 ++++----
 .../server/lookup/cache/polling/PollingCache.java  | 12 ++++----
 .../lookup/cache/polling/PollingCacheFactory.java  | 12 ++++----
 .../druid/server/lookup/jdbc/JdbcDataFetcher.java  | 12 ++++----
 .../lookup/jdbc/KeyValueResultSetMapper.java       | 12 ++++----
 .../io/druid/server/lookup/jdbc/QueryKeys.java     | 12 ++++----
 .../services/io.druid.initialization.DruidModule   | 34 ++++++++++------------
 .../io/druid/server/lookup/CacheRefKeeperTest.java | 12 ++++----
 .../server/lookup/LoadingLookupFactoryTest.java    | 12 ++++----
 .../io/druid/server/lookup/LoadingLookupTest.java  | 12 ++++----
 .../server/lookup/PollingLookupFactoryTest.java    | 12 ++++----
 .../server/lookup/PollingLookupSerDeserTest.java   | 12 ++++----
 .../io/druid/server/lookup/PollingLookupTest.java  | 12 ++++----
 .../lookup/cache/loading/LoadingCacheTest.java     | 12 ++++----
 .../cache/loading/OffHeapLoadingCacheTest.java     | 12 ++++----
 .../cache/loading/OnHeapLoadingCacheTest.java      | 12 ++++----
 .../server/lookup/jdbc/JdbcDataFetcherTest.java    | 12 ++++----
 extensions-core/mysql-metadata-storage/pom.xml     | 26 +++++++++--------
 .../sql/MySQLFirehoseDatabaseConnector.java        | 12 ++++----
 .../metadata/storage/mysql/MySQLConnector.java     | 12 ++++----
 .../storage/mysql/MySQLConnectorConfig.java        | 12 ++++----
 .../storage/mysql/MySQLMetadataStorageModule.java  | 12 ++++----
 .../postgresql-metadata-storage/pom.xml            | 26 +++++++++--------
 .../storage/postgresql/PostgreSQLConnector.java    | 12 ++++----
 .../PostgreSQLMetadataStorageModule.java           | 12 ++++----
 .../postgresql/PostgreSQLConnectorTest.java        | 12 ++++----
 extensions-core/protobuf-extensions/pom.xml        | 26 +++++++++--------
 .../input/protobuf/ProtobufExtensionsModule.java   | 12 ++++----
 .../input/protobuf/ProtobufInputRowParser.java     | 12 ++++----
 .../data/input/protobuf/ProtoTestEventWrapper.java | 12 ++++----
 .../input/protobuf/ProtobufInputRowParserTest.java | 12 ++++----
 extensions-core/s3-extensions/pom.xml              | 26 +++++++++--------
 .../druid/firehose/s3/S3FirehoseDruidModule.java   | 12 ++++----
 .../druid/firehose/s3/StaticS3FirehoseFactory.java | 12 ++++----
 .../storage/s3/CustomServerSideEncryption.java     | 12 ++++----
 .../druid/storage/s3/KmsServerSideEncryption.java  | 12 ++++----
 .../druid/storage/s3/NoopServerSideEncryption.java | 12 ++++----
 .../io/druid/storage/s3/S3DataSegmentArchiver.java | 12 ++++----
 .../storage/s3/S3DataSegmentArchiverConfig.java    | 12 ++++----
 .../io/druid/storage/s3/S3DataSegmentFinder.java   | 12 ++++----
 .../io/druid/storage/s3/S3DataSegmentKiller.java   | 12 ++++----
 .../io/druid/storage/s3/S3DataSegmentMover.java    | 12 ++++----
 .../io/druid/storage/s3/S3DataSegmentPuller.java   | 12 ++++----
 .../io/druid/storage/s3/S3DataSegmentPusher.java   | 12 ++++----
 .../storage/s3/S3DataSegmentPusherConfig.java      | 12 ++++----
 .../main/java/io/druid/storage/s3/S3LoadSpec.java  | 12 ++++----
 .../io/druid/storage/s3/S3SSECustomConfig.java     | 12 ++++----
 .../java/io/druid/storage/s3/S3SSEKmsConfig.java   | 12 ++++----
 .../druid/storage/s3/S3ServerSideEncryption.java   | 12 ++++----
 .../java/io/druid/storage/s3/S3StorageConfig.java  | 12 ++++----
 .../io/druid/storage/s3/S3StorageDruidModule.java  | 12 ++++----
 .../main/java/io/druid/storage/s3/S3TaskLogs.java  | 12 ++++----
 .../java/io/druid/storage/s3/S3TaskLogsConfig.java | 12 ++++----
 .../storage/s3/S3TimestampVersionedDataFinder.java | 12 ++++----
 .../src/main/java/io/druid/storage/s3/S3Utils.java | 12 ++++----
 .../storage/s3/ServerSideEncryptingAmazonS3.java   | 12 ++++----
 .../io/druid/storage/s3/ServerSideEncryption.java  | 12 ++++----
 .../firehose/s3/StaticS3FirehoseFactoryTest.java   | 12 ++++----
 .../storage/s3/S3DataSegmentArchiverTest.java      | 12 ++++----
 .../druid/storage/s3/S3DataSegmentFinderTest.java  | 12 ++++----
 .../druid/storage/s3/S3DataSegmentMoverTest.java   | 12 ++++----
 .../druid/storage/s3/S3DataSegmentPullerTest.java  | 12 ++++----
 .../storage/s3/S3DataSegmentPusherConfigTest.java  | 12 ++++----
 .../druid/storage/s3/S3DataSegmentPusherTest.java  | 12 ++++----
 .../s3/S3TimestampVersionedDataFinderTest.java     | 12 ++++----
 .../storage/s3/TestAWSCredentialsProvider.java     | 12 ++++----
 .../s3/TestFileSessionCredentialsProvider.java     | 12 ++++----
 extensions-core/simple-client-sslcontext/pom.xml   | 19 ++++++++++++
 .../main/java/io/druid/https/SSLClientConfig.java  | 12 ++++----
 .../main/java/io/druid/https/SSLContextModule.java | 12 ++++----
 .../java/io/druid/https/SSLContextProvider.java    | 12 ++++----
 extensions-core/stats/pom.xml                      | 14 ++++-----
 .../query/aggregation/stats/DruidStatsModule.java  | 12 ++++----
 .../teststats/PvaluefromZscorePostAggregator.java  | 12 ++++----
 .../aggregation/teststats/ZtestPostAggregator.java | 12 ++++----
 .../variance/StandardDeviationPostAggregator.java  | 12 ++++----
 .../aggregation/variance/VarianceAggregator.java   | 12 ++++----
 .../variance/VarianceAggregatorCollector.java      | 12 ++++----
 .../variance/VarianceAggregatorFactory.java        | 12 ++++----
 .../variance/VarianceBufferAggregator.java         | 12 ++++----
 .../variance/VarianceFoldingAggregatorFactory.java | 12 ++++----
 .../query/aggregation/variance/VarianceSerde.java  | 12 ++++----
 .../PvaluefromZscorePostAggregatorTest.java        | 12 ++++----
 .../teststats/ZtestPostAggregatorTest.java         | 12 ++++----
 .../variance/VarianceAggregatorCollectorTest.java  | 12 ++++----
 .../variance/VarianceAggregatorTest.java           | 12 ++++----
 .../variance/VarianceGroupByQueryTest.java         | 12 ++++----
 .../aggregation/variance/VarianceSerdeTest.java    | 12 ++++----
 .../aggregation/variance/VarianceTestHelper.java   | 12 ++++----
 .../variance/VarianceTimeseriesQueryTest.java      | 12 ++++----
 .../variance/VarianceTopNQueryTest.java            | 12 ++++----
 hll/pom.xml                                        | 12 ++++----
 hll/src/main/java/io/druid/hll/ByteBitLookup.java  | 12 ++++----
 hll/src/main/java/io/druid/hll/HLLCV0.java         | 12 ++++----
 hll/src/main/java/io/druid/hll/HLLCV1.java         | 12 ++++----
 .../java/io/druid/hll/HyperLogLogCollector.java    | 12 ++++----
 .../main/java/io/druid/hll/HyperLogLogHash.java    | 12 ++++----
 .../druid/hll/HyperLogLogCollectorBenchmark.java   | 12 ++++----
 .../io/druid/hll/HyperLogLogCollectorTest.java     | 12 ++++----
 .../druid/hll/HyperLogLogSerdeBenchmarkTest.java   | 12 ++++----
 indexing-hadoop/pom.xml                            | 26 +++++++++--------
 .../src/main/java/io/druid/indexer/Bucket.java     | 12 ++++----
 .../indexer/DetermineHashedPartitionsJob.java      | 12 ++++----
 .../io/druid/indexer/DeterminePartitionsJob.java   | 12 ++++----
 .../HadoopDruidDetermineConfigurationJob.java      | 12 ++++----
 .../io/druid/indexer/HadoopDruidIndexerConfig.java | 12 ++++----
 .../io/druid/indexer/HadoopDruidIndexerJob.java    | 12 ++++----
 .../io/druid/indexer/HadoopDruidIndexerMapper.java | 12 ++++----
 .../main/java/io/druid/indexer/HadoopIOConfig.java | 12 ++++----
 .../java/io/druid/indexer/HadoopIngestionSpec.java | 12 ++++----
 .../io/druid/indexer/HadoopKerberosConfig.java     | 12 ++++----
 .../java/io/druid/indexer/HadoopTuningConfig.java  | 12 ++++----
 .../io/druid/indexer/HadoopWorkingDirCleaner.java  | 12 ++++----
 .../java/io/druid/indexer/HadoopyShardSpec.java    | 12 ++++----
 .../druid/indexer/HadoopyStringInputRowParser.java | 12 ++++----
 .../java/io/druid/indexer/IndexGeneratorJob.java   | 12 ++++----
 .../io/druid/indexer/IndexingHadoopModule.java     | 12 ++++----
 .../main/java/io/druid/indexer/InputRowSerde.java  | 12 ++++----
 .../src/main/java/io/druid/indexer/JobHelper.java  | 12 ++++----
 .../druid/indexer/MetadataStorageUpdaterJob.java   | 12 ++++----
 .../main/java/io/druid/indexer/SortableBytes.java  | 12 ++++----
 .../src/main/java/io/druid/indexer/Utils.java      | 12 ++++----
 .../indexer/hadoop/DatasourceIngestionSpec.java    | 12 ++++----
 .../indexer/hadoop/DatasourceInputFormat.java      | 12 ++++----
 .../druid/indexer/hadoop/DatasourceInputSplit.java | 12 ++++----
 .../indexer/hadoop/DatasourceRecordReader.java     | 12 ++++----
 .../druid/indexer/hadoop/FSSpideringIterator.java  | 12 ++++----
 .../io/druid/indexer/hadoop/SegmentInputRow.java   | 12 ++++----
 .../druid/indexer/hadoop/WindowedDataSegment.java  | 12 ++++----
 .../indexer/partitions/AbstractPartitionsSpec.java | 12 ++++----
 .../indexer/partitions/HashedPartitionsSpec.java   | 12 ++++----
 .../druid/indexer/partitions/PartitionsSpec.java   | 12 ++++----
 .../partitions/SingleDimensionPartitionsSpec.java  | 12 ++++----
 .../io/druid/indexer/path/DatasourcePathSpec.java  | 12 ++++----
 .../indexer/path/GranularUnprocessedPathSpec.java  | 12 ++++----
 .../io/druid/indexer/path/GranularityPathSpec.java | 12 ++++----
 .../druid/indexer/path/HadoopGlobPathSplitter.java | 12 ++++----
 .../path/MetadataStoreBasedUsedSegmentLister.java  | 12 ++++----
 .../io/druid/indexer/path/MultiplePathSpec.java    | 12 ++++----
 .../main/java/io/druid/indexer/path/PathSpec.java  | 12 ++++----
 .../java/io/druid/indexer/path/StaticPathSpec.java | 12 ++++----
 .../io/druid/indexer/path/UsedSegmentLister.java   | 12 ++++----
 .../druid/indexer/updater/HadoopConverterJob.java  | 12 ++++----
 .../updater/HadoopDruidConverterConfig.java        | 12 ++++----
 .../updater/MetadataStorageUpdaterJobSpec.java     | 12 ++++----
 .../io/druid/indexer/BatchDeltaIngestionTest.java  | 12 ++++----
 .../src/test/java/io/druid/indexer/BucketTest.java | 12 ++++----
 .../indexer/DetermineHashedPartitionsJobTest.java  | 12 ++++----
 .../druid/indexer/DeterminePartitionsJobTest.java  | 12 ++++----
 .../indexer/HadoopDruidIndexerConfigTest.java      | 12 ++++----
 .../indexer/HadoopDruidIndexerMapperTest.java      | 12 ++++----
 .../io/druid/indexer/HadoopIngestionSpecTest.java  | 12 ++++----
 ...onSpecUpdateDatasourcePathSpecSegmentsTest.java | 12 ++++----
 .../io/druid/indexer/HadoopKerberosConfigTest.java | 12 ++++----
 .../io/druid/indexer/HadoopTuningConfigTest.java   | 12 ++++----
 .../indexer/HadoopyStringInputRowParserTest.java   | 12 ++++----
 .../io/druid/indexer/HdfsClasspathSetupTest.java   | 12 ++++----
 .../druid/indexer/IndexGeneratorCombinerTest.java  | 12 ++++----
 .../io/druid/indexer/IndexGeneratorJobTest.java    | 12 ++++----
 .../java/io/druid/indexer/InputRowSerdeTest.java   | 12 ++++----
 .../test/java/io/druid/indexer/JobHelperTest.java  | 12 ++++----
 .../java/io/druid/indexer/SortableBytesTest.java   | 12 ++++----
 .../io/druid/indexer/UtilsCompressionTest.java     | 12 ++++----
 .../src/test/java/io/druid/indexer/UtilsTest.java  | 12 ++++----
 .../hadoop/DatasourceIngestionSpecTest.java        | 12 ++++----
 .../indexer/hadoop/DatasourceInputFormatTest.java  | 12 ++++----
 .../indexer/hadoop/DatasourceInputSplitTest.java   | 12 ++++----
 .../indexer/hadoop/DatasourceRecordReaderTest.java | 12 ++++----
 .../indexer/hadoop/FSSpideringIteratorTest.java    | 12 ++++----
 .../indexer/hadoop/WindowedDataSegmentTest.java    | 12 ++++----
 .../partitions/HashedPartitionsSpecTest.java       | 12 ++++----
 .../druid/indexer/path/DatasourcePathSpecTest.java | 12 ++++----
 .../path/GranularUnprocessedPathSpecTest.java      | 12 ++++----
 .../indexer/path/GranularityPathSpecTest.java      | 12 ++++----
 .../indexer/path/HadoopGlobPathSplitterTest.java   | 12 ++++----
 .../druid/indexer/path/MultiplePathSpecTest.java   | 12 ++++----
 .../io/druid/indexer/path/StaticPathSpecTest.java  | 12 ++++----
 .../indexer/updater/HadoopConverterJobTest.java    | 12 ++++----
 .../updater/HadoopDruidConverterConfigTest.java    | 12 ++++----
 .../updater/MetadataStorageUpdaterJobSpecTest.java | 12 ++++----
 indexing-service/pom.xml                           | 26 +++++++++--------
 .../druid/guice/IndexingServiceFirehoseModule.java | 12 ++++----
 .../druid/guice/IndexingServiceModuleHelper.java   | 12 ++++----
 .../druid/guice/IndexingServiceTaskLogsModule.java | 12 ++++----
 .../appenderator/ActionBasedSegmentAllocator.java  | 12 ++++----
 .../ActionBasedUsedSegmentChecker.java             | 12 ++++----
 .../common/IngestionStatsAndErrorsTaskReport.java  | 12 ++++----
 .../IngestionStatsAndErrorsTaskReportData.java     | 12 ++++----
 .../java/io/druid/indexing/common/RetryPolicy.java | 12 ++++----
 .../druid/indexing/common/RetryPolicyConfig.java   | 12 ++++----
 .../druid/indexing/common/RetryPolicyFactory.java  | 12 ++++----
 .../indexing/common/SegmentLoaderFactory.java      | 12 ++++----
 .../io/druid/indexing/common/TaskInfoProvider.java | 12 ++++----
 .../java/io/druid/indexing/common/TaskLock.java    | 12 ++++----
 .../io/druid/indexing/common/TaskLockType.java     | 12 ++++----
 .../common/TaskRealtimeMetricsMonitorBuilder.java  | 12 ++++----
 .../java/io/druid/indexing/common/TaskReport.java  | 12 ++++----
 .../indexing/common/TaskReportFileWriter.java      | 12 ++++----
 .../java/io/druid/indexing/common/TaskToolbox.java | 12 ++++----
 .../druid/indexing/common/TaskToolboxFactory.java  | 12 ++++----
 .../CheckPointDataSourceMetadataAction.java        | 12 ++++----
 .../common/actions/LocalTaskActionClient.java      | 12 ++++----
 .../actions/LocalTaskActionClientFactory.java      | 12 ++++----
 .../indexing/common/actions/LockAcquireAction.java | 12 ++++----
 .../indexing/common/actions/LockListAction.java    | 12 ++++----
 .../indexing/common/actions/LockReleaseAction.java | 12 ++++----
 .../common/actions/LockTryAcquireAction.java       | 12 ++++----
 .../common/actions/RemoteTaskActionClient.java     | 12 ++++----
 .../actions/RemoteTaskActionClientFactory.java     | 12 ++++----
 .../actions/ResetDataSourceMetadataAction.java     | 12 ++++----
 .../common/actions/SegmentAllocateAction.java      | 12 ++++----
 .../common/actions/SegmentInsertAction.java        | 12 ++++----
 .../common/actions/SegmentListUnusedAction.java    | 12 ++++----
 .../common/actions/SegmentListUsedAction.java      | 12 ++++----
 .../actions/SegmentMetadataUpdateAction.java       | 12 ++++----
 .../indexing/common/actions/SegmentNukeAction.java | 12 ++++----
 .../actions/SegmentTransactionalInsertAction.java  | 12 ++++----
 .../druid/indexing/common/actions/TaskAction.java  | 12 ++++----
 .../indexing/common/actions/TaskActionClient.java  | 12 ++++----
 .../common/actions/TaskActionClientFactory.java    | 12 ++++----
 .../indexing/common/actions/TaskActionHolder.java  | 12 ++++----
 .../common/actions/TaskActionPreconditions.java    | 12 ++++----
 .../indexing/common/actions/TaskActionToolbox.java | 12 ++++----
 .../indexing/common/config/FileTaskLogsConfig.java | 12 ++++----
 .../druid/indexing/common/config/TaskConfig.java   | 12 ++++----
 .../indexing/common/config/TaskStorageConfig.java  | 12 ++++----
 .../index/RealtimeAppenderatorIngestionSpec.java   | 12 ++++----
 .../index/RealtimeAppenderatorTuningConfig.java    | 12 ++++----
 .../indexing/common/index/YeOldePlumberSchool.java | 12 ++++----
 .../common/stats/DropwizardRowIngestionMeters.java | 12 ++++----
 .../stats/DropwizardRowIngestionMetersFactory.java | 12 ++++----
 .../indexing/common/stats/RowIngestionMeters.java  | 12 ++++----
 .../common/stats/RowIngestionMetersFactory.java    | 12 ++++----
 .../common/stats/RowIngestionMetersTotals.java     | 12 ++++----
 .../common/stats/TaskRealtimeMetricsMonitor.java   | 12 ++++----
 .../common/task/AbstractFixedIntervalTask.java     | 12 ++++----
 .../druid/indexing/common/task/AbstractTask.java   | 12 ++++----
 .../io/druid/indexing/common/task/AppendTask.java  | 12 ++++----
 .../task/AppenderatorDriverRealtimeIndexTask.java  | 12 ++++----
 .../io/druid/indexing/common/task/ArchiveTask.java | 12 ++++----
 .../druid/indexing/common/task/CompactionTask.java | 12 ++++----
 .../ConvertSegmentBackwardsCompatibleTask.java     | 12 ++++----
 .../indexing/common/task/ConvertSegmentTask.java   | 12 ++++----
 .../indexing/common/task/HadoopConverterTask.java  | 12 ++++----
 .../indexing/common/task/HadoopIndexTask.java      | 12 ++++----
 .../io/druid/indexing/common/task/HadoopTask.java  | 12 ++++----
 .../io/druid/indexing/common/task/IndexTask.java   | 12 ++++----
 .../druid/indexing/common/task/IndexTaskUtils.java | 12 ++++----
 .../io/druid/indexing/common/task/KillTask.java    | 12 ++++----
 .../io/druid/indexing/common/task/MergeTask.java   | 12 ++++----
 .../druid/indexing/common/task/MergeTaskBase.java  | 12 ++++----
 .../io/druid/indexing/common/task/MoveTask.java    | 12 ++++----
 .../io/druid/indexing/common/task/NoopTask.java    | 12 ++++----
 .../indexing/common/task/RealtimeIndexTask.java    | 12 ++++----
 .../io/druid/indexing/common/task/RestoreTask.java | 12 ++++----
 .../common/task/SameIntervalMergeTask.java         | 12 ++++----
 .../java/io/druid/indexing/common/task/Task.java   | 12 ++++----
 .../druid/indexing/common/task/TaskResource.java   | 12 ++++----
 .../java/io/druid/indexing/common/task/Tasks.java  | 12 ++++----
 .../indexing/common/tasklogs/FileTaskLogs.java     | 12 ++++----
 .../druid/indexing/common/tasklogs/LogUtils.java   | 12 ++++----
 .../common/tasklogs/SwitchingTaskLogStreamer.java  | 12 ++++----
 .../common/tasklogs/TaskRunnerTaskLogStreamer.java | 12 ++++----
 .../firehose/IngestSegmentFirehoseFactory.java     | 12 ++++----
 .../OverlordActionBasedUsedSegmentLister.java      | 12 ++++----
 .../io/druid/indexing/overlord/CriticalAction.java | 12 ++++----
 .../druid/indexing/overlord/ForkingTaskRunner.java | 12 ++++----
 .../overlord/ForkingTaskRunnerFactory.java         | 12 ++++----
 .../indexing/overlord/HeapMemoryTaskStorage.java   | 12 ++++----
 .../indexing/overlord/ImmutableWorkerInfo.java     | 12 ++++----
 .../overlord/IndexerMetadataStorageAdapter.java    | 12 ++++----
 .../io/druid/indexing/overlord/LockResult.java     | 12 ++++----
 .../indexing/overlord/MetadataTaskStorage.java     | 12 ++++----
 .../io/druid/indexing/overlord/PortFinder.java     | 12 ++++----
 .../druid/indexing/overlord/RemoteTaskRunner.java  | 12 ++++----
 .../indexing/overlord/RemoteTaskRunnerFactory.java | 12 ++++----
 .../overlord/RemoteTaskRunnerWorkItem.java         | 12 ++++----
 .../overlord/RemoteTaskRunnerWorkQueue.java        | 12 ++++----
 .../overlord/SingleTaskBackgroundRunner.java       | 12 ++++----
 .../io/druid/indexing/overlord/TaskLockbox.java    | 12 ++++----
 .../io/druid/indexing/overlord/TaskMaster.java     | 12 ++++----
 .../java/io/druid/indexing/overlord/TaskQueue.java | 12 ++++----
 .../io/druid/indexing/overlord/TaskRunner.java     | 12 ++++----
 .../druid/indexing/overlord/TaskRunnerFactory.java | 12 ++++----
 .../indexing/overlord/TaskRunnerListener.java      | 12 ++++----
 .../druid/indexing/overlord/TaskRunnerUtils.java   | 12 ++++----
 .../indexing/overlord/TaskRunnerWorkItem.java      | 12 ++++----
 .../io/druid/indexing/overlord/TaskStorage.java    | 12 ++++----
 .../indexing/overlord/TaskStorageQueryAdapter.java | 12 ++++----
 .../druid/indexing/overlord/WorkerTaskRunner.java  | 12 ++++----
 .../java/io/druid/indexing/overlord/ZkWorker.java  | 12 ++++----
 .../AbstractWorkerProvisioningStrategy.java        | 12 ++++----
 .../indexing/overlord/autoscaling/AutoScaler.java  | 12 ++++----
 .../overlord/autoscaling/AutoScalingData.java      | 12 ++++----
 .../overlord/autoscaling/NoopAutoScaler.java       | 12 ++++----
 .../autoscaling/NoopProvisioningStrategy.java      | 12 ++++----
 .../PendingTaskBasedWorkerProvisioningConfig.java  | 12 ++++----
 ...PendingTaskBasedWorkerProvisioningStrategy.java | 12 ++++----
 .../indexing/overlord/autoscaling/Provisioner.java | 12 ++++----
 .../autoscaling/ProvisioningSchedulerConfig.java   | 12 ++++----
 .../overlord/autoscaling/ProvisioningService.java  | 12 ++++----
 .../overlord/autoscaling/ProvisioningStrategy.java | 12 ++++----
 .../overlord/autoscaling/ProvisioningUtil.java     | 12 ++++----
 .../overlord/autoscaling/ScalingStats.java         | 12 ++++----
 .../SimpleWorkerProvisioningConfig.java            | 12 ++++----
 .../SimpleWorkerProvisioningStrategy.java          | 12 ++++----
 .../overlord/autoscaling/ec2/EC2AutoScaler.java    | 12 ++++----
 .../autoscaling/ec2/EC2EnvironmentConfig.java      | 12 ++++----
 .../autoscaling/ec2/EC2IamProfileData.java         | 12 ++++----
 .../overlord/autoscaling/ec2/EC2NodeData.java      | 12 ++++----
 .../overlord/autoscaling/ec2/EC2UserData.java      | 12 ++++----
 .../autoscaling/ec2/GalaxyEC2UserData.java         | 12 ++++----
 .../autoscaling/ec2/StringEC2UserData.java         | 12 ++++----
 .../overlord/config/ForkingTaskRunnerConfig.java   | 12 ++++----
 .../config/HttpRemoteTaskRunnerConfig.java         | 12 ++++----
 .../overlord/config/RemoteTaskRunnerConfig.java    | 12 ++++----
 .../indexing/overlord/config/TaskQueueConfig.java  | 12 ++++----
 .../overlord/config/WorkerTaskRunnerConfig.java    | 12 ++++----
 .../indexing/overlord/helpers/OverlordHelper.java  | 12 ++++----
 .../overlord/helpers/OverlordHelperManager.java    | 12 ++++----
 .../overlord/helpers/TaskLogAutoCleaner.java       | 12 ++++----
 .../overlord/helpers/TaskLogAutoCleanerConfig.java | 12 ++++----
 .../overlord/hrtr/HttpRemoteTaskRunner.java        | 12 ++++----
 .../overlord/hrtr/HttpRemoteTaskRunnerFactory.java | 12 ++++----
 .../hrtr/HttpRemoteTaskRunnerResource.java         | 12 ++++----
 .../druid/indexing/overlord/hrtr/WorkerHolder.java | 12 ++++----
 .../overlord/http/OverlordRedirectInfo.java        | 12 ++++----
 .../indexing/overlord/http/OverlordResource.java   | 12 ++++----
 .../overlord/http/TaskPayloadResponse.java         | 12 ++++----
 .../indexing/overlord/http/TaskStatusResponse.java | 12 ++++----
 .../http/security/SupervisorResourceFilter.java    | 12 ++++----
 .../overlord/http/security/TaskResourceFilter.java | 12 ++++----
 .../indexing/overlord/setup/AffinityConfig.java    | 12 ++++----
 .../setup/DefaultWorkerBehaviorConfig.java         | 12 ++++----
 ...stributionWithAffinityWorkerSelectStrategy.java | 12 ++++----
 .../EqualDistributionWorkerSelectStrategy.java     | 12 ++++----
 ...llCapacityWithAffinityWorkerSelectStrategy.java | 12 ++++----
 .../setup/FillCapacityWorkerSelectStrategy.java    | 12 ++++----
 .../setup/JavaScriptWorkerSelectStrategy.java      | 12 ++++----
 .../overlord/setup/WorkerBehaviorConfig.java       | 12 ++++----
 .../overlord/setup/WorkerSelectStrategy.java       | 12 ++++----
 .../indexing/overlord/setup/WorkerSelectUtils.java | 12 ++++----
 .../overlord/supervisor/SupervisorManager.java     | 12 ++++----
 .../overlord/supervisor/SupervisorResource.java    | 12 ++++----
 .../io/druid/indexing/worker/TaskAnnouncement.java | 12 ++++----
 .../main/java/io/druid/indexing/worker/Worker.java | 12 ++++----
 .../indexing/worker/WorkerCuratorCoordinator.java  | 12 ++++----
 .../druid/indexing/worker/WorkerHistoryItem.java   | 12 ++++----
 .../druid/indexing/worker/WorkerTaskManager.java   | 12 ++++----
 .../druid/indexing/worker/WorkerTaskMonitor.java   | 12 ++++----
 .../druid/indexing/worker/config/WorkerConfig.java | 12 ++++----
 .../worker/executor/ExecutorLifecycle.java         | 12 ++++----
 .../worker/executor/ExecutorLifecycleConfig.java   | 12 ++++----
 .../worker/http/TaskManagementResource.java        | 12 ++++----
 .../druid/indexing/worker/http/WorkerResource.java | 12 ++++----
 .../server/initialization/IndexerZkConfig.java     | 12 ++++----
 .../src/main/resources/indexer_static/console.html | 26 +++++++++--------
 .../ActionBasedUsedSegmentCheckerTest.java         | 12 ++++----
 .../indexing/common/IndexingServiceCondition.java  | 12 ++++----
 .../indexing/common/RetryPolicyFactoryTest.java    | 12 ++++----
 .../io/druid/indexing/common/RetryPolicyTest.java  | 12 ++++----
 .../io/druid/indexing/common/TaskToolboxTest.java  | 12 ++++----
 .../io/druid/indexing/common/TestRealtimeTask.java | 12 ++++----
 .../java/io/druid/indexing/common/TestTasks.java   | 12 ++++----
 .../java/io/druid/indexing/common/TestUtils.java   | 12 ++++----
 .../common/actions/LockAcquireActionTest.java      | 12 ++++----
 .../common/actions/LockTryAcquireActionTest.java   | 12 ++++----
 .../common/actions/RemoteTaskActionClientTest.java | 12 ++++----
 .../common/actions/SegmentAllocateActionTest.java  | 12 ++++----
 .../common/actions/SegmentInsertActionTest.java    | 12 ++++----
 .../common/actions/SegmentListActionsTest.java     | 12 ++++----
 .../actions/SegmentListUsedActionSerdeTest.java    | 12 ++++----
 .../SegmentTransactionalInsertActionTest.java      | 12 ++++----
 .../actions/TaskActionPreconditionsTest.java       | 12 ++++----
 .../indexing/common/actions/TaskActionTestKit.java | 12 ++++----
 .../common/config/TaskStorageConfigTest.java       | 12 ++++----
 .../AppenderatorDriverRealtimeIndexTaskTest.java   | 12 ++++----
 .../indexing/common/task/CompactionTaskTest.java   | 12 ++++----
 .../common/task/ConvertSegmentTaskTest.java        | 12 ++++----
 .../common/task/HadoopConverterTaskSerDeTest.java  | 12 ++++----
 .../druid/indexing/common/task/HadoopTaskTest.java | 12 ++++----
 .../druid/indexing/common/task/IndexTaskTest.java  | 12 ++++----
 .../indexing/common/task/MergeTaskBaseTest.java    | 12 ++++----
 .../common/task/NoopTestTaskFileWriter.java        | 12 ++++----
 .../common/task/RealtimeIndexTaskTest.java         | 12 ++++----
 .../common/task/SameIntervalMergeTaskTest.java     | 12 ++++----
 .../indexing/common/task/TaskReportSerdeTest.java  | 12 ++++----
 .../druid/indexing/common/task/TaskSerdeTest.java  | 12 ++++----
 .../io/druid/indexing/common/task/TasksTest.java   | 12 ++++----
 .../indexing/common/tasklogs/FileTaskLogsTest.java | 12 ++++----
 .../firehose/IngestSegmentFirehoseFactoryTest.java | 12 ++++----
 .../IngestSegmentFirehoseFactoryTimelineTest.java  | 12 ++++----
 .../indexing/overlord/ForkingTaskRunnerTest.java   | 12 ++++----
 .../indexing/overlord/ImmutableWorkerInfoTest.java | 12 ++++----
 .../IndexerMetadataStorageAdapterTest.java         | 12 ++++----
 .../overlord/OverlordBlinkLeadershipTest.java      | 12 ++++----
 .../io/druid/indexing/overlord/PortFinderTest.java | 12 ++++----
 .../druid/indexing/overlord/RealtimeishTask.java   | 12 ++++----
 ...teTaskRunnerRunPendingTasksConcurrencyTest.java | 12 ++++----
 .../indexing/overlord/RemoteTaskRunnerTest.java    | 12 ++++----
 .../overlord/RemoteTaskRunnerTestUtils.java        | 12 ++++----
 .../overlord/SingleTaskBackgroundRunnerTest.java   | 12 ++++----
 .../druid/indexing/overlord/TaskLifecycleTest.java | 12 ++++----
 .../overlord/TaskLockBoxConcurrencyTest.java       | 12 ++++----
 .../druid/indexing/overlord/TaskLockboxTest.java   | 12 ++++----
 .../overlord/TestRemoteTaskRunnerConfig.java       | 12 ++++----
 .../io/druid/indexing/overlord/TestTaskRunner.java | 12 ++++----
 .../autoscaling/EC2AutoScalerSerdeTest.java        | 12 ++++----
 .../overlord/autoscaling/EC2AutoScalerTest.java    | 12 ++++----
 .../PendingTaskBasedProvisioningStrategyTest.java  | 12 ++++----
 .../SimpleProvisioningStrategyTest.java            | 12 ++++----
 .../overlord/autoscaling/ec2/EC2NodeDataTest.java  | 12 ++++----
 .../config/ForkingTaskRunnerConfigTest.java        | 12 ++++----
 .../config/RemoteTaskRunnerConfigTest.java         | 12 ++++----
 .../helpers/TaskLogAutoCleanerConfigTest.java      | 12 ++++----
 .../overlord/hrtr/HttpRemoteTaskRunnerTest.java    | 12 ++++----
 .../indexing/overlord/hrtr/WorkerHolderTest.java   | 12 ++++----
 .../overlord/http/OverlordRedirectInfoTest.java    | 12 ++++----
 .../overlord/http/OverlordResourceTest.java        | 12 ++++----
 .../druid/indexing/overlord/http/OverlordTest.java | 12 ++++----
 .../OverlordSecurityResourceFilterTest.java        | 12 ++++----
 ...butionWithAffinityWorkerSelectStrategyTest.java | 12 ++++----
 .../EqualDistributionWorkerSelectStrategyTest.java | 12 ++++----
 ...pacityWithAffinityWorkerSelectStrategyTest.java | 12 ++++----
 .../setup/JavaScriptWorkerSelectStrategyTest.java  | 12 ++++----
 .../overlord/setup/WorkerBehaviorConfigTest.java   | 12 ++++----
 .../overlord/supervisor/SupervisorManagerTest.java | 12 ++++----
 .../supervisor/SupervisorResourceTest.java         | 12 ++++----
 .../indexing/test/TestDataSegmentAnnouncer.java    | 12 ++++----
 .../druid/indexing/test/TestDataSegmentKiller.java | 12 ++++----
 .../druid/indexing/test/TestDataSegmentPusher.java | 12 ++++----
 .../TestIndexerMetadataStorageCoordinator.java     | 12 ++++----
 .../indexing/worker/TaskAnnouncementTest.java      | 12 ++++----
 .../indexing/worker/WorkerTaskManagerTest.java     | 12 ++++----
 .../indexing/worker/WorkerTaskMonitorTest.java     | 12 ++++----
 .../indexing/worker/http/WorkerResourceTest.java   | 12 ++++----
 .../server/initialization/IndexerZkConfigTest.java | 12 ++++----
 integration-tests/pom.xml                          | 26 +++++++++--------
 .../io/druid/testing/ConfigFileConfigProvider.java | 12 ++++----
 .../io/druid/testing/DockerConfigProvider.java     | 12 ++++----
 .../io/druid/testing/IntegrationTestingConfig.java | 12 ++++----
 .../testing/IntegrationTestingConfigProvider.java  | 12 ++++----
 .../testing/IntegrationTestingCuratorConfig.java   | 12 ++++----
 .../clients/ClientInfoResourceTestClient.java      | 12 ++++----
 .../clients/CoordinatorResourceTestClient.java     | 12 ++++----
 .../clients/EventReceiverFirehoseTestClient.java   | 12 ++++----
 .../clients/OverlordResourceTestClient.java        | 12 ++++----
 .../testing/clients/QueryResourceTestClient.java   | 12 ++++----
 .../druid/testing/clients/TaskResponseObject.java  | 12 ++++----
 .../io/druid/testing/guice/DruidTestModule.java    | 12 ++++----
 .../testing/guice/DruidTestModuleFactory.java      | 12 ++++----
 .../java/io/druid/testing/guice/TestClient.java    | 12 ++++----
 .../io/druid/testing/utils/LoggerListener.java     | 12 ++++----
 .../druid/testing/utils/QueryResultVerifier.java   | 12 ++++----
 .../io/druid/testing/utils/QueryWithResults.java   | 12 ++++----
 .../java/io/druid/testing/utils/RetryUtil.java     | 12 ++++----
 .../druid/testing/utils/ServerDiscoveryUtil.java   | 12 ++++----
 .../io/druid/testing/utils/TestQueryHelper.java    | 12 ++++----
 .../java/org/testng/DruidTestRunnerFactory.java    | 12 ++++----
 .../io/druid/tests/hadoop/ITHadoopIndexTest.java   | 12 ++++----
 .../indexer/AbstractITRealtimeIndexTaskTest.java   | 12 ++++----
 .../druid/tests/indexer/AbstractIndexerTest.java   | 12 ++++----
 .../ITAppenderatorDriverRealtimeIndexTaskTest.java | 12 ++++----
 .../druid/tests/indexer/ITCompactionTaskTest.java  | 12 ++++----
 .../java/io/druid/tests/indexer/ITIndexerTest.java | 12 ++++----
 .../tests/indexer/ITKafkaIndexingServiceTest.java  | 12 ++++----
 .../java/io/druid/tests/indexer/ITKafkaTest.java   | 12 ++++----
 .../tests/indexer/ITRealtimeIndexTaskTest.java     | 12 ++++----
 .../io/druid/tests/indexer/ITUnionQueryTest.java   | 12 ++++----
 .../io/druid/tests/query/ITTwitterQueryTest.java   | 12 ++++----
 .../io/druid/tests/query/ITWikipediaQueryTest.java | 12 ++++----
 .../security/ITBasicAuthConfigurationTest.java     | 12 ++++----
 .../ITCoordinatorOverlordProxyAuthTest.java        | 12 ++++----
 integration-tests/src/test/resources/testng.xml    | 26 +++++++++--------
 java-util/pom.xml                                  | 12 ++++----
 .../concurrent/ConcurrentAwaitableCounter.java     | 12 ++++----
 .../io/druid/guice/annotations/ExtensionPoint.java | 12 ++++----
 .../java/io/druid/guice/annotations/PublicApi.java | 12 ++++----
 .../io/druid/java/util/common/ByteBufferUtils.java | 12 ++++----
 .../java/io/druid/java/util/common/Cacheable.java  | 12 ++++----
 .../druid/java/util/common/CloseableIterators.java | 12 ++++----
 .../druid/java/util/common/CompressionUtils.java   | 12 ++++----
 .../java/io/druid/java/util/common/DateTimes.java  | 12 ++++----
 .../java/io/druid/java/util/common/FileUtils.java  | 12 ++++----
 .../main/java/io/druid/java/util/common/IAE.java   | 12 ++++----
 .../main/java/io/druid/java/util/common/IOE.java   | 12 ++++----
 .../main/java/io/druid/java/util/common/ISE.java   | 12 ++++----
 .../java/io/druid/java/util/common/Intervals.java  | 12 ++++----
 .../java/io/druid/java/util/common/JodaUtils.java  | 12 ++++----
 .../java/io/druid/java/util/common/MapUtils.java   | 12 ++++----
 .../java/util/common/MappedByteBufferHandler.java  | 12 ++++----
 .../java/io/druid/java/util/common/Numbers.java    | 12 ++++----
 .../main/java/io/druid/java/util/common/Pair.java  | 12 ++++----
 .../main/java/io/druid/java/util/common/RE.java    | 12 ++++----
 .../java/io/druid/java/util/common/RetryUtils.java | 12 ++++----
 .../io/druid/java/util/common/StreamUtils.java     | 12 ++++----
 .../io/druid/java/util/common/StringUtils.java     | 12 ++++----
 .../main/java/io/druid/java/util/common/UOE.java   | 12 ++++----
 .../io/druid/java/util/common/collect/Utils.java   | 12 ++++----
 .../common/concurrent/DummyExecutorService.java    | 12 ++++----
 .../druid/java/util/common/concurrent/Execs.java   | 12 ++++----
 .../common/concurrent/ExecutorServiceConfig.java   | 12 ++++----
 .../util/common/concurrent/ExecutorServices.java   | 12 ++++----
 .../util/common/concurrent/ListenableFutures.java  | 12 ++++----
 .../concurrent/ScheduledExecutorFactory.java       | 12 ++++----
 .../util/common/concurrent/ScheduledExecutors.java | 12 ++++----
 .../io/druid/java/util/common/config/Config.java   | 12 ++++----
 .../java/util/common/config/DurationCoercible.java | 12 ++++----
 .../util/common/granularity/AllGranularity.java    | 12 ++++----
 .../common/granularity/DurationGranularity.java    | 12 ++++----
 .../util/common/granularity/Granularities.java     | 12 ++++----
 .../java/util/common/granularity/Granularity.java  | 12 ++++----
 .../util/common/granularity/GranularityType.java   | 12 ++++----
 .../util/common/granularity/NoneGranularity.java   | 12 ++++----
 .../util/common/granularity/PeriodGranularity.java | 12 ++++----
 .../druid/java/util/common/guava/Accumulator.java  | 12 ++++----
 .../druid/java/util/common/guava/Accumulators.java | 12 ++++----
 .../druid/java/util/common/guava/BaseSequence.java | 12 ++++----
 .../druid/java/util/common/guava/CloseQuietly.java | 12 ++++----
 .../druid/java/util/common/guava/Comparators.java  | 12 ++++----
 .../java/util/common/guava/ConcatSequence.java     | 12 ++++----
 .../guava/DelegatingYieldingAccumulator.java       | 12 ++++----
 .../java/util/common/guava/DroppingIterable.java   | 12 ++++----
 .../java/util/common/guava/DroppingIterator.java   | 12 ++++----
 .../util/common/guava/ExecuteWhenDoneYielder.java  | 12 ++++----
 .../java/util/common/guava/FilteredSequence.java   | 12 ++++----
 .../util/common/guava/FilteringAccumulator.java    | 12 ++++----
 .../common/guava/FilteringYieldingAccumulator.java | 12 ++++----
 .../java/util/common/guava/FunctionalIterable.java | 12 ++++----
 .../java/util/common/guava/FunctionalIterator.java | 12 ++++----
 .../druid/java/util/common/guava/LazySequence.java | 12 ++++----
 .../java/util/common/guava/LimitedSequence.java    | 12 ++++----
 .../java/util/common/guava/MappedSequence.java     | 12 ++++----
 .../java/util/common/guava/MappingAccumulator.java | 12 ++++----
 .../common/guava/MappingYieldingAccumulator.java   | 12 ++++----
 .../java/util/common/guava/MergeIterable.java      | 12 ++++----
 .../java/util/common/guava/MergeIterator.java      | 12 ++++----
 .../java/util/common/guava/MergeSequence.java      | 12 ++++----
 .../io/druid/java/util/common/guava/Sequence.java  | 12 ++++----
 .../java/util/common/guava/SequenceWrapper.java    | 12 ++++----
 .../io/druid/java/util/common/guava/Sequences.java | 12 ++++----
 .../java/util/common/guava/WrappingSequence.java   | 12 ++++----
 .../java/util/common/guava/WrappingYielder.java    | 12 ++++----
 .../io/druid/java/util/common/guava/Yielder.java   | 12 ++++----
 .../io/druid/java/util/common/guava/Yielders.java  | 12 ++++----
 .../util/common/guava/YieldingAccumulator.java     | 12 ++++----
 .../util/common/guava/YieldingAccumulators.java    | 12 ++++----
 .../util/common/guava/YieldingSequenceBase.java    | 12 ++++----
 .../java/util/common/guava/nary/BinaryFn.java      | 12 ++++----
 .../common/guava/nary/SortedMergeIterator.java     | 12 ++++----
 .../java/util/common/guava/nary/TrinaryFn.java     | 12 ++++----
 .../guava/nary/TrinaryTransformIterable.java       | 12 ++++----
 .../guava/nary/TrinaryTransformIterator.java       | 12 ++++----
 .../java/io/druid/java/util/common/io/Closer.java  | 12 ++++----
 .../io/druid/java/util/common/io/NativeIO.java     | 12 ++++----
 .../java/util/common/io/smoosh/FileSmoosher.java   | 12 ++++----
 .../druid/java/util/common/io/smoosh/Metadata.java | 12 ++++----
 .../druid/java/util/common/io/smoosh/Smoosh.java   | 12 ++++----
 .../util/common/io/smoosh/SmooshedFileMapper.java  | 12 ++++----
 .../java/util/common/io/smoosh/SmooshedWriter.java | 12 ++++----
 .../java/util/common/jackson/JacksonUtils.java     | 12 ++++----
 .../java/util/common/lifecycle/Lifecycle.java      | 12 ++++----
 .../java/util/common/lifecycle/LifecycleStart.java | 12 ++++----
 .../java/util/common/lifecycle/LifecycleStop.java  | 12 ++++----
 .../io/druid/java/util/common/logger/Logger.java   | 12 ++++----
 .../parsers/AbstractFlatTextFormatParser.java      | 12 ++++----
 .../druid/java/util/common/parsers/CSVParser.java  | 12 ++++----
 .../util/common/parsers/CloseableIterator.java     | 12 ++++----
 .../java/util/common/parsers/DelimitedParser.java  | 12 ++++----
 .../util/common/parsers/JSONFlattenerMaker.java    | 12 ++++----
 .../util/common/parsers/JSONPathFieldSpec.java     | 12 ++++----
 .../util/common/parsers/JSONPathFieldType.java     | 12 ++++----
 .../java/util/common/parsers/JSONPathParser.java   | 12 ++++----
 .../java/util/common/parsers/JSONPathSpec.java     | 12 ++++----
 .../util/common/parsers/JSONToLowerParser.java     | 12 ++++----
 .../java/util/common/parsers/JavaScriptParser.java | 12 ++++----
 .../java/util/common/parsers/ObjectFlattener.java  | 12 ++++----
 .../java/util/common/parsers/ObjectFlatteners.java | 12 ++++----
 .../java/util/common/parsers/ParseException.java   | 12 ++++----
 .../io/druid/java/util/common/parsers/Parser.java  | 12 ++++----
 .../java/util/common/parsers/ParserUtils.java      | 12 ++++----
 .../io/druid/java/util/common/parsers/Parsers.java | 12 ++++----
 .../java/util/common/parsers/RegexParser.java      | 12 ++++----
 .../java/util/common/parsers/TimestampParser.java  | 12 ++++----
 .../io/druid/java/util/emitter/EmittingLogger.java | 12 ++++----
 .../util/emitter/core/BaseHttpEmittingConfig.java  | 12 ++++----
 .../io/druid/java/util/emitter/core/Batch.java     | 12 ++++----
 .../java/util/emitter/core/BatchingStrategy.java   | 12 ++++----
 .../java/util/emitter/core/ComposingEmitter.java   | 12 ++++----
 .../util/emitter/core/ConcurrentTimeCounter.java   | 12 ++++----
 .../java/util/emitter/core/ContentEncoding.java    | 12 ++++----
 .../io/druid/java/util/emitter/core/Emitter.java   | 12 ++++----
 .../io/druid/java/util/emitter/core/Emitters.java  | 12 ++++----
 .../io/druid/java/util/emitter/core/Event.java     | 12 ++++----
 .../java/util/emitter/core/FeedUriExtractor.java   | 12 ++++----
 .../java/util/emitter/core/HttpEmitterConfig.java  | 12 ++++----
 .../java/util/emitter/core/HttpPostEmitter.java    | 12 ++++----
 .../java/util/emitter/core/LoggingEmitter.java     | 12 ++++----
 .../util/emitter/core/LoggingEmitterConfig.java    | 12 ++++----
 .../druid/java/util/emitter/core/NoopEmitter.java  | 12 ++++----
 .../util/emitter/core/ParametrizedUriEmitter.java  | 12 ++++----
 .../emitter/core/ParametrizedUriEmitterConfig.java | 12 ++++----
 .../emitter/core/ParametrizedUriExtractor.java     | 12 ++++----
 .../druid/java/util/emitter/core/UriExtractor.java | 12 ++++----
 .../core/ZeroCopyByteArrayOutputStream.java        | 12 ++++----
 .../java/util/emitter/factory/EmitterFactory.java  | 12 ++++----
 .../util/emitter/factory/HttpEmitterFactory.java   | 12 ++++----
 .../emitter/factory/LoggingEmitterFactory.java     | 12 ++++----
 .../util/emitter/factory/NoopEmitterFactory.java   | 12 ++++----
 .../factory/ParametrizedUriEmitterFactory.java     | 12 ++++----
 .../java/util/emitter/service/AlertBuilder.java    | 12 ++++----
 .../java/util/emitter/service/AlertEvent.java      | 12 ++++----
 .../java/util/emitter/service/ServiceEmitter.java  | 12 ++++----
 .../util/emitter/service/ServiceEventBuilder.java  | 12 ++++----
 .../util/emitter/service/ServiceMetricEvent.java   | 12 ++++----
 .../java/util/http/client/AbstractHttpClient.java  | 12 ++++----
 .../util/http/client/CredentialedHttpClient.java   | 12 ++++----
 .../io/druid/java/util/http/client/HttpClient.java | 12 ++++----
 .../java/util/http/client/HttpClientConfig.java    | 12 ++++----
 .../java/util/http/client/HttpClientInit.java      | 12 ++++----
 .../java/util/http/client/NettyHttpClient.java     | 12 ++++----
 .../io/druid/java/util/http/client/Request.java    | 12 ++++----
 .../util/http/client/auth/BasicCredentials.java    | 12 ++++----
 .../java/util/http/client/auth/Credentials.java    | 12 ++++----
 .../client/io/AppendableByteArrayInputStream.java  | 12 ++++----
 .../client/netty/HttpClientPipelineFactory.java    | 12 ++++----
 .../http/client/pool/ChannelResourceFactory.java   | 12 ++++----
 .../util/http/client/pool/ResourceContainer.java   | 12 ++++----
 .../util/http/client/pool/ResourceFactory.java     | 12 ++++----
 .../java/util/http/client/pool/ResourcePool.java   | 12 ++++----
 .../util/http/client/pool/ResourcePoolConfig.java  | 12 ++++----
 .../util/http/client/response/ClientResponse.java  | 12 ++++----
 .../http/client/response/FullResponseHandler.java  | 12 ++++----
 .../http/client/response/FullResponseHolder.java   | 12 ++++----
 .../http/client/response/HttpResponseHandler.java  | 12 ++++----
 .../response/InputStreamResponseHandler.java       | 12 ++++----
 .../SequenceInputStreamResponseHandler.java        | 12 ++++----
 .../client/response/StatusResponseHandler.java     | 12 ++++----
 .../http/client/response/StatusResponseHolder.java | 12 ++++----
 .../druid/java/util/metrics/AbstractMonitor.java   | 12 ++++----
 .../java/util/metrics/CgroupMemoryMonitor.java     | 12 ++++----
 .../io/druid/java/util/metrics/CgroupUtil.java     | 12 ++++----
 .../druid/java/util/metrics/CompoundMonitor.java   | 12 ++++----
 .../java/util/metrics/CpuAcctDeltaMonitor.java     | 12 ++++----
 .../java/util/metrics/FeedDefiningMonitor.java     | 12 ++++----
 .../java/util/metrics/HttpPostEmitterMonitor.java  | 12 ++++----
 .../io/druid/java/util/metrics/JvmCpuMonitor.java  | 12 ++++----
 .../io/druid/java/util/metrics/JvmMonitor.java     | 12 ++++----
 .../druid/java/util/metrics/JvmPidDiscoverer.java  | 12 ++++----
 .../druid/java/util/metrics/JvmThreadsMonitor.java | 12 ++++----
 .../java/io/druid/java/util/metrics/KeyedDiff.java | 12 ++++----
 .../java/io/druid/java/util/metrics/Monitor.java   | 12 ++++----
 .../druid/java/util/metrics/MonitorScheduler.java  | 12 ++++----
 .../java/util/metrics/MonitorSchedulerConfig.java  | 12 ++++----
 .../io/druid/java/util/metrics/MonitorUtils.java   | 12 ++++----
 .../java/io/druid/java/util/metrics/Monitors.java  | 12 ++++----
 .../metrics/ParametrizedUriEmitterMonitor.java     | 12 ++++----
 .../io/druid/java/util/metrics/PidDiscoverer.java  | 12 ++++----
 .../java/util/metrics/SigarPidDiscoverer.java      | 12 ++++----
 .../java/io/druid/java/util/metrics/SigarUtil.java | 12 ++++----
 .../io/druid/java/util/metrics/SysMonitor.java     | 12 ++++----
 .../util/metrics/cgroups/CgroupDiscoverer.java     | 12 ++++----
 .../druid/java/util/metrics/cgroups/CpuAcct.java   | 12 ++++----
 .../io/druid/java/util/metrics/cgroups/Memory.java | 12 ++++----
 .../util/metrics/cgroups/ProcCgroupDiscoverer.java | 12 ++++----
 .../metrics/cgroups/ProcSelfCgroupDiscoverer.java  | 12 ++++----
 .../concurrent/ConcurrentAwaitableCounterTest.java | 12 ++++----
 .../io/druid/java/util/common/BufferUtils.java     | 12 ++++----
 .../java/util/common/ByteBufferUtilsTest.java      | 12 ++++----
 .../java/util/common/CompressionUtilsTest.java     | 12 ++++----
 .../io/druid/java/util/common/FileUtilsTest.java   | 12 ++++----
 .../io/druid/java/util/common/GranularityTest.java | 12 ++++----
 .../io/druid/java/util/common/NumbersTest.java     | 12 ++++----
 .../io/druid/java/util/common/RetryUtilsTest.java  | 12 ++++----
 .../io/druid/java/util/common/StreamUtilsTest.java | 12 ++++----
 .../io/druid/java/util/common/StringUtilsTest.java | 12 ++++----
 .../java/util/common/guava/BaseSequenceTest.java   | 12 ++++----
 .../java/util/common/guava/ComparatorsTest.java    | 12 ++++----
 .../java/util/common/guava/ConcatSequenceTest.java | 12 ++++----
 .../util/common/guava/FilteredSequenceTest.java    | 12 ++++----
 .../util/common/guava/FunctionalIterableTest.java  | 12 ++++----
 .../util/common/guava/FunctionalIteratorTest.java  | 12 ++++----
 .../util/common/guava/LimitedSequenceTest.java     | 12 ++++----
 .../java/util/common/guava/MappedSequenceTest.java | 12 ++++----
 .../java/util/common/guava/MergeIteratorTest.java  | 12 ++++----
 .../java/util/common/guava/MergeSequenceTest.java  | 12 ++++----
 .../java/util/common/guava/SequenceTestHelper.java | 12 ++++----
 .../druid/java/util/common/guava/TestSequence.java | 12 ++++----
 .../util/common/guava/UnsupportedSequence.java     | 12 ++++----
 .../util/common/guava/WithEffectSequenceTest.java  | 12 ++++----
 .../util/common/guava/WrappingSequenceTest.java    | 12 ++++----
 .../common/guava/nary/SortedMergeIteratorTest.java | 12 ++++----
 .../io/druid/java/util/common/io/NativeIOTest.java | 12 ++++----
 .../common/io/smoosh/SmooshedFileMapperTest.java   | 12 ++++----
 .../java/util/common/lifecycle/LifecycleTest.java  | 12 ++++----
 .../druid/java/util/common/logger/LoggerTest.java  | 12 ++++----
 .../common/parsers/FlatTextFormatParserTest.java   | 12 ++++----
 .../util/common/parsers/JSONPathParserTest.java    | 12 ++++----
 .../util/common/parsers/JavaScriptParserTest.java  | 12 ++++----
 .../java/util/common/parsers/RegexParserTest.java  | 12 ++++----
 .../util/common/parsers/TimestampParserTest.java   | 12 ++++----
 .../util/emitter/core/ComposingEmitterTest.java    | 12 ++++----
 .../emitter/core/CustomEmitterFactoryTest.java     | 12 ++++----
 .../druid/java/util/emitter/core/EmitterTest.java  | 12 ++++----
 .../io/druid/java/util/emitter/core/GoHandler.java | 12 ++++----
 .../druid/java/util/emitter/core/GoHandlers.java   | 12 ++++----
 .../util/emitter/core/HttpEmitterConfigTest.java   | 12 ++++----
 .../java/util/emitter/core/HttpEmitterTest.java    | 12 ++++----
 .../emitter/core/HttpPostEmitterStressTest.java    | 12 ++++----
 .../io/druid/java/util/emitter/core/IntEvent.java  | 12 ++++----
 .../emitter/core/LoggingEmitterConfigTest.java     | 12 ++++----
 .../java/util/emitter/core/MockHttpClient.java     | 12 ++++----
 .../core/ParametrizedUriEmitterConfigTest.java     | 12 ++++----
 .../emitter/core/ParametrizedUriEmitterTest.java   | 12 ++++----
 .../java/util/emitter/service/AlertEventTest.java  | 12 ++++----
 .../emitter/service/ServiceMetricEventTest.java    | 12 ++++----
 .../druid/java/util/emitter/service/UnitEvent.java | 12 ++++----
 .../java/util/http/client/AsyncHttpClientTest.java | 12 ++++----
 .../java/util/http/client/FriendlyServersTest.java | 12 ++++----
 .../java/util/http/client/JankyServersTest.java    | 12 ++++----
 .../io/AppendableByteArrayInputStreamTest.java     | 12 ++++----
 .../util/http/client/pool/ResourcePoolTest.java    | 12 ++++----
 .../SequenceInputStreamResponseHandlerTest.java    | 12 ++++----
 .../java/util/metrics/CgroupMemoryMonitorTest.java | 12 ++++----
 .../java/util/metrics/CpuAcctDeltaMonitorTest.java | 12 ++++----
 .../io/druid/java/util/metrics/GcNameTest.java     | 12 ++++----
 .../io/druid/java/util/metrics/JvmMonitorTest.java | 12 ++++----
 .../java/util/metrics/JvmPidDiscovererTest.java    | 12 ++++----
 .../druid/java/util/metrics/MonitorUtilsTest.java  | 12 ++++----
 .../io/druid/java/util/metrics/MonitorsTest.java   | 12 ++++----
 .../io/druid/java/util/metrics/SigarLoadTest.java  | 12 ++++----
 .../java/util/metrics/SigarPidDiscovererTest.java  | 12 ++++----
 .../java/util/metrics/StubServiceEmitter.java      | 12 ++++----
 .../java/util/metrics/cgroups/CpuAcctTest.java     | 12 ++++----
 .../java/util/metrics/cgroups/MemoryTest.java      | 12 ++++----
 .../metrics/cgroups/ProcCgroupDiscovererTest.java  | 12 ++++----
 .../druid/java/util/metrics/cgroups/TestUtils.java | 12 ++++----
 java-util/src/test/resources/log4j2.xml            |  4 +--
 pom.xml                                            | 26 +++++++++--------
 ...ollections.bitmap.RangeBitmapBenchmarkTest.html | 12 ++++----
 ...lections.bitmap.UniformBitmapBenchmarkTest.html | 12 ++++----
 processing/pom.xml                                 | 26 +++++++++--------
 .../main/java/io/druid/collections/IntegerSet.java | 12 ++++----
 .../collections/bitmap/BitSetBitmapFactory.java    | 12 ++++----
 .../io/druid/collections/bitmap/BitmapFactory.java | 12 ++++----
 .../collections/bitmap/ConciseBitmapFactory.java   | 12 ++++----
 .../druid/collections/bitmap/ImmutableBitmap.java  | 12 ++++----
 .../io/druid/collections/bitmap/MutableBitmap.java | 12 ++++----
 .../collections/bitmap/RoaringBitmapFactory.java   | 12 ++++----
 .../collections/bitmap/WrappedBitSetBitmap.java    | 12 ++++----
 .../collections/bitmap/WrappedConciseBitmap.java   | 12 ++++----
 .../bitmap/WrappedImmutableBitSetBitmap.java       | 12 ++++----
 .../bitmap/WrappedImmutableConciseBitmap.java      | 12 ++++----
 .../bitmap/WrappedImmutableRoaringBitmap.java      | 12 ++++----
 .../collections/bitmap/WrappedRoaringBitmap.java   | 12 ++++----
 .../druid/collections/spatial/ImmutableNode.java   | 12 ++++----
 .../druid/collections/spatial/ImmutablePoint.java  | 12 ++++----
 .../druid/collections/spatial/ImmutableRTree.java  | 12 ++++----
 .../java/io/druid/collections/spatial/Node.java    | 12 ++++----
 .../java/io/druid/collections/spatial/Point.java   | 12 ++++----
 .../java/io/druid/collections/spatial/RTree.java   | 12 ++++----
 .../io/druid/collections/spatial/RTreeUtils.java   | 12 ++++----
 .../io/druid/collections/spatial/search/Bound.java | 12 ++++----
 .../spatial/search/GutmanSearchStrategy.java       | 12 ++++----
 .../collections/spatial/search/PolygonBound.java   | 12 ++++----
 .../collections/spatial/search/RadiusBound.java    | 12 ++++----
 .../spatial/search/RectangularBound.java           | 12 ++++----
 .../collections/spatial/search/SearchStrategy.java | 12 ++++----
 .../spatial/split/GutmanSplitStrategy.java         | 12 ++++----
 .../spatial/split/LinearGutmanSplitStrategy.java   | 12 ++++----
 .../collections/spatial/split/SplitStrategy.java   | 12 ++++----
 .../src/main/java/io/druid/guice/ConfigModule.java | 12 ++++----
 .../main/java/io/druid/guice/ExtensionsConfig.java | 12 ++++----
 .../main/java/io/druid/guice/GuiceInjectors.java   | 12 ++++----
 .../main/java/io/druid/guice/ModulesConfig.java    | 12 ++++----
 .../main/java/io/druid/guice/PropertiesModule.java | 12 ++++----
 .../druid/guice/annotations/BackgroundCaching.java | 12 ++++----
 .../java/io/druid/guice/annotations/Merging.java   | 12 ++++----
 .../io/druid/guice/annotations/Processing.java     | 12 ++++----
 .../java/io/druid/jackson/AggregatorsModule.java   | 12 ++++----
 .../java/io/druid/jackson/DefaultObjectMapper.java | 12 ++++----
 .../jackson/DruidDefaultSerializersModule.java     | 12 ++++----
 .../java/io/druid/jackson/GranularityModule.java   | 12 ++++----
 .../main/java/io/druid/jackson/JacksonModule.java  | 12 ++++----
 .../src/main/java/io/druid/jackson/JodaStuff.java  | 12 ++++----
 .../java/io/druid/jackson/SegmentizerModule.java   | 12 ++++----
 .../main/java/io/druid/jackson/SegmentsModule.java | 12 ++++----
 .../io/druid/jackson/StringComparatorModule.java   | 12 ++++----
 .../druid/query/AbstractPrioritizedCallable.java   | 12 ++++----
 .../main/java/io/druid/query/AsyncQueryRunner.java | 12 ++++----
 .../src/main/java/io/druid/query/BaseQuery.java    | 12 ++++----
 .../java/io/druid/query/BitmapResultFactory.java   | 12 ++++----
 .../java/io/druid/query/BySegmentQueryRunner.java  | 12 ++++----
 .../java/io/druid/query/BySegmentResultValue.java  | 12 ++++----
 .../io/druid/query/BySegmentResultValueClass.java  | 12 ++++----
 .../druid/query/BySegmentSkippingQueryRunner.java  | 12 ++++----
 .../io/druid/query/CPUTimeMetricQueryRunner.java   | 12 ++++----
 .../main/java/io/druid/query/CacheStrategy.java    | 12 ++++----
 .../druid/query/ChainedExecutionQueryRunner.java   | 12 ++++----
 .../java/io/druid/query/ColumnSelectorPlus.java    | 12 ++++----
 .../java/io/druid/query/ConcatQueryRunner.java     | 12 ++++----
 .../src/main/java/io/druid/query/DataSource.java   | 12 ++++----
 .../main/java/io/druid/query/DataSourceUtil.java   | 12 ++++----
 .../io/druid/query/DefaultBitmapResultFactory.java | 12 ++++----
 .../query/DefaultGenericQueryMetricsFactory.java   | 12 ++++----
 .../java/io/druid/query/DefaultQueryMetrics.java   | 12 ++++----
 .../DefaultQueryRunnerFactoryConglomerate.java     | 12 ++++----
 .../src/main/java/io/druid/query/DruidMetrics.java | 12 ++++----
 .../java/io/druid/query/DruidProcessingConfig.java | 12 ++++----
 .../src/main/java/io/druid/query/Druids.java       | 12 ++++----
 .../io/druid/query/ExecutorServiceMonitor.java     | 12 ++++----
 .../io/druid/query/FinalizeResultsQueryRunner.java | 12 ++++----
 .../io/druid/query/FluentQueryRunnerBuilder.java   | 12 ++++----
 .../io/druid/query/GenericQueryMetricsFactory.java | 12 ++++----
 .../io/druid/query/GroupByMergedQueryRunner.java   | 12 ++++----
 .../query/InsufficientResourcesException.java      | 12 ++++----
 .../druid/query/IntervalChunkingQueryRunner.java   | 12 ++++----
 .../IntervalChunkingQueryRunnerDecorator.java      | 12 ++++----
 .../main/java/io/druid/query/LegacyDataSource.java | 12 ++++----
 .../io/druid/query/MapQueryToolChestWarehouse.java | 12 ++++----
 .../java/io/druid/query/MetricValueExtractor.java  | 12 ++++----
 .../query/MetricsEmittingExecutorService.java      | 12 ++++----
 .../io/druid/query/MetricsEmittingQueryRunner.java | 12 ++++----
 .../main/java/io/druid/query/NoopQueryRunner.java  | 12 ++++----
 .../io/druid/query/PostProcessingOperator.java     | 12 ++++----
 .../java/io/druid/query/PrioritizedCallable.java   | 12 ++++----
 .../io/druid/query/PrioritizedExecutorService.java | 12 ++++----
 .../java/io/druid/query/PrioritizedRunnable.java   | 12 ++++----
 .../src/main/java/io/druid/query/Queries.java      | 12 ++++----
 processing/src/main/java/io/druid/query/Query.java | 12 ++++----
 .../main/java/io/druid/query/QueryContexts.java    | 12 ++++----
 .../main/java/io/druid/query/QueryDataSource.java  | 12 ++++----
 .../io/druid/query/QueryInterruptedException.java  | 12 ++++----
 .../src/main/java/io/druid/query/QueryMetrics.java | 12 ++++----
 .../src/main/java/io/druid/query/QueryPlus.java    | 12 ++++----
 .../src/main/java/io/druid/query/QueryRunner.java  | 12 ++++----
 .../java/io/druid/query/QueryRunnerFactory.java    | 12 ++++----
 .../query/QueryRunnerFactoryConglomerate.java      | 12 ++++----
 .../java/io/druid/query/QueryRunnerHelper.java     | 12 ++++----
 .../java/io/druid/query/QuerySegmentWalker.java    | 12 ++++----
 .../main/java/io/druid/query/QueryToolChest.java   | 12 ++++----
 .../io/druid/query/QueryToolChestWarehouse.java    | 12 ++++----
 .../src/main/java/io/druid/query/QueryWatcher.java | 12 ++++----
 .../query/ReferenceCountingSegmentQueryRunner.java | 12 ++++----
 .../io/druid/query/ReflectionLoaderThingy.java     | 12 ++++----
 .../query/ReflectionQueryToolChestWarehouse.java   | 12 ++++----
 .../ReportTimelineMissingSegmentQueryRunner.java   | 12 ++++----
 .../query/ResourceLimitExceededException.java      | 12 ++++----
 .../src/main/java/io/druid/query/Result.java       | 12 ++++----
 .../query/ResultGranularTimestampComparator.java   | 12 ++++----
 .../io/druid/query/ResultMergeQueryRunner.java     | 12 ++++----
 .../main/java/io/druid/query/RetryQueryRunner.java | 12 ++++----
 .../io/druid/query/RetryQueryRunnerConfig.java     | 12 ++++----
 .../java/io/druid/query/SubqueryQueryRunner.java   | 12 ++++----
 .../main/java/io/druid/query/TableDataSource.java  | 12 ++++----
 .../main/java/io/druid/query/TimewarpOperator.java | 12 ++++----
 .../main/java/io/druid/query/UnionDataSource.java  | 12 ++++----
 .../main/java/io/druid/query/UnionQueryRunner.java | 12 ++++----
 .../druid/query/aggregation/AggregateCombiner.java | 12 ++++----
 .../io/druid/query/aggregation/Aggregator.java     | 12 ++++----
 .../druid/query/aggregation/AggregatorFactory.java | 12 ++++----
 .../AggregatorFactoryNotMergeableException.java    | 12 ++++----
 .../io/druid/query/aggregation/AggregatorUtil.java | 12 ++++----
 .../druid/query/aggregation/BufferAggregator.java  | 12 ++++----
 .../druid/query/aggregation/CountAggregator.java   | 12 ++++----
 .../query/aggregation/CountAggregatorFactory.java  | 12 ++++----
 .../query/aggregation/CountBufferAggregator.java   | 12 ++++----
 .../query/aggregation/DoubleAggregateCombiner.java | 12 ++++----
 .../aggregation/DoubleMaxAggregateCombiner.java    | 12 ++++----
 .../query/aggregation/DoubleMaxAggregator.java     | 12 ++++----
 .../aggregation/DoubleMaxAggregatorFactory.java    | 12 ++++----
 .../aggregation/DoubleMaxBufferAggregator.java     | 12 ++++----
 .../aggregation/DoubleMinAggregateCombiner.java    | 12 ++++----
 .../query/aggregation/DoubleMinAggregator.java     | 12 ++++----
 .../aggregation/DoubleMinAggregatorFactory.java    | 12 ++++----
 .../aggregation/DoubleMinBufferAggregator.java     | 12 ++++----
 .../aggregation/DoubleSumAggregateCombiner.java    | 12 ++++----
 .../query/aggregation/DoubleSumAggregator.java     | 12 ++++----
 .../aggregation/DoubleSumAggregatorFactory.java    | 12 ++++----
 .../aggregation/DoubleSumBufferAggregator.java     | 12 ++++----
 .../query/aggregation/FilteredAggregator.java      | 12 ++++----
 .../aggregation/FilteredAggregatorFactory.java     | 12 ++++----
 .../aggregation/FilteredBufferAggregator.java      | 12 ++++----
 .../query/aggregation/FloatMaxAggregator.java      | 12 ++++----
 .../aggregation/FloatMaxAggregatorFactory.java     | 12 ++++----
 .../aggregation/FloatMaxBufferAggregator.java      | 12 ++++----
 .../query/aggregation/FloatMinAggregator.java      | 12 ++++----
 .../aggregation/FloatMinAggregatorFactory.java     | 12 ++++----
 .../aggregation/FloatMinBufferAggregator.java      | 12 ++++----
 .../query/aggregation/FloatSumAggregator.java      | 12 ++++----
 .../aggregation/FloatSumAggregatorFactory.java     | 12 ++++----
 .../aggregation/FloatSumBufferAggregator.java      | 12 ++++----
 .../java/io/druid/query/aggregation/Histogram.java | 12 ++++----
 .../query/aggregation/HistogramAggregator.java     | 12 ++++----
 .../aggregation/HistogramAggregatorFactory.java    | 12 ++++----
 .../aggregation/HistogramBufferAggregator.java     | 12 ++++----
 .../druid/query/aggregation/HistogramVisual.java   | 12 ++++----
 .../query/aggregation/JavaScriptAggregator.java    | 12 ++++----
 .../aggregation/JavaScriptAggregatorFactory.java   | 12 ++++----
 .../aggregation/JavaScriptBufferAggregator.java    | 12 ++++----
 .../query/aggregation/LongAggregateCombiner.java   | 12 ++++----
 .../aggregation/LongMaxAggregateCombiner.java      | 12 ++++----
 .../druid/query/aggregation/LongMaxAggregator.java | 12 ++++----
 .../aggregation/LongMaxAggregatorFactory.java      | 12 ++++----
 .../query/aggregation/LongMaxBufferAggregator.java | 12 ++++----
 .../aggregation/LongMinAggregateCombiner.java      | 12 ++++----
 .../druid/query/aggregation/LongMinAggregator.java | 12 ++++----
 .../aggregation/LongMinAggregatorFactory.java      | 12 ++++----
 .../query/aggregation/LongMinBufferAggregator.java | 12 ++++----
 .../aggregation/LongSumAggregateCombiner.java      | 12 ++++----
 .../druid/query/aggregation/LongSumAggregator.java | 12 ++++----
 .../aggregation/LongSumAggregatorFactory.java      | 12 ++++----
 .../query/aggregation/LongSumBufferAggregator.java | 12 ++++----
 .../query/aggregation/MetricManipulationFn.java    | 12 ++++----
 .../query/aggregation/MetricManipulatorFns.java    | 12 ++++----
 .../io/druid/query/aggregation/NoopAggregator.java | 12 ++++----
 .../query/aggregation/NoopBufferAggregator.java    | 12 ++++----
 .../query/aggregation/ObjectAggregateCombiner.java | 12 ++++----
 .../io/druid/query/aggregation/PostAggregator.java | 12 ++++----
 .../aggregation/SimpleDoubleAggregatorFactory.java | 12 ++++----
 .../aggregation/SimpleDoubleBufferAggregator.java  | 12 ++++----
 .../aggregation/SimpleFloatAggregatorFactory.java  | 12 ++++----
 .../aggregation/SimpleFloatBufferAggregator.java   | 12 ++++----
 .../aggregation/SimpleLongAggregatorFactory.java   | 12 ++++----
 .../aggregation/SimpleLongBufferAggregator.java    | 12 ++++----
 .../cardinality/CardinalityAggregator.java         | 12 ++++----
 .../cardinality/CardinalityAggregatorFactory.java  | 12 ++++----
 .../cardinality/CardinalityBufferAggregator.java   | 12 ++++----
 .../HyperLogLogCollectorAggregateCombiner.java     | 12 ++++----
 ...ardinalityAggregatorColumnSelectorStrategy.java | 12 ++++----
 ...ityAggregatorColumnSelectorStrategyFactory.java | 12 ++++----
 ...ardinalityAggregatorColumnSelectorStrategy.java | 12 ++++----
 ...ardinalityAggregatorColumnSelectorStrategy.java | 12 ++++----
 ...ardinalityAggregatorColumnSelectorStrategy.java | 12 ++++----
 ...ardinalityAggregatorColumnSelectorStrategy.java | 12 ++++----
 .../aggregation/first/DoubleFirstAggregator.java   | 12 ++++----
 .../first/DoubleFirstAggregatorFactory.java        | 12 ++++----
 .../first/DoubleFirstBufferAggregator.java         | 12 ++++----
 .../aggregation/first/FloatFirstAggregator.java    | 12 ++++----
 .../first/FloatFirstAggregatorFactory.java         | 12 ++++----
 .../first/FloatFirstBufferAggregator.java          | 12 ++++----
 .../aggregation/first/LongFirstAggregator.java     | 12 ++++----
 .../first/LongFirstAggregatorFactory.java          | 12 ++++----
 .../first/LongFirstBufferAggregator.java           | 12 ++++----
 .../HyperUniqueFinalizingPostAggregator.java       | 12 ++++----
 .../hyperloglog/HyperUniquesAggregator.java        | 12 ++++----
 .../hyperloglog/HyperUniquesAggregatorFactory.java | 12 ++++----
 .../hyperloglog/HyperUniquesBufferAggregator.java  | 12 ++++----
 .../aggregation/hyperloglog/HyperUniquesSerde.java | 12 ++++----
 .../hyperloglog/PreComputedHyperUniquesSerde.java  | 12 ++++----
 .../aggregation/last/DoubleLastAggregator.java     | 12 ++++----
 .../last/DoubleLastAggregatorFactory.java          | 12 ++++----
 .../last/DoubleLastBufferAggregator.java           | 12 ++++----
 .../aggregation/last/FloatLastAggregator.java      | 12 ++++----
 .../last/FloatLastAggregatorFactory.java           | 12 ++++----
 .../last/FloatLastBufferAggregator.java            | 12 ++++----
 .../query/aggregation/last/LongLastAggregator.java | 12 ++++----
 .../last/LongLastAggregatorFactory.java            | 12 ++++----
 .../aggregation/last/LongLastBufferAggregator.java | 12 ++++----
 .../aggregation/post/ArithmeticPostAggregator.java | 12 ++++----
 .../aggregation/post/ConstantPostAggregator.java   | 12 ++++----
 .../post/DoubleGreatestPostAggregator.java         | 12 ++++----
 .../post/DoubleLeastPostAggregator.java            | 12 ++++----
 .../aggregation/post/ExpressionPostAggregator.java | 12 ++++----
 .../post/FieldAccessPostAggregator.java            | 12 ++++----
 .../post/FinalizingFieldAccessPostAggregator.java  | 12 ++++----
 .../aggregation/post/JavaScriptPostAggregator.java | 12 ++++----
 .../post/LongGreatestPostAggregator.java           | 12 ++++----
 .../aggregation/post/LongLeastPostAggregator.java  | 12 ++++----
 .../query/aggregation/post/PostAggregatorIds.java  | 12 ++++----
 .../java/io/druid/query/cache/CacheKeyBuilder.java | 12 ++++----
 .../DataSourceMetadataQuery.java                   | 12 ++++----
 .../DataSourceMetadataQueryRunnerFactory.java      | 12 ++++----
 .../DataSourceMetadataResultValue.java             | 12 ++++----
 .../DataSourceQueryQueryToolChest.java             | 12 ++++----
 .../query/dimension/BaseFilteredDimensionSpec.java | 12 ++++----
 .../query/dimension/ColumnSelectorStrategy.java    | 12 ++++----
 .../dimension/ColumnSelectorStrategyFactory.java   | 12 ++++----
 .../query/dimension/DefaultDimensionSpec.java      | 12 ++++----
 .../io/druid/query/dimension/DimensionSpec.java    | 12 ++++----
 .../query/dimension/ExtractionDimensionSpec.java   | 12 ++++----
 .../ForwardingFilteredDimensionSelector.java       | 12 ++++----
 .../druid/query/dimension/LegacyDimensionSpec.java | 12 ++++----
 .../query/dimension/ListFilteredDimensionSpec.java | 12 ++++----
 .../PredicateFilteredDimensionSelector.java        | 12 ++++----
 .../dimension/RegexFilteredDimensionSpec.java      | 12 ++++----
 .../java/io/druid/query/expression/ExprUtils.java  | 12 ++++----
 .../query/expression/GuiceExprMacroTable.java      | 12 ++++----
 .../io/druid/query/expression/LikeExprMacro.java   | 12 ++++----
 .../query/expression/RegexpExtractExprMacro.java   | 12 ++++----
 .../query/expression/TimestampCeilExprMacro.java   | 12 ++++----
 .../expression/TimestampExtractExprMacro.java      | 12 ++++----
 .../query/expression/TimestampFloorExprMacro.java  | 12 ++++----
 .../query/expression/TimestampFormatExprMacro.java | 12 ++++----
 .../query/expression/TimestampParseExprMacro.java  | 12 ++++----
 .../query/expression/TimestampShiftExprMacro.java  | 12 ++++----
 .../io/druid/query/expression/TrimExprMacro.java   | 12 ++++----
 .../druid/query/extraction/BucketExtractionFn.java | 12 ++++----
 .../query/extraction/CascadeExtractionFn.java      | 12 ++++----
 .../io/druid/query/extraction/DimExtractionFn.java | 12 ++++----
 .../query/extraction/ExtractionCacheHelper.java    | 12 ++++----
 .../io/druid/query/extraction/ExtractionFn.java    | 12 ++++----
 .../query/extraction/FunctionalExtraction.java     | 12 ++++----
 .../query/extraction/IdentityExtractionFn.java     | 12 ++++----
 .../query/extraction/JavaScriptExtractionFn.java   | 12 ++++----
 .../druid/query/extraction/LowerExtractionFn.java  | 12 ++++----
 .../druid/query/extraction/MapLookupExtractor.java | 12 ++++----
 .../query/extraction/MatchingDimExtractionFn.java  | 12 ++++----
 .../query/extraction/RegexDimExtractionFn.java     | 12 ++++----
 .../extraction/SearchQuerySpecDimExtractionFn.java | 12 ++++----
 .../query/extraction/StringFormatExtractionFn.java | 12 ++++----
 .../druid/query/extraction/StrlenExtractionFn.java | 12 ++++----
 .../query/extraction/SubstringDimExtractionFn.java | 12 ++++----
 .../query/extraction/TimeDimExtractionFn.java      | 12 ++++----
 .../query/extraction/TimeFormatExtractionFn.java   | 12 ++++----
 .../druid/query/extraction/UpperExtractionFn.java  | 12 ++++----
 .../java/io/druid/query/filter/AndDimFilter.java   | 12 ++++----
 .../io/druid/query/filter/BitmapIndexSelector.java | 12 ++++----
 .../java/io/druid/query/filter/BooleanFilter.java  | 12 ++++----
 .../java/io/druid/query/filter/BoundDimFilter.java | 12 ++++----
 .../query/filter/ColumnComparisonDimFilter.java    | 12 ++++----
 .../main/java/io/druid/query/filter/DimFilter.java | 12 ++++----
 .../java/io/druid/query/filter/DimFilterUtils.java | 12 ++++----
 .../java/io/druid/query/filter/DimFilters.java     | 12 ++++----
 .../DoubleValueMatcherColumnSelectorStrategy.java  | 12 ++++----
 .../druid/query/filter/DruidDoublePredicate.java   | 12 ++++----
 .../io/druid/query/filter/DruidFloatPredicate.java | 12 ++++----
 .../io/druid/query/filter/DruidLongPredicate.java  | 12 ++++----
 .../druid/query/filter/DruidPredicateFactory.java  | 12 ++++----
 .../io/druid/query/filter/ExpressionDimFilter.java | 12 ++++----
 .../io/druid/query/filter/ExtractionDimFilter.java | 12 ++++----
 .../main/java/io/druid/query/filter/Filter.java    | 12 ++++----
 .../FloatValueMatcherColumnSelectorStrategy.java   | 12 ++++----
 .../java/io/druid/query/filter/InDimFilter.java    | 12 ++++----
 .../io/druid/query/filter/IntervalDimFilter.java   | 12 ++++----
 .../io/druid/query/filter/JavaScriptDimFilter.java | 12 ++++----
 .../java/io/druid/query/filter/LikeDimFilter.java  | 12 ++++----
 .../LongValueMatcherColumnSelectorStrategy.java    | 12 ++++----
 .../java/io/druid/query/filter/NotDimFilter.java   | 12 ++++----
 .../java/io/druid/query/filter/OrDimFilter.java    | 12 ++++----
 .../java/io/druid/query/filter/RegexDimFilter.java | 12 ++++----
 .../query/filter/RowOffsetMatcherFactory.java      | 12 ++++----
 .../druid/query/filter/SearchQueryDimFilter.java   | 12 ++++----
 .../io/druid/query/filter/SelectorDimFilter.java   | 12 ++++----
 .../io/druid/query/filter/SpatialDimFilter.java    | 12 ++++----
 .../StringValueMatcherColumnSelectorStrategy.java  | 12 ++++----
 .../java/io/druid/query/filter/TrueDimFilter.java  | 12 ++++----
 .../java/io/druid/query/filter/ValueGetter.java    | 12 ++++----
 .../java/io/druid/query/filter/ValueMatcher.java   | 12 ++++----
 .../filter/ValueMatcherColumnSelectorStrategy.java | 12 ++++----
 .../ValueMatcherColumnSelectorStrategyFactory.java | 12 ++++----
 .../query/groupby/DefaultGroupByQueryMetrics.java  | 12 ++++----
 .../groupby/DefaultGroupByQueryMetricsFactory.java | 12 ++++----
 .../java/io/druid/query/groupby/GroupByQuery.java  | 12 ++++----
 .../io/druid/query/groupby/GroupByQueryConfig.java | 12 ++++----
 .../io/druid/query/groupby/GroupByQueryEngine.java | 12 ++++----
 .../io/druid/query/groupby/GroupByQueryHelper.java | 12 ++++----
 .../druid/query/groupby/GroupByQueryMetrics.java   | 12 ++++----
 .../query/groupby/GroupByQueryMetricsFactory.java  | 12 ++++----
 .../query/groupby/GroupByQueryQueryToolChest.java  | 12 ++++----
 .../query/groupby/GroupByQueryRunnerFactory.java   | 12 ++++----
 .../groupby/RowBasedColumnSelectorFactory.java     | 12 ++++----
 .../epinephelinae/AbstractBufferHashGrouper.java   | 12 ++++----
 .../groupby/epinephelinae/AggregateResult.java     | 12 ++++----
 .../groupby/epinephelinae/BufferArrayGrouper.java  | 12 ++++----
 .../groupby/epinephelinae/BufferHashGrouper.java   | 12 ++++----
 .../groupby/epinephelinae/ByteBufferHashTable.java | 12 ++++----
 .../groupby/epinephelinae/ByteBufferIntList.java   | 12 ++++----
 .../epinephelinae/ByteBufferMinMaxOffsetHeap.java  | 12 ++++----
 .../epinephelinae/CloseableGrouperIterator.java    | 12 ++++----
 .../groupby/epinephelinae/ConcurrentGrouper.java   | 12 ++++----
 .../groupby/epinephelinae/GroupByBinaryFnV2.java   | 12 ++++----
 .../epinephelinae/GroupByMergingQueryRunnerV2.java | 12 ++++----
 .../epinephelinae/GroupByQueryEngineV2.java        | 12 ++++----
 .../groupby/epinephelinae/GroupByRowProcessor.java | 12 ++++----
 .../druid/query/groupby/epinephelinae/Grouper.java | 12 ++++----
 .../query/groupby/epinephelinae/Groupers.java      | 12 ++++----
 .../query/groupby/epinephelinae/IntGrouper.java    | 12 ++++----
 .../epinephelinae/LimitedBufferHashGrouper.java    | 12 ++++----
 .../epinephelinae/LimitedTemporaryStorage.java     | 12 ++++----
 .../groupby/epinephelinae/ParallelCombiner.java    | 12 ++++----
 .../epinephelinae/RowBasedGrouperHelper.java       | 12 ++++----
 .../epinephelinae/RowBasedKeySerdeHelper.java      | 12 ++++----
 .../groupby/epinephelinae/SpillingGrouper.java     | 12 ++++----
 .../epinephelinae/StreamingMergeSortedGrouper.java | 12 ++++----
 .../TemporaryStorageFullException.java             | 12 ++++----
 ...uildingStringGroupByColumnSelectorStrategy.java | 12 ++++----
 .../DoubleGroupByColumnSelectorStrategy.java       | 12 ++++----
 .../column/FloatGroupByColumnSelectorStrategy.java | 12 ++++----
 .../column/GroupByColumnSelectorPlus.java          | 12 ++++----
 .../column/GroupByColumnSelectorStrategy.java      | 12 ++++----
 .../column/LongGroupByColumnSelectorStrategy.java  | 12 ++++----
 .../StringGroupByColumnSelectorStrategy.java       | 12 ++++----
 .../query/groupby/having/AlwaysHavingSpec.java     | 12 ++++----
 .../druid/query/groupby/having/AndHavingSpec.java  | 12 ++++----
 .../druid/query/groupby/having/BaseHavingSpec.java | 12 ++++----
 .../query/groupby/having/DimFilterHavingSpec.java  | 12 ++++----
 .../having/DimensionSelectorHavingSpec.java        | 12 ++++----
 .../query/groupby/having/EqualToHavingSpec.java    | 12 ++++----
 .../groupby/having/GreaterThanHavingSpec.java      | 12 ++++----
 .../io/druid/query/groupby/having/HavingSpec.java  | 12 ++++----
 .../groupby/having/HavingSpecMetricComparator.java | 12 ++++----
 .../query/groupby/having/LessThanHavingSpec.java   | 12 ++++----
 .../query/groupby/having/NeverHavingSpec.java      | 12 ++++----
 .../druid/query/groupby/having/NotHavingSpec.java  | 12 ++++----
 .../druid/query/groupby/having/OrHavingSpec.java   | 12 ++++----
 .../query/groupby/orderby/DefaultLimitSpec.java    | 12 ++++----
 .../io/druid/query/groupby/orderby/LimitSpec.java  | 12 ++++----
 .../druid/query/groupby/orderby/NoopLimitSpec.java | 12 ++++----
 .../query/groupby/orderby/OrderByColumnSpec.java   | 12 ++++----
 .../druid/query/groupby/orderby/TopNSequence.java  | 12 ++++----
 .../groupby/resource/GroupByQueryResource.java     | 12 ++++----
 .../query/groupby/strategy/GroupByStrategy.java    | 12 ++++----
 .../groupby/strategy/GroupByStrategySelector.java  | 12 ++++----
 .../query/groupby/strategy/GroupByStrategyV1.java  | 12 ++++----
 .../query/groupby/strategy/GroupByStrategyV2.java  | 12 ++++----
 .../java/io/druid/query/lookup/LookupBean.java     | 12 ++++----
 .../java/io/druid/query/lookup/LookupConfig.java   | 12 ++++----
 .../io/druid/query/lookup/LookupExtractionFn.java  | 12 ++++----
 .../io/druid/query/lookup/LookupExtractor.java     | 12 ++++----
 .../druid/query/lookup/LookupExtractorFactory.java | 12 ++++----
 .../lookup/LookupExtractorFactoryContainer.java    | 12 ++++----
 .../query/lookup/LookupIntrospectHandler.java      | 12 ++++----
 .../io/druid/query/lookup/LookupSnapshotTaker.java | 12 ++++----
 .../java/io/druid/query/lookup/LookupsState.java   | 12 ++++----
 .../io/druid/query/metadata/SegmentAnalyzer.java   | 12 ++++----
 .../query/metadata/SegmentMetadataQueryConfig.java | 12 ++++----
 .../SegmentMetadataQueryQueryToolChest.java        | 12 ++++----
 .../SegmentMetadataQueryRunnerFactory.java         | 12 ++++----
 .../metadata/metadata/AllColumnIncluderator.java   | 12 ++++----
 .../query/metadata/metadata/ColumnAnalysis.java    | 12 ++++----
 .../metadata/metadata/ColumnIncluderator.java      | 12 ++++----
 .../metadata/metadata/ListColumnIncluderator.java  | 12 ++++----
 .../metadata/metadata/NoneColumnIncluderator.java  | 12 ++++----
 .../query/metadata/metadata/SegmentAnalysis.java   | 12 ++++----
 .../metadata/metadata/SegmentMetadataQuery.java    | 12 ++++----
 .../monomorphicprocessing/CalledFromHotLoop.java   | 12 ++++----
 .../query/monomorphicprocessing/HotLoopCallee.java | 12 ++++----
 .../RuntimeShapeInspector.java                     | 12 ++++----
 .../SpecializationService.java                     | 12 ++++----
 .../monomorphicprocessing/SpecializationState.java | 12 ++++----
 .../monomorphicprocessing/StringRuntimeShape.java  | 12 ++++----
 .../io/druid/query/ordering/StringComparator.java  | 12 ++++----
 .../io/druid/query/ordering/StringComparators.java | 12 ++++----
 .../main/java/io/druid/query/scan/ScanQuery.java   | 12 ++++----
 .../java/io/druid/query/scan/ScanQueryConfig.java  | 12 ++++----
 .../java/io/druid/query/scan/ScanQueryEngine.java  | 12 ++++----
 .../query/scan/ScanQueryLimitRowIterator.java      | 12 ++++----
 .../druid/query/scan/ScanQueryQueryToolChest.java  | 12 ++++----
 .../druid/query/scan/ScanQueryRunnerFactory.java   | 12 ++++----
 .../java/io/druid/query/scan/ScanResultValue.java  | 12 ++++----
 .../io/druid/query/search/AllSearchQuerySpec.java  | 12 ++++----
 .../java/io/druid/query/search/AutoStrategy.java   | 12 ++++----
 .../query/search/BySegmentSearchResultValue.java   | 12 ++++----
 .../query/search/ConciseBitmapDecisionHelper.java  | 12 ++++----
 .../query/search/ContainsSearchQuerySpec.java      | 12 ++++----
 .../io/druid/query/search/CursorOnlyStrategy.java  | 12 ++++----
 .../query/search/DefaultSearchQueryMetrics.java    | 12 ++++----
 .../search/DefaultSearchQueryMetricsFactory.java   | 12 ++++----
 .../query/search/FragmentSearchQuerySpec.java      | 12 ++++----
 .../search/InsensitiveContainsSearchQuerySpec.java | 12 ++++----
 .../druid/query/search/RegexSearchQuerySpec.java   | 12 ++++----
 .../query/search/RoaringBitmapDecisionHelper.java  | 12 ++++----
 .../java/io/druid/query/search/SearchBinaryFn.java | 12 ++++----
 .../main/java/io/druid/query/search/SearchHit.java | 12 ++++----
 .../java/io/druid/query/search/SearchQuery.java    | 12 ++++----
 .../io/druid/query/search/SearchQueryConfig.java   | 12 ++++----
 .../query/search/SearchQueryDecisionHelper.java    | 12 ++++----
 .../io/druid/query/search/SearchQueryExecutor.java | 12 ++++----
 .../io/druid/query/search/SearchQueryMetrics.java  | 12 ++++----
 .../query/search/SearchQueryMetricsFactory.java    | 12 ++++----
 .../query/search/SearchQueryQueryToolChest.java    | 12 ++++----
 .../io/druid/query/search/SearchQueryRunner.java   | 12 ++++----
 .../query/search/SearchQueryRunnerFactory.java     | 12 ++++----
 .../io/druid/query/search/SearchQuerySpec.java     | 12 ++++----
 .../io/druid/query/search/SearchResultValue.java   | 12 ++++----
 .../java/io/druid/query/search/SearchSortSpec.java | 12 ++++----
 .../java/io/druid/query/search/SearchStrategy.java | 12 ++++----
 .../druid/query/search/SearchStrategySelector.java | 12 ++++----
 .../io/druid/query/search/UseIndexesStrategy.java  | 12 ++++----
 .../query/select/DefaultSelectQueryMetrics.java    | 12 ++++----
 .../select/DefaultSelectQueryMetricsFactory.java   | 12 ++++----
 .../java/io/druid/query/select/EventHolder.java    | 12 ++++----
 .../java/io/druid/query/select/PagingOffset.java   | 12 ++++----
 .../java/io/druid/query/select/PagingSpec.java     | 12 ++++----
 .../java/io/druid/query/select/SelectBinaryFn.java | 12 ++++----
 .../java/io/druid/query/select/SelectQuery.java    | 12 ++++----
 .../io/druid/query/select/SelectQueryConfig.java   | 12 ++++----
 .../io/druid/query/select/SelectQueryEngine.java   | 12 ++++----
 .../io/druid/query/select/SelectQueryMetrics.java  | 12 ++++----
 .../query/select/SelectQueryMetricsFactory.java    | 12 ++++----
 .../query/select/SelectQueryQueryToolChest.java    | 12 ++++----
 .../query/select/SelectQueryRunnerFactory.java     | 12 ++++----
 .../io/druid/query/select/SelectResultValue.java   | 12 ++++----
 .../query/select/SelectResultValueBuilder.java     | 12 ++++----
 .../io/druid/query/spec/LegacySegmentSpec.java     | 12 ++++----
 .../query/spec/MultipleIntervalSegmentSpec.java    | 12 ++++----
 .../query/spec/MultipleSpecificSegmentSpec.java    | 12 ++++----
 .../java/io/druid/query/spec/QuerySegmentSpec.java | 12 ++++----
 .../query/spec/SpecificSegmentQueryRunner.java     | 12 ++++----
 .../io/druid/query/spec/SpecificSegmentSpec.java   | 12 ++++----
 .../query/timeboundary/TimeBoundaryQuery.java      | 12 ++++----
 .../TimeBoundaryQueryQueryToolChest.java           | 12 ++++----
 .../TimeBoundaryQueryRunnerFactory.java            | 12 ++++----
 .../timeboundary/TimeBoundaryResultValue.java      | 12 ++++----
 .../timeseries/DefaultTimeseriesQueryMetrics.java  | 12 ++++----
 .../DefaultTimeseriesQueryMetricsFactory.java      | 12 ++++----
 .../druid/query/timeseries/TimeseriesBinaryFn.java | 12 ++++----
 .../io/druid/query/timeseries/TimeseriesQuery.java | 12 ++++----
 .../query/timeseries/TimeseriesQueryEngine.java    | 12 ++++----
 .../query/timeseries/TimeseriesQueryMetrics.java   | 12 ++++----
 .../timeseries/TimeseriesQueryMetricsFactory.java  | 12 ++++----
 .../timeseries/TimeseriesQueryQueryToolChest.java  | 12 ++++----
 .../timeseries/TimeseriesQueryRunnerFactory.java   | 12 ++++----
 .../query/timeseries/TimeseriesResultBuilder.java  | 12 ++++----
 .../query/timeseries/TimeseriesResultValue.java    | 12 ++++----
 .../topn/AggregateTopNMetricFirstAlgorithm.java    | 12 ++++----
 .../query/topn/AlphaNumericTopNMetricSpec.java     | 12 ++++----
 .../io/druid/query/topn/BaseTopNAlgorithm.java     | 12 ++++----
 .../druid/query/topn/BySegmentTopNResultValue.java | 12 ++++----
 .../druid/query/topn/DefaultTopNQueryMetrics.java  | 12 ++++----
 .../query/topn/DefaultTopNQueryMetricsFactory.java | 12 ++++----
 .../query/topn/DimExtractionTopNAlgorithm.java     | 12 ++++----
 .../java/io/druid/query/topn/DimValHolder.java     | 12 ++++----
 .../topn/DimensionAndMetricValueExtractor.java     | 12 ++++----
 .../druid/query/topn/DimensionTopNMetricSpec.java  | 12 ++++----
 .../query/topn/Generic1AggPooledTopNScanner.java   | 12 ++++----
 .../Generic1AggPooledTopNScannerPrototype.java     | 12 ++++----
 .../query/topn/Generic2AggPooledTopNScanner.java   | 12 ++++----
 .../Generic2AggPooledTopNScannerPrototype.java     | 12 ++++----
 .../topn/Historical1AggPooledTopNScanner.java      | 12 ++++----
 ...1SimpleDoubleAggPooledTopNScannerPrototype.java | 12 ++++----
 ...1SimpleDoubleAggPooledTopNScannerPrototype.java | 12 ++++----
 .../druid/query/topn/InvertedTopNMetricSpec.java   | 12 ++++----
 .../io/druid/query/topn/LegacyTopNMetricSpec.java  | 12 ++++----
 .../query/topn/LexicographicTopNMetricSpec.java    | 12 ++++----
 .../io/druid/query/topn/NumericTopNMetricSpec.java | 12 ++++----
 .../io/druid/query/topn/PooledTopNAlgorithm.java   | 12 ++++----
 .../query/topn/TimeExtractionTopNAlgorithm.java    | 12 ++++----
 .../java/io/druid/query/topn/TopNAlgorithm.java    | 12 ++++----
 .../io/druid/query/topn/TopNAlgorithmSelector.java | 12 ++++----
 .../java/io/druid/query/topn/TopNBinaryFn.java     | 12 ++++----
 .../query/topn/TopNLexicographicResultBuilder.java | 12 ++++----
 .../main/java/io/druid/query/topn/TopNMapFn.java   | 12 ++++----
 .../java/io/druid/query/topn/TopNMetricSpec.java   | 12 ++++----
 .../io/druid/query/topn/TopNMetricSpecBuilder.java | 12 ++++----
 .../druid/query/topn/TopNNumericResultBuilder.java | 12 ++++----
 .../main/java/io/druid/query/topn/TopNParams.java  | 12 ++++----
 .../main/java/io/druid/query/topn/TopNQuery.java   | 12 ++++----
 .../java/io/druid/query/topn/TopNQueryBuilder.java | 12 ++++----
 .../java/io/druid/query/topn/TopNQueryConfig.java  | 12 ++++----
 .../java/io/druid/query/topn/TopNQueryEngine.java  | 12 ++++----
 .../java/io/druid/query/topn/TopNQueryMetrics.java | 12 ++++----
 .../druid/query/topn/TopNQueryMetricsFactory.java  | 12 ++++----
 .../druid/query/topn/TopNQueryQueryToolChest.java  | 12 ++++----
 .../druid/query/topn/TopNQueryRunnerFactory.java   | 12 ++++----
 .../io/druid/query/topn/TopNResultBuilder.java     | 12 ++++----
 .../java/io/druid/query/topn/TopNResultValue.java  | 12 ++++----
 .../main/java/io/druid/query/topn/TopNUtils.java   | 12 ++++----
 .../types/NumericTopNColumnSelectorStrategy.java   | 12 ++++----
 .../types/StringTopNColumnSelectorStrategy.java    | 12 ++++----
 .../topn/types/TopNColumnSelectorStrategy.java     | 12 ++++----
 .../types/TopNColumnSelectorStrategyFactory.java   | 12 ++++----
 .../main/java/io/druid/segment/AbstractIndex.java  | 12 ++++----
 .../java/io/druid/segment/AbstractSegment.java     | 12 ++++----
 .../segment/BaseDoubleColumnValueSelector.java     | 12 ++++----
 .../segment/BaseFloatColumnValueSelector.java      | 12 ++++----
 .../druid/segment/BaseLongColumnValueSelector.java | 12 ++++----
 .../segment/BaseNullableColumnValueSelector.java   | 12 ++++----
 .../segment/BaseObjectColumnValueSelector.java     | 12 ++++----
 .../io/druid/segment/BaseProgressIndicator.java    | 12 ++++----
 .../main/java/io/druid/segment/BitmapOffset.java   | 12 ++++----
 .../main/java/io/druid/segment/Capabilities.java   | 12 ++++----
 .../main/java/io/druid/segment/ColumnSelector.java | 12 ++++----
 .../segment/ColumnSelectorBitmapIndexSelector.java | 12 ++++----
 .../io/druid/segment/ColumnSelectorFactory.java    | 12 ++++----
 .../java/io/druid/segment/ColumnValueSelector.java | 12 ++++----
 .../java/io/druid/segment/CompressedPools.java     | 12 ++++----
 .../druid/segment/ConstantColumnValueSelector.java | 12 ++++----
 .../druid/segment/ConstantDimensionSelector.java   | 12 ++++----
 .../src/main/java/io/druid/segment/Cursor.java     | 12 ++++----
 .../main/java/io/druid/segment/CursorFactory.java  | 12 ++++----
 .../java/io/druid/segment/DimensionHandler.java    | 12 ++++----
 .../io/druid/segment/DimensionHandlerUtils.java    | 12 ++++----
 .../java/io/druid/segment/DimensionIndexer.java    | 12 ++++----
 .../java/io/druid/segment/DimensionMerger.java     | 12 ++++----
 .../java/io/druid/segment/DimensionMergerV9.java   | 12 ++++----
 .../java/io/druid/segment/DimensionSelector.java   | 12 ++++----
 .../io/druid/segment/DimensionSelectorUtils.java   | 12 ++++----
 .../io/druid/segment/DoubleColumnSelector.java     | 12 ++++----
 .../io/druid/segment/DoubleColumnSerializer.java   | 12 ++++----
 .../io/druid/segment/DoubleColumnSerializerV2.java | 12 ++++----
 .../io/druid/segment/DoubleDimensionHandler.java   | 12 ++++----
 .../io/druid/segment/DoubleDimensionIndexer.java   | 12 ++++----
 .../io/druid/segment/DoubleDimensionMergerV9.java  | 12 ++++----
 .../segment/DoubleWrappingDimensionSelector.java   | 12 ++++----
 .../main/java/io/druid/segment/FilteredOffset.java | 12 ++++----
 .../java/io/druid/segment/FloatColumnSelector.java | 12 ++++----
 .../io/druid/segment/FloatColumnSerializer.java    | 12 ++++----
 .../io/druid/segment/FloatColumnSerializerV2.java  | 12 ++++----
 .../io/druid/segment/FloatDimensionHandler.java    | 12 ++++----
 .../io/druid/segment/FloatDimensionIndexer.java    | 12 ++++----
 .../io/druid/segment/FloatDimensionMergerV9.java   | 12 ++++----
 .../segment/FloatWrappingDimensionSelector.java    | 12 ++++----
 .../io/druid/segment/ForwardingRowIterator.java    | 12 ++++----
 .../io/druid/segment/GenericColumnSerializer.java  | 12 ++++----
 .../src/main/java/io/druid/segment/IdLookup.java   | 12 ++++----
 .../io/druid/segment/IncrementalIndexSegment.java  | 12 ++++----
 .../src/main/java/io/druid/segment/IndexIO.java    | 12 ++++----
 .../main/java/io/druid/segment/IndexMerger.java    | 12 ++++----
 .../main/java/io/druid/segment/IndexMergerV9.java  | 12 ++++----
 .../src/main/java/io/druid/segment/IndexSpec.java  | 12 ++++----
 .../java/io/druid/segment/IndexableAdapter.java    | 12 ++++----
 .../java/io/druid/segment/IntIteratorUtils.java    | 12 ++++----
 .../main/java/io/druid/segment/IntListUtils.java   | 12 ++++----
 .../java/io/druid/segment/LongColumnSelector.java  | 12 ++++----
 .../io/druid/segment/LongColumnSerializer.java     | 12 ++++----
 .../io/druid/segment/LongColumnSerializerV2.java   | 12 ++++----
 .../io/druid/segment/LongDimensionHandler.java     | 12 ++++----
 .../io/druid/segment/LongDimensionIndexer.java     | 12 ++++----
 .../io/druid/segment/LongDimensionMergerV9.java    | 12 ++++----
 .../segment/LongWrappingDimensionSelector.java     | 12 ++++----
 .../main/java/io/druid/segment/MMappedIndex.java   | 12 ++++----
 .../java/io/druid/segment/MergingRowIterator.java  | 12 ++++----
 .../src/main/java/io/druid/segment/Metadata.java   | 12 ++++----
 .../main/java/io/druid/segment/MetricHolder.java   | 12 ++++----
 .../io/druid/segment/NilColumnValueSelector.java   | 12 ++++----
 .../io/druid/segment/NullDimensionSelector.java    | 12 ++++----
 .../io/druid/segment/NumericDimensionMergerV9.java | 12 ++++----
 .../io/druid/segment/ObjectColumnSelector.java     | 12 ++++----
 .../java/io/druid/segment/ProgressIndicator.java   | 12 ++++----
 .../main/java/io/druid/segment/QueryableIndex.java | 12 ++++----
 .../QueryableIndexColumnSelectorFactory.java       | 12 ++++----
 .../segment/QueryableIndexIndexableAdapter.java    | 12 ++++----
 .../io/druid/segment/QueryableIndexSegment.java    | 12 ++++----
 .../segment/QueryableIndexStorageAdapter.java      | 12 ++++----
 .../io/druid/segment/ReferenceCountingSegment.java | 12 ++++----
 .../segment/RowCombiningTimeAndDimsIterator.java   | 12 ++++----
 .../io/druid/segment/RowFilteringIndexAdapter.java | 12 ++++----
 .../main/java/io/druid/segment/RowIterator.java    | 12 ++++----
 .../main/java/io/druid/segment/RowNumCounter.java  | 12 ++++----
 .../src/main/java/io/druid/segment/RowPointer.java | 12 ++++----
 .../src/main/java/io/druid/segment/Segment.java    | 12 ++++----
 .../io/druid/segment/SegmentMissingException.java  | 12 ++++----
 .../druid/segment/SegmentValidationException.java  | 12 ++++----
 .../io/druid/segment/SimpleAscendingOffset.java    | 12 ++++----
 .../io/druid/segment/SimpleDescendingOffset.java   | 12 ++++----
 .../io/druid/segment/SimpleQueryableIndex.java     | 12 ++++----
 .../druid/segment/SingleScanTimeDimSelector.java   | 12 ++++----
 .../main/java/io/druid/segment/StorageAdapter.java | 12 ++++----
 .../io/druid/segment/StringDimensionHandler.java   | 12 ++++----
 .../io/druid/segment/StringDimensionIndexer.java   | 12 ++++----
 .../io/druid/segment/StringDimensionMergerV9.java  | 12 ++++----
 .../java/io/druid/segment/TimeAndDimsIterator.java | 12 ++++----
 .../java/io/druid/segment/TimeAndDimsPointer.java  | 12 ++++----
 .../io/druid/segment/TransformableRowIterator.java | 12 ++++----
 .../main/java/io/druid/segment/VirtualColumn.java  | 12 ++++----
 .../main/java/io/druid/segment/VirtualColumns.java | 12 ++++----
 .../java/io/druid/segment/column/BaseColumn.java   | 12 ++++----
 .../java/io/druid/segment/column/BitmapIndex.java  | 12 ++++----
 .../main/java/io/druid/segment/column/Column.java  | 12 ++++----
 .../io/druid/segment/column/ColumnBuilder.java     | 12 ++++----
 .../druid/segment/column/ColumnCapabilities.java   | 12 ++++----
 .../segment/column/ColumnCapabilitiesImpl.java     | 12 ++++----
 .../java/io/druid/segment/column/ColumnConfig.java | 12 ++++----
 .../io/druid/segment/column/ColumnDescriptor.java  | 12 ++++----
 .../io/druid/segment/column/ComplexColumn.java     | 12 ++++----
 .../segment/column/DictionaryEncodedColumn.java    | 12 ++++----
 .../io/druid/segment/column/DoublesColumn.java     | 12 ++++----
 .../segment/column/DoublesColumnWithNulls.java     | 12 ++++----
 .../java/io/druid/segment/column/FloatsColumn.java | 12 ++++----
 .../segment/column/FloatsColumnWithNulls.java      | 12 ++++----
 .../io/druid/segment/column/GenericColumn.java     | 12 ++++----
 .../druid/segment/column/IndexedComplexColumn.java | 12 ++++----
 .../java/io/druid/segment/column/LongsColumn.java  | 12 ++++----
 .../druid/segment/column/LongsColumnWithNulls.java | 12 ++++----
 .../java/io/druid/segment/column/SimpleColumn.java | 12 ++++----
 .../column/SimpleDictionaryEncodedColumn.java      | 12 ++++----
 .../java/io/druid/segment/column/SpatialIndex.java | 12 ++++----
 .../java/io/druid/segment/column/ValueType.java    | 12 ++++----
 .../druid/segment/data/ArrayBasedIndexedInts.java  | 12 ++++----
 .../java/io/druid/segment/data/ArrayIndexed.java   | 12 ++++----
 .../java/io/druid/segment/data/BitmapSerde.java    | 12 ++++----
 .../io/druid/segment/data/BitmapSerdeFactory.java  | 12 ++++----
 .../java/io/druid/segment/data/BitmapValues.java   | 12 ++++----
 .../data/BlockLayoutColumnarDoublesSerializer.java | 12 ++++----
 .../data/BlockLayoutColumnarDoublesSupplier.java   | 12 ++++----
 .../data/BlockLayoutColumnarFloatsSerializer.java  | 12 ++++----
 .../data/BlockLayoutColumnarFloatsSupplier.java    | 12 ++++----
 .../data/BlockLayoutColumnarLongsSerializer.java   | 12 ++++----
 .../data/BlockLayoutColumnarLongsSupplier.java     | 12 ++++----
 .../io/druid/segment/data/ByteBufferWriter.java    | 12 ++++----
 .../segment/data/CacheableObjectStrategy.java      | 12 ++++----
 .../java/io/druid/segment/data/CachingIndexed.java | 12 ++++----
 .../io/druid/segment/data/ColumnarDoubles.java     | 12 ++++----
 .../segment/data/ColumnarDoublesSerializer.java    | 12 ++++----
 .../java/io/druid/segment/data/ColumnarFloats.java | 12 ++++----
 .../segment/data/ColumnarFloatsSerializer.java     | 12 ++++----
 .../java/io/druid/segment/data/ColumnarInts.java   | 12 ++++----
 .../druid/segment/data/ColumnarIntsSerializer.java | 12 ++++----
 .../java/io/druid/segment/data/ColumnarLongs.java  | 12 ++++----
 .../segment/data/ColumnarLongsSerializer.java      | 12 ++++----
 .../io/druid/segment/data/ColumnarMultiInts.java   | 12 ++++----
 .../segment/data/ColumnarMultiIntsSerializer.java  | 12 ++++----
 .../data/CompressedColumnarDoublesSuppliers.java   | 12 ++++----
 .../data/CompressedColumnarFloatsSupplier.java     | 12 ++++----
 .../data/CompressedColumnarIntsSerializer.java     | 12 ++++----
 .../data/CompressedColumnarIntsSupplier.java       | 12 ++++----
 .../data/CompressedColumnarLongsSupplier.java      | 12 ++++----
 .../CompressedVSizeColumnarIntsSerializer.java     | 12 ++++----
 .../data/CompressedVSizeColumnarIntsSupplier.java  | 12 ++++----
 .../CompressedVSizeColumnarMultiIntsSupplier.java  | 12 ++++----
 .../io/druid/segment/data/CompressionFactory.java  | 12 ++++----
 .../io/druid/segment/data/CompressionStrategy.java | 12 ++++----
 .../segment/data/ConciseBitmapSerdeFactory.java    | 12 ++++----
 .../DecompressingByteBufferObjectStrategy.java     | 12 ++++----
 .../segment/data/DeltaLongEncodingReader.java      | 12 ++++----
 .../segment/data/DeltaLongEncodingWriter.java      | 12 ++++----
 .../EntireLayoutColumnarDoublesSerializer.java     | 12 ++++----
 .../data/EntireLayoutColumnarDoublesSupplier.java  | 12 ++++----
 .../data/EntireLayoutColumnarFloatsSerializer.java | 12 ++++----
 .../data/EntireLayoutColumnarFloatsSupplier.java   | 12 ++++----
 .../data/EntireLayoutColumnarLongsSerializer.java  | 12 ++++----
 .../data/EntireLayoutColumnarLongsSupplier.java    | 12 ++++----
 .../java/io/druid/segment/data/GenericIndexed.java | 12 ++++----
 .../druid/segment/data/GenericIndexedWriter.java   | 12 ++++----
 .../druid/segment/data/ImmutableBitmapValues.java  | 12 ++++----
 .../segment/data/ImmutableRTreeObjectStrategy.java | 12 ++++----
 .../main/java/io/druid/segment/data/Indexed.java   | 12 ++++----
 .../java/io/druid/segment/data/IndexedInts.java    | 12 ++++----
 .../io/druid/segment/data/IndexedIterable.java     | 12 ++++----
 .../data/IntermediateColumnarLongsSerializer.java  | 12 ++++----
 .../java/io/druid/segment/data/ListIndexed.java    | 12 ++++----
 .../segment/data/LongsLongEncodingReader.java      | 12 ++++----
 .../segment/data/LongsLongEncodingWriter.java      | 12 ++++----
 .../java/io/druid/segment/data/ObjectStrategy.java | 12 ++++----
 .../main/java/io/druid/segment/data/Offset.java    | 12 ++++----
 .../io/druid/segment/data/RangeIndexedInts.java    | 12 ++++----
 .../java/io/druid/segment/data/ReadableOffset.java | 12 ++++----
 .../segment/data/RoaringBitmapSerdeFactory.java    | 12 ++++----
 .../io/druid/segment/data/SingleIndexedInt.java    | 12 ++++----
 .../data/SingleValueColumnarIntsSerializer.java    | 12 ++++----
 .../io/druid/segment/data/SliceIndexedInts.java    | 12 ++++----
 .../segment/data/TableLongEncodingReader.java      | 12 ++++----
 .../segment/data/TableLongEncodingWriter.java      | 12 ++++----
 ...CompressedVSizeColumnarMultiIntsSerializer.java | 12 ++++----
 ...V3CompressedVSizeColumnarMultiIntsSupplier.java | 12 ++++----
 .../io/druid/segment/data/VSizeColumnarInts.java   | 12 ++++----
 .../segment/data/VSizeColumnarIntsSerializer.java  | 12 ++++----
 .../druid/segment/data/VSizeColumnarMultiInts.java | 12 ++++----
 .../data/VSizeColumnarMultiIntsSerializer.java     | 12 ++++----
 .../java/io/druid/segment/data/VSizeLongSerde.java | 12 ++++----
 .../io/druid/segment/data/WritableSupplier.java    | 12 ++++----
 .../io/druid/segment/data/ZeroIndexedInts.java     | 12 ++++----
 .../java/io/druid/segment/filter/AndFilter.java    | 12 ++++----
 .../druid/segment/filter/BooleanValueMatcher.java  | 12 ++++----
 .../java/io/druid/segment/filter/BoundFilter.java  | 12 ++++----
 .../segment/filter/ColumnComparisonFilter.java     | 12 ++++----
 .../segment/filter/DimensionPredicateFilter.java   | 12 ++++----
 .../io/druid/segment/filter/ExpressionFilter.java  | 12 ++++----
 .../io/druid/segment/filter/FalseValueMatcher.java | 12 ++++----
 .../main/java/io/druid/segment/filter/Filters.java | 12 ++++----
 .../java/io/druid/segment/filter/InFilter.java     | 12 ++++----
 .../io/druid/segment/filter/JavaScriptFilter.java  | 12 ++++----
 .../java/io/druid/segment/filter/LikeFilter.java   | 12 ++++----
 .../java/io/druid/segment/filter/NotFilter.java    | 12 ++++----
 .../java/io/druid/segment/filter/OrFilter.java     | 12 ++++----
 .../java/io/druid/segment/filter/RegexFilter.java  | 12 ++++----
 .../io/druid/segment/filter/SearchQueryFilter.java | 12 ++++----
 .../io/druid/segment/filter/SelectorFilter.java    | 12 ++++----
 .../io/druid/segment/filter/SpatialFilter.java     | 12 ++++----
 .../java/io/druid/segment/filter/TrueFilter.java   | 12 ++++----
 .../io/druid/segment/filter/TrueValueMatcher.java  | 12 ++++----
 .../historical/HistoricalColumnSelector.java       | 12 ++++----
 .../druid/segment/historical/HistoricalCursor.java | 12 ++++----
 .../historical/HistoricalDimensionSelector.java    | 12 ++++----
 .../SingleValueHistoricalDimensionSelector.java    | 12 ++++----
 .../segment/incremental/IncrementalIndex.java      | 12 ++++----
 .../incremental/IncrementalIndexAdapter.java       | 12 ++++----
 .../incremental/IncrementalIndexAddResult.java     | 12 ++++----
 .../IncrementalIndexColumnSelectorFactory.java     | 12 ++++----
 .../segment/incremental/IncrementalIndexRow.java   | 12 ++++----
 .../incremental/IncrementalIndexRowHolder.java     | 12 ++++----
 .../incremental/IncrementalIndexRowIterator.java   | 12 ++++----
 .../incremental/IncrementalIndexSchema.java        | 12 ++++----
 .../IncrementalIndexStorageAdapter.java            | 12 ++++----
 .../incremental/IndexSizeExceededException.java    | 12 ++++----
 .../incremental/OffheapIncrementalIndex.java       | 12 ++++----
 .../incremental/OnheapIncrementalIndex.java        | 12 ++++----
 .../SpatialDimensionRowTransformer.java            | 12 ++++----
 .../io/druid/segment/incremental/package-info.java | 12 ++++----
 .../MMappedQueryableSegmentizerFactory.java        | 12 ++++----
 .../druid/segment/loading/SegmentizerFactory.java  | 12 ++++----
 .../main/java/io/druid/segment/package-info.java   | 12 ++++----
 .../settable/SettableColumnValueSelector.java      | 12 ++++----
 .../settable/SettableDimensionValueSelector.java   | 12 ++++----
 .../SettableDoubleColumnValueSelector.java         | 12 ++++----
 .../settable/SettableFloatColumnValueSelector.java | 12 ++++----
 .../settable/SettableLongColumnValueSelector.java  | 12 ++++----
 .../SettableObjectColumnValueSelector.java         | 12 ++++----
 .../serde/BitmapIndexColumnPartSupplier.java       | 12 ++++----
 .../io/druid/segment/serde/ColumnPartSerde.java    | 12 ++++----
 .../segment/serde/ComplexColumnPartSerde.java      | 12 ++++----
 .../segment/serde/ComplexColumnPartSupplier.java   | 12 ++++----
 .../segment/serde/ComplexColumnSerializer.java     | 12 ++++----
 .../segment/serde/ComplexMetricExtractor.java      | 12 ++++----
 .../io/druid/segment/serde/ComplexMetricSerde.java | 12 ++++----
 .../io/druid/segment/serde/ComplexMetrics.java     | 12 ++++----
 .../serde/DictionaryEncodedColumnPartSerde.java    | 12 ++++----
 .../serde/DictionaryEncodedColumnSupplier.java     | 12 ++++----
 .../serde/DoubleGenericColumnPartSerde.java        | 12 ++++----
 .../serde/DoubleGenericColumnPartSerdeV2.java      | 12 ++++----
 .../segment/serde/DoubleGenericColumnSupplier.java | 12 ++++----
 .../segment/serde/FloatGenericColumnPartSerde.java | 12 ++++----
 .../serde/FloatGenericColumnPartSerdeV2.java       | 12 ++++----
 .../segment/serde/FloatGenericColumnSupplier.java  | 12 ++++----
 ...argeColumnSupportedComplexColumnSerializer.java | 12 ++++----
 .../segment/serde/LongGenericColumnPartSerde.java  | 12 ++++----
 .../serde/LongGenericColumnPartSerdeV2.java        | 12 ++++----
 .../segment/serde/LongGenericColumnSupplier.java   | 12 ++++----
 .../io/druid/segment/serde/MetaSerdeHelper.java    | 12 ++++----
 .../java/io/druid/segment/serde/Serializer.java    | 12 ++++----
 .../serde/SpatialIndexColumnPartSupplier.java      | 12 ++++----
 .../java/io/druid/segment/serde/package-info.java  | 12 ++++----
 .../segment/transform/ExpressionTransform.java     | 12 ++++----
 .../io/druid/segment/transform/RowFunction.java    | 12 ++++----
 .../java/io/druid/segment/transform/Transform.java | 12 ++++----
 .../io/druid/segment/transform/TransformSpec.java  | 12 ++++----
 .../io/druid/segment/transform/Transformer.java    | 12 ++++----
 .../transform/TransformingInputRowParser.java      | 12 ++++----
 .../TransformingStringInputRowParser.java          | 12 ++++----
 .../virtual/BaseSingleValueDimensionSelector.java  | 12 ++++----
 .../virtual/ExpressionColumnValueSelector.java     | 12 ++++----
 .../druid/segment/virtual/ExpressionSelectors.java | 12 ++++----
 .../segment/virtual/ExpressionVirtualColumn.java   | 12 ++++----
 .../druid/segment/virtual/SingleInputBindings.java | 12 ++++----
 ...gInputCachingExpressionColumnValueSelector.java | 12 ++++----
 ...gInputCachingExpressionColumnValueSelector.java | 12 ++++----
 .../SingleStringInputDimensionSelector.java        | 12 ++++----
 .../segment/virtual/VirtualColumnCacheHelper.java  | 12 ++++----
 .../virtual/VirtualizedColumnSelectorFactory.java  | 12 ++++----
 .../segment/writeout/ByteBufferWriteOutBytes.java  | 12 ++++----
 .../writeout/DirectByteBufferWriteOutBytes.java    | 12 ++++----
 .../druid/segment/writeout/FileWriteOutBytes.java  | 12 ++++----
 .../writeout/HeapByteBufferWriteOutBytes.java      | 12 ++++----
 .../OffHeapMemorySegmentWriteOutMedium.java        | 12 ++++----
 .../OffHeapMemorySegmentWriteOutMediumFactory.java | 12 ++++----
 .../OnHeapMemorySegmentWriteOutMedium.java         | 12 ++++----
 .../segment/writeout/SegmentWriteOutMedium.java    | 12 ++++----
 .../writeout/SegmentWriteOutMediumFactory.java     | 12 ++++----
 .../writeout/SegmentWriteOutMediumModule.java      | 12 ++++----
 .../writeout/TmpFileSegmentWriteOutMedium.java     | 12 ++++----
 .../TmpFileSegmentWriteOutMediumFactory.java       | 12 ++++----
 .../io/druid/segment/writeout/WriteOutBytes.java   | 12 ++++----
 .../druid/collections/CombiningIterableTest.java   | 12 ++++----
 .../io/druid/collections/IntSetTestUtility.java    | 12 ++++----
 .../java/io/druid/collections/TestIntegerSet.java  | 12 ++++----
 .../druid/collections/bitmap/BitmapBenchmark.java  | 12 ++++----
 .../collections/bitmap/BitmapIterationTest.java    | 12 ++++----
 .../bitmap/ConciseBitmapFactoryTest.java           | 12 ++++----
 .../bitmap/RangeBitmapBenchmarkTest.java           | 12 ++++----
 .../bitmap/RoaringBitmapFactoryTest.java           | 12 ++++----
 .../bitmap/UniformBitmapBenchmarkTest.java         | 12 ++++----
 .../bitmap/WrappedBitSetBitmapBitSetTest.java      | 12 ++++----
 .../bitmap/WrappedRoaringBitmapTest.java           | 12 ++++----
 .../collections/spatial/ImmutableRTreeTest.java    | 12 ++++----
 .../io/druid/collections/spatial/RTreeTest.java    | 12 ++++----
 .../spatial/search/PolygonBoundTest.java           | 12 ++++----
 .../spatial/search/RadiusBoundTest.java            | 12 ++++----
 .../spatial/search/RectangularBoundTest.java       | 12 ++++----
 .../split/LinearGutmanSplitStrategyTest.java       | 12 ++++----
 .../collections/test/annotation/Benchmark.java     | 12 ++++----
 .../druid/collections/test/annotation/Dummy.java   | 12 ++++----
 .../io/druid/granularity/QueryGranularityTest.java | 12 ++++----
 .../java/io/druid/guice/ExtensionsConfigTest.java  | 12 ++++----
 .../java/io/druid/guice/GuiceInjectorsTest.java    | 12 ++++----
 .../guice/MetadataStorageTablesConfigTest.java     | 12 ++++----
 .../guice/SegmentMetadataQueryConfigTest.java      | 12 ++++----
 .../io/druid/jackson/DefaultObjectMapperTest.java  | 12 ++++----
 .../java/io/druid/query/AsyncQueryRunnerTest.java  | 12 ++++----
 .../test/java/io/druid/query/CachingEmitter.java   | 12 ++++----
 .../query/ChainedExecutionQueryRunnerTest.java     | 12 ++++----
 .../test/java/io/druid/query/DataSourceTest.java   | 12 ++++----
 .../io/druid/query/DefaultQueryMetricsTest.java    | 12 ++++----
 .../java/io/druid/query/DoubleStorageTest.java     | 12 ++++----
 .../io/druid/query/DruidProcessingConfigTest.java  | 12 ++++----
 .../query/IntervalChunkingQueryRunnerTest.java     | 12 ++++----
 .../io/druid/query/MultiValuedDimensionTest.java   | 12 ++++----
 .../query/PrioritizedExecutorServiceTest.java      | 12 ++++----
 .../src/test/java/io/druid/query/QueriesTest.java  | 12 ++++----
 .../java/io/druid/query/QueryContextsTest.java     | 12 ++++----
 .../druid/query/QueryInterruptedExceptionTest.java | 12 ++++----
 .../java/io/druid/query/QueryRunnerTestHelper.java | 12 ++++----
 .../ResultGranularTimestampComparatorTest.java     | 12 ++++----
 .../java/io/druid/query/RetryQueryRunnerTest.java  | 12 ++++----
 .../java/io/druid/query/SchemaEvolutionTest.java   | 12 ++++----
 .../src/test/java/io/druid/query/TestQuery.java    | 12 ++++----
 .../test/java/io/druid/query/TestQueryRunners.java | 12 ++++----
 .../java/io/druid/query/TimewarpOperatorTest.java  | 12 ++++----
 .../java/io/druid/query/UnionQueryRunnerTest.java  | 12 ++++----
 .../query/aggregation/AggregationTestHelper.java   | 12 ++++----
 .../query/aggregation/AggregatorFactoryTest.java   | 12 ++++----
 .../query/aggregation/AggregatorUtilTest.java      | 12 ++++----
 .../query/aggregation/CountAggregatorTest.java     | 12 ++++----
 .../aggregation/DoubleMaxAggregationTest.java      | 12 ++++----
 .../aggregation/DoubleMinAggregationTest.java      | 12 ++++----
 .../query/aggregation/DoubleSumAggregatorTest.java | 12 ++++----
 .../query/aggregation/FilteredAggregatorTest.java  | 12 ++++----
 .../query/aggregation/HistogramAggregatorTest.java | 12 ++++----
 .../io/druid/query/aggregation/HistogramTest.java  | 12 ++++----
 .../aggregation/JavaScriptAggregatorBenchmark.java | 12 ++++----
 .../aggregation/JavaScriptAggregatorTest.java      | 12 ++++----
 .../query/aggregation/LongMaxAggregationTest.java  | 12 ++++----
 .../query/aggregation/LongMinAggregationTest.java  | 12 ++++----
 .../query/aggregation/LongSumAggregatorTest.java   | 12 ++++----
 .../aggregation/MetricManipulatorFnsTest.java      | 12 ++++----
 .../aggregation/TestDoubleColumnSelectorImpl.java  | 12 ++++----
 .../query/aggregation/TestFloatColumnSelector.java | 12 ++++----
 .../query/aggregation/TestLongColumnSelector.java  | 12 ++++----
 .../aggregation/TestObjectColumnSelector.java      | 12 ++++----
 .../CardinalityAggregatorBenchmark.java            | 12 ++++----
 .../cardinality/CardinalityAggregatorTest.java     | 12 ++++----
 .../first/DoubleFirstAggregationTest.java          | 12 ++++----
 .../first/FloatFirstAggregationTest.java           | 12 ++++----
 .../first/LongFirstAggregationTest.java            | 12 ++++----
 .../HyperUniqueFinalizingPostAggregatorTest.java   | 12 ++++----
 .../hyperloglog/HyperUniquesAggregationTest.java   | 12 ++++----
 .../HyperUniquesAggregatorFactoryTest.java         | 12 ++++----
 .../last/DoubleLastAggregationTest.java            | 12 ++++----
 .../aggregation/last/FloatLastAggregationTest.java | 12 ++++----
 .../aggregation/last/LongLastAggregationTest.java  | 12 ++++----
 .../post/ArithmeticPostAggregatorTest.java         | 12 ++++----
 .../post/ConstantPostAggregatorTest.java           | 12 ++++----
 .../post/DoubleGreatestPostAggregatorTest.java     | 12 ++++----
 .../post/DoubleLeastPostAggregatorTest.java        | 12 ++++----
 .../post/FieldAccessPostAggregatorTest.java        | 12 ++++----
 .../FinalizingFieldAccessPostAggregatorTest.java   | 12 ++++----
 .../post/JavaScriptPostAggregatorTest.java         | 12 ++++----
 .../post/LongGreatestPostAggregatorTest.java       | 12 ++++----
 .../post/LongLeastPostAggregatorTest.java          | 12 ++++----
 .../io/druid/query/cache/CacheKeyBuilderTest.java  | 12 ++++----
 .../DataSourceMetadataQueryTest.java               | 12 ++++----
 .../query/dimension/DefaultDimensionSpecTest.java  | 12 ++++----
 .../dimension/ExtractionDimensionSpecTest.java     | 12 ++++----
 .../query/dimension/LegacyDimensionSpecTest.java   | 12 ++++----
 .../dimension/ListFilteredDimensionSpecTest.java   | 12 ++++----
 .../dimension/RegexFilteredDimensionSpecTest.java  | 12 ++++----
 .../query/dimension/TestDimensionSelector.java     | 12 ++++----
 .../druid/query/expression/TestExprMacroTable.java | 12 ++++----
 .../query/extraction/BucketExtractionFnTest.java   | 12 ++++----
 .../query/extraction/CascadeExtractionFnTest.java  | 12 ++++----
 .../query/extraction/FunctionalExtractionTest.java | 12 ++++----
 .../extraction/JavaScriptExtractionFnTest.java     | 12 ++++----
 .../query/extraction/LowerExtractionFnTest.java    | 12 ++++----
 .../extraction/MapLookupExtractionFnSerDeTest.java | 12 ++++----
 .../query/extraction/MapLookupExtractorTest.java   | 12 ++++----
 .../extraction/MatchingDimExtractionFnTest.java    | 12 ++++----
 .../query/extraction/RegexDimExtractionFnTest.java | 12 ++++----
 .../SearchQuerySpecDimExtractionFnTest.java        | 12 ++++----
 .../extraction/StringFormatExtractionFnTest.java   | 12 ++++----
 .../query/extraction/StrlenExtractionFnTest.java   | 12 ++++----
 .../extraction/SubstringDimExtractionFnTest.java   | 12 ++++----
 .../query/extraction/TimeDimExtractionFnTest.java  | 12 ++++----
 .../extraction/TimeFormatExtractionFnTest.java     | 12 ++++----
 .../query/extraction/UpperExtractionFnTest.java    | 12 ++++----
 .../io/druid/query/filter/AndDimFilterTest.java    | 12 ++++----
 .../io/druid/query/filter/BoundDimFilterTest.java  | 32 ++++----------------
 .../filter/ColumnComparisonDimFilterTest.java      | 12 ++++----
 .../io/druid/query/filter/DimFilterUtilsTest.java  | 12 ++++----
 .../query/filter/ExtractionDimFilterTest.java      | 12 ++++----
 .../query/filter/GetDimensionRangeSetTest.java     | 12 ++++----
 .../druid/query/filter/InDimFilterSerDesrTest.java | 12 ++++----
 .../druid/query/filter/IntervalDimFilterTest.java  | 12 ++++----
 .../query/filter/JavaScriptDimFilterTest.java      | 12 ++++----
 .../io/druid/query/filter/LikeDimFilterTest.java   | 12 ++++----
 .../io/druid/query/filter/RegexDimFilterTest.java  | 12 ++++----
 .../query/filter/SearchQueryDimFilterTest.java     | 12 ++++----
 .../druid/query/filter/SelectorDimFilterTest.java  | 12 ++++----
 .../groupby/DefaultGroupByQueryMetricsTest.java    | 12 ++++----
 ...GroupByLimitPushDownInsufficientBufferTest.java | 12 ++++----
 .../GroupByLimitPushDownMultiNodeMergeTest.java    | 12 ++++----
 .../query/groupby/GroupByMultiSegmentTest.java     | 12 ++++----
 .../query/groupby/GroupByQueryConfigTest.java      | 12 ++++----
 .../query/groupby/GroupByQueryMergeBufferTest.java | 12 ++++----
 .../groupby/GroupByQueryRunnerFactoryTest.java     | 12 ++++----
 .../groupby/GroupByQueryRunnerFailureTest.java     | 12 ++++----
 .../query/groupby/GroupByQueryRunnerTest.java      | 12 ++++----
 .../groupby/GroupByQueryRunnerTestHelper.java      | 12 ++++----
 .../io/druid/query/groupby/GroupByQueryTest.java   | 12 ++++----
 .../groupby/GroupByTimeseriesQueryRunnerTest.java  | 12 ++++----
 .../epinephelinae/BufferArrayGrouperTest.java      | 12 ++++----
 .../epinephelinae/BufferHashGrouperTest.java       | 12 ++++----
 .../ByteBufferMinMaxOffsetHeapTest.java            | 12 ++++----
 .../epinephelinae/ConcurrentGrouperTest.java       | 12 ++++----
 .../groupby/epinephelinae/GrouperTestUtil.java     | 12 ++++----
 .../query/groupby/epinephelinae/IntKeySerde.java   | 12 ++++----
 .../LimitedBufferHashGrouperTest.java              | 12 ++++----
 .../epinephelinae/ParallelCombinerTest.java        | 12 ++++----
 .../StreamingMergeSortedGrouperTest.java           | 12 ++++----
 .../epinephelinae/TestColumnSelectorFactory.java   | 12 ++++----
 .../groupby/having/DimFilterHavingSpecTest.java    | 12 ++++----
 .../having/DimensionSelectorHavingSpecTest.java    | 12 ++++----
 .../having/HavingSpecMetricComparatorTest.java     | 12 ++++----
 .../druid/query/groupby/having/HavingSpecTest.java | 12 ++++----
 .../groupby/orderby/DefaultLimitSpecTest.java      | 12 ++++----
 .../query/groupby/orderby/TopNSequenceTest.java    | 12 ++++----
 .../io/druid/query/lookup/LookupConfigTest.java    | 12 ++++----
 .../lookup/LookupExtractionFnExpectationsTest.java | 12 ++++----
 .../druid/query/lookup/LookupExtractionFnTest.java | 12 ++++----
 .../LookupExtractorFactoryContainerTest.java       | 12 ++++----
 .../io/druid/query/lookup/LookupExtractorTest.java | 12 ++++----
 .../io/druid/query/lookup/LookupsStateTest.java    | 12 ++++----
 .../druid/query/metadata/SegmentAnalyzerTest.java  | 12 ++++----
 .../SegmentMetadataQueryQueryToolChestTest.java    | 12 ++++----
 .../query/metadata/SegmentMetadataQueryTest.java   | 12 ++++----
 .../metadata/SegmentMetadataUnionQueryTest.java    | 12 ++++----
 .../metadata/metadata/ColumnAnalysisTest.java      | 12 ++++----
 .../StringRuntimeShapeTest.java                    | 12 ++++----
 .../query/ordering/StringComparatorsTest.java      | 12 ++++----
 .../query/scan/MultiSegmentScanQueryTest.java      | 12 ++++----
 .../io/druid/query/scan/ScanQueryRunnerTest.java   | 12 ++++----
 .../io/druid/query/scan/ScanQuerySpecTest.java     | 12 ++++----
 .../search/DefaultSearchQueryMetricsTest.java      | 12 ++++----
 .../druid/query/search/RegexSearchQueryTest.java   | 12 ++++----
 .../io/druid/query/search/SearchBinaryFnTest.java  | 12 ++++----
 .../search/SearchQueryQueryToolChestTest.java      | 12 ++++----
 .../druid/query/search/SearchQueryRunnerTest.java  | 12 ++++----
 .../search/SearchQueryRunnerWithCaseTest.java      | 12 ++++----
 .../io/druid/query/search/SearchQueryTest.java     | 12 ++++----
 .../io/druid/query/search/SearchSortSpecTest.java  | 12 ++++----
 .../select/DefaultSelectQueryMetricsTest.java      | 12 ++++----
 .../query/select/MultiSegmentSelectQueryTest.java  | 12 ++++----
 .../io/druid/query/select/PagingOffsetTest.java    | 12 ++++----
 .../io/druid/query/select/SelectBinaryFnTest.java  | 12 ++++----
 .../druid/query/select/SelectQueryConfigTest.java  | 12 ++++----
 .../select/SelectQueryQueryToolChestTest.java      | 12 ++++----
 .../druid/query/select/SelectQueryRunnerTest.java  | 12 ++++----
 .../io/druid/query/select/SelectQuerySpecTest.java | 12 ++++----
 .../io/druid/query/spec/QuerySegmentSpecTest.java  | 12 ++++----
 .../query/spec/SpecificSegmentQueryRunnerTest.java | 12 ++++----
 .../TimeBoundaryQueryQueryToolChestTest.java       | 12 ++++----
 .../timeboundary/TimeBoundaryQueryRunnerTest.java  | 12 ++++----
 .../query/timeboundary/TimeBoundaryQueryTest.java  | 12 ++++----
 .../DefaultTimeseriesQueryMetricsTest.java         | 12 ++++----
 .../timeseries/TimeSeriesUnionQueryRunnerTest.java | 12 ++++----
 .../query/timeseries/TimeseriesBinaryFnTest.java   | 12 ++++----
 .../TimeseriesQueryQueryToolChestTest.java         | 12 ++++----
 .../timeseries/TimeseriesQueryRunnerBonusTest.java | 12 ++++----
 .../timeseries/TimeseriesQueryRunnerTest.java      | 12 ++++----
 .../query/timeseries/TimeseriesQueryTest.java      | 12 ++++----
 .../query/topn/AlphaNumericTopNMetricSpecTest.java | 12 ++++----
 .../query/topn/DefaultTopNQueryMetricsTest.java    | 12 ++++----
 .../query/topn/DimensionTopNMetricSpecTest.java    | 12 ++++----
 .../druid/query/topn/PooledTopNAlgorithmTest.java  | 12 ++++----
 .../io/druid/query/topn/TopNBinaryFnBenchmark.java | 12 ++++----
 .../java/io/druid/query/topn/TopNBinaryFnTest.java | 12 ++++----
 .../topn/TopNMetricSpecOptimizationsTest.java      | 12 ++++----
 .../query/topn/TopNQueryQueryToolChestTest.java    | 12 ++++----
 .../druid/query/topn/TopNQueryRunnerBenchmark.java | 12 ++++----
 .../io/druid/query/topn/TopNQueryRunnerTest.java   | 12 ++++----
 .../query/topn/TopNQueryRunnerTestHelper.java      | 12 ++++----
 .../java/io/druid/query/topn/TopNQueryTest.java    | 12 ++++----
 .../io/druid/query/topn/TopNUnionQueryTest.java    | 12 ++++----
 .../src/test/java/io/druid/segment/AppendTest.java | 12 ++++----
 .../java/io/druid/segment/BitmapOffsetTest.java    | 12 ++++----
 .../src/test/java/io/druid/segment/CloserRule.java | 12 ++++----
 .../test/java/io/druid/segment/CloserRuleTest.java | 12 ++++----
 .../segment/ConciseBitmapIndexMergerV9Test.java    | 12 ++++----
 .../segment/ConstantDimensionSelectorTest.java     | 12 ++++----
 .../src/test/java/io/druid/segment/DebugRow.java   | 12 ++++----
 .../druid/segment/DictionaryMergeIteratorTest.java | 12 ++++----
 .../test/java/io/druid/segment/EmptyIndexTest.java | 12 ++++----
 .../test/java/io/druid/segment/IndexBuilder.java   | 12 ++++----
 .../test/java/io/druid/segment/IndexIOTest.java    | 12 ++++----
 .../druid/segment/IndexMergerNullHandlingTest.java | 12 ++++----
 .../java/io/druid/segment/IndexMergerTestBase.java | 12 ++++----
 .../segment/IndexMergerV9CompatibilityTest.java    | 12 ++++----
 .../segment/IndexMergerV9WithSpatialIndexTest.java | 12 ++++----
 .../test/java/io/druid/segment/IndexSpecTest.java  | 12 ++++----
 .../io/druid/segment/IntIteratorUtilsTest.java     | 12 ++++----
 .../java/io/druid/segment/IntListUtilsTest.java    | 12 ++++----
 .../io/druid/segment/MergeIntIteratorTest.java     | 12 ++++----
 .../io/druid/segment/MergingRowIteratorTest.java   | 12 ++++----
 .../test/java/io/druid/segment/MetadataTest.java   | 12 ++++----
 .../druid/segment/NoBitmapIndexMergerV9Test.java   | 12 ++++----
 .../QueryableIndexIndexableAdapterTest.java        | 12 ++++----
 .../segment/ReferenceCountingSegmentTest.java      | 12 ++++----
 .../segment/RoaringBitmapIndexMergerV9Test.java    | 12 ++++----
 .../java/io/druid/segment/RowIteratorHelper.java   | 12 ++++----
 .../java/io/druid/segment/SchemalessIndexTest.java | 12 ++++----
 .../io/druid/segment/SchemalessTestFullTest.java   | 12 ++++----
 .../io/druid/segment/SchemalessTestSimpleTest.java | 12 ++++----
 .../io/druid/segment/TestDoubleColumnSelector.java | 12 ++++----
 .../io/druid/segment/TestFloatColumnSelector.java  | 12 ++++----
 .../src/test/java/io/druid/segment/TestHelper.java | 12 ++++----
 .../src/test/java/io/druid/segment/TestIndex.java  | 12 ++++----
 .../io/druid/segment/TestLongColumnSelector.java   | 12 ++++----
 .../io/druid/segment/TestObjectColumnSelector.java | 12 ++++----
 .../segment/data/BenchmarkIndexibleWrites.java     | 12 ++++----
 .../segment/data/BitmapCreationBenchmark.java      | 12 ++++----
 .../druid/segment/data/BitmapSerdeFactoryTest.java | 12 ++++----
 .../data/CompressedColumnarIntsSerializerTest.java | 12 ++++----
 .../data/CompressedColumnarIntsSupplierTest.java   | 12 ++++----
 .../segment/data/CompressedFloatsSerdeTest.java    | 12 ++++----
 .../segment/data/CompressedLongsSerdeTest.java     | 12 ++++----
 .../CompressedVSizeColumnarIntsSerializerTest.java | 12 ++++----
 .../CompressedVSizeColumnarIntsSupplierTest.java   | 12 ++++----
 ...mpressedVSizeColumnarMultiIntsSupplierTest.java | 12 ++++----
 .../segment/data/CompressionStrategyTest.java      | 12 ++++----
 .../data/GenericIndexedStringWriterTest.java       | 12 ++++----
 .../io/druid/segment/data/GenericIndexedTest.java  | 12 ++++----
 .../druid/segment/data/IncrementalIndexTest.java   | 12 ++++----
 .../io/druid/segment/data/IndexedIntsTest.java     | 12 ++++----
 ...ressedVSizeColumnarMultiIntsSerializerTest.java | 12 ++++----
 ...mpressedVSizeColumnarMultiIntsSupplierTest.java | 12 ++++----
 .../data/VSizeColumnarIntsSerializerTest.java      | 12 ++++----
 .../druid/segment/data/VSizeColumnarIntsTest.java  | 12 ++++----
 .../segment/data/VSizeColumnarMultiIntsTest.java   | 12 ++++----
 .../io/druid/segment/data/VSizeLongSerdeTest.java  | 12 ++++----
 .../io/druid/segment/filter/AndFilterTest.java     | 12 ++++----
 .../io/druid/segment/filter/BaseFilterTest.java    | 12 ++++----
 .../io/druid/segment/filter/BoundFilterTest.java   | 12 ++++----
 .../segment/filter/ColumnComparisonFilterTest.java | 12 ++++----
 .../druid/segment/filter/ExpressionFilterTest.java | 12 ++++----
 .../segment/filter/ExtractionDimFilterTest.java    | 12 ++++----
 .../druid/segment/filter/FilterPartitionTest.java  | 12 ++++----
 .../java/io/druid/segment/filter/FiltersTest.java  | 12 ++++----
 .../filter/FloatAndDoubleFilteringTest.java        | 12 ++++----
 .../java/io/druid/segment/filter/InFilterTest.java | 12 ++++----
 .../druid/segment/filter/InvalidFilteringTest.java | 12 ++++----
 .../druid/segment/filter/JavaScriptFilterTest.java | 12 ++++----
 .../io/druid/segment/filter/LikeFilterTest.java    | 12 ++++----
 .../io/druid/segment/filter/LongFilteringTest.java | 12 ++++----
 .../io/druid/segment/filter/NotFilterTest.java     | 12 ++++----
 .../io/druid/segment/filter/RegexFilterTest.java   | 12 ++++----
 .../segment/filter/SearchQueryFilterTest.java      | 12 ++++----
 .../druid/segment/filter/SelectorFilterTest.java   | 12 ++++----
 .../segment/filter/SpatialFilterBonusTest.java     | 12 ++++----
 .../io/druid/segment/filter/SpatialFilterTest.java | 12 ++++----
 .../io/druid/segment/filter/TimeFilteringTest.java | 12 ++++----
 .../incremental/IncrementalIndexAdapterTest.java   | 12 ++++----
 .../IncrementalIndexMultiValueSpecTest.java        | 12 ++++----
 .../incremental/IncrementalIndexRowCompTest.java   | 12 ++++----
 .../incremental/IncrementalIndexRowSizeTest.java   | 12 ++++----
 .../IncrementalIndexStorageAdapterTest.java        | 12 ++++----
 .../segment/incremental/IncrementalIndexTest.java  | 12 ++++----
 .../OnheapIncrementalIndexBenchmark.java           | 12 ++++----
 .../incremental/OnheapIncrementalIndexTest.java    | 12 ++++----
 .../segment/loading/SegmentizerFactoryTest.java    | 12 ++++----
 .../DictionaryEncodedColumnPartSerdeTest.java      | 12 ++++----
 .../segment/serde/HyperUniquesSerdeForTest.java    | 12 ++++----
 ...ColumnSupportedComplexColumnSerializerTest.java | 12 ++++----
 .../virtual/ExpressionColumnValueSelectorTest.java | 12 ++++----
 .../virtual/ExpressionVirtualColumnTest.java       | 12 ++++----
 .../druid/segment/virtual/VirtualColumnsTest.java  | 12 ++++----
 .../druid/segment/writeout/WriteOutBytesTest.java  | 12 ++++----
 .../src/test/resources/test.runtime.properties     | 19 ++++++++++++
 server/pom.xml                                     | 26 +++++++++--------
 .../client/AbstractCuratorServerInventoryView.java | 12 ++++----
 .../io/druid/client/BatchServerInventoryView.java  | 12 ++++----
 .../client/BatchServerInventoryViewProvider.java   | 12 ++++----
 .../druid/client/BrokerSegmentWatcherConfig.java   | 12 ++++----
 .../java/io/druid/client/BrokerServerView.java     | 12 ++++----
 .../src/main/java/io/druid/client/CacheUtil.java   | 12 ++++----
 .../io/druid/client/CachingClusteredClient.java    | 12 ++++----
 .../java/io/druid/client/CachingQueryRunner.java   | 12 ++++----
 .../io/druid/client/CoordinatorServerView.java     | 12 ++++----
 .../java/io/druid/client/DirectDruidClient.java    | 12 ++++----
 .../main/java/io/druid/client/DruidDataSource.java | 12 ++++----
 .../src/main/java/io/druid/client/DruidServer.java | 12 ++++----
 .../java/io/druid/client/DruidServerConfig.java    | 12 ++++----
 .../FilteredBatchServerInventoryViewProvider.java  | 12 ++++----
 .../FilteredHttpServerInventoryViewProvider.java   | 12 ++++----
 .../druid/client/FilteredServerInventoryView.java  | 12 ++++----
 .../FilteredServerInventoryViewProvider.java       | 12 ++++----
 .../FilteredSingleServerInventoryViewProvider.java | 12 ++++----
 .../io/druid/client/HttpServerInventoryView.java   | 12 ++++----
 .../client/HttpServerInventoryViewConfig.java      | 12 ++++----
 .../client/HttpServerInventoryViewProvider.java    | 12 ++++----
 .../client/HttpServerInventoryViewResource.java    | 12 ++++----
 .../io/druid/client/ImmutableDruidDataSource.java  | 12 ++++----
 .../java/io/druid/client/ImmutableDruidServer.java | 12 ++++----
 .../io/druid/client/ImmutableSegmentLoadInfo.java  | 12 ++++----
 .../main/java/io/druid/client/InventoryView.java   | 12 ++++----
 .../java/io/druid/client/ResultLevelCacheUtil.java | 12 ++++----
 .../main/java/io/druid/client/SegmentLoadInfo.java | 12 ++++----
 .../java/io/druid/client/ServerInventoryView.java  | 12 ++++----
 .../druid/client/ServerInventoryViewProvider.java  | 12 ++++----
 .../src/main/java/io/druid/client/ServerView.java  | 12 ++++----
 .../main/java/io/druid/client/ServerViewUtil.java  | 12 ++++----
 .../client/SingleServerInventoryProvider.java      | 12 ++++----
 .../io/druid/client/SingleServerInventoryView.java | 12 ++++----
 .../java/io/druid/client/TimelineServerView.java   | 12 ++++----
 .../io/druid/client/cache/ByteCountingLRUMap.java  | 12 ++++----
 .../client/cache/BytesBoundedLinkedQueue.java      | 12 ++++----
 .../src/main/java/io/druid/client/cache/Cache.java | 12 ++++----
 .../java/io/druid/client/cache/CacheConfig.java    | 12 ++++----
 .../druid/client/cache/CacheExecutorFactory.java   | 12 ++++----
 .../java/io/druid/client/cache/CacheMonitor.java   | 12 ++++----
 .../java/io/druid/client/cache/CacheProvider.java  | 12 ++++----
 .../java/io/druid/client/cache/CacheStats.java     | 12 ++++----
 .../java/io/druid/client/cache/CaffeineCache.java  | 12 ++++----
 .../io/druid/client/cache/CaffeineCacheConfig.java | 12 ++++----
 .../druid/client/cache/CaffeineCacheProvider.java  | 12 ++++----
 .../java/io/druid/client/cache/HybridCache.java    | 12 ++++----
 .../io/druid/client/cache/HybridCacheConfig.java   | 12 ++++----
 .../io/druid/client/cache/HybridCacheProvider.java | 12 ++++----
 .../java/io/druid/client/cache/LZ4Transcoder.java  | 12 ++++----
 .../io/druid/client/cache/LocalCacheProvider.java  | 12 ++++----
 .../main/java/io/druid/client/cache/MapCache.java  | 12 ++++----
 .../io/druid/client/cache/MemcacheClientPool.java  | 12 ++++----
 .../java/io/druid/client/cache/MemcachedCache.java | 12 ++++----
 .../druid/client/cache/MemcachedCacheConfig.java   | 12 ++++----
 .../druid/client/cache/MemcachedCacheProvider.java | 12 ++++----
 .../MemcachedCustomConnectionFactoryBuilder.java   | 12 ++++----
 .../cache/MemcachedOperationQueueFactory.java      | 12 ++++----
 .../io/druid/client/coordinator/Coordinator.java   | 12 ++++----
 .../client/coordinator/CoordinatorClient.java      | 12 ++++----
 .../coordinator/CoordinatorSelectorConfig.java     | 12 ++++----
 .../druid/client/indexing/ClientAppendQuery.java   | 12 ++++----
 .../druid/client/indexing/ClientCompactQuery.java  | 12 ++++----
 .../indexing/ClientCompactQueryTuningConfig.java   | 12 ++++----
 .../client/indexing/ClientConversionQuery.java     | 12 ++++----
 .../io/druid/client/indexing/ClientKillQuery.java  | 12 ++++----
 .../io/druid/client/indexing/ClientMergeQuery.java | 12 ++++----
 .../io/druid/client/indexing/IndexingService.java  | 12 ++++----
 .../client/indexing/IndexingServiceClient.java     | 12 ++++----
 .../indexing/IndexingServiceSelectorConfig.java    | 12 ++++----
 .../io/druid/client/indexing/IndexingWorker.java   | 12 ++++----
 .../druid/client/indexing/IndexingWorkerInfo.java  | 12 ++++----
 .../java/io/druid/client/indexing/QueryStatus.java | 12 ++++----
 .../selector/AbstractTierSelectorStrategy.java     | 12 ++++----
 .../ConnectionCountServerSelectorStrategy.java     | 12 ++++----
 .../selector/CustomTierSelectorStrategy.java       | 12 ++++----
 .../selector/CustomTierSelectorStrategyConfig.java | 12 ++++----
 .../druid/client/selector/DiscoverySelector.java   | 12 ++++----
 .../HighestPriorityTierSelectorStrategy.java       | 12 ++++----
 .../LowestPriorityTierSelectorStrategy.java        | 12 ++++----
 .../client/selector/QueryableDruidServer.java      | 12 ++++----
 .../selector/RandomServerSelectorStrategy.java     | 12 ++++----
 .../main/java/io/druid/client/selector/Server.java | 12 ++++----
 .../io/druid/client/selector/ServerSelector.java   | 12 ++++----
 .../client/selector/ServerSelectorStrategy.java    | 12 ++++----
 .../client/selector/TierSelectorStrategy.java      | 12 ++++----
 .../main/java/io/druid/curator/CuratorConfig.java  | 12 ++++----
 .../main/java/io/druid/curator/CuratorModule.java  | 12 ++++----
 .../main/java/io/druid/curator/CuratorUtils.java   | 12 ++++----
 .../java/io/druid/curator/ExhibitorConfig.java     | 12 ++++----
 .../PotentiallyGzippedCompressionProvider.java     | 12 ++++----
 .../io/druid/curator/announcement/Announcer.java   | 12 ++++----
 .../curator/cache/PathChildrenCacheFactory.java    | 12 ++++----
 .../discovery/CuratorDruidLeaderSelector.java      | 12 ++++----
 .../discovery/CuratorDruidNodeAnnouncer.java       | 12 ++++----
 .../CuratorDruidNodeDiscoveryProvider.java         | 12 ++++----
 .../curator/discovery/CuratorServiceAnnouncer.java | 12 ++++----
 .../curator/discovery/CuratorServiceUtils.java     | 12 ++++----
 .../druid/curator/discovery/DiscoveryModule.java   | 12 ++++----
 .../curator/discovery/NoopServiceAnnouncer.java    | 12 ++++----
 .../curator/discovery/ServerDiscoveryFactory.java  | 12 ++++----
 .../curator/discovery/ServerDiscoverySelector.java | 12 ++++----
 .../druid/curator/discovery/ServiceAnnouncer.java  | 12 ++++----
 .../curator/inventory/CuratorInventoryManager.java | 12 ++++----
 .../inventory/CuratorInventoryManagerStrategy.java | 12 ++++----
 .../curator/inventory/InventoryManagerConfig.java  | 12 ++++----
 .../java/io/druid/discovery/DataNodeService.java   | 12 ++++----
 .../io/druid/discovery/DiscoveryDruidNode.java     | 12 ++++----
 .../java/io/druid/discovery/DruidLeaderClient.java | 12 ++++----
 .../io/druid/discovery/DruidLeaderSelector.java    | 12 ++++----
 .../io/druid/discovery/DruidNodeAnnouncer.java     | 12 ++++----
 .../io/druid/discovery/DruidNodeDiscovery.java     | 12 ++++----
 .../discovery/DruidNodeDiscoveryProvider.java      | 12 ++++----
 .../main/java/io/druid/discovery/DruidService.java | 12 ++++----
 .../java/io/druid/discovery/LookupNodeService.java | 12 ++++----
 .../java/io/druid/discovery/WorkerNodeService.java | 12 ++++----
 server/src/main/java/io/druid/guice/AWSModule.java | 12 ++++----
 .../main/java/io/druid/guice/AnnouncerModule.java  | 12 ++++----
 .../src/main/java/io/druid/guice/CacheModule.java  | 12 ++++----
 .../io/druid/guice/CoordinatorDiscoveryModule.java | 12 ++++----
 .../src/main/java/io/druid/guice/DruidBinders.java | 12 ++++----
 .../druid/guice/DruidProcessingConfigModule.java   | 12 ++++----
 .../java/io/druid/guice/DruidProcessingModule.java | 12 ++++----
 .../main/java/io/druid/guice/ExpressionModule.java | 12 ++++----
 .../io/druid/guice/FireDepartmentsProvider.java    | 12 ++++----
 .../main/java/io/druid/guice/FirehoseModule.java   | 12 ++++----
 .../guice/IndexingServiceDiscoveryModule.java      | 12 ++++----
 .../main/java/io/druid/guice/JavaScriptModule.java | 12 ++++----
 .../druid/guice/LocalDataStorageDruidModule.java   | 12 ++++----
 .../java/io/druid/guice/MetadataConfigModule.java  | 12 ++++----
 .../main/java/io/druid/guice/NodeTypeConfig.java   | 12 ++++----
 .../druid/guice/NoopSegmentPublisherProvider.java  | 12 ++++----
 .../main/java/io/druid/guice/ParsersModule.java    | 12 ++++----
 .../io/druid/guice/QueryRunnerFactoryModule.java   | 12 ++++----
 .../java/io/druid/guice/QueryToolChestModule.java  | 12 ++++----
 .../main/java/io/druid/guice/QueryableModule.java  | 12 ++++----
 .../java/io/druid/guice/RealtimeManagerConfig.java | 12 ++++----
 .../io/druid/guice/RouterProcessingModule.java     | 12 ++++----
 .../druid/guice/SQLMetadataStorageDruidModule.java | 12 ++++----
 .../src/main/java/io/druid/guice/ServerModule.java | 12 ++++----
 .../main/java/io/druid/guice/ServerViewModule.java | 12 ++++----
 .../java/io/druid/guice/StartupLoggingModule.java  | 12 ++++----
 .../java/io/druid/guice/StorageNodeModule.java     | 12 ++++----
 .../java/io/druid/guice/annotations/Client.java    | 12 ++++----
 .../CoordinatorIndexingServiceHelper.java          | 12 ++++----
 .../druid/guice/annotations/EscalatedClient.java   | 12 ++++----
 .../druid/guice/annotations/RemoteChatHandler.java | 12 ++++----
 .../guice/http/AbstractHttpClientProvider.java     | 12 ++++----
 .../io/druid/guice/http/DruidHttpClientConfig.java | 12 ++++----
 .../java/io/druid/guice/http/HttpClientModule.java | 12 ++++----
 .../io/druid/guice/http/JettyHttpClientModule.java | 12 ++++----
 .../java/io/druid/guice/http/LifecycleUtils.java   | 12 ++++----
 .../druid/guice/security/AuthenticatorModule.java  | 12 ++++----
 .../io/druid/guice/security/AuthorizerModule.java  | 12 ++++----
 .../io/druid/guice/security/DruidAuthModule.java   | 12 ++++----
 .../io/druid/guice/security/EscalatorModule.java   | 12 ++++----
 .../SQLMetadataStorageUpdaterJobHandler.java       | 12 ++++----
 .../indexing/overlord/DataSourceMetadata.java      | 12 ++++----
 .../IndexerMetadataStorageCoordinator.java         | 12 ++++----
 .../io/druid/indexing/overlord/ObjectMetadata.java | 12 ++++----
 .../indexing/overlord/SegmentPublishResult.java    | 12 ++++----
 .../overlord/supervisor/NoopSupervisorSpec.java    | 12 ++++----
 .../indexing/overlord/supervisor/Supervisor.java   | 12 ++++----
 .../overlord/supervisor/SupervisorReport.java      | 12 ++++----
 .../overlord/supervisor/SupervisorSpec.java        | 12 ++++----
 .../supervisor/VersionedSupervisorSpec.java        | 12 ++++----
 .../initialization/ExtensionFirstClassLoader.java  | 12 ++++----
 .../io/druid/initialization/Initialization.java    | 12 ++++----
 .../initialization/Log4jShutterDownerModule.java   | 12 ++++----
 .../DerbyMetadataStorageActionHandler.java         | 12 ++++----
 .../DerbyMetadataStorageActionHandlerFactory.java  | 12 ++++----
 .../IndexerSQLMetadataStorageCoordinator.java      | 12 ++++----
 .../io/druid/metadata/MetadataRuleManager.java     | 12 ++++----
 .../druid/metadata/MetadataRuleManagerConfig.java  | 12 ++++----
 .../metadata/MetadataRuleManagerProvider.java      | 12 ++++----
 .../io/druid/metadata/MetadataSegmentManager.java  | 12 ++++----
 .../metadata/MetadataSegmentManagerConfig.java     | 12 ++++----
 .../metadata/MetadataSegmentManagerProvider.java   | 12 ++++----
 .../druid/metadata/MetadataSegmentPublisher.java   | 12 ++++----
 .../metadata/MetadataSegmentPublisherProvider.java | 12 ++++----
 .../java/io/druid/metadata/MetadataStorage.java    | 12 ++++----
 .../io/druid/metadata/MetadataStorageProvider.java | 12 ++++----
 .../druid/metadata/MetadataSupervisorManager.java  | 12 ++++----
 .../MySQLMetadataStorageActionHandler.java         | 12 ++++----
 .../MySQLMetadataStorageActionHandlerFactory.java  | 12 ++++----
 .../metadata/NoopMetadataStorageProvider.java      | 12 ++++----
 .../PostgreSQLMetadataStorageActionHandler.java    | 12 ++++----
 ...tgreSQLMetadataStorageActionHandlerFactory.java | 12 ++++----
 .../druid/metadata/RetryTransactionException.java  | 12 ++++----
 .../metadata/SQLFirehoseDatabaseConnector.java     | 12 ++++----
 .../io/druid/metadata/SQLMetadataConnector.java    | 12 ++++----
 .../io/druid/metadata/SQLMetadataRuleManager.java  | 12 ++++----
 .../metadata/SQLMetadataRuleManagerProvider.java   | 12 ++++----
 .../druid/metadata/SQLMetadataSegmentManager.java  | 12 ++++----
 .../SQLMetadataSegmentManagerProvider.java         | 12 ++++----
 .../metadata/SQLMetadataSegmentPublisher.java      | 12 ++++----
 .../SQLMetadataSegmentPublisherProvider.java       | 12 ++++----
 .../metadata/SQLMetadataStorageActionHandler.java  | 12 ++++----
 .../SQLMetadataStorageActionHandlerFactory.java    | 12 ++++----
 .../metadata/SQLMetadataSupervisorManager.java     | 12 ++++----
 .../SQLServerMetadataStorageActionHandler.java     | 12 ++++----
 ...LServerMetadataStorageActionHandlerFactory.java | 12 ++++----
 .../druid/metadata/SegmentPublisherProvider.java   | 12 ++++----
 .../metadata/storage/derby/DerbyConnector.java     | 12 ++++----
 .../storage/derby/DerbyMetadataStorage.java        | 12 ++++----
 .../derby/DerbyMetadataStorageDruidModule.java     | 12 ++++----
 .../derby/DerbyMetadataStorageProvider.java        | 12 ++++----
 .../io/druid/offheap/OffheapBufferGenerator.java   | 12 ++++----
 .../io/druid/query/LocatedSegmentDescriptor.java   | 12 ++++----
 .../druid/query/ResultLevelCachingQueryRunner.java | 12 ++++----
 .../druid/query/dimension/LookupDimensionSpec.java | 12 ++++----
 .../io/druid/query/expression/LookupExprMacro.java | 12 ++++----
 .../query/lookup/LookupIntrospectionResource.java  | 12 ++++----
 .../java/io/druid/query/lookup/LookupModule.java   | 12 ++++----
 .../query/lookup/LookupReferencesManager.java      | 12 ++++----
 .../query/lookup/MapLookupExtractorFactory.java    | 12 ++++----
 .../query/lookup/RegisteredLookupExtractionFn.java | 12 ++++----
 .../java/io/druid/segment/indexing/DataSchema.java | 12 ++++----
 .../java/io/druid/segment/indexing/IOConfig.java   | 12 ++++----
 .../io/druid/segment/indexing/IngestionSpec.java   | 12 ++++----
 .../druid/segment/indexing/RealtimeIOConfig.java   | 12 ++++----
 .../segment/indexing/RealtimeTuningConfig.java     | 12 ++++----
 .../io/druid/segment/indexing/TuningConfig.java    | 12 ++++----
 .../io/druid/segment/indexing/TuningConfigs.java   | 12 ++++----
 .../granularity/ArbitraryGranularitySpec.java      | 12 ++++----
 .../indexing/granularity/GranularitySpec.java      | 12 ++++----
 .../granularity/UniformGranularitySpec.java        | 12 ++++----
 .../segment/loading/LocalDataSegmentFinder.java    | 12 ++++----
 .../segment/loading/LocalDataSegmentKiller.java    | 12 ++++----
 .../segment/loading/LocalDataSegmentPuller.java    | 12 ++++----
 .../segment/loading/LocalDataSegmentPusher.java    | 12 ++++----
 .../loading/LocalDataSegmentPusherConfig.java      | 12 ++++----
 .../loading/LocalFileTimestampVersionFinder.java   | 12 ++++----
 .../io/druid/segment/loading/LocalLoadSpec.java    | 12 ++++----
 .../segment/loading/OmniDataSegmentArchiver.java   | 12 ++++----
 .../segment/loading/OmniDataSegmentKiller.java     | 12 ++++----
 .../segment/loading/OmniDataSegmentMover.java      | 12 ++++----
 .../io/druid/segment/loading/SegmentLoader.java    | 12 ++++----
 .../druid/segment/loading/SegmentLoaderConfig.java | 12 ++++----
 .../loading/SegmentLoaderLocalCacheManager.java    | 12 ++++----
 .../io/druid/segment/loading/StorageLocation.java  | 12 ++++----
 .../segment/loading/StorageLocationConfig.java     | 12 ++++----
 .../segment/realtime/DbSegmentPublisherConfig.java | 12 ++++----
 .../io/druid/segment/realtime/FireDepartment.java  | 12 ++++----
 .../segment/realtime/FireDepartmentConfig.java     | 12 ++++----
 .../segment/realtime/FireDepartmentMetrics.java    | 12 ++++----
 .../io/druid/segment/realtime/FireHydrant.java     | 12 ++++----
 .../segment/realtime/NoopSegmentPublisher.java     | 12 ++++----
 .../io/druid/segment/realtime/RealtimeManager.java | 12 ++++----
 .../segment/realtime/RealtimeMetricsMonitor.java   | 12 ++++----
 .../druid/segment/realtime/SegmentPublisher.java   | 12 ++++----
 .../realtime/appenderator/Appenderator.java        | 12 ++++----
 .../realtime/appenderator/AppenderatorConfig.java  | 12 ++++----
 .../appenderator/AppenderatorDriverAddResult.java  | 12 ++++----
 .../appenderator/AppenderatorDriverMetadata.java   | 12 ++++----
 .../realtime/appenderator/AppenderatorFactory.java | 12 ++++----
 .../realtime/appenderator/AppenderatorImpl.java    | 12 ++++----
 .../realtime/appenderator/AppenderatorPlumber.java | 12 ++++----
 .../appenderator/AppenderatorPlumberSchool.java    | 12 ++++----
 .../realtime/appenderator/Appenderators.java       | 12 ++++----
 .../appenderator/BaseAppenderatorDriver.java       | 12 ++++----
 .../appenderator/BatchAppenderatorDriver.java      | 12 ++++----
 .../segment/realtime/appenderator/Committed.java   | 12 ++++----
 .../DefaultOfflineAppenderatorFactory.java         | 12 ++++----
 .../DefaultRealtimeAppenderatorFactory.java        | 12 ++++----
 .../realtime/appenderator/SegmentAllocator.java    | 12 ++++----
 .../realtime/appenderator/SegmentIdentifier.java   | 12 ++++----
 .../appenderator/SegmentNotWritableException.java  | 12 ++++----
 .../realtime/appenderator/SegmentWithState.java    | 12 ++++----
 .../realtime/appenderator/SegmentsAndMetadata.java | 12 ++++----
 .../appenderator/SinkQuerySegmentWalker.java       | 12 ++++----
 .../appenderator/StreamAppenderatorDriver.java     | 12 ++++----
 .../TransactionalSegmentPublisher.java             | 12 ++++----
 .../realtime/appenderator/UsedSegmentChecker.java  | 12 ++++----
 .../segment/realtime/firehose/ChatHandler.java     | 12 ++++----
 .../realtime/firehose/ChatHandlerProvider.java     | 12 ++++----
 .../realtime/firehose/ChatHandlerResource.java     | 12 ++++----
 .../realtime/firehose/ClippedFirehoseFactory.java  | 12 ++++----
 .../firehose/CombiningFirehoseFactory.java         | 12 ++++----
 .../segment/realtime/firehose/EventReceiver.java   | 12 ++++----
 .../firehose/EventReceiverFirehoseFactory.java     | 12 ++++----
 .../firehose/FixedCountFirehoseFactory.java        | 12 ++++----
 .../realtime/firehose/HttpFirehoseFactory.java     | 12 ++++----
 .../realtime/firehose/IngestSegmentFirehose.java   | 12 ++++----
 .../segment/realtime/firehose/IrcDecoder.java      | 12 ++++----
 .../realtime/firehose/IrcFirehoseFactory.java      | 12 ++++----
 .../realtime/firehose/IrcInputRowParser.java       | 12 ++++----
 .../realtime/firehose/LocalFirehoseFactory.java    | 12 ++++----
 .../realtime/firehose/NoopChatHandlerProvider.java | 12 ++++----
 .../realtime/firehose/PredicateFirehose.java       | 12 ++++----
 .../ServiceAnnouncingChatHandlerProvider.java      | 12 ++++----
 .../realtime/firehose/SqlFirehoseFactory.java      | 12 ++++----
 .../firehose/TimedShutoffFirehoseFactory.java      | 12 ++++----
 .../realtime/firehose/WikipediaIrcDecoder.java     | 12 ++++----
 .../realtime/firehose/WindowedStorageAdapter.java  | 12 ++++----
 .../druid/segment/realtime/plumber/Committers.java | 12 ++++----
 .../CoordinatorBasedSegmentHandoffNotifier.java    | 12 ++++----
 ...ordinatorBasedSegmentHandoffNotifierConfig.java | 12 ++++----
 ...rdinatorBasedSegmentHandoffNotifierFactory.java | 12 ++++----
 .../realtime/plumber/CustomVersioningPolicy.java   | 12 ++++----
 .../segment/realtime/plumber/FlushingPlumber.java  | 12 ++++----
 .../realtime/plumber/FlushingPlumberSchool.java    | 12 ++++----
 .../plumber/IntervalStartVersioningPolicy.java     | 12 ++++----
 .../plumber/MessageTimeRejectionPolicyFactory.java | 12 ++++----
 .../plumber/NoopRejectionPolicyFactory.java        | 12 ++++----
 .../plumber/NoopSegmentHandoffNotifierFactory.java | 12 ++++----
 .../io/druid/segment/realtime/plumber/Plumber.java | 12 ++++----
 .../segment/realtime/plumber/PlumberSchool.java    | 12 ++++----
 .../druid/segment/realtime/plumber/Plumbers.java   | 12 ++++----
 .../segment/realtime/plumber/RealtimePlumber.java  | 12 ++++----
 .../realtime/plumber/RealtimePlumberSchool.java    | 12 ++++----
 .../segment/realtime/plumber/RejectionPolicy.java  | 12 ++++----
 .../realtime/plumber/RejectionPolicyFactory.java   | 12 ++++----
 .../realtime/plumber/SegmentHandoffNotifier.java   | 12 ++++----
 .../plumber/SegmentHandoffNotifierFactory.java     | 12 ++++----
 .../plumber/ServerTimeRejectionPolicyFactory.java  | 12 ++++----
 .../io/druid/segment/realtime/plumber/Sink.java    | 12 ++++----
 .../segment/realtime/plumber/VersioningPolicy.java | 12 ++++----
 .../server/AsyncManagementForwardingServlet.java   | 12 ++++----
 .../druid/server/AsyncQueryForwardingServlet.java  | 12 ++++----
 .../java/io/druid/server/BrokerQueryResource.java  | 12 ++++----
 .../java/io/druid/server/ClientInfoResource.java   | 12 ++++----
 .../io/druid/server/ClientQuerySegmentWalker.java  | 12 ++++----
 .../src/main/java/io/druid/server/DruidNode.java   | 12 ++++----
 .../java/io/druid/server/GuiceServletConfig.java   | 12 ++++----
 .../main/java/io/druid/server/QueryLifecycle.java  | 12 ++++----
 .../io/druid/server/QueryLifecycleFactory.java     | 12 ++++----
 .../main/java/io/druid/server/QueryManager.java    | 12 ++++----
 .../main/java/io/druid/server/QueryResource.java   | 12 ++++----
 .../src/main/java/io/druid/server/QueryStats.java  | 12 ++++----
 .../main/java/io/druid/server/RequestLogLine.java  | 12 ++++----
 .../main/java/io/druid/server/SegmentManager.java  | 12 ++++----
 .../server/SetAndVerifyContextQueryRunner.java     | 12 ++++----
 .../main/java/io/druid/server/StatusResource.java  | 12 ++++----
 .../main/java/io/druid/server/ZkPathsModule.java   | 12 ++++----
 .../druid/server/audit/AuditManagerProvider.java   | 12 ++++----
 .../io/druid/server/audit/SQLAuditManager.java     | 12 ++++----
 .../druid/server/audit/SQLAuditManagerConfig.java  | 12 ++++----
 .../server/audit/SQLAuditManagerProvider.java      | 12 ++++----
 .../coordination/BatchDataSegmentAnnouncer.java    | 12 ++++----
 .../BatchDataSegmentAnnouncerProvider.java         | 12 ++++----
 .../server/coordination/ChangeRequestHistory.java  | 12 ++++----
 .../coordination/ChangeRequestHttpSyncer.java      | 12 ++++----
 .../coordination/ChangeRequestsSnapshot.java       | 12 ++++----
 .../CuratorDataSegmentServerAnnouncer.java         | 12 ++++----
 .../server/coordination/DataSegmentAnnouncer.java  | 12 ++++----
 .../coordination/DataSegmentAnnouncerProvider.java | 12 ++++----
 .../coordination/DataSegmentChangeCallback.java    | 12 ++++----
 .../coordination/DataSegmentChangeHandler.java     | 12 ++++----
 .../coordination/DataSegmentChangeRequest.java     | 12 ++++----
 .../coordination/DataSegmentServerAnnouncer.java   | 12 ++++----
 .../server/coordination/DruidServerMetadata.java   | 12 ++++----
 .../coordination/NoopDataSegmentAnnouncer.java     | 12 ++++----
 .../coordination/SegmentChangeRequestDrop.java     | 12 ++++----
 .../coordination/SegmentChangeRequestLoad.java     | 12 ++++----
 .../coordination/SegmentChangeRequestNoop.java     | 12 ++++----
 .../coordination/SegmentLoadDropHandler.java       | 12 ++++----
 .../druid/server/coordination/ServerManager.java   | 12 ++++----
 .../io/druid/server/coordination/ServerType.java   | 12 ++++----
 .../druid/server/coordination/ZkCoordinator.java   | 12 ++++----
 .../server/coordination/broker/DruidBroker.java    | 12 ++++----
 .../server/coordinator/BalancerSegmentHolder.java  | 12 ++++----
 .../druid/server/coordinator/BalancerStrategy.java | 12 ++++----
 .../coordinator/BalancerStrategyFactory.java       | 12 ++++----
 .../coordinator/CachingCostBalancerStrategy.java   | 12 ++++----
 .../CachingCostBalancerStrategyFactory.java        | 12 ++++----
 .../coordinator/CoordinatorCompactionConfig.java   | 12 ++++----
 .../coordinator/CoordinatorDynamicConfig.java      | 12 ++++----
 .../CoordinatorOverlordServiceConfig.java          | 12 ++++----
 .../druid/server/coordinator/CoordinatorStats.java | 12 ++++----
 .../server/coordinator/CostBalancerStrategy.java   | 12 ++++----
 .../coordinator/CostBalancerStrategyFactory.java   | 12 ++++----
 .../server/coordinator/CuratorLoadQueuePeon.java   | 12 ++++----
 .../coordinator/DataSourceCompactionConfig.java    | 12 ++++----
 .../server/coordinator/DatasourceWhitelist.java    | 12 ++++----
 .../DiskNormalizedCostBalancerStrategy.java        | 12 ++++----
 .../DiskNormalizedCostBalancerStrategyFactory.java | 12 ++++----
 .../io/druid/server/coordinator/DruidCluster.java  | 12 ++++----
 .../druid/server/coordinator/DruidCoordinator.java | 12 ++++----
 .../DruidCoordinatorCleanupPendingSegments.java    | 12 ++++----
 .../server/coordinator/DruidCoordinatorConfig.java | 12 ++++----
 .../coordinator/DruidCoordinatorRuntimeParams.java | 12 ++++----
 .../server/coordinator/HttpLoadQueuePeon.java      | 12 ++++----
 .../druid/server/coordinator/LoadPeonCallback.java | 12 ++++----
 .../io/druid/server/coordinator/LoadQueuePeon.java | 12 ++++----
 .../server/coordinator/LoadQueueTaskMaster.java    | 12 ++++----
 .../server/coordinator/RandomBalancerStrategy.java | 12 ++++----
 .../coordinator/RandomBalancerStrategyFactory.java | 12 ++++----
 .../server/coordinator/ReplicationThrottler.java   | 12 ++++----
 .../coordinator/ReservoirSegmentSampler.java       | 12 ++++----
 .../server/coordinator/SegmentReplicantLookup.java | 12 ++++----
 .../io/druid/server/coordinator/ServerHolder.java  | 12 ++++----
 .../server/coordinator/cost/ClusterCostCache.java  | 12 ++++----
 .../server/coordinator/cost/SegmentsCostCache.java | 12 ++++----
 .../server/coordinator/cost/ServerCostCache.java   | 12 ++++----
 .../server/coordinator/cost/package-info.java      | 12 ++++----
 .../helper/CompactionSegmentIterator.java          | 12 ++++----
 .../helper/CompactionSegmentSearchPolicy.java      | 12 ++++----
 .../helper/DruidCoordinatorBalancer.java           | 12 ++++----
 .../DruidCoordinatorCleanupOvershadowed.java       | 12 ++++----
 .../helper/DruidCoordinatorCleanupUnneeded.java    | 12 ++++----
 .../coordinator/helper/DruidCoordinatorHelper.java | 12 ++++----
 .../coordinator/helper/DruidCoordinatorLogger.java | 12 ++++----
 .../helper/DruidCoordinatorRuleRunner.java         | 12 ++++----
 .../helper/DruidCoordinatorSegmentCompactor.java   | 12 ++++----
 .../helper/DruidCoordinatorSegmentInfoLoader.java  | 12 ++++----
 .../helper/DruidCoordinatorSegmentKiller.java      | 12 ++++----
 .../helper/DruidCoordinatorSegmentMerger.java      | 12 ++++----
 .../helper/DruidCoordinatorVersionConverter.java   | 12 ++++----
 .../helper/NewestSegmentFirstIterator.java         | 12 ++++----
 .../helper/NewestSegmentFirstPolicy.java           | 12 ++++----
 .../coordinator/helper/SegmentCompactorUtil.java   | 12 ++++----
 .../rules/BroadcastDistributionRule.java           | 12 ++++----
 .../druid/server/coordinator/rules/DropRule.java   | 12 ++++----
 .../rules/ForeverBroadcastDistributionRule.java    | 12 ++++----
 .../server/coordinator/rules/ForeverDropRule.java  | 12 ++++----
 .../server/coordinator/rules/ForeverLoadRule.java  | 12 ++++----
 .../rules/IntervalBroadcastDistributionRule.java   | 12 ++++----
 .../server/coordinator/rules/IntervalDropRule.java | 12 ++++----
 .../server/coordinator/rules/IntervalLoadRule.java | 12 ++++----
 .../druid/server/coordinator/rules/LoadRule.java   | 12 ++++----
 .../rules/PeriodBroadcastDistributionRule.java     | 12 ++++----
 .../server/coordinator/rules/PeriodDropRule.java   | 12 ++++----
 .../server/coordinator/rules/PeriodLoadRule.java   | 12 ++++----
 .../io/druid/server/coordinator/rules/Rule.java    | 12 ++++----
 .../io/druid/server/coordinator/rules/RuleMap.java | 12 ++++----
 .../io/druid/server/coordinator/rules/Rules.java   | 12 ++++----
 .../server/emitter/ComposingEmitterConfig.java     | 12 ++++----
 .../server/emitter/ComposingEmitterModule.java     | 12 ++++----
 .../io/druid/server/emitter/EmitterModule.java     | 12 ++++----
 .../server/emitter/ExtraServiceDimensions.java     | 12 ++++----
 .../io/druid/server/emitter/HttpEmitterModule.java | 12 ++++----
 .../server/emitter/HttpEmitterSSLClientConfig.java | 12 ++++----
 .../druid/server/emitter/HttpEmittingMonitor.java  | 12 ++++----
 .../io/druid/server/emitter/LogEmitterModule.java  | 12 ++++----
 .../io/druid/server/emitter/NoopEmitterModule.java | 12 ++++----
 .../emitter/ParametrizedUriEmitterModule.java      | 12 ++++----
 .../ParametrizedUriEmitterSSLClientConfig.java     | 12 ++++----
 .../java/io/druid/server/http/BrokerResource.java  | 12 ++++----
 .../java/io/druid/server/http/ClusterResource.java | 12 ++++----
 .../http/CoordinatorCompactionConfigsResource.java | 12 ++++----
 .../http/CoordinatorDynamicConfigsResource.java    | 12 ++++----
 .../druid/server/http/CoordinatorRedirectInfo.java | 12 ++++----
 .../io/druid/server/http/CoordinatorResource.java  | 12 ++++----
 .../io/druid/server/http/DatasourcesResource.java  | 12 ++++----
 .../io/druid/server/http/HistoricalResource.java   | 12 ++++----
 .../druid/server/http/HostAndPortWithScheme.java   | 12 ++++----
 .../io/druid/server/http/IntervalsResource.java    | 12 ++++----
 .../io/druid/server/http/InventoryViewUtils.java   | 12 ++++----
 .../server/http/LookupCoordinatorResource.java     | 12 ++++----
 .../io/druid/server/http/MetadataResource.java     | 12 ++++----
 .../io/druid/server/http/OverlordProxyServlet.java | 12 ++++----
 .../java/io/druid/server/http/RedirectFilter.java  | 12 ++++----
 .../java/io/druid/server/http/RedirectInfo.java    | 12 ++++----
 .../java/io/druid/server/http/RouterResource.java  | 12 ++++----
 .../java/io/druid/server/http/RulesResource.java   | 12 ++++----
 .../druid/server/http/SegmentListerResource.java   | 12 ++++----
 .../java/io/druid/server/http/SegmentToDrop.java   | 12 ++++----
 .../java/io/druid/server/http/SegmentToMove.java   | 12 ++++----
 .../java/io/druid/server/http/ServersResource.java | 12 ++++----
 .../java/io/druid/server/http/TiersResource.java   | 12 ++++----
 .../http/security/AbstractResourceFilter.java      | 12 ++++----
 .../server/http/security/ConfigResourceFilter.java | 12 ++++----
 .../http/security/DatasourceResourceFilter.java    | 12 ++++----
 .../server/http/security/RulesResourceFilter.java  | 12 ++++----
 .../server/http/security/StateResourceFilter.java  | 12 ++++----
 .../initialization/AuthenticatorMapperModule.java  | 12 ++++----
 .../initialization/AuthorizerMapperModule.java     | 12 ++++----
 .../BatchDataSegmentAnnouncerConfig.java           | 12 ++++----
 .../initialization/CuratorDiscoveryConfig.java     | 12 ++++----
 .../druid/server/initialization/ServerConfig.java  | 12 ++++----
 .../server/initialization/TLSServerConfig.java     | 12 ++++----
 .../druid/server/initialization/ZkPathsConfig.java | 12 ++++----
 .../jetty/ChatHandlerServerModule.java             | 12 ++++----
 .../jetty/CustomExceptionMapper.java               | 12 ++++----
 .../jetty/ForbiddenExceptionMapper.java            | 12 ++++----
 .../server/initialization/jetty/JettyBindings.java | 12 ++++----
 .../jetty/JettyMonitoringConnectionFactory.java    | 12 ++++----
 .../initialization/jetty/JettyRequestLog.java      | 12 ++++----
 .../initialization/jetty/JettyServerInitUtils.java | 12 ++++----
 .../jetty/JettyServerInitializer.java              | 12 ++++----
 .../initialization/jetty/JettyServerModule.java    | 12 ++++----
 .../initialization/jetty/LimitRequestsFilter.java  | 12 ++++----
 .../jetty/ResponseHeaderFilterHolder.java          | 12 ++++----
 .../initialization/jetty/ServletFilterHolder.java  | 12 ++++----
 .../jetty/TaskIdResponseHeaderFilterHolder.java    | 12 ++++----
 .../announcer/ListenerResourceAnnouncer.java       | 12 ++++----
 .../announcer/ListeningAnnouncerConfig.java        | 12 ++++----
 .../listener/resource/AbstractListenerHandler.java | 12 ++++----
 .../server/listener/resource/ListenerHandler.java  | 12 ++++----
 .../server/listener/resource/ListenerResource.java | 12 ++++----
 .../server/log/ComposingRequestLoggerProvider.java | 12 ++++----
 .../io/druid/server/log/EmittingRequestLogger.java | 12 ++++----
 .../server/log/EmittingRequestLoggerProvider.java  | 12 ++++----
 .../io/druid/server/log/FileRequestLogger.java     | 12 ++++----
 .../server/log/FileRequestLoggerProvider.java      | 12 ++++----
 .../server/log/FilteredRequestLoggerProvider.java  | 12 ++++----
 .../io/druid/server/log/LoggingRequestLogger.java  | 12 ++++----
 .../server/log/LoggingRequestLoggerProvider.java   | 12 ++++----
 .../io/druid/server/log/NoopRequestLogger.java     | 12 ++++----
 .../server/log/NoopRequestLoggerProvider.java      | 12 ++++----
 .../java/io/druid/server/log/RequestLogger.java    | 12 ++++----
 .../io/druid/server/log/RequestLoggerProvider.java | 12 ++++----
 .../io/druid/server/log/StartupLoggingConfig.java  | 12 ++++----
 .../lookup/cache/LookupCoordinatorManager.java     | 12 ++++----
 .../cache/LookupCoordinatorManagerConfig.java      | 12 ++++----
 .../cache/LookupExtractorFactoryMapContainer.java  | 12 ++++----
 .../server/lookup/cache/LookupNodeDiscovery.java   | 12 ++++----
 .../server/metrics/DataSourceTaskIdHolder.java     | 12 ++++----
 .../metrics/DruidMonitorSchedulerConfig.java       | 12 ++++----
 .../io/druid/server/metrics/DruidSysMonitor.java   | 12 ++++----
 .../metrics/EventReceiverFirehoseMetric.java       | 12 ++++----
 .../metrics/EventReceiverFirehoseMonitor.java      | 12 ++++----
 .../metrics/EventReceiverFirehoseRegister.java     | 12 ++++----
 .../server/metrics/HistoricalMetricsMonitor.java   | 12 ++++----
 .../io/druid/server/metrics/MetricsModule.java     | 12 ++++----
 .../io/druid/server/metrics/MonitorsConfig.java    | 12 ++++----
 .../server/metrics/QueryCountStatsMonitor.java     | 12 ++++----
 .../server/metrics/QueryCountStatsProvider.java    | 12 ++++----
 .../server/router/AvaticaConnectionBalancer.java   | 12 ++++----
 .../ConsistentHashAvaticaConnectionBalancer.java   | 12 ++++----
 .../io/druid/server/router/ConsistentHasher.java   | 12 ++++----
 .../server/router/CoordinatorRuleManager.java      | 12 ++++----
 .../JavaScriptTieredBrokerSelectorStrategy.java    | 12 ++++----
 .../druid/server/router/ManagementProxyConfig.java | 12 ++++----
 .../PriorityTieredBrokerSelectorStrategy.java      | 12 ++++----
 .../io/druid/server/router/QueryHostFinder.java    | 12 ++++----
 .../RendezvousHashAvaticaConnectionBalancer.java   | 12 ++++----
 .../io/druid/server/router/RendezvousHasher.java   | 12 ++++----
 .../main/java/io/druid/server/router/Router.java   | 12 ++++----
 .../io/druid/server/router/TieredBrokerConfig.java | 12 ++++----
 .../server/router/TieredBrokerHostSelector.java    | 12 ++++----
 .../TieredBrokerSelectorStrategiesProvider.java    | 12 ++++----
 .../router/TieredBrokerSelectorStrategy.java       | 12 ++++----
 .../TimeBoundaryTieredBrokerSelectorStrategy.java  | 12 ++++----
 .../main/java/io/druid/server/security/Access.java | 12 ++++----
 .../main/java/io/druid/server/security/Action.java | 12 ++++----
 .../server/security/AllowAllAuthenticator.java     | 12 ++++----
 .../druid/server/security/AllowAllAuthorizer.java  | 12 ++++----
 .../security/AllowOptionsResourceFilter.java       | 12 ++++----
 .../server/security/AnonymousAuthenticator.java    | 12 ++++----
 .../java/io/druid/server/security/AuthConfig.java  | 12 ++++----
 .../io/druid/server/security/AuthTestUtils.java    | 12 ++++----
 .../server/security/AuthenticationResult.java      | 12 ++++----
 .../druid/server/security/AuthenticationUtils.java | 12 ++++----
 .../security/AuthenticationWrappingFilter.java     | 12 ++++----
 .../io/druid/server/security/Authenticator.java    | 12 ++++----
 .../druid/server/security/AuthenticatorMapper.java | 12 ++++----
 .../druid/server/security/AuthorizationUtils.java  | 12 ++++----
 .../java/io/druid/server/security/Authorizer.java  | 12 ++++----
 .../io/druid/server/security/AuthorizerMapper.java | 12 ++++----
 .../java/io/druid/server/security/Escalator.java   | 12 ++++----
 .../druid/server/security/ForbiddenException.java  | 12 ++++----
 .../io/druid/server/security/NoopEscalator.java    | 12 ++++----
 .../PreResponseAuthorizationCheckFilter.java       | 12 ++++----
 .../java/io/druid/server/security/Resource.java    | 12 ++++----
 .../io/druid/server/security/ResourceAction.java   | 12 ++++----
 .../io/druid/server/security/ResourceType.java     | 12 ++++----
 .../server/security/SecuritySanityCheckFilter.java | 12 ++++----
 .../java/io/druid/server/security/TLSUtils.java    | 12 ++++----
 .../server/security/UnsecuredResourceFilter.java   | 12 ++++----
 .../partition/HashBasedNumberedShardSpec.java      | 12 ++++----
 .../druid/timeline/partition/LinearShardSpec.java  | 12 ++++----
 .../timeline/partition/NumberedShardSpec.java      | 12 ++++----
 .../partition/SingleDimensionShardSpec.java        | 12 ++++----
 .../main/resources/static/old-console/cluster.html | 26 +++++++++--------
 .../main/resources/static/old-console/config.html  | 26 +++++++++--------
 .../main/resources/static/old-console/enable.html  | 26 +++++++++--------
 .../main/resources/static/old-console/index.html   | 26 +++++++++--------
 .../main/resources/static/old-console/kill.html    | 26 +++++++++--------
 .../main/resources/static/old-console/rules.html   | 26 +++++++++--------
 .../main/resources/static/old-console/view.html    | 26 +++++++++--------
 .../client/BrokerSegmentWatcherConfigTest.java     | 12 ++++----
 .../java/io/druid/client/BrokerServerViewTest.java | 12 ++++----
 .../CachingClusteredClientFunctionalityTest.java   | 12 ++++----
 .../druid/client/CachingClusteredClientTest.java   | 12 ++++----
 .../io/druid/client/CachingQueryRunnerTest.java    | 12 ++++----
 .../io/druid/client/CoordinatorServerViewTest.java | 12 ++++----
 .../io/druid/client/DirectDruidClientTest.java     | 12 ++++----
 .../client/HttpServerInventoryViewConfigTest.java  | 12 ++++----
 .../druid/client/HttpServerInventoryViewTest.java  | 12 ++++----
 .../druid/client/ImmutableDruidDataSourceTest.java | 12 ++++----
 .../test/java/io/druid/client/RangeIterable.java   | 12 ++++----
 .../druid/client/cache/ByteCountingLRUMapTest.java | 12 ++++----
 .../client/cache/BytesBoundedLinkedQueueTest.java  | 12 ++++----
 .../io/druid/client/cache/CacheConfigTest.java     | 12 ++++----
 .../druid/client/cache/CacheDistributionTest.java  | 12 ++++----
 .../io/druid/client/cache/CacheMonitorTest.java    | 12 ++++----
 .../io/druid/client/cache/CaffeineCacheTest.java   | 12 ++++----
 .../io/druid/client/cache/HybridCacheTest.java     | 12 ++++----
 .../java/io/druid/client/cache/MapCacheTest.java   | 12 ++++----
 .../druid/client/cache/MemcacheClientPoolTest.java | 12 ++++----
 .../client/cache/MemcachedCacheBenchmark.java      | 12 ++++----
 .../io/druid/client/cache/MemcachedCacheTest.java  | 12 ++++----
 .../client/BatchServerInventoryViewTest.java       | 12 ++++----
 .../client/ImmutableSegmentLoadInfoTest.java       | 12 ++++----
 .../client/indexing/ClientAppendQueryTest.java     | 12 ++++----
 .../client/indexing/ClientConversionQueryTest.java | 12 ++++----
 .../druid/client/indexing/ClientKillQueryTest.java | 12 ++++----
 .../client/indexing/ClientMergeQueryTest.java      | 12 ++++----
 .../druid/client/selector/ServerSelectorTest.java  | 12 ++++----
 .../client/selector/TierSelectorStrategyTest.java  | 12 ++++----
 .../java/io/druid/curator/CuratorConfigTest.java   | 12 ++++----
 .../java/io/druid/curator/CuratorModuleTest.java   | 12 ++++----
 .../java/io/druid/curator/CuratorTestBase.java     | 12 ++++----
 .../java/io/druid/curator/CuratorUtilsTest.java    | 12 ++++----
 .../java/io/druid/curator/ExhibitorConfigTest.java | 12 ++++----
 .../druid/curator/announcement/AnnouncerTest.java  | 12 ++++----
 .../discovery/CuratorDruidLeaderSelectorTest.java  | 12 ++++----
 .../CuratorDruidNodeAnnouncerAndDiscoveryTest.java | 12 ++++----
 .../discovery/ServerDiscoverySelectorTest.java     | 12 ++++----
 .../curator/discovery/ServiceAnnouncerTest.java    | 12 ++++----
 .../inventory/CuratorInventoryManagerTest.java     | 12 ++++----
 .../io/druid/discovery/DataNodeServiceTest.java    | 12 ++++----
 .../io/druid/discovery/DruidLeaderClientTest.java  | 12 ++++----
 .../discovery/DruidNodeDiscoveryProviderTest.java  | 12 ++++----
 .../io/druid/discovery/LookupNodeServiceTest.java  | 12 ++++----
 .../io/druid/discovery/WorkerNodeServiceTest.java  | 12 ++++----
 .../io/druid/guice/DruidProcessingModuleTest.java  | 12 ++++----
 .../java/io/druid/guice/JavaScriptModuleTest.java  | 12 ++++----
 .../java/io/druid/guice/JsonConfigTesterBase.java  | 12 ++++----
 .../io/druid/guice/JsonConfigTesterBaseTest.java   | 12 ++++----
 .../initialization/ComposingEmitterModuleTest.java | 12 ++++----
 .../druid/initialization/InitializationTest.java   | 12 ++++----
 .../io/druid/initialization/ZkPathsConfigTest.java | 12 ++++----
 .../IndexerSQLMetadataStorageCoordinatorTest.java  | 12 ++++----
 .../druid/metadata/SQLMetadataConnectorTest.java   | 12 ++++----
 .../druid/metadata/SQLMetadataRuleManagerTest.java | 12 ++++----
 .../metadata/SQLMetadataSegmentManagerTest.java    | 12 ++++----
 .../SQLMetadataStorageActionHandlerTest.java       | 12 ++++----
 .../metadata/SQLMetadataSupervisorManagerTest.java | 12 ++++----
 .../java/io/druid/metadata/TestDerbyConnector.java | 12 ++++----
 .../java/io/druid/metadata/TestSupervisorSpec.java | 12 ++++----
 .../query/LocatedSegmentDescriptorSerdeTest.java   | 12 ++++----
 .../query/dimension/LookupDimensionSpecTest.java   | 12 ++++----
 .../io/druid/query/expression/ExprMacroTest.java   | 12 ++++----
 .../LookupEnabledTestExprMacroTable.java           | 12 ++++----
 .../LookupIntrospectionResourceImplTest.java       | 12 ++++----
 .../lookup/LookupIntrospectionResourceTest.java    | 12 ++++----
 .../lookup/LookupListeningAnnouncerConfigTest.java | 12 ++++----
 .../query/lookup/LookupReferencesManagerTest.java  | 12 ++++----
 .../query/lookup/LookupSnapshotTakerTest.java      | 12 ++++----
 .../lookup/MapLookupExtractorFactoryTest.java      | 12 ++++----
 .../lookup/RegisteredLookupExtractionFnTest.java   | 12 ++++----
 .../firehose/CombiningFirehoseFactoryTest.java     | 12 ++++----
 .../io/druid/segment/indexing/DataSchemaTest.java  | 12 ++++----
 .../segment/indexing/RealtimeTuningConfigTest.java | 12 ++++----
 .../druid/segment/indexing/TransformSpecTest.java  | 12 ++++----
 .../granularity/ArbitraryGranularityTest.java      | 12 ++++----
 .../granularity/UniformGranularityTest.java        | 12 ++++----
 .../segment/loading/CacheTestSegmentLoader.java    | 12 ++++----
 .../io/druid/segment/loading/LoadSpecTest.java     | 12 ++++----
 .../loading/LocalDataSegmentFinderTest.java        | 12 ++++----
 .../loading/LocalDataSegmentKillerTest.java        | 12 ++++----
 .../loading/LocalDataSegmentPullerTest.java        | 12 ++++----
 .../loading/LocalDataSegmentPusherTest.java        | 12 ++++----
 .../LocalFileTimestampVersionFinderTest.java       | 12 ++++----
 .../SegmentLoaderLocalCacheManagerTest.java        | 12 ++++----
 .../druid/segment/loading/StorageLocationTest.java | 12 ++++----
 .../druid/segment/realtime/FireDepartmentTest.java | 12 ++++----
 .../segment/realtime/RealtimeManagerTest.java      | 12 ++++----
 .../appenderator/AppenderatorPlumberTest.java      | 12 ++++----
 .../realtime/appenderator/AppenderatorTest.java    | 12 ++++----
 .../realtime/appenderator/AppenderatorTester.java  | 12 ++++----
 .../appenderator/BatchAppenderatorDriverTest.java  | 12 ++++----
 .../realtime/appenderator/CommittedTest.java       | 12 ++++----
 .../DefaultOfflineAppenderatorFactoryTest.java     | 12 ++++----
 .../appenderator/SegmentIdentifierTest.java        | 12 ++++----
 .../appenderator/SegmentWithStateTest.java         | 12 ++++----
 .../StreamAppenderatorDriverFailTest.java          | 12 ++++----
 .../appenderator/StreamAppenderatorDriverTest.java | 12 ++++----
 .../appenderator/TestUsedSegmentChecker.java       | 12 ++++----
 .../firehose/EventReceiverFirehoseTest.java        | 12 ++++----
 .../realtime/firehose/HttpFirehoseFactoryTest.java | 12 ++++----
 .../firehose/IngestSegmentFirehoseTest.java        | 12 ++++----
 .../firehose/LocalFirehoseFactoryTest.java         | 12 ++++----
 .../ServiceAnnouncingChatHandlerProviderTest.java  | 12 ++++----
 .../realtime/firehose/SqlFirehoseFactoryTest.java  | 12 ++++----
 ...CoordinatorBasedSegmentHandoffNotifierTest.java | 12 ++++----
 .../plumber/CustomVersioningPolicyTest.java        | 12 ++++----
 .../plumber/IntervalStartVersioningPolicyTest.java | 12 ++++----
 .../MessageTimeRejectionPolicyFactoryTest.java     | 12 ++++----
 .../plumber/RealtimePlumberSchoolTest.java         | 12 ++++----
 .../ServerTimeRejectionPolicyFactoryTest.java      | 12 ++++----
 .../druid/segment/realtime/plumber/SinkTest.java   | 12 ++++----
 .../AsyncManagementForwardingServletTest.java      | 12 ++++----
 .../server/AsyncQueryForwardingServletTest.java    | 12 ++++----
 .../io/druid/server/ClientInfoResourceTest.java    | 29 ++++--------------
 .../java/io/druid/server/ConsistentHasherTest.java | 12 ++++----
 .../test/java/io/druid/server/DruidNodeTest.java   | 12 ++++----
 .../java/io/druid/server/QueryResourceTest.java    | 12 ++++----
 .../java/io/druid/server/RendezvousHasherTest.java | 12 ++++----
 .../java/io/druid/server/SegmentManagerTest.java   | 12 ++++----
 .../java/io/druid/server/ServerTestHelper.java     | 12 ++++----
 .../java/io/druid/server/StatusResourceTest.java   | 12 ++++----
 .../io/druid/server/audit/SQLAuditManagerTest.java | 12 ++++----
 .../coordination/ChangeRequestHistoryTest.java     | 12 ++++----
 .../coordination/ChangeRequestHttpSyncerTest.java  | 12 ++++----
 .../coordination/SegmentChangeRequestDropTest.java | 12 ++++----
 .../coordination/SegmentChangeRequestLoadTest.java | 12 ++++----
 .../coordination/SegmentLoadDropHandlerTest.java   | 12 ++++----
 .../server/coordination/ServerManagerTest.java     | 12 ++++----
 .../druid/server/coordination/ServerTypeTest.java  | 12 ++++----
 .../server/coordination/ZkCoordinatorTest.java     | 12 ++++----
 .../BatchDataSegmentAnnouncerTest.java             | 12 ++++----
 .../server/coordinator/CoordinatorStatsTest.java   | 12 ++++----
 .../coordinator/CostBalancerStrategyBenchmark.java | 12 ++++----
 .../coordinator/CostBalancerStrategyTest.java      | 12 ++++----
 .../coordinator/CuratorDruidCoordinatorTest.java   | 12 ++++----
 .../DiskNormalizedCostBalancerStrategyTest.java    | 12 ++++----
 .../druid/server/coordinator/DruidClusterTest.java | 12 ++++----
 .../DruidCoordinatorBalancerProfiler.java          | 12 ++++----
 .../coordinator/DruidCoordinatorBalancerTest.java  | 12 ++++----
 .../DruidCoordinatorBalancerTester.java            | 12 ++++----
 .../coordinator/DruidCoordinatorConfigTest.java    | 12 ++++----
 .../DruidCoordinatorRuleRunnerTest.java            | 12 ++++----
 .../DruidCoordinatorSegmentMergerTest.java         | 12 ++++----
 .../server/coordinator/DruidCoordinatorTest.java   | 12 ++++----
 .../server/coordinator/HttpLoadQueuePeonTest.java  | 12 ++++----
 .../server/coordinator/LoadQueuePeonTest.java      | 12 ++++----
 .../server/coordinator/LoadQueuePeonTester.java    | 12 ++++----
 .../coordinator/ReservoirSegmentSamplerTest.java   | 12 ++++----
 .../druid/server/coordinator/ServerHolderTest.java | 12 ++++----
 .../coordinator/TestDruidCoordinatorConfig.java    | 12 ++++----
 .../cost/CachingCostBalancerStrategyTest.java      | 12 ++++----
 .../coordinator/cost/SegmentsCostCacheTest.java    | 12 ++++----
 .../DruidCoordinatorCleanupOvershadowedTest.java   | 12 ++++----
 .../DruidCoordinatorSegmentCompactorTest.java      | 12 ++++----
 .../helper/DruidCoordinatorSegmentKillerTest.java  | 12 ++++----
 .../helper/NewestSegmentFirstPolicyTest.java       | 12 ++++----
 .../rules/BroadcastDistributionRuleSerdeTest.java  | 12 ++++----
 .../rules/BroadcastDistributionRuleTest.java       | 12 ++++----
 .../coordinator/rules/ForeverLoadRuleTest.java     | 12 ++++----
 .../coordinator/rules/IntervalLoadRuleTest.java    | 12 ++++----
 .../server/coordinator/rules/LoadRuleTest.java     | 12 ++++----
 .../coordinator/rules/PeriodDropRuleTest.java      | 12 ++++----
 .../coordinator/rules/PeriodLoadRuleTest.java      | 12 ++++----
 .../io/druid/server/emitter/EmitterModuleTest.java | 12 ++++----
 .../server/http/CoordinatorDynamicConfigTest.java  | 12 ++++----
 .../server/http/CoordinatorRedirectInfoTest.java   | 12 ++++----
 .../druid/server/http/CoordinatorResourceTest.java | 12 ++++----
 .../druid/server/http/DatasourcesResourceTest.java | 12 ++++----
 .../druid/server/http/IntervalsResourceTest.java   | 12 ++++----
 .../server/http/LookupCoordinatorResourceTest.java | 12 ++++----
 .../server/http/OverlordProxyServletTest.java      | 12 ++++----
 .../io/druid/server/http/RulesResourceTest.java    | 12 ++++----
 .../io/druid/server/http/ServersResourceTest.java  | 12 ++++----
 .../PreResponseAuthorizationCheckFilterTest.java   | 12 ++++----
 .../http/security/ResourceFilterTestHelper.java    | 12 ++++----
 .../http/security/SecurityResourceFilterTest.java  | 12 ++++----
 .../security/SecuritySanityCheckFilterTest.java    | 12 ++++----
 .../druid/server/initialization/BaseJettyTest.java | 12 ++++----
 .../druid/server/initialization/JettyQosTest.java  | 12 ++++----
 .../io/druid/server/initialization/JettyTest.java  | 12 ++++----
 .../jetty/LimitRequestsFilterTest.java             | 12 ++++----
 .../announcer/ListenerResourceAnnouncerTest.java   | 12 ++++----
 .../resource/AbstractListenerHandlerTest.java      | 12 ++++----
 .../listener/resource/ListenerResourceTest.java    | 12 ++++----
 .../io/druid/server/log/FileRequestLoggerTest.java | 12 ++++----
 .../server/log/FilteredRequestLoggerTest.java      | 12 ++++----
 .../log/LoggingRequestLoggerProviderTest.java      | 12 ++++----
 .../druid/server/log/LoggingRequestLoggerTest.java | 12 ++++----
 .../io/druid/server/log/TestRequestLogger.java     | 12 ++++----
 .../cache/LookupCoordinatorManagerConfigTest.java  | 12 ++++----
 .../lookup/cache/LookupCoordinatorManagerTest.java | 12 ++++----
 .../LookupExtractorFactoryMapContainerTest.java    | 12 ++++----
 .../lookup/cache/LookupNodeDiscoveryTest.java      | 12 ++++----
 .../metrics/HistoricalMetricsMonitorTest.java      | 12 ++++----
 .../io/druid/server/metrics/MetricsModuleTest.java | 12 ++++----
 .../druid/server/metrics/NoopServiceEmitter.java   | 12 ++++----
 ...JavaScriptTieredBrokerSelectorStrategyTest.java | 12 ++++----
 .../druid/server/router/QueryHostFinderTest.java   | 12 ++++----
 .../router/TieredBrokerHostSelectorTest.java       | 12 ++++----
 .../io/druid/server/security/EscalatorTest.java    | 12 ++++----
 .../druid/server/shard/NumberedShardSpecTest.java  | 12 ++++----
 .../server/shard/SingleDimensionShardSpecTest.java | 12 ++++----
 .../java/io/druid/timeline/DataSegmentTest.java    | 12 ++++----
 .../partition/HashBasedNumberedShardSpecTest.java  | 12 ++++----
 .../status.resource.test.runtime.properties        | 19 ++++++++++++
 services/pom.xml                                   | 26 +++++++++--------
 services/src/main/java/io/druid/cli/CliBroker.java | 12 ++++----
 .../src/main/java/io/druid/cli/CliCoordinator.java | 12 ++++----
 .../main/java/io/druid/cli/CliHadoopIndexer.java   | 12 ++++----
 .../src/main/java/io/druid/cli/CliHistorical.java  | 12 ++++----
 .../io/druid/cli/CliInternalHadoopIndexer.java     | 12 ++++----
 .../main/java/io/druid/cli/CliMiddleManager.java   | 12 ++++----
 .../src/main/java/io/druid/cli/CliOverlord.java    | 12 ++++----
 services/src/main/java/io/druid/cli/CliPeon.java   | 12 ++++----
 .../src/main/java/io/druid/cli/CliRealtime.java    | 12 ++++----
 .../main/java/io/druid/cli/CliRealtimeExample.java | 12 ++++----
 services/src/main/java/io/druid/cli/CliRouter.java | 12 ++++----
 .../cli/CoordinatorJettyServerInitializer.java     | 12 ++++----
 .../druid/cli/CoordinatorOverlordRedirectInfo.java | 12 ++++----
 .../src/main/java/io/druid/cli/CreateTables.java   | 12 ++++----
 .../src/main/java/io/druid/cli/DumpSegment.java    | 12 ++++----
 .../src/main/java/io/druid/cli/GuiceRunnable.java  | 12 ++++----
 .../src/main/java/io/druid/cli/InsertSegment.java  | 12 ++++----
 .../io/druid/cli/Log4JShutdownPropertyChecker.java | 12 ++++----
 services/src/main/java/io/druid/cli/Main.java      | 12 ++++----
 .../cli/MiddleManagerJettyServerInitializer.java   | 12 ++++----
 .../main/java/io/druid/cli/PropertyChecker.java    | 12 ++++----
 .../main/java/io/druid/cli/PullDependencies.java   | 12 ++++----
 .../io/druid/cli/QueryJettyServerInitializer.java  | 12 ++++----
 .../src/main/java/io/druid/cli/ResetCluster.java   | 12 ++++----
 .../io/druid/cli/RouterJettyServerInitializer.java | 12 ++++----
 .../src/main/java/io/druid/cli/ServerRunnable.java | 12 ++++----
 .../main/java/io/druid/cli/ValidateSegments.java   | 12 ++++----
 services/src/main/java/io/druid/cli/Version.java   | 12 ++++----
 .../io/druid/cli/convert/ChatHandlerConverter.java | 12 ++++----
 .../convert/DataSegmentPusherDefaultConverter.java | 12 ++++----
 .../cli/convert/DatabasePropertiesConverter.java   | 12 ++++----
 .../io/druid/cli/convert/IndexCacheConverter.java  | 12 ++++----
 .../java/io/druid/cli/convert/PrefixRename.java    | 12 ++++----
 .../io/druid/cli/convert/PropertyConverter.java    | 12 ++++----
 .../src/main/java/io/druid/cli/convert/Remove.java | 12 ++++----
 .../src/main/java/io/druid/cli/convert/Rename.java | 12 ++++----
 .../io/druid/cli/validate/DruidJsonValidator.java  | 12 ++++----
 .../java/io/druid/guice/QueryablePeonModule.java   | 12 ++++----
 .../main/java/io/druid/guice/RealtimeModule.java   | 12 ++++----
 .../META-INF/services/io.druid.cli.PropertyChecker |  4 +--
 services/src/test/java/io/druid/cli/MainTest.java  | 12 ++++----
 .../java/io/druid/cli/PullDependenciesTest.java    | 12 ++++----
 .../druid/cli/validate/DruidJsonValidatorTest.java | 12 ++++----
 .../src/test/resources/convertProps/new.properties | 19 ++++++++++++
 .../src/test/resources/convertProps/old.properties | 19 ++++++++++++
 sql/pom.xml                                        | 12 ++++----
 .../java/io/druid/sql/avatica/AvaticaMonitor.java  | 12 ++++----
 .../io/druid/sql/avatica/AvaticaServerConfig.java  | 12 ++++----
 .../io/druid/sql/avatica/DruidAvaticaHandler.java  | 12 ++++----
 .../java/io/druid/sql/avatica/DruidConnection.java | 12 ++++----
 .../main/java/io/druid/sql/avatica/DruidMeta.java  | 12 ++++----
 .../java/io/druid/sql/avatica/DruidStatement.java  | 12 ++++----
 .../druid/sql/calcite/aggregation/Aggregation.java | 12 ++++----
 .../sql/calcite/aggregation/Aggregations.java      | 12 ++++----
 .../calcite/aggregation/DimensionExpression.java   | 12 ++++----
 .../sql/calcite/aggregation/SqlAggregator.java     | 12 ++++----
 .../builtin/ApproxCountDistinctSqlAggregator.java  | 12 ++++----
 .../aggregation/builtin/AvgSqlAggregator.java      | 12 ++++----
 .../aggregation/builtin/CountSqlAggregator.java    | 12 ++++----
 .../aggregation/builtin/MaxSqlAggregator.java      | 12 ++++----
 .../aggregation/builtin/MinSqlAggregator.java      | 12 ++++----
 .../aggregation/builtin/SumSqlAggregator.java      | 12 ++++----
 .../aggregation/builtin/SumZeroSqlAggregator.java  | 12 ++++----
 .../expression/AliasedOperatorConversion.java      | 12 ++++----
 .../expression/BinaryOperatorConversion.java       | 12 ++++----
 .../expression/DirectOperatorConversion.java       | 12 ++++----
 .../sql/calcite/expression/DruidExpression.java    | 12 ++++----
 .../druid/sql/calcite/expression/Expressions.java  | 12 ++++----
 .../sql/calcite/expression/ExtractionFns.java      | 12 ++++----
 .../calcite/expression/OperatorConversions.java    | 12 ++++----
 .../sql/calcite/expression/SimpleExtraction.java   | 12 ++++----
 .../calcite/expression/SqlOperatorConversion.java  | 12 ++++----
 .../io/druid/sql/calcite/expression/TimeUnits.java | 12 ++++----
 .../expression/UnaryPrefixOperatorConversion.java  | 12 ++++----
 .../expression/UnarySuffixOperatorConversion.java  | 12 ++++----
 .../builtin/BTrimOperatorConversion.java           | 12 ++++----
 .../expression/builtin/CastOperatorConversion.java | 12 ++++----
 .../expression/builtin/CeilOperatorConversion.java | 12 ++++----
 .../builtin/DateTruncOperatorConversion.java       | 12 ++++----
 .../builtin/ExtractOperatorConversion.java         | 12 ++++----
 .../builtin/FloorOperatorConversion.java           | 12 ++++----
 .../builtin/LTrimOperatorConversion.java           | 12 ++++----
 .../builtin/LookupOperatorConversion.java          | 12 ++++----
 .../MillisToTimestampOperatorConversion.java       | 12 ++++----
 .../builtin/RTrimOperatorConversion.java           | 12 ++++----
 .../builtin/RegexpExtractOperatorConversion.java   | 12 ++++----
 .../builtin/ReinterpretOperatorConversion.java     | 12 ++++----
 .../builtin/StrposOperatorConversion.java          | 12 ++++----
 .../builtin/SubstringOperatorConversion.java       | 12 ++++----
 .../builtin/TimeArithmeticOperatorConversion.java  | 12 ++++----
 .../builtin/TimeExtractOperatorConversion.java     | 12 ++++----
 .../builtin/TimeFloorOperatorConversion.java       | 12 ++++----
 .../builtin/TimeFormatOperatorConversion.java      | 12 ++++----
 .../builtin/TimeParseOperatorConversion.java       | 12 ++++----
 .../builtin/TimeShiftOperatorConversion.java       | 12 ++++----
 .../TimestampToMillisOperatorConversion.java       | 12 ++++----
 .../expression/builtin/TrimOperatorConversion.java | 12 ++++----
 .../builtin/TruncateOperatorConversion.java        | 12 ++++----
 .../sql/calcite/filtration/BottomUpTransform.java  | 12 ++++----
 .../druid/sql/calcite/filtration/BoundRefKey.java  | 12 ++++----
 .../druid/sql/calcite/filtration/BoundValue.java   | 12 ++++----
 .../io/druid/sql/calcite/filtration/Bounds.java    | 12 ++++----
 .../filtration/CombineAndSimplifyBounds.java       | 12 ++++----
 .../filtration/ConvertBoundsToSelectors.java       | 12 ++++----
 .../calcite/filtration/ConvertSelectorsToIns.java  | 12 ++++----
 .../druid/sql/calcite/filtration/Filtration.java   | 12 ++++----
 .../filtration/MoveMarkerFiltersToIntervals.java   | 12 ++++----
 .../filtration/MoveTimeFiltersToIntervals.java     | 12 ++++----
 .../io/druid/sql/calcite/filtration/RangeSets.java | 12 ++++----
 .../filtration/ValidateNoMarkerFiltersRemain.java  | 12 ++++----
 .../io/druid/sql/calcite/planner/Calcites.java     | 12 ++++----
 .../sql/calcite/planner/DruidConformance.java      | 12 ++++----
 .../sql/calcite/planner/DruidConvertletTable.java  | 12 ++++----
 .../sql/calcite/planner/DruidOperatorTable.java    | 12 ++++----
 .../io/druid/sql/calcite/planner/DruidPlanner.java | 12 ++++----
 .../sql/calcite/planner/DruidRexExecutor.java      | 12 ++++----
 .../druid/sql/calcite/planner/DruidTypeSystem.java | 12 ++++----
 .../druid/sql/calcite/planner/PlannerConfig.java   | 12 ++++----
 .../druid/sql/calcite/planner/PlannerContext.java  | 12 ++++----
 .../druid/sql/calcite/planner/PlannerFactory.java  | 12 ++++----
 .../druid/sql/calcite/planner/PlannerResult.java   | 12 ++++----
 .../java/io/druid/sql/calcite/planner/Rules.java   | 12 ++++----
 .../sql/calcite/rel/CannotBuildQueryException.java | 12 ++++----
 .../io/druid/sql/calcite/rel/DruidConvention.java  | 12 ++++----
 .../druid/sql/calcite/rel/DruidOuterQueryRel.java  | 12 ++++----
 .../java/io/druid/sql/calcite/rel/DruidQuery.java  | 12 ++++----
 .../io/druid/sql/calcite/rel/DruidQueryRel.java    | 12 ++++----
 .../java/io/druid/sql/calcite/rel/DruidRel.java    | 12 ++++----
 .../io/druid/sql/calcite/rel/DruidSemiJoin.java    | 12 ++++----
 .../java/io/druid/sql/calcite/rel/Grouping.java    | 12 ++++----
 .../druid/sql/calcite/rel/PartialDruidQuery.java   | 12 ++++----
 .../java/io/druid/sql/calcite/rel/QueryMaker.java  | 12 ++++----
 .../io/druid/sql/calcite/rel/SelectProjection.java | 12 ++++----
 .../java/io/druid/sql/calcite/rel/SortProject.java | 12 ++++----
 .../calcite/rule/CaseFilteredAggregatorRule.java   | 12 ++++----
 .../sql/calcite/rule/DruidRelToBindableRule.java   | 12 ++++----
 .../sql/calcite/rule/DruidRelToDruidRule.java      | 12 ++++----
 .../java/io/druid/sql/calcite/rule/DruidRules.java | 12 ++++----
 .../druid/sql/calcite/rule/DruidSemiJoinRule.java  | 12 ++++----
 .../druid/sql/calcite/rule/DruidTableScanRule.java | 12 ++++----
 .../io/druid/sql/calcite/rule/GroupByRules.java    | 12 ++++----
 .../rule/ProjectAggregatePruneUnusedCallRule.java  | 12 ++++----
 .../druid/sql/calcite/rule/SortCollapseRule.java   | 12 ++++----
 .../io/druid/sql/calcite/schema/DruidSchema.java   | 12 ++++----
 .../sql/calcite/schema/InformationSchema.java      | 12 ++++----
 .../io/druid/sql/calcite/table/DruidTable.java     | 12 ++++----
 .../io/druid/sql/calcite/table/RowSignature.java   | 12 ++++----
 .../io/druid/sql/calcite/view/DruidViewMacro.java  | 12 ++++----
 .../sql/calcite/view/InProcessViewManager.java     | 12 ++++----
 .../io/druid/sql/calcite/view/NoopViewManager.java | 12 ++++----
 .../io/druid/sql/calcite/view/ViewManager.java     | 12 ++++----
 .../main/java/io/druid/sql/guice/SqlBindings.java  | 12 ++++----
 .../main/java/io/druid/sql/guice/SqlModule.java    | 12 ++++----
 sql/src/main/java/io/druid/sql/http/SqlQuery.java  | 12 ++++----
 .../main/java/io/druid/sql/http/SqlResource.java   | 12 ++++----
 .../druid/sql/avatica/DruidAvaticaHandlerTest.java | 12 ++++----
 .../io/druid/sql/avatica/DruidStatementTest.java   | 12 ++++----
 .../io/druid/sql/calcite/CalciteQueryTest.java     | 12 ++++----
 .../sql/calcite/expression/ExpressionsTest.java    | 12 ++++----
 .../sql/calcite/filtration/FiltrationTest.java     | 12 ++++----
 .../io/druid/sql/calcite/http/SqlQueryTest.java    | 12 ++++----
 .../io/druid/sql/calcite/http/SqlResourceTest.java | 12 ++++----
 .../io/druid/sql/calcite/planner/CalcitesTest.java | 12 ++++----
 .../druid/sql/calcite/schema/DruidSchemaTest.java  | 12 ++++----
 .../io/druid/sql/calcite/util/CalciteTestBase.java | 12 ++++----
 .../io/druid/sql/calcite/util/CalciteTests.java    | 12 ++++----
 .../io/druid/sql/calcite/util/QueryLogHook.java    | 12 ++++----
 .../util/SpecificSegmentsQuerySegmentWalker.java   | 12 ++++----
 .../sql/calcite/util/TestServerInventoryView.java  | 12 ++++----
 3709 files changed, 22998 insertions(+), 22575 deletions(-)

diff --git a/api/pom.xml b/api/pom.xml
index 74a6f86..0ae6241 100644
--- a/api/pom.xml
+++ b/api/pom.xml
@@ -1,22 +1,22 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
- ~ Licensed to Metamarkets Group Inc. (Metamarkets) under one
- ~ or more contributor license agreements.  See the NOTICE file
- ~ distributed with this work for additional information
- ~ regarding copyright ownership.  Metamarkets 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.
- -->
+  ~ 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.
+  -->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
     <modelVersion>4.0.0</modelVersion>
diff --git a/api/src/main/java/io/druid/cli/CliCommandCreator.java b/api/src/main/java/io/druid/cli/CliCommandCreator.java
index ff48b70..c4e8f36 100644
--- a/api/src/main/java/io/druid/cli/CliCommandCreator.java
+++ b/api/src/main/java/io/druid/cli/CliCommandCreator.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/ByteBufferInputRowParser.java b/api/src/main/java/io/druid/data/input/ByteBufferInputRowParser.java
index 9f73be4..7402072 100644
--- a/api/src/main/java/io/druid/data/input/ByteBufferInputRowParser.java
+++ b/api/src/main/java/io/druid/data/input/ByteBufferInputRowParser.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/Committer.java b/api/src/main/java/io/druid/data/input/Committer.java
index 3c913d4..64b9833 100644
--- a/api/src/main/java/io/druid/data/input/Committer.java
+++ b/api/src/main/java/io/druid/data/input/Committer.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/Firehose.java b/api/src/main/java/io/druid/data/input/Firehose.java
index a6f403c..da9ce15 100644
--- a/api/src/main/java/io/druid/data/input/Firehose.java
+++ b/api/src/main/java/io/druid/data/input/Firehose.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/FirehoseFactory.java b/api/src/main/java/io/druid/data/input/FirehoseFactory.java
index f99369b..2396769 100644
--- a/api/src/main/java/io/druid/data/input/FirehoseFactory.java
+++ b/api/src/main/java/io/druid/data/input/FirehoseFactory.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/FirehoseFactoryV2.java b/api/src/main/java/io/druid/data/input/FirehoseFactoryV2.java
index f4b1e7a..86c67b0 100644
--- a/api/src/main/java/io/druid/data/input/FirehoseFactoryV2.java
+++ b/api/src/main/java/io/druid/data/input/FirehoseFactoryV2.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/FirehoseV2.java b/api/src/main/java/io/druid/data/input/FirehoseV2.java
index 0be5747..c8acfa1 100644
--- a/api/src/main/java/io/druid/data/input/FirehoseV2.java
+++ b/api/src/main/java/io/druid/data/input/FirehoseV2.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/InputRow.java b/api/src/main/java/io/druid/data/input/InputRow.java
index b5512c9..0de7c19 100644
--- a/api/src/main/java/io/druid/data/input/InputRow.java
+++ b/api/src/main/java/io/druid/data/input/InputRow.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/MapBasedInputRow.java b/api/src/main/java/io/druid/data/input/MapBasedInputRow.java
index d6f3647..d373e24 100644
--- a/api/src/main/java/io/druid/data/input/MapBasedInputRow.java
+++ b/api/src/main/java/io/druid/data/input/MapBasedInputRow.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/MapBasedRow.java b/api/src/main/java/io/druid/data/input/MapBasedRow.java
index 5a7c4db..4fae739 100644
--- a/api/src/main/java/io/druid/data/input/MapBasedRow.java
+++ b/api/src/main/java/io/druid/data/input/MapBasedRow.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/Row.java b/api/src/main/java/io/druid/data/input/Row.java
index 4a314fb..9657c61 100644
--- a/api/src/main/java/io/druid/data/input/Row.java
+++ b/api/src/main/java/io/druid/data/input/Row.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/Rows.java b/api/src/main/java/io/druid/data/input/Rows.java
index 0ef09e9..2d52b5b 100644
--- a/api/src/main/java/io/druid/data/input/Rows.java
+++ b/api/src/main/java/io/druid/data/input/Rows.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/AbstractTextFilesFirehoseFactory.java b/api/src/main/java/io/druid/data/input/impl/AbstractTextFilesFirehoseFactory.java
index 4059715..c9340e6 100644
--- a/api/src/main/java/io/druid/data/input/impl/AbstractTextFilesFirehoseFactory.java
+++ b/api/src/main/java/io/druid/data/input/impl/AbstractTextFilesFirehoseFactory.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/CSVParseSpec.java b/api/src/main/java/io/druid/data/input/impl/CSVParseSpec.java
index 262b67f..576f0b9 100644
--- a/api/src/main/java/io/druid/data/input/impl/CSVParseSpec.java
+++ b/api/src/main/java/io/druid/data/input/impl/CSVParseSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/DelimitedParseSpec.java b/api/src/main/java/io/druid/data/input/impl/DelimitedParseSpec.java
index 8636b34..5ccd53a 100644
--- a/api/src/main/java/io/druid/data/input/impl/DelimitedParseSpec.java
+++ b/api/src/main/java/io/druid/data/input/impl/DelimitedParseSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/DimensionSchema.java b/api/src/main/java/io/druid/data/input/impl/DimensionSchema.java
index f2d9f91..b0e7c1f 100644
--- a/api/src/main/java/io/druid/data/input/impl/DimensionSchema.java
+++ b/api/src/main/java/io/druid/data/input/impl/DimensionSchema.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/DimensionsSpec.java b/api/src/main/java/io/druid/data/input/impl/DimensionsSpec.java
index dd57c05..1381382 100644
--- a/api/src/main/java/io/druid/data/input/impl/DimensionsSpec.java
+++ b/api/src/main/java/io/druid/data/input/impl/DimensionsSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/DoubleDimensionSchema.java b/api/src/main/java/io/druid/data/input/impl/DoubleDimensionSchema.java
index 2f4f403..6d4f924 100644
--- a/api/src/main/java/io/druid/data/input/impl/DoubleDimensionSchema.java
+++ b/api/src/main/java/io/druid/data/input/impl/DoubleDimensionSchema.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/FileIteratingFirehose.java b/api/src/main/java/io/druid/data/input/impl/FileIteratingFirehose.java
index eb60b36..27b9df3 100644
--- a/api/src/main/java/io/druid/data/input/impl/FileIteratingFirehose.java
+++ b/api/src/main/java/io/druid/data/input/impl/FileIteratingFirehose.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/FloatDimensionSchema.java b/api/src/main/java/io/druid/data/input/impl/FloatDimensionSchema.java
index d1752e7..91aaf6d 100644
--- a/api/src/main/java/io/druid/data/input/impl/FloatDimensionSchema.java
+++ b/api/src/main/java/io/druid/data/input/impl/FloatDimensionSchema.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/InputRowParser.java b/api/src/main/java/io/druid/data/input/impl/InputRowParser.java
index c3b8fba..5e24888 100644
--- a/api/src/main/java/io/druid/data/input/impl/InputRowParser.java
+++ b/api/src/main/java/io/druid/data/input/impl/InputRowParser.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/JSONLowercaseParseSpec.java b/api/src/main/java/io/druid/data/input/impl/JSONLowercaseParseSpec.java
index 177a2b3..d8a7ae0 100644
--- a/api/src/main/java/io/druid/data/input/impl/JSONLowercaseParseSpec.java
+++ b/api/src/main/java/io/druid/data/input/impl/JSONLowercaseParseSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/JSONParseSpec.java b/api/src/main/java/io/druid/data/input/impl/JSONParseSpec.java
index ce33d41..6141958 100644
--- a/api/src/main/java/io/druid/data/input/impl/JSONParseSpec.java
+++ b/api/src/main/java/io/druid/data/input/impl/JSONParseSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/JavaScriptParseSpec.java b/api/src/main/java/io/druid/data/input/impl/JavaScriptParseSpec.java
index 71fe381..119fda6 100644
--- a/api/src/main/java/io/druid/data/input/impl/JavaScriptParseSpec.java
+++ b/api/src/main/java/io/druid/data/input/impl/JavaScriptParseSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/LongDimensionSchema.java b/api/src/main/java/io/druid/data/input/impl/LongDimensionSchema.java
index 7d4c417..58f44af 100644
--- a/api/src/main/java/io/druid/data/input/impl/LongDimensionSchema.java
+++ b/api/src/main/java/io/druid/data/input/impl/LongDimensionSchema.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/MapInputRowParser.java b/api/src/main/java/io/druid/data/input/impl/MapInputRowParser.java
index 49d40fd..90de904 100644
--- a/api/src/main/java/io/druid/data/input/impl/MapInputRowParser.java
+++ b/api/src/main/java/io/druid/data/input/impl/MapInputRowParser.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/NewSpatialDimensionSchema.java b/api/src/main/java/io/druid/data/input/impl/NewSpatialDimensionSchema.java
index d22ab13..9bae7e4 100644
--- a/api/src/main/java/io/druid/data/input/impl/NewSpatialDimensionSchema.java
+++ b/api/src/main/java/io/druid/data/input/impl/NewSpatialDimensionSchema.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/NoopInputRowParser.java b/api/src/main/java/io/druid/data/input/impl/NoopInputRowParser.java
index 19459df..fa86df7 100644
--- a/api/src/main/java/io/druid/data/input/impl/NoopInputRowParser.java
+++ b/api/src/main/java/io/druid/data/input/impl/NoopInputRowParser.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/ParseSpec.java b/api/src/main/java/io/druid/data/input/impl/ParseSpec.java
index be16548..114aa3c 100644
--- a/api/src/main/java/io/druid/data/input/impl/ParseSpec.java
+++ b/api/src/main/java/io/druid/data/input/impl/ParseSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/RegexParseSpec.java b/api/src/main/java/io/druid/data/input/impl/RegexParseSpec.java
index d23f287..5c82975 100644
--- a/api/src/main/java/io/druid/data/input/impl/RegexParseSpec.java
+++ b/api/src/main/java/io/druid/data/input/impl/RegexParseSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/SpatialDimensionSchema.java b/api/src/main/java/io/druid/data/input/impl/SpatialDimensionSchema.java
index 60a9224..32f96cc 100644
--- a/api/src/main/java/io/druid/data/input/impl/SpatialDimensionSchema.java
+++ b/api/src/main/java/io/druid/data/input/impl/SpatialDimensionSchema.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/SqlFirehose.java b/api/src/main/java/io/druid/data/input/impl/SqlFirehose.java
index e597792..a678329 100644
--- a/api/src/main/java/io/druid/data/input/impl/SqlFirehose.java
+++ b/api/src/main/java/io/druid/data/input/impl/SqlFirehose.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/StringDimensionSchema.java b/api/src/main/java/io/druid/data/input/impl/StringDimensionSchema.java
index d00d6fb..7538b14 100644
--- a/api/src/main/java/io/druid/data/input/impl/StringDimensionSchema.java
+++ b/api/src/main/java/io/druid/data/input/impl/StringDimensionSchema.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/StringInputRowParser.java b/api/src/main/java/io/druid/data/input/impl/StringInputRowParser.java
index 2a7fcdc..3a646ea 100644
--- a/api/src/main/java/io/druid/data/input/impl/StringInputRowParser.java
+++ b/api/src/main/java/io/druid/data/input/impl/StringInputRowParser.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/TimeAndDimsParseSpec.java b/api/src/main/java/io/druid/data/input/impl/TimeAndDimsParseSpec.java
index 4b962b9..081723c 100644
--- a/api/src/main/java/io/druid/data/input/impl/TimeAndDimsParseSpec.java
+++ b/api/src/main/java/io/druid/data/input/impl/TimeAndDimsParseSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/TimestampSpec.java b/api/src/main/java/io/druid/data/input/impl/TimestampSpec.java
index 7fc274d..e93d00f 100644
--- a/api/src/main/java/io/druid/data/input/impl/TimestampSpec.java
+++ b/api/src/main/java/io/druid/data/input/impl/TimestampSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/CacheManager.java b/api/src/main/java/io/druid/data/input/impl/prefetch/CacheManager.java
index 96a7a41..3a3031a 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/CacheManager.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/CacheManager.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/FetchedFile.java b/api/src/main/java/io/druid/data/input/impl/prefetch/FetchedFile.java
index 8f3111e..c788371 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/FetchedFile.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/FetchedFile.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/Fetcher.java b/api/src/main/java/io/druid/data/input/impl/prefetch/Fetcher.java
index 919f44d..f645087 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/Fetcher.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/Fetcher.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/FileFetcher.java b/api/src/main/java/io/druid/data/input/impl/prefetch/FileFetcher.java
index 6752e04..7173fde 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/FileFetcher.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/FileFetcher.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/JsonIterator.java b/api/src/main/java/io/druid/data/input/impl/prefetch/JsonIterator.java
index d049304..cf73abc 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/JsonIterator.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/JsonIterator.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/ObjectOpenFunction.java b/api/src/main/java/io/druid/data/input/impl/prefetch/ObjectOpenFunction.java
index 0412cc3..43d47df 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/ObjectOpenFunction.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/ObjectOpenFunction.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/OpenedObject.java b/api/src/main/java/io/druid/data/input/impl/prefetch/OpenedObject.java
index 791a8db..631d171 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/OpenedObject.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/OpenedObject.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchConfig.java b/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchConfig.java
index a1c5fe4..8b6c8cb 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchConfig.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchConfig.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchSqlFirehoseFactory.java b/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchSqlFirehoseFactory.java
index 1e40949..3169961 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchSqlFirehoseFactory.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchSqlFirehoseFactory.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchableTextFilesFirehoseFactory.java b/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchableTextFilesFirehoseFactory.java
index 370262c..10406ee 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchableTextFilesFirehoseFactory.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/PrefetchableTextFilesFirehoseFactory.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/RetryingInputStream.java b/api/src/main/java/io/druid/data/input/impl/prefetch/RetryingInputStream.java
index 20bb615..31f3611 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/RetryingInputStream.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/RetryingInputStream.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/data/input/impl/prefetch/SqlFetcher.java b/api/src/main/java/io/druid/data/input/impl/prefetch/SqlFetcher.java
index 080ba86..9ac098e 100644
--- a/api/src/main/java/io/druid/data/input/impl/prefetch/SqlFetcher.java
+++ b/api/src/main/java/io/druid/data/input/impl/prefetch/SqlFetcher.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/Binders.java b/api/src/main/java/io/druid/guice/Binders.java
index 0257b1f..3795b56 100644
--- a/api/src/main/java/io/druid/guice/Binders.java
+++ b/api/src/main/java/io/druid/guice/Binders.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/ConditionalMultibind.java b/api/src/main/java/io/druid/guice/ConditionalMultibind.java
index bd01f97..7a6ae9d 100644
--- a/api/src/main/java/io/druid/guice/ConditionalMultibind.java
+++ b/api/src/main/java/io/druid/guice/ConditionalMultibind.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/DruidGuiceExtensions.java b/api/src/main/java/io/druid/guice/DruidGuiceExtensions.java
index 956abc7..a4f75b9 100644
--- a/api/src/main/java/io/druid/guice/DruidGuiceExtensions.java
+++ b/api/src/main/java/io/druid/guice/DruidGuiceExtensions.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/DruidScopes.java b/api/src/main/java/io/druid/guice/DruidScopes.java
index d7aeab3..b815109 100644
--- a/api/src/main/java/io/druid/guice/DruidScopes.java
+++ b/api/src/main/java/io/druid/guice/DruidScopes.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/Jerseys.java b/api/src/main/java/io/druid/guice/Jerseys.java
index 51520ea..f6b7f13 100644
--- a/api/src/main/java/io/druid/guice/Jerseys.java
+++ b/api/src/main/java/io/druid/guice/Jerseys.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/JsonConfigProvider.java b/api/src/main/java/io/druid/guice/JsonConfigProvider.java
index 609567b..15a8e64 100644
--- a/api/src/main/java/io/druid/guice/JsonConfigProvider.java
+++ b/api/src/main/java/io/druid/guice/JsonConfigProvider.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/JsonConfigurator.java b/api/src/main/java/io/druid/guice/JsonConfigurator.java
index 09721a9..845f274 100644
--- a/api/src/main/java/io/druid/guice/JsonConfigurator.java
+++ b/api/src/main/java/io/druid/guice/JsonConfigurator.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/KeyHolder.java b/api/src/main/java/io/druid/guice/KeyHolder.java
index 24533fc..5f9a328 100644
--- a/api/src/main/java/io/druid/guice/KeyHolder.java
+++ b/api/src/main/java/io/druid/guice/KeyHolder.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/LazySingleton.java b/api/src/main/java/io/druid/guice/LazySingleton.java
index 5acf646..11a86a1 100644
--- a/api/src/main/java/io/druid/guice/LazySingleton.java
+++ b/api/src/main/java/io/druid/guice/LazySingleton.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/LifecycleModule.java b/api/src/main/java/io/druid/guice/LifecycleModule.java
index 9d294fb..a16f9e0 100644
--- a/api/src/main/java/io/druid/guice/LifecycleModule.java
+++ b/api/src/main/java/io/druid/guice/LifecycleModule.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/LifecycleScope.java b/api/src/main/java/io/druid/guice/LifecycleScope.java
index 19914b0..f4d6d01 100644
--- a/api/src/main/java/io/druid/guice/LifecycleScope.java
+++ b/api/src/main/java/io/druid/guice/LifecycleScope.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/ManageLifecycle.java b/api/src/main/java/io/druid/guice/ManageLifecycle.java
index 53d4d8f..67536e1 100644
--- a/api/src/main/java/io/druid/guice/ManageLifecycle.java
+++ b/api/src/main/java/io/druid/guice/ManageLifecycle.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/ManageLifecycleLast.java b/api/src/main/java/io/druid/guice/ManageLifecycleLast.java
index 02a7ff1..2857f43 100644
--- a/api/src/main/java/io/druid/guice/ManageLifecycleLast.java
+++ b/api/src/main/java/io/druid/guice/ManageLifecycleLast.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/PolyBind.java b/api/src/main/java/io/druid/guice/PolyBind.java
index fbcdaaa..41c265a 100644
--- a/api/src/main/java/io/druid/guice/PolyBind.java
+++ b/api/src/main/java/io/druid/guice/PolyBind.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/SupplierProvider.java b/api/src/main/java/io/druid/guice/SupplierProvider.java
index 32afa50..205d1b1 100644
--- a/api/src/main/java/io/druid/guice/SupplierProvider.java
+++ b/api/src/main/java/io/druid/guice/SupplierProvider.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/annotations/EscalatedGlobal.java b/api/src/main/java/io/druid/guice/annotations/EscalatedGlobal.java
index ef60239..ffca49b 100644
--- a/api/src/main/java/io/druid/guice/annotations/EscalatedGlobal.java
+++ b/api/src/main/java/io/druid/guice/annotations/EscalatedGlobal.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/annotations/Global.java b/api/src/main/java/io/druid/guice/annotations/Global.java
index 84de201..b81e737 100644
--- a/api/src/main/java/io/druid/guice/annotations/Global.java
+++ b/api/src/main/java/io/druid/guice/annotations/Global.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/annotations/JSR311Resource.java b/api/src/main/java/io/druid/guice/annotations/JSR311Resource.java
index 948bd57..d763181 100644
--- a/api/src/main/java/io/druid/guice/annotations/JSR311Resource.java
+++ b/api/src/main/java/io/druid/guice/annotations/JSR311Resource.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/annotations/Json.java b/api/src/main/java/io/druid/guice/annotations/Json.java
index 4371554..378819f 100644
--- a/api/src/main/java/io/druid/guice/annotations/Json.java
+++ b/api/src/main/java/io/druid/guice/annotations/Json.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/annotations/Self.java b/api/src/main/java/io/druid/guice/annotations/Self.java
index f5a8b34..f26b258 100644
--- a/api/src/main/java/io/druid/guice/annotations/Self.java
+++ b/api/src/main/java/io/druid/guice/annotations/Self.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/guice/annotations/Smile.java b/api/src/main/java/io/druid/guice/annotations/Smile.java
index babfb5a..4dc02b1 100644
--- a/api/src/main/java/io/druid/guice/annotations/Smile.java
+++ b/api/src/main/java/io/druid/guice/annotations/Smile.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/indexer/IngestionState.java b/api/src/main/java/io/druid/indexer/IngestionState.java
index 9a52e3e..1c78c4e 100644
--- a/api/src/main/java/io/druid/indexer/IngestionState.java
+++ b/api/src/main/java/io/druid/indexer/IngestionState.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/indexer/RunnerTaskState.java b/api/src/main/java/io/druid/indexer/RunnerTaskState.java
index 0374274..a834491 100644
--- a/api/src/main/java/io/druid/indexer/RunnerTaskState.java
+++ b/api/src/main/java/io/druid/indexer/RunnerTaskState.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/indexer/TaskInfo.java b/api/src/main/java/io/druid/indexer/TaskInfo.java
index ee3be02..e20e9ee 100644
--- a/api/src/main/java/io/druid/indexer/TaskInfo.java
+++ b/api/src/main/java/io/druid/indexer/TaskInfo.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/indexer/TaskLocation.java b/api/src/main/java/io/druid/indexer/TaskLocation.java
index 70fd0b2..7cbb02b 100644
--- a/api/src/main/java/io/druid/indexer/TaskLocation.java
+++ b/api/src/main/java/io/druid/indexer/TaskLocation.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/indexer/TaskMetricsGetter.java b/api/src/main/java/io/druid/indexer/TaskMetricsGetter.java
index c29e890..ba1469a 100644
--- a/api/src/main/java/io/druid/indexer/TaskMetricsGetter.java
+++ b/api/src/main/java/io/druid/indexer/TaskMetricsGetter.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/indexer/TaskMetricsUtils.java b/api/src/main/java/io/druid/indexer/TaskMetricsUtils.java
index 5845b24..a420340 100644
--- a/api/src/main/java/io/druid/indexer/TaskMetricsUtils.java
+++ b/api/src/main/java/io/druid/indexer/TaskMetricsUtils.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/indexer/TaskState.java b/api/src/main/java/io/druid/indexer/TaskState.java
index c4f54a1..b6c9638 100644
--- a/api/src/main/java/io/druid/indexer/TaskState.java
+++ b/api/src/main/java/io/druid/indexer/TaskState.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/indexer/TaskStatus.java b/api/src/main/java/io/druid/indexer/TaskStatus.java
index dbe99da..e657389 100644
--- a/api/src/main/java/io/druid/indexer/TaskStatus.java
+++ b/api/src/main/java/io/druid/indexer/TaskStatus.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/indexer/TaskStatusPlus.java b/api/src/main/java/io/druid/indexer/TaskStatusPlus.java
index 761752f..71f0ac1 100644
--- a/api/src/main/java/io/druid/indexer/TaskStatusPlus.java
+++ b/api/src/main/java/io/druid/indexer/TaskStatusPlus.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/initialization/DruidModule.java b/api/src/main/java/io/druid/initialization/DruidModule.java
index 9479df1..f6f7070 100644
--- a/api/src/main/java/io/druid/initialization/DruidModule.java
+++ b/api/src/main/java/io/druid/initialization/DruidModule.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/jackson/CommaListJoinDeserializer.java b/api/src/main/java/io/druid/jackson/CommaListJoinDeserializer.java
index 15746a0..5511fbf 100644
--- a/api/src/main/java/io/druid/jackson/CommaListJoinDeserializer.java
+++ b/api/src/main/java/io/druid/jackson/CommaListJoinDeserializer.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/jackson/CommaListJoinSerializer.java b/api/src/main/java/io/druid/jackson/CommaListJoinSerializer.java
index 7e39b7c..8dceb48 100644
--- a/api/src/main/java/io/druid/jackson/CommaListJoinSerializer.java
+++ b/api/src/main/java/io/druid/jackson/CommaListJoinSerializer.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/js/JavaScriptConfig.java b/api/src/main/java/io/druid/js/JavaScriptConfig.java
index e97f19b..35dc71a 100644
--- a/api/src/main/java/io/druid/js/JavaScriptConfig.java
+++ b/api/src/main/java/io/druid/js/JavaScriptConfig.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/query/SegmentDescriptor.java b/api/src/main/java/io/druid/query/SegmentDescriptor.java
index ca7dfb2..bda3543 100644
--- a/api/src/main/java/io/druid/query/SegmentDescriptor.java
+++ b/api/src/main/java/io/druid/query/SegmentDescriptor.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/segment/SegmentUtils.java b/api/src/main/java/io/druid/segment/SegmentUtils.java
index 448eaf0..76bdca2 100644
--- a/api/src/main/java/io/druid/segment/SegmentUtils.java
+++ b/api/src/main/java/io/druid/segment/SegmentUtils.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/segment/loading/DataSegmentArchiver.java b/api/src/main/java/io/druid/segment/loading/DataSegmentArchiver.java
index 2776bfb..922595a 100644
--- a/api/src/main/java/io/druid/segment/loading/DataSegmentArchiver.java
+++ b/api/src/main/java/io/druid/segment/loading/DataSegmentArchiver.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/segment/loading/DataSegmentFinder.java b/api/src/main/java/io/druid/segment/loading/DataSegmentFinder.java
index 66af835..aa6cadf 100644
--- a/api/src/main/java/io/druid/segment/loading/DataSegmentFinder.java
+++ b/api/src/main/java/io/druid/segment/loading/DataSegmentFinder.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/segment/loading/DataSegmentKiller.java b/api/src/main/java/io/druid/segment/loading/DataSegmentKiller.java
index 96bbeb9..8622c4f 100644
--- a/api/src/main/java/io/druid/segment/loading/DataSegmentKiller.java
+++ b/api/src/main/java/io/druid/segment/loading/DataSegmentKiller.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/segment/loading/DataSegmentMover.java b/api/src/main/java/io/druid/segment/loading/DataSegmentMover.java
index a7554f3..2ee5433 100644
--- a/api/src/main/java/io/druid/segment/loading/DataSegmentMover.java
+++ b/api/src/main/java/io/druid/segment/loading/DataSegmentMover.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/segment/loading/DataSegmentPusher.java b/api/src/main/java/io/druid/segment/loading/DataSegmentPusher.java
index 7c4cead..5f3466d 100644
--- a/api/src/main/java/io/druid/segment/loading/DataSegmentPusher.java
+++ b/api/src/main/java/io/druid/segment/loading/DataSegmentPusher.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/segment/loading/LoadSpec.java b/api/src/main/java/io/druid/segment/loading/LoadSpec.java
index 12bfefe..23f5536 100644
--- a/api/src/main/java/io/druid/segment/loading/LoadSpec.java
+++ b/api/src/main/java/io/druid/segment/loading/LoadSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/segment/loading/NoopDataSegmentPusher.java b/api/src/main/java/io/druid/segment/loading/NoopDataSegmentPusher.java
index cfef672..f7aa07f 100644
--- a/api/src/main/java/io/druid/segment/loading/NoopDataSegmentPusher.java
+++ b/api/src/main/java/io/druid/segment/loading/NoopDataSegmentPusher.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/segment/loading/SegmentLoadingException.java b/api/src/main/java/io/druid/segment/loading/SegmentLoadingException.java
index 3bd388d..26048c8 100644
--- a/api/src/main/java/io/druid/segment/loading/SegmentLoadingException.java
+++ b/api/src/main/java/io/druid/segment/loading/SegmentLoadingException.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/segment/loading/URIDataPuller.java b/api/src/main/java/io/druid/segment/loading/URIDataPuller.java
index 41ea811..5936bd8 100644
--- a/api/src/main/java/io/druid/segment/loading/URIDataPuller.java
+++ b/api/src/main/java/io/druid/segment/loading/URIDataPuller.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/tasklogs/NoopTaskLogs.java b/api/src/main/java/io/druid/tasklogs/NoopTaskLogs.java
index d54c63c..9b53adc 100644
--- a/api/src/main/java/io/druid/tasklogs/NoopTaskLogs.java
+++ b/api/src/main/java/io/druid/tasklogs/NoopTaskLogs.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/tasklogs/TaskLogKiller.java b/api/src/main/java/io/druid/tasklogs/TaskLogKiller.java
index 7a63f64..fca5fe7 100644
--- a/api/src/main/java/io/druid/tasklogs/TaskLogKiller.java
+++ b/api/src/main/java/io/druid/tasklogs/TaskLogKiller.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/tasklogs/TaskLogPusher.java b/api/src/main/java/io/druid/tasklogs/TaskLogPusher.java
index 6329aac..c50b002 100644
--- a/api/src/main/java/io/druid/tasklogs/TaskLogPusher.java
+++ b/api/src/main/java/io/druid/tasklogs/TaskLogPusher.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/tasklogs/TaskLogStreamer.java b/api/src/main/java/io/druid/tasklogs/TaskLogStreamer.java
index 7569cdd..0641098 100644
--- a/api/src/main/java/io/druid/tasklogs/TaskLogStreamer.java
+++ b/api/src/main/java/io/druid/tasklogs/TaskLogStreamer.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/tasklogs/TaskLogs.java b/api/src/main/java/io/druid/tasklogs/TaskLogs.java
index 383c355..1852195 100644
--- a/api/src/main/java/io/druid/tasklogs/TaskLogs.java
+++ b/api/src/main/java/io/druid/tasklogs/TaskLogs.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/timeline/DataSegment.java b/api/src/main/java/io/druid/timeline/DataSegment.java
index bfb2653..332e5cc 100644
--- a/api/src/main/java/io/druid/timeline/DataSegment.java
+++ b/api/src/main/java/io/druid/timeline/DataSegment.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/timeline/DataSegmentUtils.java b/api/src/main/java/io/druid/timeline/DataSegmentUtils.java
index a89e970..04e5b46 100644
--- a/api/src/main/java/io/druid/timeline/DataSegmentUtils.java
+++ b/api/src/main/java/io/druid/timeline/DataSegmentUtils.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/timeline/PruneLoadSpec.java b/api/src/main/java/io/druid/timeline/PruneLoadSpec.java
index 758b5b5..2be099b 100644
--- a/api/src/main/java/io/druid/timeline/PruneLoadSpec.java
+++ b/api/src/main/java/io/druid/timeline/PruneLoadSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/timeline/partition/NoneShardSpec.java b/api/src/main/java/io/druid/timeline/partition/NoneShardSpec.java
index d20c3b5..a57762b 100644
--- a/api/src/main/java/io/druid/timeline/partition/NoneShardSpec.java
+++ b/api/src/main/java/io/druid/timeline/partition/NoneShardSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/timeline/partition/PartitionChunk.java b/api/src/main/java/io/druid/timeline/partition/PartitionChunk.java
index 9c4450a..656106d 100644
--- a/api/src/main/java/io/druid/timeline/partition/PartitionChunk.java
+++ b/api/src/main/java/io/druid/timeline/partition/PartitionChunk.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/timeline/partition/ShardSpec.java b/api/src/main/java/io/druid/timeline/partition/ShardSpec.java
index c691c39..68c6a88 100644
--- a/api/src/main/java/io/druid/timeline/partition/ShardSpec.java
+++ b/api/src/main/java/io/druid/timeline/partition/ShardSpec.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/timeline/partition/ShardSpecLookup.java b/api/src/main/java/io/druid/timeline/partition/ShardSpecLookup.java
index 721b83a..bf2ce2f 100644
--- a/api/src/main/java/io/druid/timeline/partition/ShardSpecLookup.java
+++ b/api/src/main/java/io/druid/timeline/partition/ShardSpecLookup.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/timeline/partition/SingleElementPartitionChunk.java b/api/src/main/java/io/druid/timeline/partition/SingleElementPartitionChunk.java
index fd5da69..7d15f0f 100644
--- a/api/src/main/java/io/druid/timeline/partition/SingleElementPartitionChunk.java
+++ b/api/src/main/java/io/druid/timeline/partition/SingleElementPartitionChunk.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/utils/CircularBuffer.java b/api/src/main/java/io/druid/utils/CircularBuffer.java
index e5f8158..7f2f96b 100644
--- a/api/src/main/java/io/druid/utils/CircularBuffer.java
+++ b/api/src/main/java/io/druid/utils/CircularBuffer.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/utils/CompressionUtils.java b/api/src/main/java/io/druid/utils/CompressionUtils.java
index 6a665d2..bbe7aff 100644
--- a/api/src/main/java/io/druid/utils/CompressionUtils.java
+++ b/api/src/main/java/io/druid/utils/CompressionUtils.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/main/java/io/druid/utils/Runnables.java b/api/src/main/java/io/druid/utils/Runnables.java
index 883aae6..30ccf37 100644
--- a/api/src/main/java/io/druid/utils/Runnables.java
+++ b/api/src/main/java/io/druid/utils/Runnables.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/TestObjectMapper.java b/api/src/test/java/io/druid/TestObjectMapper.java
index 8ce6fed..6774d55 100644
--- a/api/src/test/java/io/druid/TestObjectMapper.java
+++ b/api/src/test/java/io/druid/TestObjectMapper.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/MapBasedRowTest.java b/api/src/test/java/io/druid/data/input/MapBasedRowTest.java
index b6b4d5a..e9a74b5 100644
--- a/api/src/test/java/io/druid/data/input/MapBasedRowTest.java
+++ b/api/src/test/java/io/druid/data/input/MapBasedRowTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/CSVParseSpecTest.java b/api/src/test/java/io/druid/data/input/impl/CSVParseSpecTest.java
index ff41172..d059868 100644
--- a/api/src/test/java/io/druid/data/input/impl/CSVParseSpecTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/CSVParseSpecTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/DelimitedParseSpecTest.java b/api/src/test/java/io/druid/data/input/impl/DelimitedParseSpecTest.java
index cba19ac..afb1bb3 100644
--- a/api/src/test/java/io/druid/data/input/impl/DelimitedParseSpecTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/DelimitedParseSpecTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/DimensionSchemaTest.java b/api/src/test/java/io/druid/data/input/impl/DimensionSchemaTest.java
index 8a807d7..fd128a4 100644
--- a/api/src/test/java/io/druid/data/input/impl/DimensionSchemaTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/DimensionSchemaTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/DimensionsSpecSerdeTest.java b/api/src/test/java/io/druid/data/input/impl/DimensionsSpecSerdeTest.java
index 99bc3e6..af4170b 100644
--- a/api/src/test/java/io/druid/data/input/impl/DimensionsSpecSerdeTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/DimensionsSpecSerdeTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/FileIteratingFirehoseTest.java b/api/src/test/java/io/druid/data/input/impl/FileIteratingFirehoseTest.java
index 3e4e31e..fac7be5 100644
--- a/api/src/test/java/io/druid/data/input/impl/FileIteratingFirehoseTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/FileIteratingFirehoseTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/InputRowParserSerdeTest.java b/api/src/test/java/io/druid/data/input/impl/InputRowParserSerdeTest.java
index d9da190..e812aa3 100644
--- a/api/src/test/java/io/druid/data/input/impl/InputRowParserSerdeTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/InputRowParserSerdeTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/JSONLowercaseParseSpecTest.java b/api/src/test/java/io/druid/data/input/impl/JSONLowercaseParseSpecTest.java
index d7331a5..e9da6f6 100644
--- a/api/src/test/java/io/druid/data/input/impl/JSONLowercaseParseSpecTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/JSONLowercaseParseSpecTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/JSONParseSpecTest.java b/api/src/test/java/io/druid/data/input/impl/JSONParseSpecTest.java
index 55622ab..3c5a2fc 100644
--- a/api/src/test/java/io/druid/data/input/impl/JSONParseSpecTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/JSONParseSpecTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/JSONPathSpecTest.java b/api/src/test/java/io/druid/data/input/impl/JSONPathSpecTest.java
index 3ef2714..ef6a93f 100644
--- a/api/src/test/java/io/druid/data/input/impl/JSONPathSpecTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/JSONPathSpecTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/JavaScriptParseSpecTest.java b/api/src/test/java/io/druid/data/input/impl/JavaScriptParseSpecTest.java
index b63caf4..f550d9e 100644
--- a/api/src/test/java/io/druid/data/input/impl/JavaScriptParseSpecTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/JavaScriptParseSpecTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/NoopInputRowParserTest.java b/api/src/test/java/io/druid/data/input/impl/NoopInputRowParserTest.java
index 7e3be69..265f8fa 100644
--- a/api/src/test/java/io/druid/data/input/impl/NoopInputRowParserTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/NoopInputRowParserTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/ParseSpecTest.java b/api/src/test/java/io/druid/data/input/impl/ParseSpecTest.java
index 7ddf369..eb81ded 100644
--- a/api/src/test/java/io/druid/data/input/impl/ParseSpecTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/ParseSpecTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/RegexParseSpecTest.java b/api/src/test/java/io/druid/data/input/impl/RegexParseSpecTest.java
index 5468ae0..b5e6445 100644
--- a/api/src/test/java/io/druid/data/input/impl/RegexParseSpecTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/RegexParseSpecTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/SqlFirehoseTest.java b/api/src/test/java/io/druid/data/input/impl/SqlFirehoseTest.java
index 3cef1d3..0a44ba6 100644
--- a/api/src/test/java/io/druid/data/input/impl/SqlFirehoseTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/SqlFirehoseTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/StringInputRowParserTest.java b/api/src/test/java/io/druid/data/input/impl/StringInputRowParserTest.java
index d532ba5..068a1cf 100644
--- a/api/src/test/java/io/druid/data/input/impl/StringInputRowParserTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/StringInputRowParserTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/TimeAndDimsParseSpecTest.java b/api/src/test/java/io/druid/data/input/impl/TimeAndDimsParseSpecTest.java
index 8f36bac..31785b3 100644
--- a/api/src/test/java/io/druid/data/input/impl/TimeAndDimsParseSpecTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/TimeAndDimsParseSpecTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/TimestampSpecTest.java b/api/src/test/java/io/druid/data/input/impl/TimestampSpecTest.java
index 726ad03..79fa718 100644
--- a/api/src/test/java/io/druid/data/input/impl/TimestampSpecTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/TimestampSpecTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/prefetch/JsonIteratorTest.java b/api/src/test/java/io/druid/data/input/impl/prefetch/JsonIteratorTest.java
index ffdca94..812669b 100644
--- a/api/src/test/java/io/druid/data/input/impl/prefetch/JsonIteratorTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/prefetch/JsonIteratorTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/prefetch/PrefetchableTextFilesFirehoseFactoryTest.java b/api/src/test/java/io/druid/data/input/impl/prefetch/PrefetchableTextFilesFirehoseFactoryTest.java
index 2d43fc3..3bfb465 100644
--- a/api/src/test/java/io/druid/data/input/impl/prefetch/PrefetchableTextFilesFirehoseFactoryTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/prefetch/PrefetchableTextFilesFirehoseFactoryTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/data/input/impl/prefetch/RetryingInputStreamTest.java b/api/src/test/java/io/druid/data/input/impl/prefetch/RetryingInputStreamTest.java
index 5f54b19..598abde 100644
--- a/api/src/test/java/io/druid/data/input/impl/prefetch/RetryingInputStreamTest.java
+++ b/api/src/test/java/io/druid/data/input/impl/prefetch/RetryingInputStreamTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/guice/ConditionalMultibindTest.java b/api/src/test/java/io/druid/guice/ConditionalMultibindTest.java
index 1f3fcbe..3a2d8f2 100644
--- a/api/src/test/java/io/druid/guice/ConditionalMultibindTest.java
+++ b/api/src/test/java/io/druid/guice/ConditionalMultibindTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/guice/JsonConfiguratorTest.java b/api/src/test/java/io/druid/guice/JsonConfiguratorTest.java
index 666ed25..fece707 100644
--- a/api/src/test/java/io/druid/guice/JsonConfiguratorTest.java
+++ b/api/src/test/java/io/druid/guice/JsonConfiguratorTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/guice/PolyBindTest.java b/api/src/test/java/io/druid/guice/PolyBindTest.java
index 8e9bf5e..ad97aa8 100644
--- a/api/src/test/java/io/druid/guice/PolyBindTest.java
+++ b/api/src/test/java/io/druid/guice/PolyBindTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/indexer/TaskStatusPlusTest.java b/api/src/test/java/io/druid/indexer/TaskStatusPlusTest.java
index af629d5..f37fc2c 100644
--- a/api/src/test/java/io/druid/indexer/TaskStatusPlusTest.java
+++ b/api/src/test/java/io/druid/indexer/TaskStatusPlusTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/jackson/JacksonExtremeDoubleValuesSerdeTest.java b/api/src/test/java/io/druid/jackson/JacksonExtremeDoubleValuesSerdeTest.java
index 789fd82..54e2c9c 100644
--- a/api/src/test/java/io/druid/jackson/JacksonExtremeDoubleValuesSerdeTest.java
+++ b/api/src/test/java/io/druid/jackson/JacksonExtremeDoubleValuesSerdeTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/js/JavaScriptConfigTest.java b/api/src/test/java/io/druid/js/JavaScriptConfigTest.java
index 6917cae..e04c686 100644
--- a/api/src/test/java/io/druid/js/JavaScriptConfigTest.java
+++ b/api/src/test/java/io/druid/js/JavaScriptConfigTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/segment/SegmentUtilsTest.java b/api/src/test/java/io/druid/segment/SegmentUtilsTest.java
index 142b896..d2f6fe9 100644
--- a/api/src/test/java/io/druid/segment/SegmentUtilsTest.java
+++ b/api/src/test/java/io/druid/segment/SegmentUtilsTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/segment/loading/NoopDataSegmentArchiver.java b/api/src/test/java/io/druid/segment/loading/NoopDataSegmentArchiver.java
index f6960ba..a4d3584 100644
--- a/api/src/test/java/io/druid/segment/loading/NoopDataSegmentArchiver.java
+++ b/api/src/test/java/io/druid/segment/loading/NoopDataSegmentArchiver.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/segment/loading/NoopDataSegmentKiller.java b/api/src/test/java/io/druid/segment/loading/NoopDataSegmentKiller.java
index 2f114c2b..353ffc6 100644
--- a/api/src/test/java/io/druid/segment/loading/NoopDataSegmentKiller.java
+++ b/api/src/test/java/io/druid/segment/loading/NoopDataSegmentKiller.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/segment/loading/NoopDataSegmentMover.java b/api/src/test/java/io/druid/segment/loading/NoopDataSegmentMover.java
index e4c276f..2675cca 100644
--- a/api/src/test/java/io/druid/segment/loading/NoopDataSegmentMover.java
+++ b/api/src/test/java/io/druid/segment/loading/NoopDataSegmentMover.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/timeline/DataSegmentTest.java b/api/src/test/java/io/druid/timeline/DataSegmentTest.java
index f2743d2..ac2fd31 100644
--- a/api/src/test/java/io/druid/timeline/DataSegmentTest.java
+++ b/api/src/test/java/io/druid/timeline/DataSegmentTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/timeline/DataSegmentUtilsTest.java b/api/src/test/java/io/druid/timeline/DataSegmentUtilsTest.java
index a58fe0b..b7ed2c3 100644
--- a/api/src/test/java/io/druid/timeline/DataSegmentUtilsTest.java
+++ b/api/src/test/java/io/druid/timeline/DataSegmentUtilsTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/java/io/druid/timeline/partition/NoneShardSpecTest.java b/api/src/test/java/io/druid/timeline/partition/NoneShardSpecTest.java
index bc9925a..0b3d032 100644
--- a/api/src/test/java/io/druid/timeline/partition/NoneShardSpecTest.java
+++ b/api/src/test/java/io/druid/timeline/partition/NoneShardSpecTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/api/src/test/resources/log4j2.xml b/api/src/test/resources/log4j2.xml
index 625f9fe..6c976ce 100644
--- a/api/src/test/resources/log4j2.xml
+++ b/api/src/test/resources/log4j2.xml
@@ -1,9 +1,9 @@
 <?xml version="1.0" encoding="UTF-8" ?>
 <!--
-  ~ Licensed to Metamarkets Group Inc. (Metamarkets) under one
+  ~ 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.  Metamarkets licenses this file
+  ~ 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
diff --git a/aws-common/pom.xml b/aws-common/pom.xml
index c6e69b0..7b69480 100644
--- a/aws-common/pom.xml
+++ b/aws-common/pom.xml
@@ -1,19 +1,21 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  ~ Druid - a distributed column store.
-  ~ Copyright 2012 - 2015 Metamarkets Group Inc.
+  ~ 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" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
diff --git a/aws-common/src/main/java/io/druid/common/aws/AWSClientConfig.java b/aws-common/src/main/java/io/druid/common/aws/AWSClientConfig.java
index 13689e0..a138314 100644
--- a/aws-common/src/main/java/io/druid/common/aws/AWSClientConfig.java
+++ b/aws-common/src/main/java/io/druid/common/aws/AWSClientConfig.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/aws-common/src/main/java/io/druid/common/aws/AWSCredentialsConfig.java b/aws-common/src/main/java/io/druid/common/aws/AWSCredentialsConfig.java
index ae213fe..9672275 100644
--- a/aws-common/src/main/java/io/druid/common/aws/AWSCredentialsConfig.java
+++ b/aws-common/src/main/java/io/druid/common/aws/AWSCredentialsConfig.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/aws-common/src/main/java/io/druid/common/aws/AWSCredentialsUtils.java b/aws-common/src/main/java/io/druid/common/aws/AWSCredentialsUtils.java
index c38254d..1838848 100644
--- a/aws-common/src/main/java/io/druid/common/aws/AWSCredentialsUtils.java
+++ b/aws-common/src/main/java/io/druid/common/aws/AWSCredentialsUtils.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/aws-common/src/main/java/io/druid/common/aws/AWSEndpointConfig.java b/aws-common/src/main/java/io/druid/common/aws/AWSEndpointConfig.java
index bd9d36f..200d30f 100644
--- a/aws-common/src/main/java/io/druid/common/aws/AWSEndpointConfig.java
+++ b/aws-common/src/main/java/io/druid/common/aws/AWSEndpointConfig.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/aws-common/src/main/java/io/druid/common/aws/AWSProxyConfig.java b/aws-common/src/main/java/io/druid/common/aws/AWSProxyConfig.java
index 0bd1ba7..8944059 100644
--- a/aws-common/src/main/java/io/druid/common/aws/AWSProxyConfig.java
+++ b/aws-common/src/main/java/io/druid/common/aws/AWSProxyConfig.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/aws-common/src/main/java/io/druid/common/aws/ConfigDrivenAwsCredentialsConfigProvider.java b/aws-common/src/main/java/io/druid/common/aws/ConfigDrivenAwsCredentialsConfigProvider.java
index 732c8c2..1b1e2a8 100644
--- a/aws-common/src/main/java/io/druid/common/aws/ConfigDrivenAwsCredentialsConfigProvider.java
+++ b/aws-common/src/main/java/io/druid/common/aws/ConfigDrivenAwsCredentialsConfigProvider.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/aws-common/src/main/java/io/druid/common/aws/FileSessionCredentialsProvider.java b/aws-common/src/main/java/io/druid/common/aws/FileSessionCredentialsProvider.java
index 920210f..4e6bacf 100644
--- a/aws-common/src/main/java/io/druid/common/aws/FileSessionCredentialsProvider.java
+++ b/aws-common/src/main/java/io/druid/common/aws/FileSessionCredentialsProvider.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/aws-common/src/main/java/io/druid/common/aws/LazyFileSessionCredentialsProvider.java b/aws-common/src/main/java/io/druid/common/aws/LazyFileSessionCredentialsProvider.java
index 029ed34..d02d1b8 100644
--- a/aws-common/src/main/java/io/druid/common/aws/LazyFileSessionCredentialsProvider.java
+++ b/aws-common/src/main/java/io/druid/common/aws/LazyFileSessionCredentialsProvider.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/aws-common/src/test/java/io/druid/common/aws/AWSCredentialsConfigTest.java b/aws-common/src/test/java/io/druid/common/aws/AWSCredentialsConfigTest.java
index daa66c5..3b2887b 100644
--- a/aws-common/src/test/java/io/druid/common/aws/AWSCredentialsConfigTest.java
+++ b/aws-common/src/test/java/io/druid/common/aws/AWSCredentialsConfigTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/pom.xml b/benchmarks/pom.xml
index 539d3df..b47a621 100644
--- a/benchmarks/pom.xml
+++ b/benchmarks/pom.xml
@@ -1,22 +1,22 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
- ~ Licensed to Metamarkets Group Inc. (Metamarkets) under one
- ~ or more contributor license agreements.  See the NOTICE file
- ~ distributed with this work for additional information
- ~ regarding copyright ownership.  Metamarkets 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.
- -->
+  ~ 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.
+  -->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
diff --git a/benchmarks/src/main/java/io/druid/benchmark/BasicAuthUserMapSerdeBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/BasicAuthUserMapSerdeBenchmark.java
index fcf7d05..b55220a 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/BasicAuthUserMapSerdeBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/BasicAuthUserMapSerdeBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/BitmapIterationBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/BitmapIterationBenchmark.java
index 2551df1..21f7496 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/BitmapIterationBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/BitmapIterationBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/BoundFilterBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/BoundFilterBenchmark.java
index 17e48fe..887e55e 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/BoundFilterBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/BoundFilterBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/CompressedColumnarIntsBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/CompressedColumnarIntsBenchmark.java
index 83773fc..aaf3593 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/CompressedColumnarIntsBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/CompressedColumnarIntsBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/CompressedVSizeColumnarMultiIntsBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/CompressedVSizeColumnarMultiIntsBenchmark.java
index 5734cf6..14e9d17 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/CompressedVSizeColumnarMultiIntsBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/CompressedVSizeColumnarMultiIntsBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/ConciseComplementBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/ConciseComplementBenchmark.java
index a31a3f7..bb9b22a 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/ConciseComplementBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/ConciseComplementBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/ConsistentHasherBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/ConsistentHasherBenchmark.java
index f65e837..9248788 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/ConsistentHasherBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/ConsistentHasherBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/DimensionPredicateFilterBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/DimensionPredicateFilterBenchmark.java
index f1be508..0023b90 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/DimensionPredicateFilterBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/DimensionPredicateFilterBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/ExpressionAggregationBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/ExpressionAggregationBenchmark.java
index 662df06..b9710cf 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/ExpressionAggregationBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/ExpressionAggregationBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/ExpressionSelectorBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/ExpressionSelectorBenchmark.java
index 8f5130a..4867fcb 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/ExpressionSelectorBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/ExpressionSelectorBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/FilterPartitionBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/FilterPartitionBenchmark.java
index 11ffcf0..c29414e 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/FilterPartitionBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/FilterPartitionBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/FilteredAggregatorBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/FilteredAggregatorBenchmark.java
index 6c90ba0..c236f1a 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/FilteredAggregatorBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/FilteredAggregatorBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/FlattenJSONBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/FlattenJSONBenchmark.java
index e241295..27ff8e1 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/FlattenJSONBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/FlattenJSONBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/FlattenJSONBenchmarkUtil.java b/benchmarks/src/main/java/io/druid/benchmark/FlattenJSONBenchmarkUtil.java
index 41ba357..018ae2f 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/FlattenJSONBenchmarkUtil.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/FlattenJSONBenchmarkUtil.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/FloatCompressionBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/FloatCompressionBenchmark.java
index 4abdee1..35886ce 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/FloatCompressionBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/FloatCompressionBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/FloatCompressionBenchmarkFileGenerator.java b/benchmarks/src/main/java/io/druid/benchmark/FloatCompressionBenchmarkFileGenerator.java
index 5cfcf93..24da6a6 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/FloatCompressionBenchmarkFileGenerator.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/FloatCompressionBenchmarkFileGenerator.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/GenericIndexedBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/GenericIndexedBenchmark.java
index 2d9a60c..b2ab25b 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/GenericIndexedBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/GenericIndexedBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/GroupByTypeInterfaceBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/GroupByTypeInterfaceBenchmark.java
index 9f74c05..3928dc4 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/GroupByTypeInterfaceBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/GroupByTypeInterfaceBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/IncrementalIndexRowTypeBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/IncrementalIndexRowTypeBenchmark.java
index bd622f6..455bba7 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/IncrementalIndexRowTypeBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/IncrementalIndexRowTypeBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/LikeFilterBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/LikeFilterBenchmark.java
index 0847b16..cb48c14 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/LikeFilterBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/LikeFilterBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/LoadStatusBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/LoadStatusBenchmark.java
index e1b877d..ac297f8 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/LoadStatusBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/LoadStatusBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/LongCompressionBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/LongCompressionBenchmark.java
index 27fce45..fe33fc0 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/LongCompressionBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/LongCompressionBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/LongCompressionBenchmarkFileGenerator.java b/benchmarks/src/main/java/io/druid/benchmark/LongCompressionBenchmarkFileGenerator.java
index 37a94f3..6b2cc94 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/LongCompressionBenchmarkFileGenerator.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/LongCompressionBenchmarkFileGenerator.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/MergeSequenceBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/MergeSequenceBenchmark.java
index 54ad24b..4f923ac 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/MergeSequenceBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/MergeSequenceBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/RegexMatchBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/RegexMatchBenchmark.java
index 7f081d7..efc5147 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/RegexMatchBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/RegexMatchBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/RendezvousHasherBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/RendezvousHasherBenchmark.java
index 2860b41..549994f 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/RendezvousHasherBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/RendezvousHasherBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/StupidPoolConcurrencyBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/StupidPoolConcurrencyBenchmark.java
index 63c82cd..2c41b22 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/StupidPoolConcurrencyBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/StupidPoolConcurrencyBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/TimeParseBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/TimeParseBenchmark.java
index ca700b8..78a5557 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/TimeParseBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/TimeParseBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/TopNTypeInterfaceBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/TopNTypeInterfaceBenchmark.java
index 6bdd202..c7cb48d 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/TopNTypeInterfaceBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/TopNTypeInterfaceBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/VSizeSerdeBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/VSizeSerdeBenchmark.java
index d0e5a21..4d50b57 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/VSizeSerdeBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/VSizeSerdeBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkColumnSchema.java b/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkColumnSchema.java
index a7490a9..8c2569f 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkColumnSchema.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkColumnSchema.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkColumnValueGenerator.java b/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkColumnValueGenerator.java
index 73062e7..25416fe 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkColumnValueGenerator.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkColumnValueGenerator.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkDataGenerator.java b/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkDataGenerator.java
index d598978..f83fc6e 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkDataGenerator.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkDataGenerator.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkSchemaInfo.java b/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkSchemaInfo.java
index 28c8c6a..b02da6d 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkSchemaInfo.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkSchemaInfo.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkSchemas.java b/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkSchemas.java
index 3f9a1dc..05da360 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkSchemas.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/datagen/BenchmarkSchemas.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/datagen/EnumeratedTreeDistribution.java b/benchmarks/src/main/java/io/druid/benchmark/datagen/EnumeratedTreeDistribution.java
index d8ff5c9..d13fefc 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/datagen/EnumeratedTreeDistribution.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/datagen/EnumeratedTreeDistribution.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/datagen/RealRoundingDistribution.java b/benchmarks/src/main/java/io/druid/benchmark/datagen/RealRoundingDistribution.java
index 8d767c4..8765dc6 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/datagen/RealRoundingDistribution.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/datagen/RealRoundingDistribution.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/datagen/SegmentGenerator.java b/benchmarks/src/main/java/io/druid/benchmark/datagen/SegmentGenerator.java
index e6bca29..d806dd1 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/datagen/SegmentGenerator.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/datagen/SegmentGenerator.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/datagen/SequentialDistribution.java b/benchmarks/src/main/java/io/druid/benchmark/datagen/SequentialDistribution.java
index dbabd9a..3b35672 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/datagen/SequentialDistribution.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/datagen/SequentialDistribution.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/indexing/IncrementalIndexReadBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/indexing/IncrementalIndexReadBenchmark.java
index e2e25dd..f447c0c 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/indexing/IncrementalIndexReadBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/indexing/IncrementalIndexReadBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexIngestionBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexIngestionBenchmark.java
index 521ae86..b101a5b 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexIngestionBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexIngestionBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexMergeBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexMergeBenchmark.java
index 17ebaff..ba68d7f 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexMergeBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexMergeBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexPersistBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexPersistBenchmark.java
index 9a6578e..6d5e172 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexPersistBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/indexing/IndexPersistBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/query/GroupByBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/query/GroupByBenchmark.java
index b583e56..931bcd7 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/query/GroupByBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/query/GroupByBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/query/QueryBenchmarkUtil.java b/benchmarks/src/main/java/io/druid/benchmark/query/QueryBenchmarkUtil.java
index 0ffe8cc..334097b 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/query/QueryBenchmarkUtil.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/query/QueryBenchmarkUtil.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/query/SearchBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/query/SearchBenchmark.java
index f9e5455..b2ff59e 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/query/SearchBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/query/SearchBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/query/SelectBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/query/SelectBenchmark.java
index c325104..e563efa 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/query/SelectBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/query/SelectBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/query/SerializingQueryRunner.java b/benchmarks/src/main/java/io/druid/benchmark/query/SerializingQueryRunner.java
index 7b70beb..0fdbab1 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/query/SerializingQueryRunner.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/query/SerializingQueryRunner.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/query/SqlBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/query/SqlBenchmark.java
index 33ffb4c..038c6ae 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/query/SqlBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/query/SqlBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/query/TimeseriesBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/query/TimeseriesBenchmark.java
index e39e7c2..06f61d8 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/query/TimeseriesBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/query/TimeseriesBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/benchmark/query/TopNBenchmark.java b/benchmarks/src/main/java/io/druid/benchmark/query/TopNBenchmark.java
index bf464ef..e13c137 100644
--- a/benchmarks/src/main/java/io/druid/benchmark/query/TopNBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/benchmark/query/TopNBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/server/coordinator/CachingCostBalancerStrategyBenchmark.java b/benchmarks/src/main/java/io/druid/server/coordinator/CachingCostBalancerStrategyBenchmark.java
index 5fffe52..a87eb60 100644
--- a/benchmarks/src/main/java/io/druid/server/coordinator/CachingCostBalancerStrategyBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/server/coordinator/CachingCostBalancerStrategyBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/server/coordinator/CostBalancerStrategyBenchmark.java b/benchmarks/src/main/java/io/druid/server/coordinator/CostBalancerStrategyBenchmark.java
index 0bb062c..1bf998e 100644
--- a/benchmarks/src/main/java/io/druid/server/coordinator/CostBalancerStrategyBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/server/coordinator/CostBalancerStrategyBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/main/java/io/druid/server/coordinator/NewestSegmentFirstPolicyBenchmark.java b/benchmarks/src/main/java/io/druid/server/coordinator/NewestSegmentFirstPolicyBenchmark.java
index 42fd631..4036fc5 100644
--- a/benchmarks/src/main/java/io/druid/server/coordinator/NewestSegmentFirstPolicyBenchmark.java
+++ b/benchmarks/src/main/java/io/druid/server/coordinator/NewestSegmentFirstPolicyBenchmark.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/test/java/io/druid/benchmark/BenchmarkDataGeneratorTest.java b/benchmarks/src/test/java/io/druid/benchmark/BenchmarkDataGeneratorTest.java
index c1eed54..315e8db 100644
--- a/benchmarks/src/test/java/io/druid/benchmark/BenchmarkDataGeneratorTest.java
+++ b/benchmarks/src/test/java/io/druid/benchmark/BenchmarkDataGeneratorTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/benchmarks/src/test/java/io/druid/benchmark/FlattenJSONBenchmarkUtilTest.java b/benchmarks/src/test/java/io/druid/benchmark/FlattenJSONBenchmarkUtilTest.java
index 3ff146e..f408361 100644
--- a/benchmarks/src/test/java/io/druid/benchmark/FlattenJSONBenchmarkUtilTest.java
+++ b/benchmarks/src/test/java/io/druid/benchmark/FlattenJSONBenchmarkUtilTest.java
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
diff --git a/ci/travis_script_integration.sh b/ci/travis_script_integration.sh
index 47f6286..3d0ca62 100755
--- a/ci/travis_script_integration.sh
+++ b/ci/travis_script_integration.sh
@@ -1,19 +1,19 @@
 #!/usr/bin/env bash
 
-# Licensed to Metamarkets Group Inc. (Metamarkets) under one
-# or more contributor license agreements. See the NOTICE file
+# 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. Metamarkets licenses this file
+# 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
+# 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
+# KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
 
diff --git a/codestyle/LICENSE.txt b/codestyle/LICENSE.txt
index 2a5a7ec..042f3ce 100644
--- a/codestyle/LICENSE.txt
+++ b/codestyle/LICENSE.txt
@@ -1,18 +1,18 @@
 /*
- * Licensed to Metamarkets Group Inc. (Metamarkets) under one
- * or more contributor license agreements. See the NOTICE file
+ * 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. Metamarkets licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied.  See the License for the
  * specific language governing permissions and limitations
  * under the License.
- */
\ No newline at end of file
+ */
diff --git a/codestyle/checkstyle-suppressions.xml b/codestyle/checkstyle-suppressions.xml
index b09b85d..601a9ad 100644
--- a/codestyle/checkstyle-suppressions.xml
+++ b/codestyle/checkstyle-suppressions.xml
@@ -1,28 +1,28 @@
 <?xml version="1.0"?>
... 101801 lines suppressed ...


---------------------------------------------------------------------
To unsubscribe, e-mail: dev-unsubscribe@druid.apache.org
For additional commands, e-mail: dev-help@druid.apache.org