You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pekko.apache.org by fa...@apache.org on 2023/02/21 22:11:01 UTC

[incubator-pekko-connectors-kafka] branch main updated: add apache copyright headers (#41)

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

fanningpj pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-pekko-connectors-kafka.git


The following commit(s) were added to refs/heads/main by this push:
     new 1f8c7206 add apache copyright headers (#41)
1f8c7206 is described below

commit 1f8c720650e6fdc157fada537be9637e8b407d7c
Author: PJ Fanning <pj...@users.noreply.github.com>
AuthorDate: Tue Feb 21 23:10:55 2023 +0100

    add apache copyright headers (#41)
---
 .../pekko/kafka/benchmarks/CsvFormatter.scala      |  9 +++
 .../apache/pekko/kafka/benchmarks/FixtureGen.scala |  9 +++
 .../pekko/kafka/benchmarks/InflightMetrics.scala   |  9 +++
 .../kafka/benchmarks/KafkaConsumerBenchmarks.scala |  9 +++
 .../kafka/benchmarks/KafkaConsumerFixtureGen.scala |  9 +++
 .../kafka/benchmarks/KafkaProducerBenchmarks.scala |  9 +++
 .../kafka/benchmarks/KafkaProducerFixtureGen.scala |  9 +++
 .../benchmarks/KafkaTransactionBenchmarks.scala    |  9 +++
 .../benchmarks/KafkaTransactionFixtureGen.scala    |  9 +++
 .../PekkoConnectorsCommittableSinkFixtures.scala   |  9 +++
 .../kafka/benchmarks/PerfFixtureHelpers.scala      |  9 +++
 .../ReactiveKafkaConsumerBenchmarks.scala          |  9 +++
 .../benchmarks/ReactiveKafkaConsumerFixtures.scala |  9 +++
 .../ReactiveKafkaProducerBenchmarks.scala          |  9 +++
 .../benchmarks/ReactiveKafkaProducerFixtures.scala |  9 +++
 .../ReactiveKafkaTransactionBenchmarks.scala       |  9 +++
 .../ReactiveKafkaTransactionFixtures.scala         |  9 +++
 .../org/apache/pekko/kafka/benchmarks/Timed.scala  |  9 +++
 .../kafka/benchmarks/app/RunTestCommand.scala      |  9 +++
 .../cluster/sharding/KafkaClusterSharding.scala    |  9 +++
 .../pekko/kafka/CommitTimeoutException.scala       |  9 +++
 .../org/apache/pekko/kafka/CommitterSettings.scala |  9 +++
 .../pekko/kafka/ConnectionCheckerSettings.scala    |  9 +++
 .../org/apache/pekko/kafka/ConsumerFailed.scala    |  9 +++
 .../org/apache/pekko/kafka/ConsumerMessage.scala   |  9 +++
 .../org/apache/pekko/kafka/ConsumerSettings.scala  |  9 +++
 .../apache/pekko/kafka/KafkaConnectionFailed.scala |  9 +++
 .../apache/pekko/kafka/KafkaConsumerActor.scala    |  9 +++
 .../scala/org/apache/pekko/kafka/Metadata.scala    |  9 +++
 .../kafka/OffsetResetProtectionSettings.scala      |  9 +++
 .../org/apache/pekko/kafka/ProducerMessage.scala   |  9 +++
 .../org/apache/pekko/kafka/ProducerSettings.scala  |  9 +++
 .../apache/pekko/kafka/RestrictedConsumer.scala    |  9 +++
 .../org/apache/pekko/kafka/Subscriptions.scala     |  9 +++
 .../kafka/internal/BaseSingleSourceLogic.scala     |  9 +++
 .../kafka/internal/CommitCollectorStage.scala      |  9 +++
 .../kafka/internal/CommitObservationLogic.scala    |  9 +++
 .../pekko/kafka/internal/CommitTrigger.scala       |  9 +++
 .../pekko/kafka/internal/CommittableSources.scala  |  9 +++
 .../internal/CommittingProducerSinkStage.scala     |  9 +++
 .../pekko/kafka/internal/ConfigSettings.scala      |  9 +++
 .../pekko/kafka/internal/ConnectionChecker.scala   |  9 +++
 .../kafka/internal/ConsumerProgressTracking.scala  |  9 +++
 .../kafka/internal/ConsumerResetProtection.scala   |  9 +++
 .../kafka/internal/ControlImplementations.scala    |  9 +++
 .../kafka/internal/DefaultProducerStage.scala      |  9 +++
 .../pekko/kafka/internal/DeferredProducer.scala    |  9 +++
 .../kafka/internal/ExternalSingleSourceLogic.scala |  9 +++
 .../pekko/kafka/internal/KafkaConsumerActor.scala  |  9 +++
 .../pekko/kafka/internal/KafkaSourceStage.scala    |  9 +++
 .../pekko/kafka/internal/LoggingWithId.scala       |  9 +++
 .../pekko/kafka/internal/MessageBuilder.scala      |  9 +++
 .../internal/PartitionAssignmentHelpers.scala      |  9 +++
 .../apache/pekko/kafka/internal/PlainSources.scala |  9 +++
 .../pekko/kafka/internal/ProducerStage.scala       |  9 +++
 .../pekko/kafka/internal/SingleSourceLogic.scala   |  9 +++
 .../pekko/kafka/internal/SourceLogicBuffer.scala   |  9 +++
 .../kafka/internal/SourceLogicSubscription.scala   |  9 +++
 .../pekko/kafka/internal/SubSourceLogic.scala      |  9 +++
 .../internal/TransactionalProducerStage.scala      |  9 +++
 .../kafka/internal/TransactionalSources.scala      |  9 +++
 .../org/apache/pekko/kafka/javadsl/Committer.scala |  9 +++
 .../org/apache/pekko/kafka/javadsl/Consumer.scala  |  9 +++
 .../pekko/kafka/javadsl/DiscoverySupport.scala     |  9 +++
 .../pekko/kafka/javadsl/MetadataClient.scala       |  9 +++
 .../kafka/javadsl/PartitionAssignmentHandler.scala |  9 +++
 .../org/apache/pekko/kafka/javadsl/Producer.scala  |  9 +++
 .../apache/pekko/kafka/javadsl/SendProducer.scala  |  9 +++
 .../apache/pekko/kafka/javadsl/Transactional.scala |  9 +++
 .../apache/pekko/kafka/scaladsl/Committer.scala    |  9 +++
 .../org/apache/pekko/kafka/scaladsl/Consumer.scala |  9 +++
 .../pekko/kafka/scaladsl/DiscoverySupport.scala    |  9 +++
 .../pekko/kafka/scaladsl/MetadataClient.scala      |  9 +++
 .../scaladsl/PartitionAssignmentHandler.scala      |  9 +++
 .../org/apache/pekko/kafka/scaladsl/Producer.scala |  9 +++
 .../apache/pekko/kafka/scaladsl/SendProducer.scala |  9 +++
 .../pekko/kafka/scaladsl/Transactional.scala       |  9 +++
 project/CopyrightHeader.scala                      | 90 ++++++++++++++++++++++
 project/CopyrightHeaderForBuild.scala              | 30 ++++++++
 project/CopyrightHeaderForProtobuf.scala           | 30 ++++++++
 project/ProjectSettings.scala                      |  6 --
 .../org/apache/pekko/kafka/testkit/KafkaTest.java  |  9 +++
 .../testkit/TestcontainersKafkaJunit4Test.java     |  9 +++
 .../kafka/testkit/TestcontainersKafkaTest.java     |  9 +++
 .../testkit/internal/KafkaContainerCluster.java    |  9 +++
 .../internal/PekkoConnectorsKafkaContainer.java    |  9 +++
 .../testkit/internal/SchemaRegistryContainer.java  |  9 +++
 .../pekko/kafka/testkit/javadsl/BaseKafkaTest.java |  9 +++
 .../kafka/testkit/javadsl/KafkaJunit4Test.java     |  9 +++
 .../kafka/testkit/ConsumerResultFactory.scala      |  9 +++
 .../pekko/kafka/testkit/KafkaTestkitSettings.scala |  9 +++
 .../KafkaTestkitTestcontainersSettings.scala       |  9 +++
 .../kafka/testkit/ProducerResultFactory.scala      |  9 +++
 .../kafka/testkit/internal/KafkaTestKit.scala      |  9 +++
 .../testkit/internal/KafkaTestKitChecks.scala      |  9 +++
 .../testkit/internal/TestFrameworkInterface.scala  |  9 +++
 .../testkit/internal/TestcontainersKafka.scala     |  9 +++
 .../testkit/javadsl/ConsumerControlFactory.scala   |  9 +++
 .../testkit/scaladsl/ConsumerControlFactory.scala  |  9 +++
 .../pekko/kafka/testkit/scaladsl/KafkaSpec.scala   |  9 +++
 .../testkit/scaladsl/ScalatestKafkaSpec.scala      |  9 +++
 .../testkit/scaladsl/TestcontainersKafkaLike.scala |  9 +++
 .../scaladsl/TestcontainersKafkaPerClassLike.scala |  9 +++
 tests/src/main/proto/order.proto                   |  9 +++
 .../scala/org/apache/pekko/kafka/KafkaPorts.scala  |  9 +++
 105 files changed, 1059 insertions(+), 6 deletions(-)

diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/CsvFormatter.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/CsvFormatter.scala
index b711f7d1..6815f40d 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/CsvFormatter.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/CsvFormatter.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/FixtureGen.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/FixtureGen.scala
index 7b084713..ea394c8c 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/FixtureGen.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/FixtureGen.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/InflightMetrics.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/InflightMetrics.scala
index 999c5561..d066c755 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/InflightMetrics.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/InflightMetrics.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaConsumerBenchmarks.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaConsumerBenchmarks.scala
index 2a8b8d8b..ca14b594 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaConsumerBenchmarks.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaConsumerBenchmarks.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaConsumerFixtureGen.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaConsumerFixtureGen.scala
index 48ddb76f..5a06e694 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaConsumerFixtureGen.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaConsumerFixtureGen.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaProducerBenchmarks.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaProducerBenchmarks.scala
index 7dc72648..fbcbdc53 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaProducerBenchmarks.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaProducerBenchmarks.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaProducerFixtureGen.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaProducerFixtureGen.scala
index 875e01c9..eedfeb39 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaProducerFixtureGen.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaProducerFixtureGen.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaTransactionBenchmarks.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaTransactionBenchmarks.scala
index 249b7eee..70f0705f 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaTransactionBenchmarks.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaTransactionBenchmarks.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaTransactionFixtureGen.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaTransactionFixtureGen.scala
index 47e21af2..b38006d2 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaTransactionFixtureGen.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/KafkaTransactionFixtureGen.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/PekkoConnectorsCommittableSinkFixtures.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/PekkoConnectorsCommittableSinkFixtures.scala
index c23bd82f..eec718cf 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/PekkoConnectorsCommittableSinkFixtures.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/PekkoConnectorsCommittableSinkFixtures.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/PerfFixtureHelpers.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/PerfFixtureHelpers.scala
index 40de6ada..5a396b0f 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/PerfFixtureHelpers.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/PerfFixtureHelpers.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaConsumerBenchmarks.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaConsumerBenchmarks.scala
index a974f65d..746213ef 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaConsumerBenchmarks.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaConsumerBenchmarks.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaConsumerFixtures.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaConsumerFixtures.scala
index 2adf6234..2cfcb98a 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaConsumerFixtures.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaConsumerFixtures.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaProducerBenchmarks.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaProducerBenchmarks.scala
index 9584b1d1..976f3148 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaProducerBenchmarks.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaProducerBenchmarks.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaProducerFixtures.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaProducerFixtures.scala
index f83820e8..e38f804b 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaProducerFixtures.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaProducerFixtures.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaTransactionBenchmarks.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaTransactionBenchmarks.scala
index 9c4ae4ca..537b987d 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaTransactionBenchmarks.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaTransactionBenchmarks.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaTransactionFixtures.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaTransactionFixtures.scala
index 0577c990..79b9d6c6 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaTransactionFixtures.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/ReactiveKafkaTransactionFixtures.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/Timed.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/Timed.scala
index 14c98bdd..143579d6 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/Timed.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/Timed.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/app/RunTestCommand.scala b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/app/RunTestCommand.scala
index 4e935d98..74214783 100644
--- a/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/app/RunTestCommand.scala
+++ b/benchmarks/src/main/scala/org/apache/pekko/kafka/benchmarks/app/RunTestCommand.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/cluster-sharding/src/main/scala/org/apache/pekko/kafka/cluster/sharding/KafkaClusterSharding.scala b/cluster-sharding/src/main/scala/org/apache/pekko/kafka/cluster/sharding/KafkaClusterSharding.scala
index 1952f181..ab63f3c5 100644
--- a/cluster-sharding/src/main/scala/org/apache/pekko/kafka/cluster/sharding/KafkaClusterSharding.scala
+++ b/cluster-sharding/src/main/scala/org/apache/pekko/kafka/cluster/sharding/KafkaClusterSharding.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/CommitTimeoutException.scala b/core/src/main/scala/org/apache/pekko/kafka/CommitTimeoutException.scala
index 82a752a5..03084eee 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/CommitTimeoutException.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/CommitTimeoutException.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/CommitterSettings.scala b/core/src/main/scala/org/apache/pekko/kafka/CommitterSettings.scala
index 4b8ecaa2..7d069426 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/CommitterSettings.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/CommitterSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/ConnectionCheckerSettings.scala b/core/src/main/scala/org/apache/pekko/kafka/ConnectionCheckerSettings.scala
index 77f8da3f..b19ab5ec 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/ConnectionCheckerSettings.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/ConnectionCheckerSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/ConsumerFailed.scala b/core/src/main/scala/org/apache/pekko/kafka/ConsumerFailed.scala
index e57ec7a2..7312fdc0 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/ConsumerFailed.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/ConsumerFailed.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/ConsumerMessage.scala b/core/src/main/scala/org/apache/pekko/kafka/ConsumerMessage.scala
index 4ace8621..9cfb47fb 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/ConsumerMessage.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/ConsumerMessage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/ConsumerSettings.scala b/core/src/main/scala/org/apache/pekko/kafka/ConsumerSettings.scala
index 18eac4fd..07330b35 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/ConsumerSettings.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/ConsumerSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/KafkaConnectionFailed.scala b/core/src/main/scala/org/apache/pekko/kafka/KafkaConnectionFailed.scala
index 3ca133da..80f69b6a 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/KafkaConnectionFailed.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/KafkaConnectionFailed.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/KafkaConsumerActor.scala b/core/src/main/scala/org/apache/pekko/kafka/KafkaConsumerActor.scala
index 856e518a..47004959 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/KafkaConsumerActor.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/KafkaConsumerActor.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/Metadata.scala b/core/src/main/scala/org/apache/pekko/kafka/Metadata.scala
index b9f384d7..52aed080 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/Metadata.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/Metadata.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/OffsetResetProtectionSettings.scala b/core/src/main/scala/org/apache/pekko/kafka/OffsetResetProtectionSettings.scala
index dcd70420..306b5af2 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/OffsetResetProtectionSettings.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/OffsetResetProtectionSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/ProducerMessage.scala b/core/src/main/scala/org/apache/pekko/kafka/ProducerMessage.scala
index 698aeaa4..24d8b95d 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/ProducerMessage.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/ProducerMessage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/ProducerSettings.scala b/core/src/main/scala/org/apache/pekko/kafka/ProducerSettings.scala
index f447d336..07e325e0 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/ProducerSettings.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/ProducerSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/RestrictedConsumer.scala b/core/src/main/scala/org/apache/pekko/kafka/RestrictedConsumer.scala
index 2dec2531..f86a677d 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/RestrictedConsumer.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/RestrictedConsumer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/Subscriptions.scala b/core/src/main/scala/org/apache/pekko/kafka/Subscriptions.scala
index 0d863e61..86c63654 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/Subscriptions.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/Subscriptions.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/BaseSingleSourceLogic.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/BaseSingleSourceLogic.scala
index fd078148..03f512ba 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/BaseSingleSourceLogic.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/BaseSingleSourceLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/CommitCollectorStage.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/CommitCollectorStage.scala
index 9d230370..4c4abe18 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/CommitCollectorStage.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/CommitCollectorStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/CommitObservationLogic.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/CommitObservationLogic.scala
index 97e476d8..5eef8d0c 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/CommitObservationLogic.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/CommitObservationLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/CommitTrigger.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/CommitTrigger.scala
index 9c30c755..0caa564c 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/CommitTrigger.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/CommitTrigger.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/CommittableSources.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/CommittableSources.scala
index 9c91a89b..668c6938 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/CommittableSources.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/CommittableSources.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/CommittingProducerSinkStage.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/CommittingProducerSinkStage.scala
index 4d130cf4..526eca00 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/CommittingProducerSinkStage.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/CommittingProducerSinkStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/ConfigSettings.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/ConfigSettings.scala
index 8f5ae20f..1b69d0db 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/ConfigSettings.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/ConfigSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/ConnectionChecker.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/ConnectionChecker.scala
index 08f028d1..8d4ff3f4 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/ConnectionChecker.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/ConnectionChecker.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/ConsumerProgressTracking.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/ConsumerProgressTracking.scala
index c7ffd93b..56621cbf 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/ConsumerProgressTracking.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/ConsumerProgressTracking.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/ConsumerResetProtection.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/ConsumerResetProtection.scala
index 8048c67e..3b27dbea 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/ConsumerResetProtection.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/ConsumerResetProtection.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/ControlImplementations.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/ControlImplementations.scala
index 029e92e6..cc21ab56 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/ControlImplementations.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/ControlImplementations.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/DefaultProducerStage.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/DefaultProducerStage.scala
index 0630a8e9..dd902b77 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/DefaultProducerStage.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/DefaultProducerStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/DeferredProducer.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/DeferredProducer.scala
index bdc504f1..b2c26797 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/DeferredProducer.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/DeferredProducer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/ExternalSingleSourceLogic.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/ExternalSingleSourceLogic.scala
index 9b834cbc..03080041 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/ExternalSingleSourceLogic.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/ExternalSingleSourceLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/KafkaConsumerActor.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/KafkaConsumerActor.scala
index 8118ba7a..679f748f 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/KafkaConsumerActor.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/KafkaConsumerActor.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/KafkaSourceStage.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/KafkaSourceStage.scala
index 161493bd..f042abb0 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/KafkaSourceStage.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/KafkaSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/LoggingWithId.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/LoggingWithId.scala
index cc7b7ec2..9d598101 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/LoggingWithId.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/LoggingWithId.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/MessageBuilder.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/MessageBuilder.scala
index 13fed0e8..2bcefd7c 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/MessageBuilder.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/MessageBuilder.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/PartitionAssignmentHelpers.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/PartitionAssignmentHelpers.scala
index 07c55e53..7a7e4970 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/PartitionAssignmentHelpers.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/PartitionAssignmentHelpers.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/PlainSources.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/PlainSources.scala
index 95ae1591..ad5d317c 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/PlainSources.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/PlainSources.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/ProducerStage.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/ProducerStage.scala
index 6aa99c8c..ca9bb068 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/ProducerStage.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/ProducerStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/SingleSourceLogic.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/SingleSourceLogic.scala
index d0b53a89..1e995964 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/SingleSourceLogic.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/SingleSourceLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/SourceLogicBuffer.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/SourceLogicBuffer.scala
index 346e0cf6..608caa69 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/SourceLogicBuffer.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/SourceLogicBuffer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/SourceLogicSubscription.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/SourceLogicSubscription.scala
index 2b98dedf..ea1ddc9a 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/SourceLogicSubscription.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/SourceLogicSubscription.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/SubSourceLogic.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/SubSourceLogic.scala
index 32dd3896..cc54084d 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/SubSourceLogic.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/SubSourceLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/TransactionalProducerStage.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/TransactionalProducerStage.scala
index d4e53b86..5411b7ef 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/TransactionalProducerStage.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/TransactionalProducerStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/internal/TransactionalSources.scala b/core/src/main/scala/org/apache/pekko/kafka/internal/TransactionalSources.scala
index 1c96792e..ce0fa180 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/internal/TransactionalSources.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/internal/TransactionalSources.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/javadsl/Committer.scala b/core/src/main/scala/org/apache/pekko/kafka/javadsl/Committer.scala
index 85f6b952..f0f8c101 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/javadsl/Committer.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/javadsl/Committer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/javadsl/Consumer.scala b/core/src/main/scala/org/apache/pekko/kafka/javadsl/Consumer.scala
index 80be91b1..821e4ac3 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/javadsl/Consumer.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/javadsl/Consumer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/javadsl/DiscoverySupport.scala b/core/src/main/scala/org/apache/pekko/kafka/javadsl/DiscoverySupport.scala
index 63e09bee..6b2a04fa 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/javadsl/DiscoverySupport.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/javadsl/DiscoverySupport.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/javadsl/MetadataClient.scala b/core/src/main/scala/org/apache/pekko/kafka/javadsl/MetadataClient.scala
index b15d7b49..fe767c57 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/javadsl/MetadataClient.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/javadsl/MetadataClient.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/javadsl/PartitionAssignmentHandler.scala b/core/src/main/scala/org/apache/pekko/kafka/javadsl/PartitionAssignmentHandler.scala
index f561d49b..9cd2a2ac 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/javadsl/PartitionAssignmentHandler.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/javadsl/PartitionAssignmentHandler.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/javadsl/Producer.scala b/core/src/main/scala/org/apache/pekko/kafka/javadsl/Producer.scala
index dba527ca..3a5a4e79 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/javadsl/Producer.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/javadsl/Producer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/javadsl/SendProducer.scala b/core/src/main/scala/org/apache/pekko/kafka/javadsl/SendProducer.scala
index 75f2a13f..3694a3dc 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/javadsl/SendProducer.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/javadsl/SendProducer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/javadsl/Transactional.scala b/core/src/main/scala/org/apache/pekko/kafka/javadsl/Transactional.scala
index 9b651911..cbdd66d9 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/javadsl/Transactional.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/javadsl/Transactional.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Committer.scala b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Committer.scala
index 7723607b..3f56aecd 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Committer.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Committer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Consumer.scala b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Consumer.scala
index 2a32705d..1a760a4e 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Consumer.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Consumer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/DiscoverySupport.scala b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/DiscoverySupport.scala
index fe027e2a..0b41286d 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/DiscoverySupport.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/DiscoverySupport.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/MetadataClient.scala b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/MetadataClient.scala
index b172897a..b171b907 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/MetadataClient.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/MetadataClient.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/PartitionAssignmentHandler.scala b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/PartitionAssignmentHandler.scala
index e5803f5a..8129af2b 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/PartitionAssignmentHandler.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/PartitionAssignmentHandler.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Producer.scala b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Producer.scala
index a5161bea..e6b8004f 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Producer.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Producer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/SendProducer.scala b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/SendProducer.scala
index 48948507..ddb31571 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/SendProducer.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/SendProducer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Transactional.scala b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Transactional.scala
index af864ee2..f77bc90e 100644
--- a/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Transactional.scala
+++ b/core/src/main/scala/org/apache/pekko/kafka/scaladsl/Transactional.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/project/CopyrightHeader.scala b/project/CopyrightHeader.scala
new file mode 100644
index 00000000..f4cfaa27
--- /dev/null
+++ b/project/CopyrightHeader.scala
@@ -0,0 +1,90 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
+/*
+ * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
+ */
+
+import de.heikoseeberger.sbtheader.HeaderPlugin.autoImport._
+import de.heikoseeberger.sbtheader.{ CommentCreator, HeaderPlugin, NewLine }
+import org.apache.commons.lang3.StringUtils
+import sbt.Keys._
+import sbt._
+
+trait CopyrightHeader extends AutoPlugin {
+
+  override def requires: Plugins = HeaderPlugin
+
+  override def trigger: PluginTrigger = allRequirements
+
+  protected def headerMappingSettings: Seq[Def.Setting[_]] =
+    Seq(Compile, Test, IntegrationTest, Default).flatMap { config =>
+      inConfig(config)(
+        Seq(
+          headerLicense := Some(HeaderLicense.Custom(apacheHeader)),
+          headerMappings := headerMappings.value ++ Map(
+            HeaderFileType.scala -> cStyleComment,
+            HeaderFileType.java -> cStyleComment,
+            HeaderFileType("template") -> cStyleComment)))
+    }
+
+  override def projectSettings: Seq[Def.Setting[_]] = Def.settings(headerMappingSettings, additional)
+
+  def additional: Seq[Def.Setting[_]] =
+    Def.settings(Compile / compile := {
+        (Compile / headerCreate).value
+        (Compile / compile).value
+      },
+      Test / compile := {
+        (Test / headerCreate).value
+        (Test / compile).value
+      })
+
+  val apacheHeader: String =
+    """Licensed to the Apache Software Foundation (ASF) under one or more
+      |license agreements; and to You under the Apache License, version 2.0:
+      |
+      |  https://www.apache.org/licenses/LICENSE-2.0
+      |
+      |This file is part of the Apache Pekko project, derived from Akka.
+      |""".stripMargin
+
+  val cStyleComment = HeaderCommentStyle.cStyleBlockComment.copy(commentCreator = new CommentCreator() {
+
+    override def apply(text: String, existingText: Option[String]): String = {
+      val formatted = existingText match {
+        case Some(currentText) if isApacheCopyrighted(currentText) || isGenerated(currentText) =>
+          currentText
+        case Some(currentText) if isOnlyLightbendCopyrightAnnotated(currentText) =>
+          HeaderCommentStyle.cStyleBlockComment.commentCreator(text, existingText) + NewLine * 2 + currentText
+        case Some(currentText) =>
+          throw new IllegalStateException(s"Unable to detect copyright for header: [${currentText}]")
+        case None =>
+          HeaderCommentStyle.cStyleBlockComment.commentCreator(text, existingText)
+      }
+      formatted.trim
+    }
+  })
+
+  private def isGenerated(text: String): Boolean =
+    StringUtils.contains(text, "DO NOT EDIT DIRECTLY")
+
+  private def isApacheCopyrighted(text: String): Boolean =
+    StringUtils.containsIgnoreCase(text, "licensed to the apache software foundation (asf)") ||
+    StringUtils.containsIgnoreCase(text, "www.apache.org/licenses/license-2.0")
+
+  private def isLightbendCopyrighted(text: String): Boolean =
+    StringUtils.containsIgnoreCase(text, "lightbend inc.")
+
+  private def isOnlyLightbendCopyrightAnnotated(text: String): Boolean = {
+    isLightbendCopyrighted(text) && !isApacheCopyrighted(text)
+  }
+}
+
+object CopyrightHeader extends CopyrightHeader
diff --git a/project/CopyrightHeaderForBuild.scala b/project/CopyrightHeaderForBuild.scala
new file mode 100644
index 00000000..5f5c36ad
--- /dev/null
+++ b/project/CopyrightHeaderForBuild.scala
@@ -0,0 +1,30 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
+/*
+ * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
+ */
+
+import de.heikoseeberger.sbtheader.HeaderPlugin.autoImport.{ headerMappings, headerSources, HeaderFileType }
+import sbt.Keys.baseDirectory
+import sbt.{ inConfig, Compile, Def, PluginTrigger, Test, _ }
+
+object CopyrightHeaderForBuild extends CopyrightHeader {
+  override def trigger: PluginTrigger = noTrigger
+
+  override def projectSettings: Seq[Def.Setting[_]] = {
+    Seq(Compile, Test).flatMap { config =>
+      inConfig(config) {
+        Seq(
+          config / headerSources ++= (((config / baseDirectory).value / "project") ** "*.scala").get,
+          headerMappings := headerMappings.value ++ Map(HeaderFileType.scala -> cStyleComment))
+      }
+    }
+  }
+}
diff --git a/project/CopyrightHeaderForProtobuf.scala b/project/CopyrightHeaderForProtobuf.scala
new file mode 100644
index 00000000..33baf482
--- /dev/null
+++ b/project/CopyrightHeaderForProtobuf.scala
@@ -0,0 +1,30 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
+/*
+ * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
+ */
+
+import de.heikoseeberger.sbtheader.HeaderPlugin.autoImport.{ headerMappings, headerSources, HeaderFileType }
+import sbt.Keys.sourceDirectory
+import sbt.{ inConfig, Compile, Def, Test, _ }
+
+object CopyrightHeaderForProtobuf extends CopyrightHeader {
+  override protected def headerMappingSettings: Seq[Def.Setting[_]] = {
+    super.headerMappingSettings
+    Seq(Compile, Test).flatMap { config =>
+      inConfig(config) {
+        Seq(
+          config / headerSources ++=
+            ((config / sourceDirectory).value ** "*.proto").get,
+          headerMappings := headerMappings.value ++ Map(HeaderFileType("proto") -> cStyleComment))
+      }
+    }
+  }
+}
diff --git a/project/ProjectSettings.scala b/project/ProjectSettings.scala
index edc6c60d..cd03b881 100644
--- a/project/ProjectSettings.scala
+++ b/project/ProjectSettings.scala
@@ -2,7 +2,6 @@ import Versions._
 import com.lightbend.paradox.projectinfo.ParadoxProjectInfoPlugin.autoImport.projectInfoVersion
 import com.lightbend.sbt.JavaFormatterPlugin.autoImport.javafmtOnCompile
 import com.typesafe.tools.mima.plugin.MimaKeys.mimaReportSignatureProblems
-import de.heikoseeberger.sbtheader.HeaderPlugin.autoImport.{ headerLicense, HeaderLicense }
 import net.aichler.jupiter.sbt.Import.jupiterTestFramework
 import org.scalafmt.sbt.ScalafmtPlugin.autoImport.scalafmtOnCompile
 import sbt.{ Def, _ }
@@ -106,11 +105,6 @@ object ProjectSettings {
     scalafmtOnCompile := false,
     javafmtOnCompile := false,
     ThisBuild / mimaReportSignatureProblems := true,
-    headerLicense := Some(
-      HeaderLicense.Custom(
-        """|Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
-           |Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
-           |""".stripMargin)),
     projectInfoVersion := (if (isSnapshot.value) "snapshot" else version.value),
     publishMavenStyle := true,
     pomIncludeRepository := (_ => false),
diff --git a/testkit/src/main/java/org/apache/pekko/kafka/testkit/KafkaTest.java b/testkit/src/main/java/org/apache/pekko/kafka/testkit/KafkaTest.java
index 92f3df6b..9ad75b40 100644
--- a/testkit/src/main/java/org/apache/pekko/kafka/testkit/KafkaTest.java
+++ b/testkit/src/main/java/org/apache/pekko/kafka/testkit/KafkaTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/java/org/apache/pekko/kafka/testkit/TestcontainersKafkaJunit4Test.java b/testkit/src/main/java/org/apache/pekko/kafka/testkit/TestcontainersKafkaJunit4Test.java
index d51ac382..628807ab 100644
--- a/testkit/src/main/java/org/apache/pekko/kafka/testkit/TestcontainersKafkaJunit4Test.java
+++ b/testkit/src/main/java/org/apache/pekko/kafka/testkit/TestcontainersKafkaJunit4Test.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/java/org/apache/pekko/kafka/testkit/TestcontainersKafkaTest.java b/testkit/src/main/java/org/apache/pekko/kafka/testkit/TestcontainersKafkaTest.java
index d14e869d..48210386 100644
--- a/testkit/src/main/java/org/apache/pekko/kafka/testkit/TestcontainersKafkaTest.java
+++ b/testkit/src/main/java/org/apache/pekko/kafka/testkit/TestcontainersKafkaTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/KafkaContainerCluster.java b/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/KafkaContainerCluster.java
index 0867b297..d9d83815 100644
--- a/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/KafkaContainerCluster.java
+++ b/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/KafkaContainerCluster.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/PekkoConnectorsKafkaContainer.java b/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/PekkoConnectorsKafkaContainer.java
index 67198617..243e3546 100644
--- a/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/PekkoConnectorsKafkaContainer.java
+++ b/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/PekkoConnectorsKafkaContainer.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/SchemaRegistryContainer.java b/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/SchemaRegistryContainer.java
index a64fb7ae..959de692 100644
--- a/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/SchemaRegistryContainer.java
+++ b/testkit/src/main/java/org/apache/pekko/kafka/testkit/internal/SchemaRegistryContainer.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/java/org/apache/pekko/kafka/testkit/javadsl/BaseKafkaTest.java b/testkit/src/main/java/org/apache/pekko/kafka/testkit/javadsl/BaseKafkaTest.java
index ca170159..fe01439f 100644
--- a/testkit/src/main/java/org/apache/pekko/kafka/testkit/javadsl/BaseKafkaTest.java
+++ b/testkit/src/main/java/org/apache/pekko/kafka/testkit/javadsl/BaseKafkaTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/java/org/apache/pekko/kafka/testkit/javadsl/KafkaJunit4Test.java b/testkit/src/main/java/org/apache/pekko/kafka/testkit/javadsl/KafkaJunit4Test.java
index 7b66b4ad..1b355d27 100644
--- a/testkit/src/main/java/org/apache/pekko/kafka/testkit/javadsl/KafkaJunit4Test.java
+++ b/testkit/src/main/java/org/apache/pekko/kafka/testkit/javadsl/KafkaJunit4Test.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/ConsumerResultFactory.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/ConsumerResultFactory.scala
index 4100ed5e..bb8ded6e 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/ConsumerResultFactory.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/ConsumerResultFactory.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/KafkaTestkitSettings.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/KafkaTestkitSettings.scala
index e10d6b7e..b3b778c0 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/KafkaTestkitSettings.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/KafkaTestkitSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/KafkaTestkitTestcontainersSettings.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/KafkaTestkitTestcontainersSettings.scala
index a7786dd9..8ccc4627 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/KafkaTestkitTestcontainersSettings.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/KafkaTestkitTestcontainersSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/ProducerResultFactory.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/ProducerResultFactory.scala
index 174159a6..e4ebe012 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/ProducerResultFactory.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/ProducerResultFactory.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/KafkaTestKit.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/KafkaTestKit.scala
index 99fa217d..6175e13a 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/KafkaTestKit.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/KafkaTestKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/KafkaTestKitChecks.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/KafkaTestKitChecks.scala
index f48d0f77..8e1631bd 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/KafkaTestKitChecks.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/KafkaTestKitChecks.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/TestFrameworkInterface.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/TestFrameworkInterface.scala
index 8da9fd53..a466cdb3 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/TestFrameworkInterface.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/TestFrameworkInterface.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/TestcontainersKafka.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/TestcontainersKafka.scala
index e65cca65..b843e23a 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/TestcontainersKafka.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/internal/TestcontainersKafka.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/javadsl/ConsumerControlFactory.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/javadsl/ConsumerControlFactory.scala
index 8649dfcd..69d8c8bf 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/javadsl/ConsumerControlFactory.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/javadsl/ConsumerControlFactory.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/ConsumerControlFactory.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/ConsumerControlFactory.scala
index e92186f7..cf9ae496 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/ConsumerControlFactory.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/ConsumerControlFactory.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/KafkaSpec.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/KafkaSpec.scala
index 0e7d76e7..88537f82 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/KafkaSpec.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/KafkaSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/ScalatestKafkaSpec.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/ScalatestKafkaSpec.scala
index a4142cc2..d4e55193 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/ScalatestKafkaSpec.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/ScalatestKafkaSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/TestcontainersKafkaLike.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/TestcontainersKafkaLike.scala
index 4ba17241..26fb0def 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/TestcontainersKafkaLike.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/TestcontainersKafkaLike.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/TestcontainersKafkaPerClassLike.scala b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/TestcontainersKafkaPerClassLike.scala
index cc19794c..65e8e84c 100644
--- a/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/TestcontainersKafkaPerClassLike.scala
+++ b/testkit/src/main/scala/org/apache/pekko/kafka/testkit/scaladsl/TestcontainersKafkaPerClassLike.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>
diff --git a/tests/src/main/proto/order.proto b/tests/src/main/proto/order.proto
index ab306852..4ce7db87 100644
--- a/tests/src/main/proto/order.proto
+++ b/tests/src/main/proto/order.proto
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 syntax = "proto3";
 
 option java_package = "docs.sample";
diff --git a/tests/src/main/scala/org/apache/pekko/kafka/KafkaPorts.scala b/tests/src/main/scala/org/apache/pekko/kafka/KafkaPorts.scala
index 01dba327..ad2a6c5d 100644
--- a/tests/src/main/scala/org/apache/pekko/kafka/KafkaPorts.scala
+++ b/tests/src/main/scala/org/apache/pekko/kafka/KafkaPorts.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014 - 2016 Softwaremill <https://softwaremill.com>
  * Copyright (C) 2016 - 2020 Lightbend Inc. <https://www.lightbend.com>


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