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

[incubator-pekko-persistence-cassandra] branch main updated: Adds apache header (#9)

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

nvollmar pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-pekko-persistence-cassandra.git


The following commit(s) were added to refs/heads/main by this push:
     new dc22b53  Adds apache header (#9)
dc22b53 is described below

commit dc22b53f4ae5ff38b84ccaf82acfe239405210bd
Author: Nicolas Vollmar <nv...@gmail.com>
AuthorDate: Wed Jan 11 13:30:45 2023 +0100

    Adds apache header (#9)
---
 .../persistence/cassandra/testkit/CassandraLauncher.scala   | 12 ++++++++++--
 .../akka/persistence/cassandra/CassandraStatements.scala    |  9 +++++++++
 .../akka/persistence/cassandra/EventsByTagMigration.scala   |  9 +++++++++
 .../akka/persistence/cassandra/EventsByTagSettings.scala    |  9 +++++++++
 .../main/scala/akka/persistence/cassandra/Extractors.scala  |  9 +++++++++
 .../persistence/cassandra/KeyspaceAndTableStatements.scala  |  9 +++++++++
 .../scala/akka/persistence/cassandra/PluginSettings.scala   |  9 +++++++++
 .../src/main/scala/akka/persistence/cassandra/Retries.scala |  9 +++++++++
 .../scala/akka/persistence/cassandra/cleanup/Cleanup.scala  |  9 +++++++++
 .../persistence/cassandra/cleanup/CleanupSettings.scala     |  9 +++++++++
 .../cassandra/compaction/BaseCompactionStrategy.scala       |  9 +++++++++
 .../cassandra/compaction/CassandraCompactionStrategy.scala  |  9 +++++++++
 .../compaction/CassandraCompactionStrategyConfig.scala      |  9 +++++++++
 .../cassandra/compaction/LeveledCompactionStrategy.scala    |  9 +++++++++
 .../cassandra/compaction/SizeTieredCompactionStrategy.scala |  9 +++++++++
 .../cassandra/compaction/TimeWindowCompactionStrategy.scala |  9 +++++++++
 .../cassandra/healthcheck/CassandraHealthCheck.scala        |  9 +++++++++
 .../cassandra/healthcheck/HealthCheckSettings.scala         |  9 +++++++++
 .../scala/akka/persistence/cassandra/journal/Buffer.scala   |  9 +++++++++
 .../cassandra/journal/CassandraEventUpdate.scala            |  9 +++++++++
 .../persistence/cassandra/journal/CassandraJournal.scala    |  9 +++++++++
 .../cassandra/journal/CassandraJournalStatements.scala      |  9 +++++++++
 .../cassandra/journal/CassandraJournalUnexpectedError.scala |  9 +++++++++
 .../cassandra/journal/CassandraTagRecovery.scala            |  9 +++++++++
 .../persistence/cassandra/journal/JournalSettings.scala     |  9 +++++++++
 .../persistence/cassandra/journal/PubSubThrottler.scala     |  9 +++++++++
 .../akka/persistence/cassandra/journal/TagWriter.scala      |  9 +++++++++
 .../akka/persistence/cassandra/journal/TagWriters.scala     |  9 +++++++++
 .../cassandra/journal/TaggedPreparedStatements.scala        |  9 +++++++++
 .../akka/persistence/cassandra/journal/TimeBucket.scala     |  9 +++++++++
 .../scala/akka/persistence/cassandra/journal/package.scala  |  9 +++++++++
 .../src/main/scala/akka/persistence/cassandra/package.scala |  9 +++++++++
 .../cassandra/query/AllPersistenceIdsStage.scala            |  9 +++++++++
 .../cassandra/query/CassandraReadJournalProvider.scala      |  9 +++++++++
 .../cassandra/query/CassandraReadStatements.scala           |  9 +++++++++
 .../cassandra/query/EventsByPersistenceIdStage.scala        |  9 +++++++++
 .../akka/persistence/cassandra/query/EventsByTagStage.scala |  9 +++++++++
 .../cassandra/query/MissingTaggedEventException.scala       |  9 +++++++++
 .../akka/persistence/cassandra/query/QuerySettings.scala    |  9 +++++++++
 .../cassandra/query/TagViewSequenceNumberScanner.scala      |  9 +++++++++
 .../persistence/cassandra/query/UUIDPersistentRepr.scala    |  9 +++++++++
 .../cassandra/query/javadsl/CassandraReadJournal.scala      |  9 +++++++++
 .../scala/akka/persistence/cassandra/query/package.scala    |  9 +++++++++
 .../cassandra/query/scaladsl/CassandraReadJournal.scala     |  9 +++++++++
 .../akka/persistence/cassandra/reconciler/AllTags.scala     |  9 +++++++++
 .../cassandra/reconciler/BuildTagViewForPersistenceId.scala |  9 +++++++++
 .../reconciler/DeleteTagViewForPersistenceId.scala          |  9 +++++++++
 .../persistence/cassandra/reconciler/Reconciliation.scala   |  9 +++++++++
 .../cassandra/reconciler/ReconciliationSettings.scala       |  9 +++++++++
 .../cassandra/snapshot/CassandraSnapshotStatements.scala    |  9 +++++++++
 .../cassandra/snapshot/CassandraSnapshotStore.scala         |  9 +++++++++
 .../persistence/cassandra/snapshot/SnapshotSettings.scala   |  9 +++++++++
 .../persistence/cassandra/EventsByTagMultiJvmSpec.scala     |  9 +++++++++
 .../persistence/cassandra/MultiNodeClusterSpec.scala        |  9 +++++++++
 .../cluster/persistence/cassandra/STMultiNodeSpec.scala     |  9 +++++++++
 .../persistence/cassandra/CassandraCorruptJournalSpec.scala |  9 +++++++++
 .../cassandra/CassandraEventsByTagLoadSpec.scala            |  9 +++++++++
 .../akka/persistence/cassandra/CassandraLifecycle.scala     |  9 +++++++++
 .../persistence/cassandra/CassandraPluginSettingsSpec.scala |  9 +++++++++
 .../cassandra/CassandraQueryJournalSettingsSpec.scala       |  9 +++++++++
 .../scala/akka/persistence/cassandra/CassandraSpec.scala    |  9 +++++++++
 .../akka/persistence/cassandra/EventsByTagCrashSpec.scala   |  9 +++++++++
 .../persistence/cassandra/EventsByTagMigrationSpec.scala    |  9 +++++++++
 .../persistence/cassandra/EventsByTagRecoverySpec.scala     |  9 +++++++++
 .../akka/persistence/cassandra/EventsByTagRestartSpec.scala |  9 +++++++++
 .../akka/persistence/cassandra/EventsByTagStressSpec.scala  |  9 +++++++++
 .../test/scala/akka/persistence/cassandra/Persister.scala   |  9 +++++++++
 .../akka/persistence/cassandra/PrintCreateStatements.scala  |  9 +++++++++
 .../scala/akka/persistence/cassandra/ReconnectSpec.scala    |  9 +++++++++
 .../scala/akka/persistence/cassandra/RequiresThree.scala    |  9 +++++++++
 .../test/scala/akka/persistence/cassandra/RetriesSpec.scala |  9 +++++++++
 .../scala/akka/persistence/cassandra/TestTaggingActor.scala |  9 +++++++++
 .../scala/akka/persistence/cassandra/WithLogCapturing.scala |  9 +++++++++
 .../akka/persistence/cassandra/cleanup/CleanupSpec.scala    |  9 +++++++++
 .../compaction/CassandraCompactionStrategySpec.scala        |  9 +++++++++
 .../cassandra/healthcheck/CassandraHealthCheckSpec.scala    |  9 +++++++++
 .../akka/persistence/cassandra/journal/BufferSpec.scala     |  9 +++++++++
 .../cassandra/journal/CassandraEventUpdateSpec.scala        |  9 +++++++++
 .../cassandra/journal/CassandraIntegrationSpec.scala        |  9 +++++++++
 .../cassandra/journal/CassandraJournalDeletionSpec.scala    |  9 +++++++++
 .../cassandra/journal/CassandraJournalSpec.scala            |  9 +++++++++
 .../persistence/cassandra/journal/CassandraLoadSpec.scala   |  9 +++++++++
 .../cassandra/journal/CassandraLoadTypedSpec.scala          |  9 +++++++++
 .../cassandra/journal/CassandraSerializationSpec.scala      |  9 +++++++++
 .../persistence/cassandra/journal/ManyActorsLoadSpec.scala  |  9 +++++++++
 .../persistence/cassandra/journal/MultiPluginSpec.scala     |  9 +++++++++
 .../akka/persistence/cassandra/journal/PersistAllSpec.scala |  9 +++++++++
 .../persistence/cassandra/journal/PubSubThrottlerSpec.scala |  9 +++++++++
 .../persistence/cassandra/journal/RecoveryLoadSpec.scala    |  9 +++++++++
 .../persistence/cassandra/journal/StartupLoadSpec.scala     |  9 +++++++++
 .../persistence/cassandra/journal/TagScanningSpec.scala     |  9 +++++++++
 .../akka/persistence/cassandra/journal/TagWriterSpec.scala  |  9 +++++++++
 .../akka/persistence/cassandra/journal/TagWritersSpec.scala |  9 +++++++++
 .../akka/persistence/cassandra/journal/TimeBucketSpec.scala |  9 +++++++++
 .../persistence/cassandra/query/AllPersistenceIdsSpec.scala |  9 +++++++++
 .../cassandra/query/CassandraQueryJournalOverrideSpec.scala |  9 +++++++++
 .../akka/persistence/cassandra/query/DirectWriting.scala    |  9 +++++++++
 .../persistence/cassandra/query/EventAdaptersReadSpec.scala |  9 +++++++++
 .../query/EventsByPersistenceIdFastForwardSpec.scala        |  9 +++++++++
 .../query/EventsByPersistenceIdMultiPartitionGapSpec.scala  |  9 +++++++++
 .../cassandra/query/EventsByPersistenceIdSpec.scala         |  9 +++++++++
 .../query/EventsByPersistenceIdWithControlSpec.scala        |  9 +++++++++
 .../persistence/cassandra/query/EventsByTagPubsubSpec.scala |  9 +++++++++
 .../akka/persistence/cassandra/query/EventsByTagSpec.scala  |  9 +++++++++
 .../persistence/cassandra/query/EventsByTagStageSpec.scala  |  9 +++++++++
 .../cassandra/query/TagViewSequenceNumberScannerSpec.scala  |  9 +++++++++
 .../scala/akka/persistence/cassandra/query/TestActor.scala  |  9 +++++++++
 .../akka/persistence/cassandra/query/TestEventAdapter.scala |  9 +++++++++
 .../akka/persistence/cassandra/query/TestTagWriter.scala    |  9 +++++++++
 .../cassandra/query/javadsl/CassandraReadJournalSpec.scala  |  9 +++++++++
 .../cassandra/query/scaladsl/CassandraReadJournalSpec.scala |  9 +++++++++
 .../reconciler/BuildTagViewForPersistenceIdSpec.scala       |  9 +++++++++
 .../reconciler/DeleteTagViewForPersistenceIdSpec.scala      |  9 +++++++++
 .../cassandra/reconciler/RebuildAllPersisetceIdsSpec.scala  |  9 +++++++++
 .../persistence/cassandra/reconciler/TagQuerySpec.scala     |  9 +++++++++
 .../persistence/cassandra/reconciler/TruncateAllSpec.scala  |  9 +++++++++
 .../sharding/ClusterShardingQuickTerminationSpec.scala      |  9 +++++++++
 .../cassandra/snapshot/CassandraSnapshotStoreSpec.scala     |  9 +++++++++
 .../cassandra/testkit/CassandraLauncherSpec.scala           |  9 +++++++++
 .../reconciler/AllPersistenceIdsMigrationCompileOnly.scala  |  9 +++++++++
 .../scala/doc/reconciler/ReconciliationCompileOnly.scala    |  9 +++++++++
 .../scala/akka/persistence/cassandra/JournalDseSpec.scala   |  9 +++++++++
 dse-test/src/test/scala/your/pack/DseSessionProvider.scala  |  9 +++++++++
 .../persistence/cassandra/example/CborSerializable.scala    |  9 +++++++++
 .../cassandra/example/ConfigurablePersistentActor.scala     |  9 +++++++++
 .../cassandra/example/EventProcessorStream.scala            |  9 +++++++++
 .../akka/persistence/cassandra/example/LoadGenerator.scala  |  9 +++++++++
 .../scala/akka/persistence/cassandra/example/Main.scala     |  9 +++++++++
 .../scala/akka/persistence/cassandra/example/ReadSide.scala |  9 +++++++++
 .../akka/persistence/cassandra/example/ReadSideTopic.scala  |  9 +++++++++
 .../scala/akka/persistence/cassandra/example/Reporter.scala |  9 +++++++++
 project/Common.scala                                        | 13 ++++++++++---
 132 files changed, 1190 insertions(+), 5 deletions(-)

diff --git a/cassandra-launcher/src/main/scala/akka/persistence/cassandra/testkit/CassandraLauncher.scala b/cassandra-launcher/src/main/scala/akka/persistence/cassandra/testkit/CassandraLauncher.scala
index ff82c8c..b40db99 100644
--- a/cassandra-launcher/src/main/scala/akka/persistence/cassandra/testkit/CassandraLauncher.scala
+++ b/cassandra-launcher/src/main/scala/akka/persistence/cassandra/testkit/CassandraLauncher.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
@@ -10,12 +19,11 @@ import java.nio.channels.ServerSocketChannel
 import java.nio.file.Files
 import java.util.concurrent.TimeUnit
 import java.util.concurrent.atomic.AtomicReference
-
 import scala.annotation.varargs
 import scala.collection.immutable
 import scala.concurrent.duration._
-import scala.util.{ Failure, Try }
 import scala.util.control.NonFatal
+import scala.util.{ Failure, Try }
 
 /**
  * Starts Cassandra in current JVM. There can only be one Cassandra instance per JVM,
diff --git a/core/src/main/scala/akka/persistence/cassandra/CassandraStatements.scala b/core/src/main/scala/akka/persistence/cassandra/CassandraStatements.scala
index 8daa218..4f79892 100644
--- a/core/src/main/scala/akka/persistence/cassandra/CassandraStatements.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/CassandraStatements.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/EventsByTagMigration.scala b/core/src/main/scala/akka/persistence/cassandra/EventsByTagMigration.scala
index 390bc3a..ce54212 100644
--- a/core/src/main/scala/akka/persistence/cassandra/EventsByTagMigration.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/EventsByTagMigration.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/EventsByTagSettings.scala b/core/src/main/scala/akka/persistence/cassandra/EventsByTagSettings.scala
index 27b59bb..8dfb68a 100644
--- a/core/src/main/scala/akka/persistence/cassandra/EventsByTagSettings.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/EventsByTagSettings.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/Extractors.scala b/core/src/main/scala/akka/persistence/cassandra/Extractors.scala
index 6a71946..1f4cde6 100644
--- a/core/src/main/scala/akka/persistence/cassandra/Extractors.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/Extractors.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/KeyspaceAndTableStatements.scala b/core/src/main/scala/akka/persistence/cassandra/KeyspaceAndTableStatements.scala
index 9586da3..e80186c 100644
--- a/core/src/main/scala/akka/persistence/cassandra/KeyspaceAndTableStatements.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/KeyspaceAndTableStatements.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/PluginSettings.scala b/core/src/main/scala/akka/persistence/cassandra/PluginSettings.scala
index 2ebd4c3..dee7aae 100644
--- a/core/src/main/scala/akka/persistence/cassandra/PluginSettings.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/PluginSettings.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/Retries.scala b/core/src/main/scala/akka/persistence/cassandra/Retries.scala
index 4bb2795..750640d 100644
--- a/core/src/main/scala/akka/persistence/cassandra/Retries.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/Retries.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/cleanup/Cleanup.scala b/core/src/main/scala/akka/persistence/cassandra/cleanup/Cleanup.scala
index b61cb09..72773a9 100644
--- a/core/src/main/scala/akka/persistence/cassandra/cleanup/Cleanup.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/cleanup/Cleanup.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/cleanup/CleanupSettings.scala b/core/src/main/scala/akka/persistence/cassandra/cleanup/CleanupSettings.scala
index 245f03e..d1848c7 100644
--- a/core/src/main/scala/akka/persistence/cassandra/cleanup/CleanupSettings.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/cleanup/CleanupSettings.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/compaction/BaseCompactionStrategy.scala b/core/src/main/scala/akka/persistence/cassandra/compaction/BaseCompactionStrategy.scala
index 7f2239a..521c319 100644
--- a/core/src/main/scala/akka/persistence/cassandra/compaction/BaseCompactionStrategy.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/compaction/BaseCompactionStrategy.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategy.scala b/core/src/main/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategy.scala
index db92a7a..1652669 100644
--- a/core/src/main/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategy.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategy.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategyConfig.scala b/core/src/main/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategyConfig.scala
index fdc9f88..01b8d34 100644
--- a/core/src/main/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategyConfig.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategyConfig.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/compaction/LeveledCompactionStrategy.scala b/core/src/main/scala/akka/persistence/cassandra/compaction/LeveledCompactionStrategy.scala
index db7c05f..769277c 100644
--- a/core/src/main/scala/akka/persistence/cassandra/compaction/LeveledCompactionStrategy.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/compaction/LeveledCompactionStrategy.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/compaction/SizeTieredCompactionStrategy.scala b/core/src/main/scala/akka/persistence/cassandra/compaction/SizeTieredCompactionStrategy.scala
index d6108de..0e95aa1 100644
--- a/core/src/main/scala/akka/persistence/cassandra/compaction/SizeTieredCompactionStrategy.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/compaction/SizeTieredCompactionStrategy.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/compaction/TimeWindowCompactionStrategy.scala b/core/src/main/scala/akka/persistence/cassandra/compaction/TimeWindowCompactionStrategy.scala
index 2235bd8..fc5c832 100644
--- a/core/src/main/scala/akka/persistence/cassandra/compaction/TimeWindowCompactionStrategy.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/compaction/TimeWindowCompactionStrategy.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/healthcheck/CassandraHealthCheck.scala b/core/src/main/scala/akka/persistence/cassandra/healthcheck/CassandraHealthCheck.scala
index a163b02..e82ab2b 100644
--- a/core/src/main/scala/akka/persistence/cassandra/healthcheck/CassandraHealthCheck.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/healthcheck/CassandraHealthCheck.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/healthcheck/HealthCheckSettings.scala b/core/src/main/scala/akka/persistence/cassandra/healthcheck/HealthCheckSettings.scala
index 9e6a6a9..213d0fd 100644
--- a/core/src/main/scala/akka/persistence/cassandra/healthcheck/HealthCheckSettings.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/healthcheck/HealthCheckSettings.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/Buffer.scala b/core/src/main/scala/akka/persistence/cassandra/journal/Buffer.scala
index 2c2aa2b..708c784 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/Buffer.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/Buffer.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/CassandraEventUpdate.scala b/core/src/main/scala/akka/persistence/cassandra/journal/CassandraEventUpdate.scala
index d474ffa..5f293ab 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/CassandraEventUpdate.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/CassandraEventUpdate.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournal.scala b/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournal.scala
index cb601de..404d0fa 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournal.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournal.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournalStatements.scala b/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournalStatements.scala
index 06e3604..b3942a2 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournalStatements.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournalStatements.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournalUnexpectedError.scala b/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournalUnexpectedError.scala
index 83357d6..b8e249a 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournalUnexpectedError.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/CassandraJournalUnexpectedError.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/CassandraTagRecovery.scala b/core/src/main/scala/akka/persistence/cassandra/journal/CassandraTagRecovery.scala
index 6ea4c40..70fc43c 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/CassandraTagRecovery.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/CassandraTagRecovery.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/JournalSettings.scala b/core/src/main/scala/akka/persistence/cassandra/journal/JournalSettings.scala
index 95c2f24..daef895 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/JournalSettings.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/JournalSettings.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/PubSubThrottler.scala b/core/src/main/scala/akka/persistence/cassandra/journal/PubSubThrottler.scala
index a947ade..daa9975 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/PubSubThrottler.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/PubSubThrottler.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/TagWriter.scala b/core/src/main/scala/akka/persistence/cassandra/journal/TagWriter.scala
index 93b81f2..9e15502 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/TagWriter.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/TagWriter.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/TagWriters.scala b/core/src/main/scala/akka/persistence/cassandra/journal/TagWriters.scala
index 4374cd9..7eb7eb5 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/TagWriters.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/TagWriters.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/TaggedPreparedStatements.scala b/core/src/main/scala/akka/persistence/cassandra/journal/TaggedPreparedStatements.scala
index 673a074..e6a14a5 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/TaggedPreparedStatements.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/TaggedPreparedStatements.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/TimeBucket.scala b/core/src/main/scala/akka/persistence/cassandra/journal/TimeBucket.scala
index 5a2d7a2..19b96ce 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/TimeBucket.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/TimeBucket.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/journal/package.scala b/core/src/main/scala/akka/persistence/cassandra/journal/package.scala
index 4c82f7a..faf8e0e 100644
--- a/core/src/main/scala/akka/persistence/cassandra/journal/package.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/journal/package.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/package.scala b/core/src/main/scala/akka/persistence/cassandra/package.scala
index 3a05d1c..01b1fd3 100644
--- a/core/src/main/scala/akka/persistence/cassandra/package.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/package.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/AllPersistenceIdsStage.scala b/core/src/main/scala/akka/persistence/cassandra/query/AllPersistenceIdsStage.scala
index 798c523..4c10e77 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/AllPersistenceIdsStage.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/AllPersistenceIdsStage.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/CassandraReadJournalProvider.scala b/core/src/main/scala/akka/persistence/cassandra/query/CassandraReadJournalProvider.scala
index f4088d0..2c48b34 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/CassandraReadJournalProvider.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/CassandraReadJournalProvider.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/CassandraReadStatements.scala b/core/src/main/scala/akka/persistence/cassandra/query/CassandraReadStatements.scala
index eb351df..ee11167 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/CassandraReadStatements.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/CassandraReadStatements.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/EventsByPersistenceIdStage.scala b/core/src/main/scala/akka/persistence/cassandra/query/EventsByPersistenceIdStage.scala
index f8d1471..3129b42 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/EventsByPersistenceIdStage.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/EventsByPersistenceIdStage.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/EventsByTagStage.scala b/core/src/main/scala/akka/persistence/cassandra/query/EventsByTagStage.scala
index ecbc797..f040ede 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/EventsByTagStage.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/EventsByTagStage.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/MissingTaggedEventException.scala b/core/src/main/scala/akka/persistence/cassandra/query/MissingTaggedEventException.scala
index 57468bc..addb162 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/MissingTaggedEventException.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/MissingTaggedEventException.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/QuerySettings.scala b/core/src/main/scala/akka/persistence/cassandra/query/QuerySettings.scala
index b5695eb..dc5a6eb 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/QuerySettings.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/QuerySettings.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/TagViewSequenceNumberScanner.scala b/core/src/main/scala/akka/persistence/cassandra/query/TagViewSequenceNumberScanner.scala
index 60b34f1..383ad85 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/TagViewSequenceNumberScanner.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/TagViewSequenceNumberScanner.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/UUIDPersistentRepr.scala b/core/src/main/scala/akka/persistence/cassandra/query/UUIDPersistentRepr.scala
index 41e1b32..b0fb268 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/UUIDPersistentRepr.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/UUIDPersistentRepr.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/javadsl/CassandraReadJournal.scala b/core/src/main/scala/akka/persistence/cassandra/query/javadsl/CassandraReadJournal.scala
index 216f47e..1adb814 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/javadsl/CassandraReadJournal.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/javadsl/CassandraReadJournal.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/package.scala b/core/src/main/scala/akka/persistence/cassandra/query/package.scala
index 0c6ec42..ed26e28 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/package.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/package.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/query/scaladsl/CassandraReadJournal.scala b/core/src/main/scala/akka/persistence/cassandra/query/scaladsl/CassandraReadJournal.scala
index e4ed50d..06e5746 100644
--- a/core/src/main/scala/akka/persistence/cassandra/query/scaladsl/CassandraReadJournal.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/query/scaladsl/CassandraReadJournal.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/reconciler/AllTags.scala b/core/src/main/scala/akka/persistence/cassandra/reconciler/AllTags.scala
index ed1b47c..82f6999 100644
--- a/core/src/main/scala/akka/persistence/cassandra/reconciler/AllTags.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/reconciler/AllTags.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/reconciler/BuildTagViewForPersistenceId.scala b/core/src/main/scala/akka/persistence/cassandra/reconciler/BuildTagViewForPersistenceId.scala
index 53c416b..43e1f17 100644
--- a/core/src/main/scala/akka/persistence/cassandra/reconciler/BuildTagViewForPersistenceId.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/reconciler/BuildTagViewForPersistenceId.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/reconciler/DeleteTagViewForPersistenceId.scala b/core/src/main/scala/akka/persistence/cassandra/reconciler/DeleteTagViewForPersistenceId.scala
index 603acc0..875b3a0 100644
--- a/core/src/main/scala/akka/persistence/cassandra/reconciler/DeleteTagViewForPersistenceId.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/reconciler/DeleteTagViewForPersistenceId.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/reconciler/Reconciliation.scala b/core/src/main/scala/akka/persistence/cassandra/reconciler/Reconciliation.scala
index de44f06..40be6a2 100644
--- a/core/src/main/scala/akka/persistence/cassandra/reconciler/Reconciliation.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/reconciler/Reconciliation.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/reconciler/ReconciliationSettings.scala b/core/src/main/scala/akka/persistence/cassandra/reconciler/ReconciliationSettings.scala
index 114eafb..187d251 100644
--- a/core/src/main/scala/akka/persistence/cassandra/reconciler/ReconciliationSettings.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/reconciler/ReconciliationSettings.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStatements.scala b/core/src/main/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStatements.scala
index 3aadcde..8bfc715 100644
--- a/core/src/main/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStatements.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStatements.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStore.scala b/core/src/main/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStore.scala
index 46b71aa..b454929 100644
--- a/core/src/main/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStore.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStore.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/main/scala/akka/persistence/cassandra/snapshot/SnapshotSettings.scala b/core/src/main/scala/akka/persistence/cassandra/snapshot/SnapshotSettings.scala
index fe40a32..4b27c0f 100644
--- a/core/src/main/scala/akka/persistence/cassandra/snapshot/SnapshotSettings.scala
+++ b/core/src/main/scala/akka/persistence/cassandra/snapshot/SnapshotSettings.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/EventsByTagMultiJvmSpec.scala b/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/EventsByTagMultiJvmSpec.scala
index 35c0403..ef43220 100644
--- a/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/EventsByTagMultiJvmSpec.scala
+++ b/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/EventsByTagMultiJvmSpec.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.
+ */
+
 package akka.cluster.persistence.cassandra
 
 import java.io.File
diff --git a/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/MultiNodeClusterSpec.scala b/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/MultiNodeClusterSpec.scala
index ee800c6..81804a7 100644
--- a/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/MultiNodeClusterSpec.scala
+++ b/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/MultiNodeClusterSpec.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.
+ */
+
 package akka.cluster.persistence.cassandra
 
 import java.util.UUID
diff --git a/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/STMultiNodeSpec.scala b/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/STMultiNodeSpec.scala
index fd3b47e..d20ba7b 100644
--- a/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/STMultiNodeSpec.scala
+++ b/core/src/multi-jvm/scala/akka/cluster/persistence/cassandra/STMultiNodeSpec.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.
+ */
+
 package akka.cluster.persistence.cassandra
 
 import akka.remote.testkit.{ MultiNodeSpec, MultiNodeSpecCallbacks }
diff --git a/core/src/test/scala/akka/persistence/cassandra/CassandraCorruptJournalSpec.scala b/core/src/test/scala/akka/persistence/cassandra/CassandraCorruptJournalSpec.scala
index 7d7b332..1a3db19 100644
--- a/core/src/test/scala/akka/persistence/cassandra/CassandraCorruptJournalSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/CassandraCorruptJournalSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/CassandraEventsByTagLoadSpec.scala b/core/src/test/scala/akka/persistence/cassandra/CassandraEventsByTagLoadSpec.scala
index 8dcd930..3d5f5df 100644
--- a/core/src/test/scala/akka/persistence/cassandra/CassandraEventsByTagLoadSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/CassandraEventsByTagLoadSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/CassandraLifecycle.scala b/core/src/test/scala/akka/persistence/cassandra/CassandraLifecycle.scala
index a8b3c04..6899c31 100644
--- a/core/src/test/scala/akka/persistence/cassandra/CassandraLifecycle.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/CassandraLifecycle.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/CassandraPluginSettingsSpec.scala b/core/src/test/scala/akka/persistence/cassandra/CassandraPluginSettingsSpec.scala
index 1dd73c4..0098d27 100644
--- a/core/src/test/scala/akka/persistence/cassandra/CassandraPluginSettingsSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/CassandraPluginSettingsSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/CassandraQueryJournalSettingsSpec.scala b/core/src/test/scala/akka/persistence/cassandra/CassandraQueryJournalSettingsSpec.scala
index 96c6b2c..1dc6b74 100644
--- a/core/src/test/scala/akka/persistence/cassandra/CassandraQueryJournalSettingsSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/CassandraQueryJournalSettingsSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/CassandraSpec.scala b/core/src/test/scala/akka/persistence/cassandra/CassandraSpec.scala
index 702ee40..65ff9e8 100644
--- a/core/src/test/scala/akka/persistence/cassandra/CassandraSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/CassandraSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/EventsByTagCrashSpec.scala b/core/src/test/scala/akka/persistence/cassandra/EventsByTagCrashSpec.scala
index a97e309..a6a63ef 100644
--- a/core/src/test/scala/akka/persistence/cassandra/EventsByTagCrashSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/EventsByTagCrashSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/EventsByTagMigrationSpec.scala b/core/src/test/scala/akka/persistence/cassandra/EventsByTagMigrationSpec.scala
index 23958ba..149cb60 100644
--- a/core/src/test/scala/akka/persistence/cassandra/EventsByTagMigrationSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/EventsByTagMigrationSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/EventsByTagRecoverySpec.scala b/core/src/test/scala/akka/persistence/cassandra/EventsByTagRecoverySpec.scala
index 6e3438b..4b2049a 100644
--- a/core/src/test/scala/akka/persistence/cassandra/EventsByTagRecoverySpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/EventsByTagRecoverySpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/EventsByTagRestartSpec.scala b/core/src/test/scala/akka/persistence/cassandra/EventsByTagRestartSpec.scala
index 8038b47..8969e1c 100644
--- a/core/src/test/scala/akka/persistence/cassandra/EventsByTagRestartSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/EventsByTagRestartSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/EventsByTagStressSpec.scala b/core/src/test/scala/akka/persistence/cassandra/EventsByTagStressSpec.scala
index 87949e3..1e777d1 100644
--- a/core/src/test/scala/akka/persistence/cassandra/EventsByTagStressSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/EventsByTagStressSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/Persister.scala b/core/src/test/scala/akka/persistence/cassandra/Persister.scala
index d4678ff..6188bc5 100644
--- a/core/src/test/scala/akka/persistence/cassandra/Persister.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/Persister.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/PrintCreateStatements.scala b/core/src/test/scala/akka/persistence/cassandra/PrintCreateStatements.scala
index 71d1d5e..e4e4ef9 100644
--- a/core/src/test/scala/akka/persistence/cassandra/PrintCreateStatements.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/PrintCreateStatements.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/ReconnectSpec.scala b/core/src/test/scala/akka/persistence/cassandra/ReconnectSpec.scala
index b5d6794..73de436 100644
--- a/core/src/test/scala/akka/persistence/cassandra/ReconnectSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/ReconnectSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/RequiresThree.scala b/core/src/test/scala/akka/persistence/cassandra/RequiresThree.scala
index f1a0cd2..bdbb95d 100644
--- a/core/src/test/scala/akka/persistence/cassandra/RequiresThree.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/RequiresThree.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/RetriesSpec.scala b/core/src/test/scala/akka/persistence/cassandra/RetriesSpec.scala
index 3241db6..fb7ab00 100644
--- a/core/src/test/scala/akka/persistence/cassandra/RetriesSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/RetriesSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/TestTaggingActor.scala b/core/src/test/scala/akka/persistence/cassandra/TestTaggingActor.scala
index 92c1edf..bc9762c 100644
--- a/core/src/test/scala/akka/persistence/cassandra/TestTaggingActor.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/TestTaggingActor.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/WithLogCapturing.scala b/core/src/test/scala/akka/persistence/cassandra/WithLogCapturing.scala
index 5e0976d..b7f264b 100644
--- a/core/src/test/scala/akka/persistence/cassandra/WithLogCapturing.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/WithLogCapturing.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/cleanup/CleanupSpec.scala b/core/src/test/scala/akka/persistence/cassandra/cleanup/CleanupSpec.scala
index 7cc691e..68456ac 100644
--- a/core/src/test/scala/akka/persistence/cassandra/cleanup/CleanupSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/cleanup/CleanupSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategySpec.scala b/core/src/test/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategySpec.scala
index dd728c3..b1510fe 100644
--- a/core/src/test/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategySpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/compaction/CassandraCompactionStrategySpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/healthcheck/CassandraHealthCheckSpec.scala b/core/src/test/scala/akka/persistence/cassandra/healthcheck/CassandraHealthCheckSpec.scala
index 7b675ad..1f6dfe2 100644
--- a/core/src/test/scala/akka/persistence/cassandra/healthcheck/CassandraHealthCheckSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/healthcheck/CassandraHealthCheckSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/BufferSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/BufferSpec.scala
index 250d939..f4d03b2 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/BufferSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/BufferSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraEventUpdateSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraEventUpdateSpec.scala
index f73a0f2..196fab3 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraEventUpdateSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraEventUpdateSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraIntegrationSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraIntegrationSpec.scala
index bbc5806..94780bc 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraIntegrationSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraIntegrationSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraJournalDeletionSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraJournalDeletionSpec.scala
index c24f006..97d7660 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraJournalDeletionSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraJournalDeletionSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraJournalSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraJournalSpec.scala
index ee32c8c..2a98a5b 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraJournalSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraJournalSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraLoadSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraLoadSpec.scala
index b7012e4..441aba1 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraLoadSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraLoadSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraLoadTypedSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraLoadTypedSpec.scala
index 0fa9981..114dc77 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraLoadTypedSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraLoadTypedSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraSerializationSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraSerializationSpec.scala
index 3fcff6d..1913f0b 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/CassandraSerializationSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/CassandraSerializationSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/ManyActorsLoadSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/ManyActorsLoadSpec.scala
index 4863126..017969d 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/ManyActorsLoadSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/ManyActorsLoadSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/MultiPluginSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/MultiPluginSpec.scala
index f7ccd57..99e6041 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/MultiPluginSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/MultiPluginSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/PersistAllSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/PersistAllSpec.scala
index b415c36..5290401 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/PersistAllSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/PersistAllSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/PubSubThrottlerSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/PubSubThrottlerSpec.scala
index ee15b8c..84e205f 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/PubSubThrottlerSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/PubSubThrottlerSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/RecoveryLoadSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/RecoveryLoadSpec.scala
index b857e07..690f4f2 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/RecoveryLoadSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/RecoveryLoadSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/StartupLoadSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/StartupLoadSpec.scala
index deaa476..4d04ece 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/StartupLoadSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/StartupLoadSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/TagScanningSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/TagScanningSpec.scala
index a20e1bb..e2a3f33 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/TagScanningSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/TagScanningSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/TagWriterSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/TagWriterSpec.scala
index 59b4191..bd4633b 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/TagWriterSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/TagWriterSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/TagWritersSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/TagWritersSpec.scala
index a77936f..15211a8 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/TagWritersSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/TagWritersSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/journal/TimeBucketSpec.scala b/core/src/test/scala/akka/persistence/cassandra/journal/TimeBucketSpec.scala
index 494e971..f737288 100644
--- a/core/src/test/scala/akka/persistence/cassandra/journal/TimeBucketSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/journal/TimeBucketSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/AllPersistenceIdsSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/AllPersistenceIdsSpec.scala
index b053961..2b25165 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/AllPersistenceIdsSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/AllPersistenceIdsSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/CassandraQueryJournalOverrideSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/CassandraQueryJournalOverrideSpec.scala
index 1e0a645..851ea58 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/CassandraQueryJournalOverrideSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/CassandraQueryJournalOverrideSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/DirectWriting.scala b/core/src/test/scala/akka/persistence/cassandra/query/DirectWriting.scala
index e08f9cc..d5135f1 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/DirectWriting.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/DirectWriting.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/EventAdaptersReadSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/EventAdaptersReadSpec.scala
index 1eab4c1..9f4d736 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/EventAdaptersReadSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/EventAdaptersReadSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdFastForwardSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdFastForwardSpec.scala
index 79ac327..3220abf 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdFastForwardSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdFastForwardSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdMultiPartitionGapSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdMultiPartitionGapSpec.scala
index bd75810..17df60a 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdMultiPartitionGapSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdMultiPartitionGapSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdSpec.scala
index ef02f61..8e19b9b 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdWithControlSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdWithControlSpec.scala
index 5585126..8c113bf 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdWithControlSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/EventsByPersistenceIdWithControlSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagPubsubSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagPubsubSpec.scala
index c4d488b..b8a02a4 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagPubsubSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagPubsubSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagSpec.scala
index 92c20ed..e4cdd01 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagStageSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagStageSpec.scala
index 2483f39..4fd9678 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagStageSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/EventsByTagStageSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/TagViewSequenceNumberScannerSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/TagViewSequenceNumberScannerSpec.scala
index b1abc91..e8b3216 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/TagViewSequenceNumberScannerSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/TagViewSequenceNumberScannerSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/TestActor.scala b/core/src/test/scala/akka/persistence/cassandra/query/TestActor.scala
index 7aaecf5..33bc577 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/TestActor.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/TestActor.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/TestEventAdapter.scala b/core/src/test/scala/akka/persistence/cassandra/query/TestEventAdapter.scala
index 4a55277..1b80a67 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/TestEventAdapter.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/TestEventAdapter.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/TestTagWriter.scala b/core/src/test/scala/akka/persistence/cassandra/query/TestTagWriter.scala
index fcccbab..e96230c 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/TestTagWriter.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/TestTagWriter.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/javadsl/CassandraReadJournalSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/javadsl/CassandraReadJournalSpec.scala
index 5b14307..a74a01c 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/javadsl/CassandraReadJournalSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/javadsl/CassandraReadJournalSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/query/scaladsl/CassandraReadJournalSpec.scala b/core/src/test/scala/akka/persistence/cassandra/query/scaladsl/CassandraReadJournalSpec.scala
index 87f3055..ffef9af 100644
--- a/core/src/test/scala/akka/persistence/cassandra/query/scaladsl/CassandraReadJournalSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/query/scaladsl/CassandraReadJournalSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/reconciler/BuildTagViewForPersistenceIdSpec.scala b/core/src/test/scala/akka/persistence/cassandra/reconciler/BuildTagViewForPersistenceIdSpec.scala
index 5fd2fed..02cebee 100644
--- a/core/src/test/scala/akka/persistence/cassandra/reconciler/BuildTagViewForPersistenceIdSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/reconciler/BuildTagViewForPersistenceIdSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/reconciler/DeleteTagViewForPersistenceIdSpec.scala b/core/src/test/scala/akka/persistence/cassandra/reconciler/DeleteTagViewForPersistenceIdSpec.scala
index 2c7749f..fd2f227 100644
--- a/core/src/test/scala/akka/persistence/cassandra/reconciler/DeleteTagViewForPersistenceIdSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/reconciler/DeleteTagViewForPersistenceIdSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/reconciler/RebuildAllPersisetceIdsSpec.scala b/core/src/test/scala/akka/persistence/cassandra/reconciler/RebuildAllPersisetceIdsSpec.scala
index 2c0bcf0..d9c0199 100644
--- a/core/src/test/scala/akka/persistence/cassandra/reconciler/RebuildAllPersisetceIdsSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/reconciler/RebuildAllPersisetceIdsSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/reconciler/TagQuerySpec.scala b/core/src/test/scala/akka/persistence/cassandra/reconciler/TagQuerySpec.scala
index 07ef1c3..4a39c60 100644
--- a/core/src/test/scala/akka/persistence/cassandra/reconciler/TagQuerySpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/reconciler/TagQuerySpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/reconciler/TruncateAllSpec.scala b/core/src/test/scala/akka/persistence/cassandra/reconciler/TruncateAllSpec.scala
index f0f398e..b21355b 100644
--- a/core/src/test/scala/akka/persistence/cassandra/reconciler/TruncateAllSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/reconciler/TruncateAllSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/sharding/ClusterShardingQuickTerminationSpec.scala b/core/src/test/scala/akka/persistence/cassandra/sharding/ClusterShardingQuickTerminationSpec.scala
index a632e76..9a36157 100644
--- a/core/src/test/scala/akka/persistence/cassandra/sharding/ClusterShardingQuickTerminationSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/sharding/ClusterShardingQuickTerminationSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStoreSpec.scala b/core/src/test/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStoreSpec.scala
index 77bf2be..f7ee074 100644
--- a/core/src/test/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStoreSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/snapshot/CassandraSnapshotStoreSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/akka/persistence/cassandra/testkit/CassandraLauncherSpec.scala b/core/src/test/scala/akka/persistence/cassandra/testkit/CassandraLauncherSpec.scala
index df7c4a2..3ad15e4 100644
--- a/core/src/test/scala/akka/persistence/cassandra/testkit/CassandraLauncherSpec.scala
+++ b/core/src/test/scala/akka/persistence/cassandra/testkit/CassandraLauncherSpec.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/doc/reconciler/AllPersistenceIdsMigrationCompileOnly.scala b/core/src/test/scala/doc/reconciler/AllPersistenceIdsMigrationCompileOnly.scala
index 913950c..4c9e50e 100644
--- a/core/src/test/scala/doc/reconciler/AllPersistenceIdsMigrationCompileOnly.scala
+++ b/core/src/test/scala/doc/reconciler/AllPersistenceIdsMigrationCompileOnly.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/core/src/test/scala/doc/reconciler/ReconciliationCompileOnly.scala b/core/src/test/scala/doc/reconciler/ReconciliationCompileOnly.scala
index 8c321bd..58f1634 100644
--- a/core/src/test/scala/doc/reconciler/ReconciliationCompileOnly.scala
+++ b/core/src/test/scala/doc/reconciler/ReconciliationCompileOnly.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) 2016-2020 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/dse-test/src/test/scala/akka/persistence/cassandra/JournalDseSpec.scala b/dse-test/src/test/scala/akka/persistence/cassandra/JournalDseSpec.scala
index 0af13ff..6c3f73a 100644
--- a/dse-test/src/test/scala/akka/persistence/cassandra/JournalDseSpec.scala
+++ b/dse-test/src/test/scala/akka/persistence/cassandra/JournalDseSpec.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.
+ */
+
 package akka.persistence.cassandra
 
 import akka.persistence.journal.JournalSpec
diff --git a/dse-test/src/test/scala/your/pack/DseSessionProvider.scala b/dse-test/src/test/scala/your/pack/DseSessionProvider.scala
index 2fe6713..5621489 100644
--- a/dse-test/src/test/scala/your/pack/DseSessionProvider.scala
+++ b/dse-test/src/test/scala/your/pack/DseSessionProvider.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.
+ */
+
 package your.pack
 
 import akka.stream.alpakka.cassandra.CqlSessionProvider
diff --git a/example/src/main/scala/akka/persistence/cassandra/example/CborSerializable.scala b/example/src/main/scala/akka/persistence/cassandra/example/CborSerializable.scala
index 9372412..2273534 100644
--- a/example/src/main/scala/akka/persistence/cassandra/example/CborSerializable.scala
+++ b/example/src/main/scala/akka/persistence/cassandra/example/CborSerializable.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.
+ */
+
 package akka.persistence.cassandra.example
 
 trait CborSerializable
diff --git a/example/src/main/scala/akka/persistence/cassandra/example/ConfigurablePersistentActor.scala b/example/src/main/scala/akka/persistence/cassandra/example/ConfigurablePersistentActor.scala
index 64d24b8..740d6b0 100644
--- a/example/src/main/scala/akka/persistence/cassandra/example/ConfigurablePersistentActor.scala
+++ b/example/src/main/scala/akka/persistence/cassandra/example/ConfigurablePersistentActor.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.
+ */
+
 package akka.persistence.cassandra.example
 
 import akka.actor.typed.scaladsl.Behaviors
diff --git a/example/src/main/scala/akka/persistence/cassandra/example/EventProcessorStream.scala b/example/src/main/scala/akka/persistence/cassandra/example/EventProcessorStream.scala
index a50e3e6..c7a8831 100644
--- a/example/src/main/scala/akka/persistence/cassandra/example/EventProcessorStream.scala
+++ b/example/src/main/scala/akka/persistence/cassandra/example/EventProcessorStream.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.
+ */
+
 package akka.persistence.cassandra.example
 
 import akka.{ Done, NotUsed }
diff --git a/example/src/main/scala/akka/persistence/cassandra/example/LoadGenerator.scala b/example/src/main/scala/akka/persistence/cassandra/example/LoadGenerator.scala
index 76933dd..7f4e026 100644
--- a/example/src/main/scala/akka/persistence/cassandra/example/LoadGenerator.scala
+++ b/example/src/main/scala/akka/persistence/cassandra/example/LoadGenerator.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.
+ */
+
 package akka.persistence.cassandra.example
 
 import akka.actor.typed.{ ActorRef, Behavior }
diff --git a/example/src/main/scala/akka/persistence/cassandra/example/Main.scala b/example/src/main/scala/akka/persistence/cassandra/example/Main.scala
index 183b90f..84b5dfd 100644
--- a/example/src/main/scala/akka/persistence/cassandra/example/Main.scala
+++ b/example/src/main/scala/akka/persistence/cassandra/example/Main.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.
+ */
+
 package akka.persistence.cassandra.example
 
 import akka.actor.typed.{ ActorRef, ActorSystem }
diff --git a/example/src/main/scala/akka/persistence/cassandra/example/ReadSide.scala b/example/src/main/scala/akka/persistence/cassandra/example/ReadSide.scala
index 81f64d4..2e68ab5 100644
--- a/example/src/main/scala/akka/persistence/cassandra/example/ReadSide.scala
+++ b/example/src/main/scala/akka/persistence/cassandra/example/ReadSide.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.
+ */
+
 package akka.persistence.cassandra.example
 
 import akka.actor.typed.pubsub.Topic
diff --git a/example/src/main/scala/akka/persistence/cassandra/example/ReadSideTopic.scala b/example/src/main/scala/akka/persistence/cassandra/example/ReadSideTopic.scala
index 1176987..ab9974c 100644
--- a/example/src/main/scala/akka/persistence/cassandra/example/ReadSideTopic.scala
+++ b/example/src/main/scala/akka/persistence/cassandra/example/ReadSideTopic.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.
+ */
+
 package akka.persistence.cassandra.example
 
 import akka.actor.typed.pubsub.Topic
diff --git a/example/src/main/scala/akka/persistence/cassandra/example/Reporter.scala b/example/src/main/scala/akka/persistence/cassandra/example/Reporter.scala
index 5b577ae..59ecbde 100644
--- a/example/src/main/scala/akka/persistence/cassandra/example/Reporter.scala
+++ b/example/src/main/scala/akka/persistence/cassandra/example/Reporter.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.
+ */
+
 package akka.persistence.cassandra.example
 
 import akka.actor.typed.{ ActorRef, Behavior }
diff --git a/project/Common.scala b/project/Common.scala
index 83e9176..031d42b 100644
--- a/project/Common.scala
+++ b/project/Common.scala
@@ -59,9 +59,7 @@ object Common extends AutoPlugin {
     Compile / doc / scalacOptions --= Seq("-Xfatal-warnings"),
     scalafmtOnCompile := true,
     autoAPIMappings := true,
-    apiURL := Some(url(s"https://doc.akka.io/api/akka-persistence-cassandra/${projectInfoVersion.value}")),
-    headerLicense := Some(
-      HeaderLicense.Custom("""Copyright (C) 2016-2020 Lightbend Inc. <https://www.lightbend.com>""")),
+    headerLicense := Some(HeaderLicense.Custom(apacheHeader)),
     sonatypeProfileName := "com.typesafe",
     Test / logBuffered := System.getProperty("akka.logBufferedTests", "false").toBoolean,
     // show full stack traces and test case durations
@@ -71,4 +69,13 @@ object Common extends AutoPlugin {
     // -q Suppress stdout for successful tests.
     Test / testOptions += Tests.Argument(TestFrameworks.JUnit, "-a", "-v", "-q"),
     Test / parallelExecution := false)
+
+  def 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
 }


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