You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pekko.apache.org by md...@apache.org on 2023/03/23 13:37:38 UTC

[incubator-pekko-persistence-cassandra] branch main updated: Remove FQCN boilerplate

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

mdedetrich 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 799e205  Remove FQCN boilerplate
799e205 is described below

commit 799e20518ce66ba7e692dd057bba0d5268bfbc1a
Author: Matthew de Detrich <ma...@aiven.io>
AuthorDate: Thu Mar 23 13:41:55 2023 +0100

    Remove FQCN boilerplate
---
 .../cassandra/CassandraStatements.scala            | 11 +++---
 .../cassandra/EventsByTagMigration.scala           | 35 ++++++++--------
 .../cassandra/EventsByTagSettings.scala            | 15 +++----
 .../pekko/persistence/cassandra/Extractors.scala   | 17 ++++----
 .../persistence/cassandra/PluginSettings.scala     | 15 +++----
 .../pekko/persistence/cassandra/Retries.scala      |  7 ++--
 .../persistence/cassandra/cleanup/Cleanup.scala    | 33 ++++++++--------
 .../healthcheck/CassandraHealthCheck.scala         | 15 +++----
 .../healthcheck/HealthCheckSettings.scala          |  5 ++-
 .../persistence/cassandra/journal/Buffer.scala     |  7 ++--
 .../cassandra/journal/CassandraEventUpdate.scala   | 13 +++---
 .../cassandra/journal/CassandraJournal.scala       | 45 ++++++++++-----------
 .../journal/CassandraJournalStatements.scala       | 13 +++---
 .../cassandra/journal/CassandraTagRecovery.scala   | 37 ++++++++---------
 .../cassandra/journal/JournalSettings.scala        | 15 +++----
 .../cassandra/journal/PubSubThrottler.scala        |  7 ++--
 .../persistence/cassandra/journal/TagWriter.scala  | 31 ++++++---------
 .../persistence/cassandra/journal/TagWriters.scala | 43 ++++++++++----------
 .../persistence/cassandra/journal/TimeBucket.scala |  9 +++--
 .../pekko/persistence/cassandra/package.scala      | 19 ++++-----
 .../cassandra/query/AllPersistenceIdsStage.scala   |  7 ++--
 .../query/CassandraReadJournalProvider.scala       |  5 ++-
 .../cassandra/query/CassandraReadStatements.scala  |  5 ++-
 .../query/EventsByPersistenceIdStage.scala         | 13 +++---
 .../cassandra/query/EventsByTagStage.scala         | 27 +++++++------
 .../cassandra/query/QuerySettings.scala            | 11 +++---
 .../query/TagViewSequenceNumberScanner.scala       | 31 ++++++++-------
 .../cassandra/query/UUIDPersistentRepr.scala       |  7 ++--
 .../query/javadsl/CassandraReadJournal.scala       | 23 +++++------
 .../query/scaladsl/CassandraReadJournal.scala      | 46 ++++++++++------------
 .../persistence/cassandra/reconciler/AllTags.scala |  7 ++--
 .../reconciler/BuildTagViewForPersistenceId.scala  | 33 ++++++++--------
 .../reconciler/DeleteTagViewForPersistenceId.scala | 19 ++++-----
 .../cassandra/reconciler/Reconciliation.scala      | 41 +++++++++----------
 .../snapshot/CassandraSnapshotStatements.scala     | 11 +++---
 .../snapshot/CassandraSnapshotStore.scala          | 29 +++++++-------
 .../cassandra/snapshot/SnapshotSettings.scala      | 11 +++---
 .../cassandra/EventsByTagMultiJvmSpec.scala        | 17 ++++----
 .../cassandra/MultiNodeClusterSpec.scala           | 29 +++++++-------
 .../AllPersistenceIdsMigrationCompileOnly.scala    |  5 ++-
 .../doc/reconciler/ReconciliationCompileOnly.scala |  7 ++--
 .../cassandra/CassandraCorruptJournalSpec.scala    |  9 +++--
 .../cassandra/CassandraEventsByTagLoadSpec.scala   | 11 +++---
 .../persistence/cassandra/CassandraLifecycle.scala | 11 +++---
 .../cassandra/CassandraPluginSettingsSpec.scala    |  7 ++--
 .../CassandraQueryJournalSettingsSpec.scala        | 13 +++---
 .../persistence/cassandra/CassandraSpec.scala      | 29 +++++++-------
 .../cassandra/EventsByTagCrashSpec.scala           | 11 +++---
 .../cassandra/EventsByTagMigrationSpec.scala       | 35 ++++++++--------
 .../cassandra/EventsByTagRecoverySpec.scala        | 13 +++---
 .../cassandra/EventsByTagRestartSpec.scala         | 13 +++---
 .../cassandra/EventsByTagStressSpec.scala          | 11 +++---
 .../pekko/persistence/cassandra/Persister.scala    |  7 ++--
 .../persistence/cassandra/ReconnectSpec.scala      |  9 +++--
 .../pekko/persistence/cassandra/RetriesSpec.scala  |  7 ++--
 .../persistence/cassandra/TestTaggingActor.scala   |  9 +++--
 .../persistence/cassandra/WithLogCapturing.scala   |  5 ++-
 .../cassandra/cleanup/CleanupSpec.scala            | 17 ++++----
 .../CassandraCompactionStrategySpec.scala          |  5 ++-
 .../persistence/cassandra/journal/BufferSpec.scala | 13 +++---
 .../journal/CassandraEventUpdateSpec.scala         | 19 ++++-----
 .../journal/CassandraIntegrationSpec.scala         | 11 +++---
 .../journal/CassandraJournalDeletionSpec.scala     | 11 +++---
 .../cassandra/journal/CassandraJournalSpec.scala   | 22 +++++------
 .../cassandra/journal/CassandraLoadSpec.scala      | 11 +++---
 .../cassandra/journal/CassandraLoadTypedSpec.scala | 21 +++++-----
 .../journal/CassandraSerializationSpec.scala       | 13 +++---
 .../cassandra/journal/ManyActorsLoadSpec.scala     | 11 +++---
 .../cassandra/journal/MultiPluginSpec.scala        | 11 +++---
 .../cassandra/journal/PersistAllSpec.scala         | 13 +++---
 .../cassandra/journal/PubSubThrottlerSpec.scala    |  5 ++-
 .../cassandra/journal/RecoveryLoadSpec.scala       |  9 +++--
 .../cassandra/journal/StartupLoadSpec.scala        |  9 +++--
 .../cassandra/journal/TagWriterSpec.scala          | 23 +++++------
 .../cassandra/journal/TagWritersSpec.scala         | 17 ++++----
 .../cassandra/journal/TimeBucketSpec.scala         |  7 ++--
 .../cassandra/query/AllPersistenceIdsSpec.scala    | 15 +++----
 .../query/CassandraQueryJournalOverrideSpec.scala  | 15 +++----
 .../cassandra/query/DirectWriting.scala            | 21 +++++-----
 .../cassandra/query/EventAdaptersReadSpec.scala    |  9 +++--
 .../EventsByPersistenceIdFastForwardSpec.scala     |  9 +++--
 ...ventsByPersistenceIdMultiPartitionGapSpec.scala |  7 ++--
 .../query/EventsByPersistenceIdSpec.scala          | 17 ++++----
 .../EventsByPersistenceIdWithControlSpec.scala     | 11 +++---
 .../cassandra/query/EventsByTagPubsubSpec.scala    | 11 +++---
 .../cassandra/query/EventsByTagSpec.scala          | 29 +++++++-------
 .../cassandra/query/EventsByTagStageSpec.scala     | 27 +++++++------
 .../query/TagViewSequenceNumberScannerSpec.scala   | 21 +++++-----
 .../persistence/cassandra/query/TestActor.scala    | 11 +++---
 .../cassandra/query/TestEventAdapter.scala         |  5 ++-
 .../cassandra/query/TestTagWriter.scala            | 19 ++++-----
 .../query/javadsl/CassandraReadJournalSpec.scala   | 11 +++---
 .../query/scaladsl/CassandraReadJournalSpec.scala  | 13 +++---
 .../DeleteTagViewForPersistenceIdSpec.scala        |  9 +++--
 .../reconciler/RebuildAllPersisetceIdsSpec.scala   |  5 ++-
 .../cassandra/reconciler/TagQuerySpec.scala        |  5 ++-
 .../cassandra/reconciler/TruncateAllSpec.scala     |  5 ++-
 .../ClusterShardingQuickTerminationSpec.scala      | 13 +++---
 .../snapshot/CassandraSnapshotStoreSpec.scala      | 13 +++---
 .../cassandra/testkit/CassandraLauncherSpec.scala  |  5 ++-
 .../test/scala/doc/cleanup/CleanupDocExample.scala |  9 +++--
 .../example/ConfigurablePersistentActor.scala      | 13 +++---
 .../cassandra/example/EventProcessorStream.scala   | 19 ++++-----
 .../cassandra/example/LoadGenerator.scala          |  9 +++--
 .../pekko/persistence/cassandra/example/Main.scala | 15 +++----
 .../persistence/cassandra/example/ReadSide.scala   | 15 +++----
 .../cassandra/example/ReadSideTopic.scala          |  7 ++--
 .../persistence/cassandra/example/Reporter.scala   |  9 +++--
 108 files changed, 858 insertions(+), 768 deletions(-)

diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/CassandraStatements.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/CassandraStatements.scala
index 1c5f509..4f4d720 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/CassandraStatements.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/CassandraStatements.scala
@@ -16,11 +16,12 @@ package org.apache.pekko.persistence.cassandra
 import scala.concurrent.ExecutionContext
 import scala.concurrent.Future
 
-import org.apache.pekko.Done
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.event.LoggingAdapter
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournalStatements
-import org.apache.pekko.persistence.cassandra.snapshot.CassandraSnapshotStatements
+import org.apache.pekko
+import pekko.Done
+import pekko.annotation.InternalApi
+import pekko.event.LoggingAdapter
+import pekko.persistence.cassandra.journal.CassandraJournalStatements
+import pekko.persistence.cassandra.snapshot.CassandraSnapshotStatements
 import com.datastax.oss.driver.api.core.CqlSession
 import com.datastax.oss.driver.api.core.cql.Row
 
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/EventsByTagMigration.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/EventsByTagMigration.scala
index 5c06286..dcdb0a7 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/EventsByTagMigration.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/EventsByTagMigration.scala
@@ -13,28 +13,29 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.pattern.ask
-import org.apache.pekko.event.Logging
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal._
-import org.apache.pekko.persistence.cassandra.journal.TagWriter.TagProgress
-import org.apache.pekko.persistence.cassandra.journal.TagWriters.{ AllFlushed, FlushAllTagWriters, TagWritersSession }
-import org.apache.pekko.persistence.cassandra.journal._
-import org.apache.pekko.persistence.cassandra.Extractors.RawEvent
-import org.apache.pekko.persistence.cassandra.Extractors.Extractor
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.persistence.query.PersistenceQuery
-import org.apache.pekko.serialization.SerializationExtension
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSession
-import org.apache.pekko.stream.scaladsl.{ Sink, Source }
-import org.apache.pekko.util.Timeout
-import org.apache.pekko.{ Done, NotUsed }
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.pattern.ask
+import pekko.event.Logging
+import pekko.persistence.cassandra.journal.CassandraJournal._
+import pekko.persistence.cassandra.journal.TagWriter.TagProgress
+import pekko.persistence.cassandra.journal.TagWriters.{ AllFlushed, FlushAllTagWriters, TagWritersSession }
+import pekko.persistence.cassandra.journal._
+import pekko.persistence.cassandra.Extractors.RawEvent
+import pekko.persistence.cassandra.Extractors.Extractor
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.persistence.query.PersistenceQuery
+import pekko.serialization.SerializationExtension
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSession
+import pekko.stream.scaladsl.{ Sink, Source }
+import pekko.util.Timeout
+import pekko.{ Done, NotUsed }
 import com.datastax.oss.driver.api.core.cql.Row
 import scala.concurrent.ExecutionContext
 import scala.concurrent.Future
 import scala.concurrent.duration._
 
-import org.apache.pekko.actor.ClassicActorSystemProvider
+import pekko.actor.ClassicActorSystemProvider
 
 object EventsByTagMigration {
   def apply(systemProvider: ClassicActorSystemProvider): EventsByTagMigration =
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/EventsByTagSettings.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/EventsByTagSettings.scala
index 0880752..ea10bd6 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/EventsByTagSettings.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/EventsByTagSettings.scala
@@ -19,13 +19,14 @@ import java.util.concurrent.TimeUnit
 
 import scala.concurrent.duration._
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.event.Logging
-import org.apache.pekko.persistence.cassandra.compaction.CassandraCompactionStrategy
-import org.apache.pekko.persistence.cassandra.journal.TagWriter.TagWriterSettings
-import org.apache.pekko.persistence.cassandra.journal.TimeBucket
-import org.apache.pekko.persistence.cassandra.query.firstBucketFormatter
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.annotation.InternalApi
+import pekko.event.Logging
+import pekko.persistence.cassandra.compaction.CassandraCompactionStrategy
+import pekko.persistence.cassandra.journal.TagWriter.TagWriterSettings
+import pekko.persistence.cassandra.journal.TimeBucket
+import pekko.persistence.cassandra.query.firstBucketFormatter
 import com.typesafe.config.Config
 
 /**
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/Extractors.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/Extractors.scala
index 4a44391..94a6955 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/Extractors.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/Extractors.scala
@@ -17,20 +17,21 @@ import com.datastax.oss.driver.api.core.cql.Row
 import scala.concurrent.ExecutionContext
 import scala.concurrent.Future
 
-import org.apache.pekko.persistence.PersistentRepr
-import org.apache.pekko.persistence.cassandra.journal._
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal._
-import org.apache.pekko.annotation.InternalApi
+import org.apache.pekko
+import pekko.persistence.PersistentRepr
+import pekko.persistence.cassandra.journal._
+import pekko.persistence.cassandra.journal.CassandraJournal._
+import pekko.annotation.InternalApi
 import java.{ util => ju }
 
-import org.apache.pekko.util.OptionVal
-import org.apache.pekko.serialization.Serialization
+import pekko.util.OptionVal
+import pekko.serialization.Serialization
 import scala.jdk.CollectionConverters._
 import java.nio.ByteBuffer
 
 import com.datastax.oss.protocol.internal.util.Bytes
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.persistence.query.TimeBasedUUID
+import pekko.actor.ActorSystem
+import pekko.persistence.query.TimeBasedUUID
 
 /**
  * An Extractor takes reads a row from the messages table. There are different extractors
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/PluginSettings.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/PluginSettings.scala
index 0ec4feb..992ff65 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/PluginSettings.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/PluginSettings.scala
@@ -13,13 +13,14 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.annotation.InternalStableApi
-import org.apache.pekko.persistence.cassandra.healthcheck.HealthCheckSettings
-import org.apache.pekko.persistence.cassandra.journal.JournalSettings
-import org.apache.pekko.persistence.cassandra.query.QuerySettings
-import org.apache.pekko.persistence.cassandra.snapshot.SnapshotSettings
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.annotation.InternalApi
+import pekko.annotation.InternalStableApi
+import pekko.persistence.cassandra.healthcheck.HealthCheckSettings
+import pekko.persistence.cassandra.journal.JournalSettings
+import pekko.persistence.cassandra.query.QuerySettings
+import pekko.persistence.cassandra.snapshot.SnapshotSettings
 import com.typesafe.config.Config
 
 /**
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/Retries.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/Retries.scala
index 2292e00..8232584 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/Retries.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/Retries.scala
@@ -13,9 +13,10 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.actor.Scheduler
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.pattern.{ after, BackoffSupervisor }
+import org.apache.pekko
+import pekko.actor.Scheduler
+import pekko.annotation.InternalApi
+import pekko.pattern.{ after, BackoffSupervisor }
 
 import scala.concurrent.{ ExecutionContext, Future }
 import scala.concurrent.duration.FiniteDuration
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/cleanup/Cleanup.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/cleanup/Cleanup.scala
index 592e68e..dab8fd6 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/cleanup/Cleanup.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/cleanup/Cleanup.scala
@@ -19,21 +19,22 @@ import scala.collection.immutable
 import scala.concurrent.Future
 import scala.util.Failure
 import scala.util.Success
-import org.apache.pekko.{ Done, NotUsed }
-import org.apache.pekko.actor.{ ActorRef, ClassicActorSystemProvider }
-import org.apache.pekko.annotation.ApiMayChange
-import org.apache.pekko.event.Logging
-import org.apache.pekko.pattern.ask
-import org.apache.pekko.persistence.JournalProtocol.DeleteMessagesTo
-import org.apache.pekko.persistence.{ Persistence, SnapshotMetadata }
-import org.apache.pekko.persistence.cassandra.PluginSettings
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal
-import org.apache.pekko.persistence.cassandra.reconciler.Reconciliation
-import org.apache.pekko.persistence.cassandra.reconciler.ReconciliationSettings
-import org.apache.pekko.persistence.cassandra.snapshot.{ CassandraSnapshotStatements, CassandraSnapshotStore }
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.{ CassandraSession, CassandraSessionRegistry }
-import org.apache.pekko.stream.scaladsl.{ Sink, Source }
-import org.apache.pekko.util.Timeout
+import org.apache.pekko
+import pekko.{ Done, NotUsed }
+import pekko.actor.{ ActorRef, ClassicActorSystemProvider }
+import pekko.annotation.ApiMayChange
+import pekko.event.Logging
+import pekko.pattern.ask
+import pekko.persistence.JournalProtocol.DeleteMessagesTo
+import pekko.persistence.{ Persistence, SnapshotMetadata }
+import pekko.persistence.cassandra.PluginSettings
+import pekko.persistence.cassandra.journal.CassandraJournal
+import pekko.persistence.cassandra.reconciler.Reconciliation
+import pekko.persistence.cassandra.reconciler.ReconciliationSettings
+import pekko.persistence.cassandra.snapshot.{ CassandraSnapshotStatements, CassandraSnapshotStore }
+import pekko.stream.connectors.cassandra.scaladsl.{ CassandraSession, CassandraSessionRegistry }
+import pekko.stream.scaladsl.{ Sink, Source }
+import pekko.util.Timeout
 import com.datastax.oss.driver.api.core.cql.Row
 
 /**
@@ -391,7 +392,7 @@ final class Cleanup(systemProvider: ClassicActorSystemProvider, settings: Cleanu
       log.info("dry run: Operation on journal: {}", create(ActorRef.noSender))
       Future.successful(Done)
     } else {
-      import org.apache.pekko.pattern.extended.ask
+      import pekko.pattern.extended.ask
       ask(journal, create).map(_ => Done)
     }
   }
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/healthcheck/CassandraHealthCheck.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/healthcheck/CassandraHealthCheck.scala
index c58698f..335c31c 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/healthcheck/CassandraHealthCheck.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/healthcheck/CassandraHealthCheck.scala
@@ -13,13 +13,14 @@
 
 package org.apache.pekko.persistence.cassandra.healthcheck
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.event.Logging
-import org.apache.pekko.pattern.{ ask, AskTimeoutException }
-import org.apache.pekko.persistence.Persistence
-import org.apache.pekko.persistence.cassandra.PluginSettings
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal.HealthCheckQuery
-import org.apache.pekko.util.Timeout
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.event.Logging
+import pekko.pattern.{ ask, AskTimeoutException }
+import pekko.persistence.Persistence
+import pekko.persistence.cassandra.PluginSettings
+import pekko.persistence.cassandra.journal.CassandraJournal.HealthCheckQuery
+import pekko.util.Timeout
 
 import scala.concurrent.{ ExecutionContextExecutor, Future }
 import scala.util.control.NonFatal
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/healthcheck/HealthCheckSettings.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/healthcheck/HealthCheckSettings.scala
index 86fc66f..0c3faf6 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/healthcheck/HealthCheckSettings.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/healthcheck/HealthCheckSettings.scala
@@ -13,8 +13,9 @@
 
 package org.apache.pekko.persistence.cassandra.healthcheck
 
-import org.apache.pekko.actor.{ ActorSystem, NoSerializationVerificationNeeded }
-import org.apache.pekko.annotation.InternalApi
+import org.apache.pekko
+import pekko.actor.{ ActorSystem, NoSerializationVerificationNeeded }
+import pekko.annotation.InternalApi
 import com.typesafe.config.Config
 
 import scala.concurrent.duration._
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/Buffer.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/Buffer.scala
index e176408..b1a3644 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/Buffer.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/Buffer.scala
@@ -13,9 +13,10 @@
 
 package org.apache.pekko.persistence.cassandra.journal
 
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.persistence.cassandra.journal.TagWriter.{ timeUuidOrdering, AwaitingWrite }
-import org.apache.pekko.util.{ OptionVal, UUIDComparator }
+import org.apache.pekko
+import pekko.annotation.InternalApi
+import pekko.persistence.cassandra.journal.TagWriter.{ timeUuidOrdering, AwaitingWrite }
+import pekko.util.{ OptionVal, UUIDComparator }
 
 /**
  * INTERNAL API
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraEventUpdate.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraEventUpdate.scala
index 452a62d..c0fe55d 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraEventUpdate.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraEventUpdate.scala
@@ -13,18 +13,19 @@
 
 package org.apache.pekko.persistence.cassandra.journal
 
-import org.apache.pekko.Done
-import org.apache.pekko.event.LoggingAdapter
-import org.apache.pekko.persistence.cassandra.PluginSettings
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal.{ Serialized, TagPidSequenceNr }
+import org.apache.pekko
+import pekko.Done
+import pekko.event.LoggingAdapter
+import pekko.persistence.cassandra.PluginSettings
+import pekko.persistence.cassandra.journal.CassandraJournal.{ Serialized, TagPidSequenceNr }
 import com.datastax.oss.driver.api.core.cql.{ PreparedStatement, Row, Statement }
 
 import scala.jdk.CollectionConverters._
 import scala.concurrent.{ ExecutionContext, Future }
 import java.lang.{ Long => JLong }
 
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSession
+import pekko.annotation.InternalApi
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSession
 
 /** INTERNAL API */
 @InternalApi private[pekko] trait CassandraEventUpdate {
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournal.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournal.scala
index 210a160..2088811 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournal.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournal.scala
@@ -17,25 +17,26 @@ import java.lang.{ Long => JLong }
 import java.nio.ByteBuffer
 import java.util.{ HashMap => JHMap, Map => JMap, UUID }
 
-import org.apache.pekko.Done
-import org.apache.pekko.actor.SupervisorStrategy.Stop
-import org.apache.pekko.actor._
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.event.{ Logging, LoggingAdapter }
-import org.apache.pekko.pattern.{ ask, pipe }
-import org.apache.pekko.persistence._
-import org.apache.pekko.persistence.cassandra._
-import org.apache.pekko.persistence.cassandra.Extractors
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.persistence.journal.{ AsyncWriteJournal, Tagged }
-import org.apache.pekko.persistence.query.PersistenceQuery
-import org.apache.pekko.persistence.cassandra.journal.TagWriters.{ BulkTagWrite, TagWrite, TagWritersSession }
-import org.apache.pekko.persistence.cassandra.journal.TagWriter.TagProgress
-import org.apache.pekko.serialization.{ AsyncSerializer, Serialization, SerializationExtension }
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.{ CassandraSession, CassandraSessionRegistry }
-import org.apache.pekko.stream.scaladsl.Sink
-import org.apache.pekko.dispatch.ExecutionContexts
-import org.apache.pekko.util.{ OptionVal, Timeout }
+import org.apache.pekko
+import pekko.Done
+import pekko.actor.SupervisorStrategy.Stop
+import pekko.actor._
+import pekko.annotation.InternalApi
+import pekko.event.{ Logging, LoggingAdapter }
+import pekko.pattern.{ ask, pipe }
+import pekko.persistence._
+import pekko.persistence.cassandra._
+import pekko.persistence.cassandra.Extractors
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.persistence.journal.{ AsyncWriteJournal, Tagged }
+import pekko.persistence.query.PersistenceQuery
+import pekko.persistence.cassandra.journal.TagWriters.{ BulkTagWrite, TagWrite, TagWritersSession }
+import pekko.persistence.cassandra.journal.TagWriter.TagProgress
+import pekko.serialization.{ AsyncSerializer, Serialization, SerializationExtension }
+import pekko.stream.connectors.cassandra.scaladsl.{ CassandraSession, CassandraSessionRegistry }
+import pekko.stream.scaladsl.Sink
+import pekko.dispatch.ExecutionContexts
+import pekko.util.{ OptionVal, Timeout }
 import com.datastax.oss.driver.api.core.cql._
 import com.typesafe.config.Config
 import com.datastax.oss.driver.api.core.uuid.Uuids
@@ -49,9 +50,9 @@ import scala.concurrent._
 import scala.util.control.NonFatal
 import scala.util.{ Failure, Success, Try }
 import scala.compat.java8.FutureConverters._
-import org.apache.pekko.annotation.DoNotInherit
-import org.apache.pekko.annotation.InternalStableApi
-import org.apache.pekko.stream.scaladsl.Source
+import pekko.annotation.DoNotInherit
+import pekko.annotation.InternalStableApi
+import pekko.stream.scaladsl.Source
 
 /**
  * INTERNAL API
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalStatements.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalStatements.scala
index 3d968b7..0848da1 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalStatements.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalStatements.scala
@@ -17,13 +17,14 @@ import scala.compat.java8.FutureConverters._
 import scala.concurrent.ExecutionContext
 import scala.concurrent.Future
 
-import org.apache.pekko.Done
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.event.LoggingAdapter
-import org.apache.pekko.persistence.cassandra.PluginSettings
-import org.apache.pekko.persistence.cassandra.indent
+import org.apache.pekko
+import pekko.Done
+import pekko.annotation.InternalApi
+import pekko.event.LoggingAdapter
+import pekko.persistence.cassandra.PluginSettings
+import pekko.persistence.cassandra.indent
 import com.datastax.oss.driver.api.core.CqlSession
-import org.apache.pekko.persistence.cassandra.FutureDone
+import pekko.persistence.cassandra.FutureDone
 
 /**
  * INTERNAL API
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraTagRecovery.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraTagRecovery.scala
index 388efcb..fdcb461 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraTagRecovery.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/CassandraTagRecovery.scala
@@ -13,33 +13,34 @@
 
 package org.apache.pekko.persistence.cassandra.journal
 
-import org.apache.pekko.Done
-import org.apache.pekko.actor.ActorRef
-import org.apache.pekko.pattern.ask
-import org.apache.pekko.event.LoggingAdapter
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal.{ SequenceNr, Tag }
-import org.apache.pekko.persistence.cassandra.journal.TagWriter.TagProgress
-import org.apache.pekko.persistence.cassandra.journal.TagWriters.{
+import org.apache.pekko
+import pekko.Done
+import pekko.actor.ActorRef
+import pekko.pattern.ask
+import pekko.event.LoggingAdapter
+import pekko.persistence.cassandra.journal.CassandraJournal.{ SequenceNr, Tag }
+import pekko.persistence.cassandra.journal.TagWriter.TagProgress
+import pekko.persistence.cassandra.journal.TagWriters.{
   PersistentActorStarting,
   PersistentActorStartingAck,
   SetTagProgress,
   TagProcessAck,
   TagWrite
 }
-import org.apache.pekko.persistence.cassandra.Extractors.RawEvent
-import org.apache.pekko.stream.scaladsl.Sink
-import org.apache.pekko.util.Timeout
+import pekko.persistence.cassandra.Extractors.RawEvent
+import pekko.stream.scaladsl.Sink
+import pekko.util.Timeout
 
 import scala.concurrent.{ ExecutionContext, Future }
 import scala.concurrent.duration._
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.event.Logging
-import org.apache.pekko.persistence.cassandra.Extractors.TaggedPersistentRepr
-import org.apache.pekko.serialization.SerializationExtension
-import org.apache.pekko.persistence.cassandra._
-import org.apache.pekko.persistence.cassandra.journal.TagWriters.FlushAllTagWriters
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSession
+import pekko.actor.ActorSystem
+import pekko.annotation.InternalApi
+import pekko.event.Logging
+import pekko.persistence.cassandra.Extractors.TaggedPersistentRepr
+import pekko.serialization.SerializationExtension
+import pekko.persistence.cassandra._
+import pekko.persistence.cassandra.journal.TagWriters.FlushAllTagWriters
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSession
 
 /**
  * INTERNAL API
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/JournalSettings.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/JournalSettings.scala
index 9517c02..9ab8f9f 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/JournalSettings.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/JournalSettings.scala
@@ -13,13 +13,14 @@
 
 package org.apache.pekko.persistence.cassandra.journal
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.actor.NoSerializationVerificationNeeded
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.annotation.InternalStableApi
-import org.apache.pekko.persistence.cassandra.PluginSettings.getReplicationStrategy
-import org.apache.pekko.persistence.cassandra.compaction.CassandraCompactionStrategy
-import org.apache.pekko.persistence.cassandra.getListFromConfig
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.actor.NoSerializationVerificationNeeded
+import pekko.annotation.InternalApi
+import pekko.annotation.InternalStableApi
+import pekko.persistence.cassandra.PluginSettings.getReplicationStrategy
+import pekko.persistence.cassandra.compaction.CassandraCompactionStrategy
+import pekko.persistence.cassandra.getListFromConfig
 import com.typesafe.config.Config
 
 /** INTERNAL API */
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/PubSubThrottler.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/PubSubThrottler.scala
index 61c5bdb..b29d3bd 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/PubSubThrottler.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/PubSubThrottler.scala
@@ -14,9 +14,10 @@
 package org.apache.pekko.persistence.cassandra.journal
 
 import scala.concurrent.duration.FiniteDuration
-import org.apache.pekko.actor.{ Actor, ActorRef }
-import org.apache.pekko.actor.Props
-import org.apache.pekko.annotation.InternalApi
+import org.apache.pekko
+import pekko.actor.{ Actor, ActorRef }
+import pekko.actor.Props
+import pekko.annotation.InternalApi
 
 /**
  * INTERNAL API: Proxies messages to another actor, only allowing identical messages through once every [interval].
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TagWriter.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TagWriter.scala
index ebeafea..df199cb 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TagWriter.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TagWriter.scala
@@ -15,25 +15,18 @@ package org.apache.pekko.persistence.cassandra.journal
 
 import java.util.UUID
 
-import org.apache.pekko.Done
-import org.apache.pekko.actor.{
-  Actor,
-  ActorLogging,
-  ActorRef,
-  NoSerializationVerificationNeeded,
-  Props,
-  ReceiveTimeout,
-  Timers
-}
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.cluster.pubsub.{ DistributedPubSub, DistributedPubSubMediator }
-import org.apache.pekko.event.LoggingAdapter
-import org.apache.pekko.pattern.pipe
-import org.apache.pekko.persistence.cassandra.formatOffset
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal._
-import org.apache.pekko.persistence.cassandra.journal.TagWriter.TagWriterSettings
-import org.apache.pekko.persistence.cassandra.journal.TagWriters.TagWritersSession
-import org.apache.pekko.util.{ OptionVal, UUIDComparator }
+import org.apache.pekko
+import pekko.Done
+import pekko.actor.{ Actor, ActorLogging, ActorRef, NoSerializationVerificationNeeded, Props, ReceiveTimeout, Timers }
+import pekko.annotation.InternalApi
+import pekko.cluster.pubsub.{ DistributedPubSub, DistributedPubSubMediator }
+import pekko.event.LoggingAdapter
+import pekko.pattern.pipe
+import pekko.persistence.cassandra.formatOffset
+import pekko.persistence.cassandra.journal.CassandraJournal._
+import pekko.persistence.cassandra.journal.TagWriter.TagWriterSettings
+import pekko.persistence.cassandra.journal.TagWriters.TagWritersSession
+import pekko.util.{ OptionVal, UUIDComparator }
 
 import scala.concurrent.duration.{ Duration, FiniteDuration, _ }
 import scala.util.control.NonFatal
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TagWriters.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TagWriters.scala
index 4dc6a15..908ac6b 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TagWriters.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TagWriters.scala
@@ -19,27 +19,28 @@ import java.net.URLEncoder
 import java.util.UUID
 
 import scala.concurrent.Promise
-import org.apache.pekko.Done
-import org.apache.pekko.actor.SupervisorStrategy.Escalate
-import org.apache.pekko.pattern.ask
-import org.apache.pekko.pattern.pipe
-import org.apache.pekko.actor.Actor
-import org.apache.pekko.actor.ActorLogging
-import org.apache.pekko.actor.ActorRef
-import org.apache.pekko.actor.NoSerializationVerificationNeeded
-import org.apache.pekko.actor.OneForOneStrategy
-import org.apache.pekko.actor.Props
-import org.apache.pekko.actor.SupervisorStrategy
-import org.apache.pekko.actor.Timers
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.dispatch.ExecutionContexts
-import org.apache.pekko.event.LoggingAdapter
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal._
-import org.apache.pekko.persistence.cassandra.journal.TagWriter._
-import org.apache.pekko.persistence.cassandra.journal.TagWriters._
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSession
-import org.apache.pekko.util.ByteString
-import org.apache.pekko.util.Timeout
+import org.apache.pekko
+import pekko.Done
+import pekko.actor.SupervisorStrategy.Escalate
+import pekko.pattern.ask
+import pekko.pattern.pipe
+import pekko.actor.Actor
+import pekko.actor.ActorLogging
+import pekko.actor.ActorRef
+import pekko.actor.NoSerializationVerificationNeeded
+import pekko.actor.OneForOneStrategy
+import pekko.actor.Props
+import pekko.actor.SupervisorStrategy
+import pekko.actor.Timers
+import pekko.annotation.InternalApi
+import pekko.dispatch.ExecutionContexts
+import pekko.event.LoggingAdapter
+import pekko.persistence.cassandra.journal.CassandraJournal._
+import pekko.persistence.cassandra.journal.TagWriter._
+import pekko.persistence.cassandra.journal.TagWriters._
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSession
+import pekko.util.ByteString
+import pekko.util.Timeout
 import com.datastax.oss.driver.api.core.cql.{ BatchStatementBuilder, BatchType, BoundStatement, Statement }
 
 import scala.concurrent.{ ExecutionContext, Future }
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TimeBucket.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TimeBucket.scala
index 83b5a91..90e9d29 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TimeBucket.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/journal/TimeBucket.scala
@@ -15,9 +15,10 @@ package org.apache.pekko.persistence.cassandra.journal
 
 import java.util.UUID
 
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.persistence.cassandra.BucketSize
-import org.apache.pekko.util.HashCode
+import org.apache.pekko
+import pekko.annotation.InternalApi
+import pekko.persistence.cassandra.BucketSize
+import pekko.util.HashCode
 import com.datastax.oss.driver.api.core.uuid.Uuids
 
 /** INTERNAL API */
@@ -81,7 +82,7 @@ import com.datastax.oss.driver.api.core.uuid.Uuids
     result
   }
 
-  import org.apache.pekko.persistence.cassandra._
+  import pekko.persistence.cassandra._
 
   override def toString =
     s"TimeBucket($key, $bucketSize, inPast: $inPast, currentBucket: $isCurrent. time: ${formatUnixTime(key)} )"
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/package.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/package.scala
index a56dac7..76bc6ef 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/package.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/package.scala
@@ -18,20 +18,21 @@ import java.time.{ Instant, LocalDateTime, ZoneOffset }
 import java.time.format.DateTimeFormatter
 import java.util.UUID
 
-import org.apache.pekko.Done
-import org.apache.pekko.persistence.cassandra.journal.TimeBucket
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal.{ Serialized, SerializedMeta }
-import org.apache.pekko.serialization.Serialization
+import org.apache.pekko
+import pekko.Done
+import pekko.persistence.cassandra.journal.TimeBucket
+import pekko.persistence.cassandra.journal.CassandraJournal.{ Serialized, SerializedMeta }
+import pekko.serialization.Serialization
 
 import scala.concurrent._
 import scala.util.control.NonFatal
 import scala.jdk.CollectionConverters._
 import com.typesafe.config.{ Config, ConfigValueType }
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.actor.ExtendedActorSystem
-import org.apache.pekko.serialization.AsyncSerializer
-import org.apache.pekko.serialization.Serializers
-import org.apache.pekko.annotation.InternalApi
+import pekko.actor.ActorSystem
+import pekko.actor.ExtendedActorSystem
+import pekko.serialization.AsyncSerializer
+import pekko.serialization.Serializers
+import pekko.annotation.InternalApi
 import com.datastax.oss.driver.api.core.uuid.Uuids
 
 package object cassandra {
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/AllPersistenceIdsStage.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/AllPersistenceIdsStage.scala
index 9ebec08..82e0c61 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/AllPersistenceIdsStage.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/AllPersistenceIdsStage.scala
@@ -15,9 +15,10 @@ package org.apache.pekko.persistence.cassandra.query
 
 import java.util.concurrent.ThreadLocalRandom
 
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.stream.stage._
-import org.apache.pekko.stream.{ Attributes, Outlet, SourceShape }
+import org.apache.pekko
+import pekko.annotation.InternalApi
+import pekko.stream.stage._
+import pekko.stream.{ Attributes, Outlet, SourceShape }
 import com.datastax.oss.driver.api.core.CqlSession
 import com.datastax.oss.driver.api.core.cql.AsyncResultSet
 import com.datastax.oss.driver.api.core.cql.PreparedStatement
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/CassandraReadJournalProvider.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/CassandraReadJournalProvider.scala
index d10f6ea..9110ec0 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/CassandraReadJournalProvider.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/CassandraReadJournalProvider.scala
@@ -13,8 +13,9 @@
 
 package org.apache.pekko.persistence.cassandra.query
 
-import org.apache.pekko.actor.ExtendedActorSystem
-import org.apache.pekko.persistence.query.ReadJournalProvider
+import org.apache.pekko
+import pekko.actor.ExtendedActorSystem
+import pekko.persistence.query.ReadJournalProvider
 import com.typesafe.config.Config
 
 class CassandraReadJournalProvider(system: ExtendedActorSystem, config: Config, configPath: String)
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/CassandraReadStatements.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/CassandraReadStatements.scala
index 5f00624..ff87421 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/CassandraReadStatements.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/CassandraReadStatements.scala
@@ -13,8 +13,9 @@
 
 package org.apache.pekko.persistence.cassandra.query
 
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.persistence.cassandra.PluginSettings
+import org.apache.pekko
+import pekko.annotation.InternalApi
+import pekko.persistence.cassandra.PluginSettings
 
 /**
  * INTERNAL API
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdStage.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdStage.scala
index be83255..b5af93d 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdStage.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdStage.scala
@@ -15,11 +15,12 @@ package org.apache.pekko.persistence.cassandra.query
 
 import com.datastax.oss.driver.api.core.CqlSession
 import com.datastax.oss.driver.api.core.cql._
-import org.apache.pekko.Done
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.persistence.cassandra.PluginSettings
-import org.apache.pekko.stream.stage._
-import org.apache.pekko.stream.{ Attributes, Outlet, SourceShape }
+import org.apache.pekko
+import pekko.Done
+import pekko.annotation.InternalApi
+import pekko.persistence.cassandra.PluginSettings
+import pekko.stream.stage._
+import pekko.stream.{ Attributes, Outlet, SourceShape }
 
 import java.lang.{ Long => JLong }
 import java.util.concurrent.ThreadLocalRandom
@@ -300,7 +301,7 @@ import scala.util.{ Failure, Success, Try }
       def lookForMissingSeqNr(): Unit =
         lookingForMissingSeqNr match {
           case Some(m) if m.deadline.isOverdue() =>
-            import org.apache.pekko.util.PrettyDuration.PrettyPrintableDuration
+            import pekko.util.PrettyDuration.PrettyPrintableDuration
             onFailure(
               new IllegalStateException(
                 s"Sequence number [$expectedNextSeqNr] still missing after " +
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagStage.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagStage.scala
index c670df5..4117394 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagStage.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagStage.scala
@@ -16,19 +16,20 @@ package org.apache.pekko.persistence.cassandra.query
 import com.datastax.oss.driver.api.core.CqlSession
 import com.datastax.oss.driver.api.core.cql.{ AsyncResultSet, Row }
 import com.datastax.oss.driver.api.core.uuid.Uuids
-import org.apache.pekko.actor.Scheduler
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.cluster.pubsub.{ DistributedPubSub, DistributedPubSubMediator }
-import org.apache.pekko.persistence.cassandra.EventsByTagSettings.RetrySettings
-import org.apache.pekko.persistence.cassandra._
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal._
-import org.apache.pekko.persistence.cassandra.journal.TimeBucket
-import org.apache.pekko.persistence.cassandra.query.EventsByTagStage._
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal.EventByTagStatements
-import org.apache.pekko.stream.stage._
-import org.apache.pekko.stream.{ Attributes, Outlet, SourceShape }
-import org.apache.pekko.util.PrettyDuration._
-import org.apache.pekko.util.UUIDComparator
+import org.apache.pekko
+import pekko.actor.Scheduler
+import pekko.annotation.InternalApi
+import pekko.cluster.pubsub.{ DistributedPubSub, DistributedPubSubMediator }
+import pekko.persistence.cassandra.EventsByTagSettings.RetrySettings
+import pekko.persistence.cassandra._
+import pekko.persistence.cassandra.journal.CassandraJournal._
+import pekko.persistence.cassandra.journal.TimeBucket
+import pekko.persistence.cassandra.query.EventsByTagStage._
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal.EventByTagStatements
+import pekko.stream.stage._
+import pekko.stream.{ Attributes, Outlet, SourceShape }
+import pekko.util.PrettyDuration._
+import pekko.util.UUIDComparator
 
 import java.lang.{ Long => JLong }
 import java.util.UUID
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/QuerySettings.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/QuerySettings.scala
index 668f27e..f105796 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/QuerySettings.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/QuerySettings.scala
@@ -15,11 +15,12 @@ package org.apache.pekko.persistence.cassandra.query
 
 import scala.concurrent.duration._
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.actor.NoSerializationVerificationNeeded
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.annotation.InternalStableApi
-import org.apache.pekko.persistence.cassandra.EventsByTagSettings
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.actor.NoSerializationVerificationNeeded
+import pekko.annotation.InternalApi
+import pekko.annotation.InternalStableApi
+import pekko.persistence.cassandra.EventsByTagSettings
 import com.typesafe.config.Config
 
 /**
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/TagViewSequenceNumberScanner.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/TagViewSequenceNumberScanner.scala
index 06d4df8..913ece3 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/TagViewSequenceNumberScanner.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/TagViewSequenceNumberScanner.scala
@@ -16,26 +16,27 @@ package org.apache.pekko.persistence.cassandra.query
 import java.lang.{ Long => JLong }
 import java.util.UUID
 
-import org.apache.pekko.NotUsed
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.event.Logging
-import org.apache.pekko.pattern.after
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal._
-import org.apache.pekko.persistence.cassandra.journal.TimeBucket
-import org.apache.pekko.persistence.cassandra.formatOffset
-import org.apache.pekko.persistence.cassandra.query.TagViewSequenceNumberScanner.Session
-import org.apache.pekko.stream.Materializer
-import org.apache.pekko.stream.scaladsl.Source
+import org.apache.pekko
+import pekko.NotUsed
+import pekko.annotation.InternalApi
+import pekko.event.Logging
+import pekko.pattern.after
+import pekko.persistence.cassandra.journal.CassandraJournal._
+import pekko.persistence.cassandra.journal.TimeBucket
+import pekko.persistence.cassandra.formatOffset
+import pekko.persistence.cassandra.query.TagViewSequenceNumberScanner.Session
+import pekko.stream.Materializer
+import pekko.stream.scaladsl.Source
 import com.datastax.oss.driver.api.core.cql.{ PreparedStatement, Row }
 import scala.annotation.nowarn
 import scala.concurrent.duration.{ Duration, FiniteDuration }
 import scala.concurrent.{ ExecutionContext, Future }
 
-import org.apache.pekko.persistence.cassandra.BucketSize
-import org.apache.pekko.stream.ActorAttributes
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSession
-import org.apache.pekko.stream.scaladsl.Keep
-import org.apache.pekko.stream.scaladsl.Sink
+import pekko.persistence.cassandra.BucketSize
+import pekko.stream.ActorAttributes
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSession
+import pekko.stream.scaladsl.Keep
+import pekko.stream.scaladsl.Sink
 
 /**
  * INTERNAL API
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/UUIDPersistentRepr.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/UUIDPersistentRepr.scala
index 20fb835..d562d30 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/UUIDPersistentRepr.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/UUIDPersistentRepr.scala
@@ -15,9 +15,10 @@ package org.apache.pekko.persistence.cassandra.query
 
 import java.util.UUID
 
-import org.apache.pekko.persistence.PersistentRepr
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal.TagPidSequenceNr
+import org.apache.pekko
+import pekko.persistence.PersistentRepr
+import pekko.annotation.InternalApi
+import pekko.persistence.cassandra.journal.CassandraJournal.TagPidSequenceNr
 
 /**
  * INTERNAL API: Wrap the [[PersistentRepr]] to add the UUID for
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/javadsl/CassandraReadJournal.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/javadsl/CassandraReadJournal.scala
index 97c133c..bd52f82 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/javadsl/CassandraReadJournal.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/javadsl/CassandraReadJournal.scala
@@ -16,13 +16,14 @@ package org.apache.pekko.persistence.cassandra.query.javadsl
 import java.util.UUID
 import java.util.concurrent.CompletionStage
 
-import org.apache.pekko.{ Done, NotUsed }
-import org.apache.pekko.persistence.query.EventEnvelope
-import org.apache.pekko.persistence.query.Offset
-import org.apache.pekko.persistence.query.TimeBasedUUID
-import org.apache.pekko.persistence.query.javadsl._
-import org.apache.pekko.stream.connectors.cassandra.javadsl.CassandraSession
-import org.apache.pekko.stream.javadsl.Source
+import org.apache.pekko
+import pekko.{ Done, NotUsed }
+import pekko.persistence.query.EventEnvelope
+import pekko.persistence.query.Offset
+import pekko.persistence.query.TimeBasedUUID
+import pekko.persistence.query.javadsl._
+import pekko.stream.connectors.cassandra.javadsl.CassandraSession
+import pekko.stream.javadsl.Source
 
 import scala.compat.java8.FutureConverters
 
@@ -36,7 +37,7 @@ object CassandraReadJournal {
    * to the absolute path to the read journal configuration entry.
    */
   final val Identifier =
-    org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal.Identifier
+    pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal.Identifier
 }
 
 /**
@@ -48,14 +49,14 @@ object CassandraReadJournal {
  *   PersistenceQuery.get(system).getReadJournalFor(CassandraReadJournal.class, CassandraReadJournal.Identifier());
  * }}}
  *
- * Corresponding Scala API is in [[org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal]].
+ * Corresponding Scala API is in [[pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal]].
  *
  * Configuration settings can be defined in the configuration section with the
  * absolute path corresponding to the identifier, which is `"pekko.persistence.cassandra.query"`
  * for the default [[CassandraReadJournal#Identifier]]. See `reference.conf`.
  */
 class CassandraReadJournal(
-    scaladslReadJournal: org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal)
+    scaladslReadJournal: pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal)
     extends ReadJournal
     with PersistenceIdsQuery
     with CurrentPersistenceIdsQuery
@@ -116,7 +117,7 @@ class CassandraReadJournal(
    * in a `akka.persistence.journal.Tagged` with the given `tags`.
    * The tags must be defined in the `tags` section of the `pekko.persistence.cassandra` configuration.
    *
-   * You can use [[org.apache.pekko.persistence.query.NoOffset]] to retrieve all events with a given tag or
+   * You can use [[pekko.persistence.query.NoOffset]] to retrieve all events with a given tag or
    * retrieve a subset of all events by specifying a [[TimeBasedUUID]] `offset`.
    *
    * The offset of each event is provided in the streamed envelopes returned,
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/scaladsl/CassandraReadJournal.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/scaladsl/CassandraReadJournal.scala
index 3c4a12d..ec2117c 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/scaladsl/CassandraReadJournal.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/query/scaladsl/CassandraReadJournal.scala
@@ -17,31 +17,27 @@ import com.datastax.oss.driver.api.core.CqlSession
 import com.datastax.oss.driver.api.core.cql._
 import com.datastax.oss.driver.api.core.uuid.Uuids
 import com.typesafe.config.Config
-import org.apache.pekko.actor.{ ActorSystem, ExtendedActorSystem }
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.event.Logging
-import org.apache.pekko.persistence.cassandra.Extractors.Extractor
-import org.apache.pekko.persistence.cassandra.{ CassandraStatements, Extractors, PluginSettings }
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal.{
-  DeserializedEvent,
-  PersistenceId,
-  Tag,
-  TagPidSequenceNr
-}
-import org.apache.pekko.persistence.cassandra.journal._
-import org.apache.pekko.persistence.cassandra.query.EventsByTagStage.TagStageSession
-import org.apache.pekko.persistence.cassandra.query._
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal.EventByTagStatements
-import org.apache.pekko.persistence.query._
-import org.apache.pekko.persistence.query.scaladsl._
-import org.apache.pekko.persistence.{ Persistence, PersistentRepr }
-import org.apache.pekko.serialization.SerializationExtension
-import org.apache.pekko.stream.ActorAttributes
-import org.apache.pekko.stream.connectors.cassandra.CassandraSessionSettings
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.{ CassandraSession, CassandraSessionRegistry }
-import org.apache.pekko.stream.scaladsl.{ Flow, Source }
-import org.apache.pekko.util.{ ByteString, OptionVal }
-import org.apache.pekko.{ Done, NotUsed }
+import org.apache.pekko
+import pekko.actor.{ ActorSystem, ExtendedActorSystem }
+import pekko.annotation.InternalApi
+import pekko.event.Logging
+import pekko.persistence.cassandra.Extractors.Extractor
+import pekko.persistence.cassandra.{ CassandraStatements, Extractors, PluginSettings }
+import pekko.persistence.cassandra.journal.CassandraJournal.{ DeserializedEvent, PersistenceId, Tag, TagPidSequenceNr }
+import pekko.persistence.cassandra.journal._
+import pekko.persistence.cassandra.query.EventsByTagStage.TagStageSession
+import pekko.persistence.cassandra.query._
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal.EventByTagStatements
+import pekko.persistence.query._
+import pekko.persistence.query.scaladsl._
+import pekko.persistence.{ Persistence, PersistentRepr }
+import pekko.serialization.SerializationExtension
+import pekko.stream.ActorAttributes
+import pekko.stream.connectors.cassandra.CassandraSessionSettings
+import pekko.stream.connectors.cassandra.scaladsl.{ CassandraSession, CassandraSessionRegistry }
+import pekko.stream.scaladsl.{ Flow, Source }
+import pekko.util.{ ByteString, OptionVal }
+import pekko.{ Done, NotUsed }
 
 import java.net.URLEncoder
 import java.util.UUID
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/AllTags.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/AllTags.scala
index b33cb44..da1c616 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/AllTags.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/AllTags.scala
@@ -13,9 +13,10 @@
 
 package org.apache.pekko.persistence.cassandra.reconciler
 
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.stream.scaladsl.Source
-import org.apache.pekko.NotUsed
+import org.apache.pekko
+import pekko.annotation.InternalApi
+import pekko.stream.scaladsl.Source
+import pekko.NotUsed
 
 /**
  * Calculates all the tags by scanning the tag_write_progress table.
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/BuildTagViewForPersistenceId.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/BuildTagViewForPersistenceId.scala
index 417ddb9..d54b47c 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/BuildTagViewForPersistenceId.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/BuildTagViewForPersistenceId.scala
@@ -13,24 +13,25 @@
 
 package org.apache.pekko.persistence.cassandra.reconciler
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.persistence.cassandra.PluginSettings
-import org.apache.pekko.Done
-import org.apache.pekko.persistence.cassandra.journal.TagWriter._
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.persistence.cassandra.PluginSettings
+import pekko.Done
+import pekko.persistence.cassandra.journal.TagWriter._
 import scala.concurrent.duration._
 import scala.concurrent.Future
-import org.apache.pekko.stream.scaladsl.Source
-import org.apache.pekko.actor.ExtendedActorSystem
-import org.apache.pekko.persistence.query.PersistenceQuery
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.event.Logging
-import org.apache.pekko.persistence.cassandra.journal.CassandraTagRecovery
-import org.apache.pekko.persistence.cassandra.Extractors
-import org.apache.pekko.util.Timeout
-import org.apache.pekko.stream.OverflowStrategy
-import org.apache.pekko.stream.scaladsl.Sink
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.serialization.SerializationExtension
+import pekko.stream.scaladsl.Source
+import pekko.actor.ExtendedActorSystem
+import pekko.persistence.query.PersistenceQuery
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.event.Logging
+import pekko.persistence.cassandra.journal.CassandraTagRecovery
+import pekko.persistence.cassandra.Extractors
+import pekko.util.Timeout
+import pekko.stream.OverflowStrategy
+import pekko.stream.scaladsl.Sink
+import pekko.annotation.InternalApi
+import pekko.serialization.SerializationExtension
 
 /**
  * INTERNAL API
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/DeleteTagViewForPersistenceId.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/DeleteTagViewForPersistenceId.scala
index a4c93b2..ddfa100 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/DeleteTagViewForPersistenceId.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/DeleteTagViewForPersistenceId.scala
@@ -13,15 +13,16 @@
 
 package org.apache.pekko.persistence.cassandra.reconciler
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.persistence.cassandra.PluginSettings
-import org.apache.pekko.Done
-import org.apache.pekko.event.Logging
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.persistence.query.NoOffset
-import org.apache.pekko.persistence.cassandra.journal.TimeBucket
-import org.apache.pekko.stream.scaladsl.Sink
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.persistence.cassandra.PluginSettings
+import pekko.Done
+import pekko.event.Logging
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.annotation.InternalApi
+import pekko.persistence.query.NoOffset
+import pekko.persistence.cassandra.journal.TimeBucket
+import pekko.stream.scaladsl.Sink
 import scala.concurrent.Future
 
 /**
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/Reconciliation.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/Reconciliation.scala
index ff88fa6..7674b10 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/Reconciliation.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/reconciler/Reconciliation.scala
@@ -13,34 +13,35 @@
 
 package org.apache.pekko.persistence.cassandra.reconciler
 
-import org.apache.pekko.Done
-import org.apache.pekko.NotUsed
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.stream.scaladsl.Source
-import org.apache.pekko.annotation.ApiMayChange
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.stream.scaladsl.Sink
-import org.apache.pekko.persistence.query.PersistenceQuery
-import org.apache.pekko.persistence.cassandra.CassandraStatements
-import org.apache.pekko.persistence.cassandra.PluginSettings
-import org.apache.pekko.persistence.cassandra.journal.TimeBucket
-import org.apache.pekko.persistence.cassandra.journal.CassandraTagRecovery
-import org.apache.pekko.persistence.cassandra.journal.TaggedPreparedStatements
-import org.apache.pekko.persistence.cassandra.journal.TagWriters
-import org.apache.pekko.persistence.cassandra.journal.TagWriters._
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import org.apache.pekko
+import pekko.Done
+import pekko.NotUsed
+import pekko.actor.ActorSystem
+import pekko.stream.scaladsl.Source
+import pekko.annotation.ApiMayChange
+import pekko.annotation.InternalApi
+import pekko.stream.scaladsl.Sink
+import pekko.persistence.query.PersistenceQuery
+import pekko.persistence.cassandra.CassandraStatements
+import pekko.persistence.cassandra.PluginSettings
+import pekko.persistence.cassandra.journal.TimeBucket
+import pekko.persistence.cassandra.journal.CassandraTagRecovery
+import pekko.persistence.cassandra.journal.TaggedPreparedStatements
+import pekko.persistence.cassandra.journal.TagWriters
+import pekko.persistence.cassandra.journal.TagWriters._
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
 import com.datastax.oss.driver.api.core.cql.Row
 import com.datastax.oss.driver.api.core.cql.SimpleStatement
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSession
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSessionRegistry
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSession
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSessionRegistry
 import scala.concurrent.ExecutionContext
 import scala.concurrent.Future
 import java.util.UUID
 import java.lang.{ Long => JLong }
 import java.util.concurrent.atomic.AtomicInteger
 
-import org.apache.pekko.actor.ClassicActorSystemProvider
-import org.apache.pekko.actor.ExtendedActorSystem
+import pekko.actor.ClassicActorSystemProvider
+import pekko.actor.ExtendedActorSystem
 
 /**
  * Database actions for reconciliation
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStatements.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStatements.scala
index dbb0337..e764a4c 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStatements.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStatements.scala
@@ -17,12 +17,13 @@ import scala.compat.java8.FutureConverters._
 import scala.concurrent.ExecutionContext
 import scala.concurrent.Future
 
-import org.apache.pekko.Done
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.event.LoggingAdapter
-import org.apache.pekko.persistence.cassandra.indent
+import org.apache.pekko
+import pekko.Done
+import pekko.annotation.InternalApi
+import pekko.event.LoggingAdapter
+import pekko.persistence.cassandra.indent
 import com.datastax.oss.driver.api.core.CqlSession
-import org.apache.pekko.persistence.cassandra.FutureDone
+import pekko.persistence.cassandra.FutureDone
 
 /**
  * INTERNAL API
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStore.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStore.scala
index ffef47b..d620196 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStore.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStore.scala
@@ -16,20 +16,21 @@ package org.apache.pekko.persistence.cassandra.snapshot
 import com.datastax.oss.driver.api.core.cql._
 import com.datastax.oss.protocol.internal.util.Bytes
 import com.typesafe.config.Config
-import org.apache.pekko.{ Done, NotUsed }
-import org.apache.pekko.actor._
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.dispatch.ExecutionContexts
-import org.apache.pekko.event.Logging
-import org.apache.pekko.pattern.pipe
-import org.apache.pekko.persistence._
-import org.apache.pekko.persistence.cassandra._
-import org.apache.pekko.persistence.serialization.Snapshot
-import org.apache.pekko.persistence.snapshot.SnapshotStore
-import org.apache.pekko.serialization.{ AsyncSerializer, Serialization, SerializationExtension, Serializers }
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.{ CassandraSession, CassandraSessionRegistry }
-import org.apache.pekko.stream.scaladsl.{ Sink, Source }
-import org.apache.pekko.util.{ unused, OptionVal }
+import org.apache.pekko
+import pekko.{ Done, NotUsed }
+import pekko.actor._
+import pekko.annotation.InternalApi
+import pekko.dispatch.ExecutionContexts
+import pekko.event.Logging
+import pekko.pattern.pipe
+import pekko.persistence._
+import pekko.persistence.cassandra._
+import pekko.persistence.serialization.Snapshot
+import pekko.persistence.snapshot.SnapshotStore
+import pekko.serialization.{ AsyncSerializer, Serialization, SerializationExtension, Serializers }
+import pekko.stream.connectors.cassandra.scaladsl.{ CassandraSession, CassandraSessionRegistry }
+import pekko.stream.scaladsl.{ Sink, Source }
+import pekko.util.{ unused, OptionVal }
 
 import java.lang.{ Long => JLong }
 import java.nio.ByteBuffer
diff --git a/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/SnapshotSettings.scala b/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/SnapshotSettings.scala
index e37d3d0..95dac11 100644
--- a/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/SnapshotSettings.scala
+++ b/core/src/main/scala/org/apache/pekko/persistence/cassandra/snapshot/SnapshotSettings.scala
@@ -13,11 +13,12 @@
 
 package org.apache.pekko.persistence.cassandra.snapshot
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.annotation.InternalApi
-import org.apache.pekko.persistence.cassandra.PluginSettings.getReplicationStrategy
-import org.apache.pekko.persistence.cassandra.compaction.CassandraCompactionStrategy
-import org.apache.pekko.persistence.cassandra.getListFromConfig
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.annotation.InternalApi
+import pekko.persistence.cassandra.PluginSettings.getReplicationStrategy
+import pekko.persistence.cassandra.compaction.CassandraCompactionStrategy
+import pekko.persistence.cassandra.getListFromConfig
 import com.typesafe.config.Config
 
 /** INTERNAL API */
diff --git a/core/src/multi-jvm/scala/org/apache/pekko/cluster/persistence/cassandra/EventsByTagMultiJvmSpec.scala b/core/src/multi-jvm/scala/org/apache/pekko/cluster/persistence/cassandra/EventsByTagMultiJvmSpec.scala
index 4b5a242..e295c3e 100644
--- a/core/src/multi-jvm/scala/org/apache/pekko/cluster/persistence/cassandra/EventsByTagMultiJvmSpec.scala
+++ b/core/src/multi-jvm/scala/org/apache/pekko/cluster/persistence/cassandra/EventsByTagMultiJvmSpec.scala
@@ -10,14 +10,15 @@
 package org.apache.pekko.cluster.persistence.cassandra
 
 import com.typesafe.config.ConfigFactory
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.persistence.cassandra.testkit.CassandraLauncher
-import org.apache.pekko.persistence.journal.Tagged
-import org.apache.pekko.persistence.query.{ NoOffset, PersistenceQuery }
-import org.apache.pekko.remote.testkit.{ MultiNodeConfig, MultiNodeSpec }
-import org.apache.pekko.stream.ActorMaterializer
-import org.apache.pekko.stream.testkit.TestSubscriber
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.persistence.cassandra.testkit.CassandraLauncher
+import pekko.persistence.journal.Tagged
+import pekko.persistence.query.{ NoOffset, PersistenceQuery }
+import pekko.remote.testkit.{ MultiNodeConfig, MultiNodeSpec }
+import pekko.stream.ActorMaterializer
+import pekko.stream.testkit.TestSubscriber
+import pekko.stream.testkit.scaladsl.TestSink
 import org.scalatest.matchers.should.Matchers
 import org.scalatest.wordspec.AnyWordSpecLike
 
diff --git a/core/src/multi-jvm/scala/org/apache/pekko/cluster/persistence/cassandra/MultiNodeClusterSpec.scala b/core/src/multi-jvm/scala/org/apache/pekko/cluster/persistence/cassandra/MultiNodeClusterSpec.scala
index a42f145..c18e19c 100644
--- a/core/src/multi-jvm/scala/org/apache/pekko/cluster/persistence/cassandra/MultiNodeClusterSpec.scala
+++ b/core/src/multi-jvm/scala/org/apache/pekko/cluster/persistence/cassandra/MultiNodeClusterSpec.scala
@@ -12,13 +12,14 @@ package org.apache.pekko.cluster.persistence.cassandra
 import java.util.UUID
 import java.util.concurrent.ConcurrentHashMap
 
-import org.apache.pekko.actor.{ Actor, ActorRef, ActorSystem, Address, RootActorPath }
-import org.apache.pekko.cluster.{ Cluster, ClusterReadView, MemberStatus, _ }
-import org.apache.pekko.event.Logging.ErrorLevel
-import org.apache.pekko.remote.testconductor.RoleName
-import org.apache.pekko.remote.testkit.{ FlightRecordingSupport, MultiNodeSpec }
-import org.apache.pekko.testkit.TestEvent._
-import org.apache.pekko.testkit._
+import org.apache.pekko
+import pekko.actor.{ Actor, ActorRef, ActorSystem, Address, RootActorPath }
+import pekko.cluster.{ Cluster, ClusterReadView, MemberStatus, _ }
+import pekko.event.Logging.ErrorLevel
+import pekko.remote.testconductor.RoleName
+import pekko.remote.testkit.{ FlightRecordingSupport, MultiNodeSpec }
+import pekko.testkit.TestEvent._
+import pekko.testkit._
 import com.typesafe.config.{ Config, ConfigFactory }
 import org.scalatest.exceptions.TestCanceledException
 import org.scalatest.{ Canceled, Outcome, Suite }
@@ -126,13 +127,13 @@ trait MultiNodeClusterSpec extends Suite with STMultiNodeSpec with FlightRecordi
       }
 
       muteDeadLetters(
-        classOf[org.apache.pekko.actor.PoisonPill],
-        classOf[org.apache.pekko.dispatch.sysmsg.DeathWatchNotification],
-        classOf[org.apache.pekko.remote.transport.AssociationHandle.Disassociated],
-        //        org.apache.pekko.remote.transport.AssociationHandle.Disassociated.getClass,
-        classOf[org.apache.pekko.remote.transport.ActorTransportAdapter.DisassociateUnderlying],
-        //        org.apache.pekko.remote.transport.ActorTransportAdapter.DisassociateUnderlying.getClass,
-        classOf[org.apache.pekko.remote.transport.AssociationHandle.InboundPayload])(sys)
+        classOf[pekko.actor.PoisonPill],
+        classOf[pekko.dispatch.sysmsg.DeathWatchNotification],
+        classOf[pekko.remote.transport.AssociationHandle.Disassociated],
+        //        pekko.remote.transport.AssociationHandle.Disassociated.getClass,
+        classOf[pekko.remote.transport.ActorTransportAdapter.DisassociateUnderlying],
+        //        pekko.remote.transport.ActorTransportAdapter.DisassociateUnderlying.getClass,
+        classOf[pekko.remote.transport.AssociationHandle.InboundPayload])(sys)
 
     }
   }
diff --git a/core/src/test/scala/doc/reconciler/AllPersistenceIdsMigrationCompileOnly.scala b/core/src/test/scala/doc/reconciler/AllPersistenceIdsMigrationCompileOnly.scala
index fe3c8fc..0184224 100644
--- a/core/src/test/scala/doc/reconciler/AllPersistenceIdsMigrationCompileOnly.scala
+++ b/core/src/test/scala/doc/reconciler/AllPersistenceIdsMigrationCompileOnly.scala
@@ -17,8 +17,9 @@ package doc.reconciler
 import scala.util.Failure
 import scala.util.Success
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.persistence.cassandra.reconciler.Reconciliation
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.persistence.cassandra.reconciler.Reconciliation
 
 //#imports
 
diff --git a/core/src/test/scala/doc/reconciler/ReconciliationCompileOnly.scala b/core/src/test/scala/doc/reconciler/ReconciliationCompileOnly.scala
index 853fc6a..bb97a10 100644
--- a/core/src/test/scala/doc/reconciler/ReconciliationCompileOnly.scala
+++ b/core/src/test/scala/doc/reconciler/ReconciliationCompileOnly.scala
@@ -14,10 +14,11 @@
 package doc.reconciler
 
 //#imports
-import org.apache.pekko.persistence.cassandra.reconciler.Reconciliation
-import org.apache.pekko.actor.ActorSystem
+import org.apache.pekko
+import pekko.persistence.cassandra.reconciler.Reconciliation
+import pekko.actor.ActorSystem
 import scala.concurrent.Future
-import org.apache.pekko.Done
+import pekko.Done
 
 //#imports
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraCorruptJournalSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraCorruptJournalSpec.scala
index 59b38b1..08b7b20 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraCorruptJournalSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraCorruptJournalSpec.scala
@@ -13,10 +13,11 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.actor.{ ActorLogging, ActorRef, PoisonPill, Props }
-import org.apache.pekko.persistence.{ PersistentActor, RecoveryCompleted }
-import org.apache.pekko.persistence.cassandra.CassandraCorruptJournalSpec.{ FullEventLog, GetEventLog, Ping, Pong }
-import org.apache.pekko.testkit.{ EventFilter, TestProbe }
+import org.apache.pekko
+import pekko.actor.{ ActorLogging, ActorRef, PoisonPill, Props }
+import pekko.persistence.{ PersistentActor, RecoveryCompleted }
+import pekko.persistence.cassandra.CassandraCorruptJournalSpec.{ FullEventLog, GetEventLog, Ping, Pong }
+import pekko.testkit.{ EventFilter, TestProbe }
 
 object CassandraCorruptJournalSpec {
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraEventsByTagLoadSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraEventsByTagLoadSpec.scala
index 542c469..b63c519 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraEventsByTagLoadSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraEventsByTagLoadSpec.scala
@@ -13,11 +13,12 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.persistence.cassandra.TestTaggingActor.Ack
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.persistence.query.{ NoOffset, PersistenceQuery }
-import org.apache.pekko.stream.scaladsl._
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.persistence.cassandra.TestTaggingActor.Ack
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.persistence.query.{ NoOffset, PersistenceQuery }
+import pekko.stream.scaladsl._
+import pekko.stream.testkit.scaladsl.TestSink
 import com.typesafe.config.ConfigFactory
 import org.scalatest.time.{ Seconds, Span }
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraLifecycle.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraLifecycle.scala
index 1821f21..de9d0b9 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraLifecycle.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraLifecycle.scala
@@ -20,17 +20,18 @@ import java.util.concurrent.TimeUnit
 
 import scala.concurrent.Await
 
-import org.apache.pekko.actor.{ ActorSystem, PoisonPill, Props }
-import org.apache.pekko.persistence.PersistentActor
-import org.apache.pekko.testkit.{ TestKitBase, TestProbe }
+import org.apache.pekko
+import pekko.actor.{ ActorSystem, PoisonPill, Props }
+import pekko.persistence.PersistentActor
+import pekko.testkit.{ TestKitBase, TestProbe }
 import com.datastax.oss.driver.api.core.CqlSession
 import com.typesafe.config.ConfigFactory
 import org.scalatest._
 import scala.concurrent.duration._
 import scala.util.{ Failure, Success, Try }
 
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSession
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSessionRegistry
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSession
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSessionRegistry
 
 object CassandraLifecycle {
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraPluginSettingsSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraPluginSettingsSpec.scala
index 2578a96..3d4a28b 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraPluginSettingsSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraPluginSettingsSpec.scala
@@ -13,8 +13,9 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.testkit.TestKit
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.testkit.TestKit
 import com.typesafe.config.ConfigFactory
 import org.scalatest.BeforeAndAfterAll
 import org.scalatest.wordspec.AnyWordSpecLike
@@ -22,7 +23,7 @@ import org.scalatest.matchers.must.Matchers
 import org.scalatest.prop.TableDrivenPropertyChecks._
 import scala.util.Random
 
-import org.apache.pekko.persistence.cassandra.journal.JournalSettings
+import pekko.persistence.cassandra.journal.JournalSettings
 
 class CassandraPluginSettingsSpec
     extends TestKit(ActorSystem("CassandraPluginConfigSpec"))
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraQueryJournalSettingsSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraQueryJournalSettingsSpec.scala
index e910514..1198632 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraQueryJournalSettingsSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraQueryJournalSettingsSpec.scala
@@ -13,12 +13,13 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.persistence.cassandra.journal.TimeBucket
-import org.apache.pekko.persistence.cassandra.EventsByTagSettings.BackTrackSettings
-import org.apache.pekko.persistence.cassandra.EventsByTagSettings.Fixed
-import org.apache.pekko.persistence.cassandra.EventsByTagSettings.Max
-import org.apache.pekko.testkit.TestKit
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.persistence.cassandra.journal.TimeBucket
+import pekko.persistence.cassandra.EventsByTagSettings.BackTrackSettings
+import pekko.persistence.cassandra.EventsByTagSettings.Fixed
+import pekko.persistence.cassandra.EventsByTagSettings.Max
+import pekko.testkit.TestKit
 import com.typesafe.config.ConfigFactory
 import org.scalatest.BeforeAndAfterAll
 import org.scalatest.wordspec.AnyWordSpecLike
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraSpec.scala
index 11c1dd7..faad7c6 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/CassandraSpec.scala
@@ -16,16 +16,17 @@ package org.apache.pekko.persistence.cassandra
 import java.io.{ OutputStream, PrintStream }
 import java.util.concurrent.atomic.AtomicInteger
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.event.Logging
-import org.apache.pekko.event.Logging.{ LogEvent, StdOutLogger }
-import org.apache.pekko.persistence.cassandra.CassandraSpec._
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.persistence.query.{ NoOffset, PersistenceQuery }
-import org.apache.pekko.stream.scaladsl.{ Keep, Sink }
-import org.apache.pekko.stream.testkit.TestSubscriber
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
-import org.apache.pekko.testkit.{ EventFilter, ImplicitSender, SocketUtil, TestKitBase }
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.event.Logging
+import pekko.event.Logging.{ LogEvent, StdOutLogger }
+import pekko.persistence.cassandra.CassandraSpec._
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.persistence.query.{ NoOffset, PersistenceQuery }
+import pekko.stream.scaladsl.{ Keep, Sink }
+import pekko.stream.testkit.TestSubscriber
+import pekko.stream.testkit.scaladsl.TestSink
+import pekko.testkit.{ EventFilter, ImplicitSender, SocketUtil, TestKitBase }
 import com.typesafe.config.{ Config, ConfigFactory }
 import org.scalatest.concurrent.ScalaFutures
 import org.scalatest.time.{ Milliseconds, Seconds, Span }
@@ -35,12 +36,12 @@ import org.scalatest.matchers.should.Matchers
 import scala.collection.immutable
 import scala.concurrent.duration._
 
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal
-import org.apache.pekko.serialization.SerializationExtension
+import pekko.persistence.cassandra.journal.CassandraJournal
+import pekko.serialization.SerializationExtension
 import scala.util.control.NonFatal
 
-import org.apache.pekko.persistence.cassandra.TestTaggingActor.Ack
-import org.apache.pekko.actor.PoisonPill
+import pekko.persistence.cassandra.TestTaggingActor.Ack
+import pekko.actor.PoisonPill
 
 object CassandraSpec {
   def getCallerName(clazz: Class[_]): String = {
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagCrashSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagCrashSpec.scala
index d56e02c..e9c44cb 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagCrashSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagCrashSpec.scala
@@ -13,11 +13,12 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.NotUsed
-import org.apache.pekko.persistence.cassandra.TestTaggingActor.{ Ack, Crash }
-import org.apache.pekko.persistence.query.{ EventEnvelope, NoOffset }
-import org.apache.pekko.stream.scaladsl.Source
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.NotUsed
+import pekko.persistence.cassandra.TestTaggingActor.{ Ack, Crash }
+import pekko.persistence.query.{ EventEnvelope, NoOffset }
+import pekko.stream.scaladsl.Source
+import pekko.stream.testkit.scaladsl.TestSink
 
 import scala.concurrent.duration._
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagMigrationSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagMigrationSpec.scala
index 562e66d..8817b7a 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagMigrationSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagMigrationSpec.scala
@@ -16,31 +16,32 @@ package org.apache.pekko.persistence.cassandra
 import java.nio.ByteBuffer
 import java.lang.{ Long => JLong }
 
-import org.apache.pekko.actor.{ ActorSystem, PoisonPill }
-import org.apache.pekko.persistence.cassandra.TestTaggingActor.Ack
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournalStatements
-import org.apache.pekko.persistence.cassandra.query.DirectWriting
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.persistence.query.{ EventEnvelope, NoOffset, PersistenceQuery }
-import org.apache.pekko.persistence.{ PersistentRepr, RecoveryCompleted }
-import org.apache.pekko.serialization.SerializationExtension
-import org.apache.pekko.stream.scaladsl.Source
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
-import org.apache.pekko.testkit.TestProbe
-import org.apache.pekko.{ Done, NotUsed }
+import org.apache.pekko
+import pekko.actor.{ ActorSystem, PoisonPill }
+import pekko.persistence.cassandra.TestTaggingActor.Ack
+import pekko.persistence.cassandra.journal.CassandraJournalStatements
+import pekko.persistence.cassandra.query.DirectWriting
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.persistence.query.{ EventEnvelope, NoOffset, PersistenceQuery }
+import pekko.persistence.{ PersistentRepr, RecoveryCompleted }
+import pekko.serialization.SerializationExtension
+import pekko.stream.scaladsl.Source
+import pekko.stream.testkit.scaladsl.TestSink
+import pekko.testkit.TestProbe
+import pekko.{ Done, NotUsed }
 import com.typesafe.config.ConfigFactory
 import org.scalatest.BeforeAndAfterAll
 import scala.concurrent.duration._
 
-import org.apache.pekko.persistence.cassandra.journal.TimeBucket
-import org.apache.pekko.serialization.Serializers
+import pekko.persistence.cassandra.journal.TimeBucket
+import pekko.serialization.Serializers
 import com.datastax.oss.driver.api.core.cql.SimpleStatement
 import com.datastax.oss.driver.api.core.uuid.Uuids
 import scala.util.control.NonFatal
 
-import org.apache.pekko.persistence.cassandra.reconciler.Reconciliation
-import org.apache.pekko.stream.SystemMaterializer
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSessionRegistry
+import pekko.persistence.cassandra.reconciler.Reconciliation
+import pekko.stream.SystemMaterializer
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSessionRegistry
 
 /**
  */
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagRecoverySpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagRecoverySpec.scala
index a853165..c6cd346 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagRecoverySpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagRecoverySpec.scala
@@ -13,12 +13,13 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.actor.{ ActorSystem, PoisonPill }
-import org.apache.pekko.persistence.cassandra.TestTaggingActor.{ Ack, DoASnapshotPlease, SnapShotAck }
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.persistence.query.{ EventEnvelope, NoOffset, PersistenceQuery }
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
-import org.apache.pekko.testkit.TestProbe
+import org.apache.pekko
+import pekko.actor.{ ActorSystem, PoisonPill }
+import pekko.persistence.cassandra.TestTaggingActor.{ Ack, DoASnapshotPlease, SnapShotAck }
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.persistence.query.{ EventEnvelope, NoOffset, PersistenceQuery }
+import pekko.stream.testkit.scaladsl.TestSink
+import pekko.testkit.TestProbe
 import com.typesafe.config.ConfigFactory
 
 import scala.concurrent.duration._
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagRestartSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagRestartSpec.scala
index f15ba8a..42e734c 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagRestartSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagRestartSpec.scala
@@ -16,15 +16,16 @@ package org.apache.pekko.persistence.cassandra
 import java.time.format.DateTimeFormatter
 import java.time.{ LocalDateTime, ZoneOffset }
 
-import org.apache.pekko.persistence.cassandra.TestTaggingActor.{ Ack, Stop }
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.persistence.query.{ EventEnvelope, NoOffset, PersistenceQuery }
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
-import org.apache.pekko.testkit.TestProbe
+import org.apache.pekko
+import pekko.persistence.cassandra.TestTaggingActor.{ Ack, Stop }
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.persistence.query.{ EventEnvelope, NoOffset, PersistenceQuery }
+import pekko.stream.testkit.scaladsl.TestSink
+import pekko.testkit.TestProbe
 import com.typesafe.config.ConfigFactory
 
 import scala.concurrent.duration._
-import org.apache.pekko.actor.PoisonPill
+import pekko.actor.PoisonPill
 import org.scalatest.matchers.should.Matchers
 
 object EventsByTagRestartSpec {
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagStressSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagStressSpec.scala
index 3898058..574cf2a 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagStressSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/EventsByTagStressSpec.scala
@@ -13,11 +13,12 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.persistence.cassandra.query.TestActor
-import org.apache.pekko.persistence.journal.Tagged
-import org.apache.pekko.persistence.query.NoOffset
-import org.apache.pekko.stream.testkit.TestSubscriber
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.persistence.cassandra.query.TestActor
+import pekko.persistence.journal.Tagged
+import pekko.persistence.query.NoOffset
+import pekko.stream.testkit.TestSubscriber
+import pekko.stream.testkit.scaladsl.TestSink
 
 import scala.collection.immutable
 import scala.concurrent.Future
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/Persister.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/Persister.scala
index a3e5ba7..e78aca2 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/Persister.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/Persister.scala
@@ -13,9 +13,10 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.actor.ActorRef
-import org.apache.pekko.persistence._
-import org.apache.pekko.persistence.cassandra.Persister._
+import org.apache.pekko
+import pekko.actor.ActorRef
+import pekko.persistence._
+import pekko.persistence.cassandra.Persister._
 
 object Persister {
   case class CrapEvent(n: Int)
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/ReconnectSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/ReconnectSpec.scala
index 2bfab3d..eb59ef3 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/ReconnectSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/ReconnectSpec.scala
@@ -14,11 +14,12 @@
 package org.apache.pekko.persistence.cassandra
 
 import java.io.File
-import org.apache.pekko.actor.{ ActorSystem, Props }
-import org.apache.pekko.persistence.cassandra.CassandraLifecycle.AwaitPersistenceInit
-import org.apache.pekko.testkit.{ ImplicitSender, SocketUtil, TestKit }
+import org.apache.pekko
+import pekko.actor.{ ActorSystem, Props }
+import pekko.persistence.cassandra.CassandraLifecycle.AwaitPersistenceInit
+import pekko.testkit.{ ImplicitSender, SocketUtil, TestKit }
 import com.typesafe.config.ConfigFactory
-import org.apache.pekko.persistence.cassandra.testkit.CassandraLauncher
+import pekko.persistence.cassandra.testkit.CassandraLauncher
 import org.scalatest.Suite
 import org.scalatest.concurrent.ScalaFutures
 import org.scalatest.matchers.should.Matchers
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/RetriesSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/RetriesSpec.scala
index db682c4..2402afd 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/RetriesSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/RetriesSpec.scala
@@ -16,9 +16,10 @@ package org.apache.pekko.persistence.cassandra
 import scala.concurrent.Future
 import scala.concurrent.duration._
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.testkit.TestKit
-import org.apache.pekko.testkit.TestProbe
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.testkit.TestKit
+import pekko.testkit.TestProbe
 import org.scalatest.BeforeAndAfterAll
 import org.scalatest.concurrent.ScalaFutures
 import org.scalatest.matchers.should.Matchers
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/TestTaggingActor.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/TestTaggingActor.scala
index d3b3aa7..e572fea 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/TestTaggingActor.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/TestTaggingActor.scala
@@ -13,10 +13,11 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.actor.{ ActorLogging, ActorRef, Props }
-import org.apache.pekko.persistence.cassandra.journal.TagWriterSpec.TestEx
-import org.apache.pekko.persistence.{ PersistentActor, RecoveryCompleted, SaveSnapshotSuccess }
-import org.apache.pekko.persistence.journal.Tagged
+import org.apache.pekko
+import pekko.actor.{ ActorLogging, ActorRef, Props }
+import pekko.persistence.cassandra.journal.TagWriterSpec.TestEx
+import pekko.persistence.{ PersistentActor, RecoveryCompleted, SaveSnapshotSuccess }
+import pekko.persistence.journal.Tagged
 
 object TestTaggingActor {
   case object Ack
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/WithLogCapturing.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/WithLogCapturing.scala
index c0bc568..ebae643 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/WithLogCapturing.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/WithLogCapturing.scala
@@ -13,8 +13,9 @@
 
 package org.apache.pekko.persistence.cassandra
 
-import org.apache.pekko.event.Logging._
-import org.apache.pekko.testkit.TestEventListener
+import org.apache.pekko
+import pekko.event.Logging._
+import pekko.testkit.TestEventListener
 
 /**
  * An adaption of TestEventListener that never prints debug logs itself. Use together with [[pekko.persistence.cassandra.CassandraSpec]].
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/cleanup/CleanupSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/cleanup/CleanupSpec.scala
index 4508d5e..d06125d 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/cleanup/CleanupSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/cleanup/CleanupSpec.scala
@@ -16,14 +16,15 @@ package org.apache.pekko.persistence.cassandra.cleanup
 import java.time.LocalDateTime
 import java.time.ZoneOffset
 
-import org.apache.pekko.actor.ActorRef
-import org.apache.pekko.actor.Props
-import org.apache.pekko.persistence.{ PersistentActor, SaveSnapshotSuccess, SnapshotMetadata, SnapshotOffer }
-import org.apache.pekko.persistence.cassandra.{ CassandraSpec, RequiresCassandraThree }
-import org.apache.pekko.persistence.cassandra.query.{ firstBucketFormatter, DirectWriting }
-import org.apache.pekko.persistence.journal.Tagged
-import org.apache.pekko.persistence.query.NoOffset
-import org.apache.pekko.stream.scaladsl.Sink
+import org.apache.pekko
+import pekko.actor.ActorRef
+import pekko.actor.Props
+import pekko.persistence.{ PersistentActor, SaveSnapshotSuccess, SnapshotMetadata, SnapshotOffer }
+import pekko.persistence.cassandra.{ CassandraSpec, RequiresCassandraThree }
+import pekko.persistence.cassandra.query.{ firstBucketFormatter, DirectWriting }
+import pekko.persistence.journal.Tagged
+import pekko.persistence.query.NoOffset
+import pekko.stream.scaladsl.Sink
 import com.typesafe.config.ConfigFactory
 
 object CleanupSpec {
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/compaction/CassandraCompactionStrategySpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/compaction/CassandraCompactionStrategySpec.scala
index 3e2b454..3bb3b0e 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/compaction/CassandraCompactionStrategySpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/compaction/CassandraCompactionStrategySpec.scala
@@ -15,10 +15,11 @@ package org.apache.pekko.persistence.cassandra.compaction
 
 import java.util.concurrent.TimeUnit
 
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, PluginSettings }
+import org.apache.pekko
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, PluginSettings }
 import com.typesafe.config.ConfigFactory
 import org.scalatest.wordspec.AnyWordSpecLike
-import org.apache.pekko.persistence.cassandra.RequiresCassandraThree
+import pekko.persistence.cassandra.RequiresCassandraThree
 
 object CassandraCompactionStrategySpec {
   lazy val config = ConfigFactory.parseString(s"""
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/BufferSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/BufferSpec.scala
index 9983506..d0f7da8 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/BufferSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/BufferSpec.scala
@@ -16,12 +16,13 @@ package org.apache.pekko.persistence.cassandra.journal
 import java.nio.ByteBuffer
 import java.util.UUID
 
-import org.apache.pekko.actor.{ ActorRef, ActorSystem }
-import org.apache.pekko.persistence.cassandra.Day
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal.{ Serialized, TagPidSequenceNr }
-import org.apache.pekko.persistence.cassandra.journal.TagWriter.AwaitingWrite
-import org.apache.pekko.testkit.{ TestKit, TestProbe }
-import org.apache.pekko.util.OptionVal
+import org.apache.pekko
+import pekko.actor.{ ActorRef, ActorSystem }
+import pekko.persistence.cassandra.Day
+import pekko.persistence.cassandra.journal.CassandraJournal.{ Serialized, TagPidSequenceNr }
+import pekko.persistence.cassandra.journal.TagWriter.AwaitingWrite
+import pekko.testkit.{ TestKit, TestProbe }
+import pekko.util.OptionVal
 import com.datastax.oss.driver.api.core.uuid.Uuids
 import org.scalatest.BeforeAndAfterAll
 import org.scalatest.matchers.should.Matchers
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraEventUpdateSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraEventUpdateSpec.scala
index 8603639..5e59f20 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraEventUpdateSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraEventUpdateSpec.scala
@@ -16,19 +16,20 @@ package org.apache.pekko.persistence.cassandra.journal
 import java.util.UUID
 
 import scala.concurrent.Await
-import org.apache.pekko.Done
-import org.apache.pekko.event.Logging
-import org.apache.pekko.persistence.PersistentRepr
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal.Serialized
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, TestTaggingActor, _ }
-import org.apache.pekko.serialization.SerializationExtension
+import org.apache.pekko
+import pekko.Done
+import pekko.event.Logging
+import pekko.persistence.PersistentRepr
+import pekko.persistence.cassandra.journal.CassandraJournal.Serialized
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, TestTaggingActor, _ }
+import pekko.serialization.SerializationExtension
 import com.typesafe.config.ConfigFactory
 
 import scala.concurrent.ExecutionContext
 import scala.concurrent.Future
-import org.apache.pekko.actor.ExtendedActorSystem
-import org.apache.pekko.stream.connectors.cassandra.CqlSessionProvider
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSession
+import pekko.actor.ExtendedActorSystem
+import pekko.stream.connectors.cassandra.CqlSessionProvider
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSession
 
 object CassandraEventUpdateSpec {
   val config = ConfigFactory.parseString("""
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraIntegrationSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraIntegrationSpec.scala
index 445c280..531e602 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraIntegrationSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraIntegrationSpec.scala
@@ -15,10 +15,11 @@ package org.apache.pekko.persistence.cassandra.journal
 
 import java.util.UUID
 
-import org.apache.pekko.actor._
-import org.apache.pekko.persistence._
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
-import org.apache.pekko.testkit._
+import org.apache.pekko
+import pekko.actor._
+import pekko.persistence._
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
+import pekko.testkit._
 import com.typesafe.config.ConfigFactory
 import org.scalatest.wordspec.AnyWordSpecLike
 import org.scalatest.matchers.should.Matchers
@@ -114,7 +115,7 @@ object CassandraIntegrationSpec {
 
 }
 
-import org.apache.pekko.persistence.cassandra.journal.CassandraIntegrationSpec._
+import pekko.persistence.cassandra.journal.CassandraIntegrationSpec._
 
 class CassandraIntegrationSpec extends CassandraSpec(config) with ImplicitSender with AnyWordSpecLike with Matchers {
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalDeletionSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalDeletionSpec.scala
index 4e1400f..61795f9 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalDeletionSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalDeletionSpec.scala
@@ -13,14 +13,15 @@
 
 package org.apache.pekko.persistence.cassandra.journal
 
-import org.apache.pekko.actor.{ ActorRef, PoisonPill, Props }
-import org.apache.pekko.persistence.{ DeleteMessagesFailure, DeleteMessagesSuccess, PersistentActor, RecoveryCompleted }
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.testkit.TestProbe
+import org.apache.pekko
+import pekko.actor.{ ActorRef, PoisonPill, Props }
+import pekko.persistence.{ DeleteMessagesFailure, DeleteMessagesSuccess, PersistentActor, RecoveryCompleted }
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.testkit.TestProbe
 import scala.collection.immutable
 import scala.concurrent.duration._
 
-import org.apache.pekko.testkit.EventFilter
+import pekko.testkit.EventFilter
 
 object CassandraJournalDeletionSpec {
   case class PersistMe(msg: Long)
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalSpec.scala
index 20955f9..fdc4f84 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraJournalSpec.scala
@@ -13,21 +13,17 @@
 
 package org.apache.pekko.persistence.cassandra.journal
 
-import org.apache.pekko.actor.Actor
-import org.apache.pekko.persistence.CapabilityFlag
-import org.apache.pekko.persistence.{ AtomicWrite, PersistentRepr }
-import org.apache.pekko.persistence.JournalProtocol.{
-  ReplayMessages,
-  WriteMessageFailure,
-  WriteMessages,
-  WriteMessagesFailed
-}
+import org.apache.pekko
+import pekko.actor.Actor
+import pekko.persistence.CapabilityFlag
+import pekko.persistence.{ AtomicWrite, PersistentRepr }
+import pekko.persistence.JournalProtocol.{ ReplayMessages, WriteMessageFailure, WriteMessages, WriteMessagesFailed }
 
 import scala.concurrent.duration._
-import org.apache.pekko.persistence.journal._
-import org.apache.pekko.persistence.cassandra.CassandraLifecycle
-import org.apache.pekko.stream.connectors.cassandra.CassandraMetricsRegistry
-import org.apache.pekko.testkit.TestProbe
+import pekko.persistence.journal._
+import pekko.persistence.cassandra.CassandraLifecycle
+import pekko.stream.connectors.cassandra.CassandraMetricsRegistry
+import pekko.testkit.TestProbe
 import com.typesafe.config.ConfigFactory
 
 object CassandraJournalConfiguration {
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraLoadSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraLoadSpec.scala
index 1d570d0..28f1ae0 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraLoadSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraLoadSpec.scala
@@ -15,11 +15,12 @@ package org.apache.pekko.persistence.cassandra.journal
 
 import scala.concurrent.duration._
 
-import org.apache.pekko.actor._
-import org.apache.pekko.persistence._
-import org.apache.pekko.persistence.cassandra.CassandraLifecycle
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.testkit._
+import org.apache.pekko
+import pekko.actor._
+import pekko.persistence._
+import pekko.persistence.cassandra.CassandraLifecycle
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.testkit._
 import com.typesafe.config.ConfigFactory
 import org.scalatest.matchers.should.Matchers
 import org.scalatest.wordspec.AnyWordSpecLike
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraLoadTypedSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraLoadTypedSpec.scala
index e3e4551..8b0b8a6 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraLoadTypedSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraLoadTypedSpec.scala
@@ -13,16 +13,17 @@
 
 package org.apache.pekko.persistence.cassandra.journal
 
-import org.apache.pekko.actor.testkit.typed.scaladsl.ActorTestKit
-import org.apache.pekko.actor.testkit.typed.scaladsl.TestProbe
-import org.apache.pekko.actor.typed.ActorRef
-import org.apache.pekko.actor.typed.Behavior
-import org.apache.pekko.actor.typed.scaladsl.Behaviors
-import org.apache.pekko.actor.typed.scaladsl.adapter._
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.persistence.typed.PersistenceId
-import org.apache.pekko.persistence.typed.scaladsl.Effect
-import org.apache.pekko.persistence.typed.scaladsl.EventSourcedBehavior
+import org.apache.pekko
+import pekko.actor.testkit.typed.scaladsl.ActorTestKit
+import pekko.actor.testkit.typed.scaladsl.TestProbe
+import pekko.actor.typed.ActorRef
+import pekko.actor.typed.Behavior
+import pekko.actor.typed.scaladsl.Behaviors
+import pekko.actor.typed.scaladsl.adapter._
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.persistence.typed.PersistenceId
+import pekko.persistence.typed.scaladsl.Effect
+import pekko.persistence.typed.scaladsl.EventSourcedBehavior
 import org.scalatest.wordspec.AnyWordSpecLike
 import org.scalatest.matchers.should.Matchers
 import scala.concurrent.duration._
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraSerializationSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraSerializationSpec.scala
index 153f5d9..c8672d9 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraSerializationSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/CassandraSerializationSpec.scala
@@ -13,11 +13,12 @@
 
 package org.apache.pekko.persistence.cassandra.journal
 
-import org.apache.pekko.actor.{ ExtendedActorSystem, Props }
-import org.apache.pekko.persistence.RecoveryCompleted
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, Persister }
-import org.apache.pekko.serialization.BaseSerializer
-import org.apache.pekko.testkit.TestProbe
+import org.apache.pekko
+import pekko.actor.{ ExtendedActorSystem, Props }
+import pekko.persistence.RecoveryCompleted
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, Persister }
+import pekko.serialization.BaseSerializer
+import pekko.testkit.TestProbe
 import com.typesafe.config.ConfigFactory
 
 object CassandraSerializationSpec {
@@ -54,7 +55,7 @@ class BrokenDeSerialization(override val system: ExtendedActorSystem) extends Ba
 
 class CassandraSerializationSpec extends CassandraSpec(CassandraSerializationSpec.config) {
 
-  import org.apache.pekko.persistence.cassandra.Persister._
+  import pekko.persistence.cassandra.Persister._
 
   "A Cassandra journal" must {
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/ManyActorsLoadSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/ManyActorsLoadSpec.scala
index f1cbb8c..19e2938 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/ManyActorsLoadSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/ManyActorsLoadSpec.scala
@@ -17,11 +17,12 @@ import java.util.concurrent.TimeUnit
 
 import scala.concurrent.duration._
 
-import org.apache.pekko.actor._
-import org.apache.pekko.persistence.PersistentActor
-import org.apache.pekko.persistence.cassandra.CassandraLifecycle
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.persistence.journal.Tagged
+import org.apache.pekko
+import pekko.actor._
+import pekko.persistence.PersistentActor
+import pekko.persistence.cassandra.CassandraLifecycle
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.persistence.journal.Tagged
 import com.typesafe.config.ConfigFactory
 
 object ManyActorsLoadSpec {
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/MultiPluginSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/MultiPluginSpec.scala
index b401a95..d78bc17 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/MultiPluginSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/MultiPluginSpec.scala
@@ -14,11 +14,12 @@
 package org.apache.pekko.persistence.cassandra.journal
 
 import com.typesafe.config.ConfigFactory
-import org.apache.pekko.actor.Props
-import org.apache.pekko.persistence.cassandra.journal.MultiPluginSpec._
-import org.apache.pekko.persistence.cassandra.testkit.CassandraLauncher
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, PluginSettings }
-import org.apache.pekko.persistence.{ PersistentActor, SaveSnapshotSuccess }
+import org.apache.pekko
+import pekko.actor.Props
+import pekko.persistence.cassandra.journal.MultiPluginSpec._
+import pekko.persistence.cassandra.testkit.CassandraLauncher
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, PluginSettings }
+import pekko.persistence.{ PersistentActor, SaveSnapshotSuccess }
 
 object MultiPluginSpec {
   val now = System.currentTimeMillis()
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/PersistAllSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/PersistAllSpec.scala
index 25727cb..ed9127c 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/PersistAllSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/PersistAllSpec.scala
@@ -15,11 +15,12 @@ package org.apache.pekko.persistence.cassandra.journal
 
 import java.util.UUID
 
-import org.apache.pekko.actor._
-import org.apache.pekko.persistence._
-import org.apache.pekko.persistence.cassandra.CassandraLifecycle
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.testkit._
+import org.apache.pekko
+import pekko.actor._
+import pekko.persistence._
+import pekko.persistence.cassandra.CassandraLifecycle
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.testkit._
 import com.typesafe.config.ConfigFactory
 import org.scalatest.matchers.should.Matchers
 import org.scalatest.wordspec.AnyWordSpecLike
@@ -52,7 +53,7 @@ object PersistAllSpec {
   }
 }
 
-import org.apache.pekko.persistence.cassandra.journal.PersistAllSpec._
+import pekko.persistence.cassandra.journal.PersistAllSpec._
 
 class PersistAllSpec extends CassandraSpec(config) with ImplicitSender with AnyWordSpecLike with Matchers {
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/PubSubThrottlerSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/PubSubThrottlerSpec.scala
index 7f346d0..e4b7e64 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/PubSubThrottlerSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/PubSubThrottlerSpec.scala
@@ -18,8 +18,9 @@ import scala.concurrent.duration.DurationInt
 import org.scalatest.wordspec.AnyWordSpecLike
 import org.scalatest.matchers.should.Matchers
 
-import org.apache.pekko.actor.{ ActorSystem, Props }
-import org.apache.pekko.testkit.{ TestKit, TestProbe }
+import org.apache.pekko
+import pekko.actor.{ ActorSystem, Props }
+import pekko.testkit.{ TestKit, TestProbe }
 
 class PubSubThrottlerSpec
     extends TestKit(ActorSystem("CassandraConfigCheckerSpec"))
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/RecoveryLoadSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/RecoveryLoadSpec.scala
index 35e10e9..b6bd27e 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/RecoveryLoadSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/RecoveryLoadSpec.scala
@@ -13,10 +13,11 @@
 
 package org.apache.pekko.persistence.cassandra.journal
 
-import org.apache.pekko.actor._
-import org.apache.pekko.persistence.{ PersistentActor, RecoveryCompleted, SnapshotOffer }
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
-import org.apache.pekko.persistence.journal.Tagged
+import org.apache.pekko
+import pekko.actor._
+import pekko.persistence.{ PersistentActor, RecoveryCompleted, SnapshotOffer }
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
+import pekko.persistence.journal.Tagged
 import com.typesafe.config.ConfigFactory
 
 import scala.concurrent.duration._
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/StartupLoadSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/StartupLoadSpec.scala
index 59cf247..694d439 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/StartupLoadSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/StartupLoadSpec.scala
@@ -13,10 +13,11 @@
 
 package org.apache.pekko.persistence.cassandra.journal
 
-import org.apache.pekko.actor._
-import org.apache.pekko.persistence._
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.testkit._
+import org.apache.pekko
+import pekko.actor._
+import pekko.persistence._
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.testkit._
 
 import scala.concurrent.duration._
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TagWriterSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TagWriterSpec.scala
index fdc33c4..4ccdf3c 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TagWriterSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TagWriterSpec.scala
@@ -15,17 +15,18 @@ package org.apache.pekko.persistence.cassandra.journal
 
 import java.nio.ByteBuffer
 import java.util.UUID
-import org.apache.pekko.Done
-import org.apache.pekko.actor.{ ActorRef, ActorSystem }
-import org.apache.pekko.event.Logging.Warning
-import org.apache.pekko.persistence.cassandra.Day
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal._
-import org.apache.pekko.persistence.cassandra.journal.TagWriter._
-import org.apache.pekko.persistence.cassandra.journal.TagWriters.TagWrite
-import org.apache.pekko.persistence.cassandra.journal.TagWriterSpec.{ EventWrite, ProgressWrite, TestEx }
-import org.apache.pekko.persistence.cassandra.formatOffset
-import org.apache.pekko.persistence.cassandra.journal.TagWriters.TagWritersSession
-import org.apache.pekko.testkit.{ TestKit, TestProbe }
+import org.apache.pekko
+import pekko.Done
+import pekko.actor.{ ActorRef, ActorSystem }
+import pekko.event.Logging.Warning
+import pekko.persistence.cassandra.Day
+import pekko.persistence.cassandra.journal.CassandraJournal._
+import pekko.persistence.cassandra.journal.TagWriter._
+import pekko.persistence.cassandra.journal.TagWriters.TagWrite
+import pekko.persistence.cassandra.journal.TagWriterSpec.{ EventWrite, ProgressWrite, TestEx }
+import pekko.persistence.cassandra.formatOffset
+import pekko.persistence.cassandra.journal.TagWriters.TagWritersSession
+import pekko.testkit.{ TestKit, TestProbe }
 import com.datastax.oss.driver.api.core.cql.{ PreparedStatement, Statement }
 import com.datastax.oss.driver.api.core.uuid.Uuids
 import com.typesafe.config.{ Config, ConfigFactory }
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TagWritersSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TagWritersSpec.scala
index 84092f1..2cd413e 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TagWritersSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TagWritersSpec.scala
@@ -15,14 +15,15 @@ package org.apache.pekko.persistence.cassandra.journal
 
 import java.nio.ByteBuffer
 
-import org.apache.pekko.Done
-import org.apache.pekko.actor.{ Actor, ActorRef, ActorSystem, PoisonPill, Props }
-import org.apache.pekko.persistence.cassandra.Hour
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal.Serialized
-import org.apache.pekko.persistence.cassandra.journal.TagWriter._
-import org.apache.pekko.persistence.cassandra.journal.TagWriters._
-import org.apache.pekko.testkit.{ ImplicitSender, TestKit, TestProbe }
-import org.apache.pekko.util.Timeout
+import org.apache.pekko
+import pekko.Done
+import pekko.actor.{ Actor, ActorRef, ActorSystem, PoisonPill, Props }
+import pekko.persistence.cassandra.Hour
+import pekko.persistence.cassandra.journal.CassandraJournal.Serialized
+import pekko.persistence.cassandra.journal.TagWriter._
+import pekko.persistence.cassandra.journal.TagWriters._
+import pekko.testkit.{ ImplicitSender, TestKit, TestProbe }
+import pekko.util.Timeout
 import com.datastax.oss.driver.api.core.uuid.Uuids
 import com.typesafe.config.{ Config, ConfigFactory }
 import org.scalatest.BeforeAndAfterAll
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TimeBucketSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TimeBucketSpec.scala
index d4990c0..fe8966d 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TimeBucketSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/journal/TimeBucketSpec.scala
@@ -13,9 +13,10 @@
 
 package org.apache.pekko.persistence.cassandra.journal
 
-import org.apache.pekko.persistence.cassandra.Day
-import org.apache.pekko.persistence.cassandra.Hour
-import org.apache.pekko.persistence.cassandra.Minute
+import org.apache.pekko
+import pekko.persistence.cassandra.Day
+import pekko.persistence.cassandra.Hour
+import pekko.persistence.cassandra.Minute
 import org.scalatest.wordspec.AnyWordSpec
 import org.scalatest.matchers.should.Matchers
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/AllPersistenceIdsSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/AllPersistenceIdsSpec.scala
index c1e7063..6f48342 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/AllPersistenceIdsSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/AllPersistenceIdsSpec.scala
@@ -17,13 +17,14 @@ import java.util.UUID
 
 import scala.concurrent.duration._
 
-import org.apache.pekko.NotUsed
-import org.apache.pekko.actor.ActorRef
-import org.apache.pekko.persistence.cassandra.CassandraLifecycle
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.persistence.cassandra.journal.JournalSettings
-import org.apache.pekko.stream.scaladsl.Source
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.NotUsed
+import pekko.actor.ActorRef
+import pekko.persistence.cassandra.CassandraLifecycle
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.persistence.cassandra.journal.JournalSettings
+import pekko.stream.scaladsl.Source
+import pekko.stream.testkit.scaladsl.TestSink
 import com.typesafe.config.ConfigFactory
 import org.scalatest.BeforeAndAfterEach
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/CassandraQueryJournalOverrideSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/CassandraQueryJournalOverrideSpec.scala
index 0def558..336b3c8 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/CassandraQueryJournalOverrideSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/CassandraQueryJournalOverrideSpec.scala
@@ -13,13 +13,14 @@
 
 package org.apache.pekko.persistence.cassandra.query
 
-import org.apache.pekko.actor.ExtendedActorSystem
-import org.apache.pekko.persistence.PersistentRepr
-import org.apache.pekko.persistence.cassandra.TestTaggingActor.Ack
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, TestTaggingActor }
-import org.apache.pekko.persistence.query.{ PersistenceQuery, ReadJournalProvider }
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.actor.ExtendedActorSystem
+import pekko.persistence.PersistentRepr
+import pekko.persistence.cassandra.TestTaggingActor.Ack
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, TestTaggingActor }
+import pekko.persistence.query.{ PersistenceQuery, ReadJournalProvider }
+import pekko.stream.testkit.scaladsl.TestSink
 import com.typesafe.config.{ Config, ConfigFactory }
 
 import scala.concurrent.duration._
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/DirectWriting.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/DirectWriting.scala
index 1f89fba..b44a13c 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/DirectWriting.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/DirectWriting.scala
@@ -15,16 +15,17 @@ package org.apache.pekko.persistence.cassandra.query
 
 import java.nio.ByteBuffer
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.persistence.{ PersistentRepr, SnapshotMetadata }
-import org.apache.pekko.persistence.cassandra.Hour
-import org.apache.pekko.persistence.cassandra.PluginSettings
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournalStatements
-import org.apache.pekko.persistence.cassandra.journal.TimeBucket
-import org.apache.pekko.persistence.cassandra.snapshot.{ CassandraSnapshotStatements, CassandraSnapshotStore }
-import org.apache.pekko.persistence.cassandra.snapshot.CassandraSnapshotStore.SnapshotSerialization
-import org.apache.pekko.serialization.SerializationExtension
-import org.apache.pekko.serialization.Serializers
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.persistence.{ PersistentRepr, SnapshotMetadata }
+import pekko.persistence.cassandra.Hour
+import pekko.persistence.cassandra.PluginSettings
+import pekko.persistence.cassandra.journal.CassandraJournalStatements
+import pekko.persistence.cassandra.journal.TimeBucket
+import pekko.persistence.cassandra.snapshot.{ CassandraSnapshotStatements, CassandraSnapshotStore }
+import pekko.persistence.cassandra.snapshot.CassandraSnapshotStore.SnapshotSerialization
+import pekko.serialization.SerializationExtension
+import pekko.serialization.Serializers
 import com.datastax.oss.driver.api.core.CqlSession
 import com.datastax.oss.driver.api.core.uuid.Uuids
 import org.scalatest.BeforeAndAfterAll
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventAdaptersReadSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventAdaptersReadSpec.scala
index a31a9d4..c4dca9a 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventAdaptersReadSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventAdaptersReadSpec.scala
@@ -13,10 +13,11 @@
 
 package org.apache.pekko.persistence.cassandra.query
 
-import org.apache.pekko.actor.ActorRef
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
-import org.apache.pekko.persistence.query.NoOffset
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.actor.ActorRef
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
+import pekko.persistence.query.NoOffset
+import pekko.stream.testkit.scaladsl.TestSink
 import com.typesafe.config.ConfigFactory
 
 import scala.concurrent.duration._
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdFastForwardSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdFastForwardSpec.scala
index a639295..9203d69 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdFastForwardSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdFastForwardSpec.scala
@@ -15,10 +15,11 @@ package org.apache.pekko.persistence.cassandra.query
 
 import java.util.UUID
 
-import org.apache.pekko.persistence.PersistentRepr
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
-import org.apache.pekko.stream.scaladsl.Keep
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.persistence.PersistentRepr
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
+import pekko.stream.scaladsl.Keep
+import pekko.stream.testkit.scaladsl.TestSink
 import com.typesafe.config.ConfigFactory
 import org.scalatest.time.{ Milliseconds, Seconds, Span }
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdMultiPartitionGapSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdMultiPartitionGapSpec.scala
index 35d446f..0fe1be2 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdMultiPartitionGapSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdMultiPartitionGapSpec.scala
@@ -15,9 +15,10 @@ package org.apache.pekko.persistence.cassandra.query
 
 import java.util.UUID
 
-import org.apache.pekko.persistence.PersistentRepr
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.persistence.PersistentRepr
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
+import pekko.stream.testkit.scaladsl.TestSink
 import com.typesafe.config.ConfigFactory
 
 object EventsByPersistenceIdMultiPartitionGapSpec {
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdSpec.scala
index 4a3e9eb..6ad3e2f 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdSpec.scala
@@ -14,14 +14,15 @@
 package org.apache.pekko.persistence.cassandra.query
 
 import com.typesafe.config.ConfigFactory
-import org.apache.pekko.actor.ActorRef
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
-import org.apache.pekko.persistence.query.TimeBasedUUID
-import org.apache.pekko.persistence.{ DeleteMessagesSuccess, PersistentRepr }
-import org.apache.pekko.stream.KillSwitches
-import org.apache.pekko.stream.scaladsl.{ Keep, Sink }
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
-import org.apache.pekko.util.UUIDComparator
+import org.apache.pekko
+import pekko.actor.ActorRef
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
+import pekko.persistence.query.TimeBasedUUID
+import pekko.persistence.{ DeleteMessagesSuccess, PersistentRepr }
+import pekko.stream.KillSwitches
+import pekko.stream.scaladsl.{ Keep, Sink }
+import pekko.stream.testkit.scaladsl.TestSink
+import pekko.util.UUIDComparator
 import org.scalatest.Inside
 
 import java.util.UUID
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdWithControlSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdWithControlSpec.scala
index bdf2c16..0decf22 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdWithControlSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByPersistenceIdWithControlSpec.scala
@@ -13,11 +13,12 @@
 
 package org.apache.pekko.persistence.cassandra.query
 
-import org.apache.pekko.actor.ActorRef
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
-import org.apache.pekko.stream.scaladsl.Keep
-import org.apache.pekko.stream.testkit.TestSubscriber.Probe
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.actor.ActorRef
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
+import pekko.stream.scaladsl.Keep
+import pekko.stream.testkit.TestSubscriber.Probe
+import pekko.stream.testkit.scaladsl.TestSink
 import com.typesafe.config.ConfigFactory
 
 import scala.annotation.tailrec
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagPubsubSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagPubsubSpec.scala
index 616f685..1c6da3f 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagPubsubSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagPubsubSpec.scala
@@ -15,11 +15,12 @@ package org.apache.pekko.persistence.cassandra.query
 
 import java.time.{ LocalDate, ZoneOffset }
 
-import org.apache.pekko.cluster.Cluster
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.persistence.cassandra.journal.JournalSettings
-import org.apache.pekko.persistence.query.{ EventEnvelope, NoOffset }
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.cluster.Cluster
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.persistence.cassandra.journal.JournalSettings
+import pekko.persistence.query.{ EventEnvelope, NoOffset }
+import pekko.stream.testkit.scaladsl.TestSink
 import com.typesafe.config.ConfigFactory
 
 import scala.concurrent.duration._
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagSpec.scala
index da655d7..b3e492e 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagSpec.scala
@@ -18,27 +18,28 @@ import java.time.{ LocalDateTime, ZoneOffset }
 import java.util.Optional
 import java.util.UUID
 
-import org.apache.pekko.actor.{ PoisonPill, Props }
-import org.apache.pekko.event.Logging.Warning
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournalStatements
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, Day }
-import org.apache.pekko.persistence.journal.{ Tagged, WriteEventAdapter }
-import org.apache.pekko.persistence.query.scaladsl.{ CurrentEventsByTagQuery, EventsByTagQuery }
-import org.apache.pekko.persistence.query.{ EventEnvelope, NoOffset, Offset, TimeBasedUUID }
-import org.apache.pekko.persistence.{ PersistentActor, PersistentRepr }
-import org.apache.pekko.serialization.SerializationExtension
-import org.apache.pekko.stream.testkit.TestSubscriber
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.actor.{ PoisonPill, Props }
+import pekko.event.Logging.Warning
+import pekko.persistence.cassandra.journal.CassandraJournalStatements
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, Day }
+import pekko.persistence.journal.{ Tagged, WriteEventAdapter }
+import pekko.persistence.query.scaladsl.{ CurrentEventsByTagQuery, EventsByTagQuery }
+import pekko.persistence.query.{ EventEnvelope, NoOffset, Offset, TimeBasedUUID }
+import pekko.persistence.{ PersistentActor, PersistentRepr }
+import pekko.serialization.SerializationExtension
+import pekko.stream.testkit.TestSubscriber
+import pekko.stream.testkit.scaladsl.TestSink
 import EventsByTagSpec._
-import org.apache.pekko.event.Logging
-import org.apache.pekko.testkit.TestProbe
+import pekko.event.Logging
+import pekko.testkit.TestProbe
 import com.datastax.oss.driver.api.core.CqlIdentifier
 import com.datastax.oss.driver.api.core.uuid.Uuids
 import com.typesafe.config.{ Config, ConfigFactory }
 import org.scalatest.BeforeAndAfterEach
 import scala.concurrent.duration._
 
-import org.apache.pekko.persistence.cassandra.PluginSettings
+import pekko.persistence.cassandra.PluginSettings
 
 object EventsByTagSpec {
   def withProbe[T](probe: TestSubscriber.Probe[Any], f: TestSubscriber.Probe[Any] => T): T = {
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagStageSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagStageSpec.scala
index 8c16c67..e7b5111 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagStageSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/EventsByTagStageSpec.scala
@@ -15,25 +15,26 @@ package org.apache.pekko.persistence.cassandra.query
 
 import java.time.{ LocalDateTime, ZoneOffset }
 
-import org.apache.pekko.NotUsed
-import org.apache.pekko.actor.ActorRef
-import org.apache.pekko.persistence.PersistentRepr
-import org.apache.pekko.persistence.cassandra.journal.TimeBucket
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, Minute }
-import org.apache.pekko.persistence.journal.Tagged
-import org.apache.pekko.persistence.query.scaladsl.EventsByTagQuery
-import org.apache.pekko.persistence.query.{ EventEnvelope, NoOffset }
-import org.apache.pekko.serialization.{ Serialization, SerializationExtension }
-import org.apache.pekko.stream.scaladsl.{ Keep, Source }
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
-import org.apache.pekko.testkit.ImplicitSender
+import org.apache.pekko
+import pekko.NotUsed
+import pekko.actor.ActorRef
+import pekko.persistence.PersistentRepr
+import pekko.persistence.cassandra.journal.TimeBucket
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec, Minute }
+import pekko.persistence.journal.Tagged
+import pekko.persistence.query.scaladsl.EventsByTagQuery
+import pekko.persistence.query.{ EventEnvelope, NoOffset }
+import pekko.serialization.{ Serialization, SerializationExtension }
+import pekko.stream.scaladsl.{ Keep, Source }
+import pekko.stream.testkit.scaladsl.TestSink
+import pekko.testkit.ImplicitSender
 import com.datastax.oss.driver.api.core.uuid.Uuids
 import com.typesafe.config.ConfigFactory
 import org.scalatest.BeforeAndAfterAll
 import scala.annotation.tailrec
 import scala.concurrent.duration._
 
-import org.apache.pekko.persistence.cassandra.PluginSettings
+import pekko.persistence.cassandra.PluginSettings
 
 object EventsByTagStageSpec {
   val fetchSize = 3L
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TagViewSequenceNumberScannerSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TagViewSequenceNumberScannerSpec.scala
index 4ee4483..3e8996f 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TagViewSequenceNumberScannerSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TagViewSequenceNumberScannerSpec.scala
@@ -16,22 +16,23 @@ package org.apache.pekko.persistence.cassandra.query
 import java.time.{ LocalDateTime, ZoneOffset }
 import java.util.UUID
 
-import org.apache.pekko.persistence.PersistentRepr
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal.PersistenceId
-import org.apache.pekko.persistence.cassandra.journal.CassandraJournal.TagPidSequenceNr
-import org.apache.pekko.persistence.cassandra.query.TagViewSequenceNumberScannerSpec.config
-import org.apache.pekko.persistence.cassandra.CassandraLifecycle
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.serialization.Serialization
-import org.apache.pekko.serialization.SerializationExtension
+import org.apache.pekko
+import pekko.persistence.PersistentRepr
+import pekko.persistence.cassandra.journal.CassandraJournal.PersistenceId
+import pekko.persistence.cassandra.journal.CassandraJournal.TagPidSequenceNr
+import pekko.persistence.cassandra.query.TagViewSequenceNumberScannerSpec.config
+import pekko.persistence.cassandra.CassandraLifecycle
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.serialization.Serialization
+import pekko.serialization.SerializationExtension
 import com.datastax.oss.driver.api.core.uuid.Uuids
 import com.typesafe.config.ConfigFactory
 import org.scalatest.BeforeAndAfter
 import org.scalatest.time.{ Seconds, Span }
 import scala.concurrent.duration.Duration
 
-import org.apache.pekko.persistence.cassandra.Hour
-import org.apache.pekko.persistence.cassandra.PluginSettings
+import pekko.persistence.cassandra.Hour
+import pekko.persistence.cassandra.PluginSettings
 
 object TagViewSequenceNumberScannerSpec {
   val bucketSize = Hour
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestActor.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestActor.scala
index a45f039..552bf2d 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestActor.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestActor.scala
@@ -14,11 +14,12 @@
 package org.apache.pekko.persistence.cassandra.query
 
 import scala.collection.immutable
-import org.apache.pekko.actor.Props
-import org.apache.pekko.persistence.PersistentActor
-import org.apache.pekko.actor.ActorRef
-import org.apache.pekko.persistence.DeleteMessagesSuccess
-import org.apache.pekko.persistence.journal.Tagged
+import org.apache.pekko
+import pekko.actor.Props
+import pekko.persistence.PersistentActor
+import pekko.actor.ActorRef
+import pekko.persistence.DeleteMessagesSuccess
+import pekko.persistence.journal.Tagged
 
 object TestActor {
   def props(persistenceId: String, journalId: String = "pekko.persistence.cassandra.journal"): Props =
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestEventAdapter.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestEventAdapter.scala
index 84b47d6..9ac968a 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestEventAdapter.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestEventAdapter.scala
@@ -13,8 +13,9 @@
 
 package org.apache.pekko.persistence.cassandra.query
 
-import org.apache.pekko.actor.ExtendedActorSystem
-import org.apache.pekko.persistence.journal.{ EventAdapter, EventSeq, Tagged }
+import org.apache.pekko
+import pekko.actor.ExtendedActorSystem
+import pekko.persistence.journal.{ EventAdapter, EventSeq, Tagged }
 
 sealed trait TestEvent[T] {
   def value: T
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestTagWriter.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestTagWriter.scala
index 4afbd8e..4cc4b36 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestTagWriter.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/TestTagWriter.scala
@@ -17,15 +17,16 @@ import java.nio.ByteBuffer
 import java.time.{ LocalDateTime, ZoneOffset }
 import java.util.UUID
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.persistence.PersistentRepr
-import org.apache.pekko.persistence.cassandra.BucketSize
-import org.apache.pekko.persistence.cassandra.EventsByTagSettings
-import org.apache.pekko.persistence.cassandra.PluginSettings
-import org.apache.pekko.persistence.cassandra.formatOffset
-import org.apache.pekko.persistence.cassandra.journal._
-import org.apache.pekko.serialization.Serialization
-import org.apache.pekko.serialization.Serializers
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.persistence.PersistentRepr
+import pekko.persistence.cassandra.BucketSize
+import pekko.persistence.cassandra.EventsByTagSettings
+import pekko.persistence.cassandra.PluginSettings
+import pekko.persistence.cassandra.formatOffset
+import pekko.persistence.cassandra.journal._
+import pekko.serialization.Serialization
+import pekko.serialization.Serializers
 import com.datastax.oss.driver.api.core.CqlSession
 import com.datastax.oss.driver.api.core.uuid.Uuids
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/javadsl/CassandraReadJournalSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/javadsl/CassandraReadJournalSpec.scala
index 45c3942..310e651 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/javadsl/CassandraReadJournalSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/javadsl/CassandraReadJournalSpec.scala
@@ -13,11 +13,12 @@
 
 package org.apache.pekko.persistence.cassandra.query.javadsl
 
-import org.apache.pekko.persistence.cassandra.query.{ javadsl, scaladsl, TestActor }
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
-import org.apache.pekko.persistence.journal.{ Tagged, WriteEventAdapter }
-import org.apache.pekko.persistence.query.{ Offset, PersistenceQuery }
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.persistence.cassandra.query.{ javadsl, scaladsl, TestActor }
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
+import pekko.persistence.journal.{ Tagged, WriteEventAdapter }
+import pekko.persistence.query.{ Offset, PersistenceQuery }
+import pekko.stream.testkit.scaladsl.TestSink
 import com.typesafe.config.ConfigFactory
 
 import scala.concurrent.duration._
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/scaladsl/CassandraReadJournalSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/scaladsl/CassandraReadJournalSpec.scala
index 9b086d3..c034819 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/scaladsl/CassandraReadJournalSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/query/scaladsl/CassandraReadJournalSpec.scala
@@ -13,12 +13,13 @@
 
 package org.apache.pekko.persistence.cassandra.query.scaladsl
 
-import org.apache.pekko.persistence.cassandra.query.TestActor
-import org.apache.pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
-import org.apache.pekko.persistence.journal.{ Tagged, WriteEventAdapter }
-import org.apache.pekko.persistence.query.NoOffset
-import org.apache.pekko.stream.connectors.cassandra.CassandraMetricsRegistry
-import org.apache.pekko.stream.testkit.scaladsl.TestSink
+import org.apache.pekko
+import pekko.persistence.cassandra.query.TestActor
+import pekko.persistence.cassandra.{ CassandraLifecycle, CassandraSpec }
+import pekko.persistence.journal.{ Tagged, WriteEventAdapter }
+import pekko.persistence.query.NoOffset
+import pekko.stream.connectors.cassandra.CassandraMetricsRegistry
+import pekko.stream.testkit.scaladsl.TestSink
 import com.typesafe.config.ConfigFactory
 
 import scala.concurrent.duration._
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/DeleteTagViewForPersistenceIdSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/DeleteTagViewForPersistenceIdSpec.scala
index 2b569c9..0e6a5d8 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/DeleteTagViewForPersistenceIdSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/DeleteTagViewForPersistenceIdSpec.scala
@@ -13,10 +13,11 @@
 
 package org.apache.pekko.persistence.cassandra.reconciler
 
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.persistence.cassandra.TestTaggingActor
-import org.apache.pekko.testkit.TestProbe
-import org.apache.pekko.persistence.RecoveryCompleted
+import org.apache.pekko
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.persistence.cassandra.TestTaggingActor
+import pekko.testkit.TestProbe
+import pekko.persistence.RecoveryCompleted
 
 /**
  * These tests depend on the output of each other, can't be run separately
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/RebuildAllPersisetceIdsSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/RebuildAllPersisetceIdsSpec.scala
index 5f8803d..610bdb2 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/RebuildAllPersisetceIdsSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/RebuildAllPersisetceIdsSpec.scala
@@ -13,8 +13,9 @@
 
 package org.apache.pekko.persistence.cassandra.reconciler
 
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.stream.scaladsl.Sink
+import org.apache.pekko
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.stream.scaladsl.Sink
 import org.scalatest.concurrent.Eventually
 
 class RebuildAllPersisetceIdsSpec extends CassandraSpec with Eventually {
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/TagQuerySpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/TagQuerySpec.scala
index aac6dfd..94fff81 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/TagQuerySpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/TagQuerySpec.scala
@@ -13,8 +13,9 @@
 
 package org.apache.pekko.persistence.cassandra.reconciler
 
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.stream.scaladsl.Sink
+import org.apache.pekko
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.stream.scaladsl.Sink
 import org.scalatest.concurrent.Eventually
 
 class TagQuerySpec extends CassandraSpec with Eventually {
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/TruncateAllSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/TruncateAllSpec.scala
index ca6476d..a110bbd 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/TruncateAllSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/reconciler/TruncateAllSpec.scala
@@ -13,9 +13,10 @@
 
 package org.apache.pekko.persistence.cassandra.reconciler
 
-import org.apache.pekko.persistence.cassandra.CassandraSpec
+import org.apache.pekko
+import pekko.persistence.cassandra.CassandraSpec
 import org.scalatest.concurrent.Eventually
-import org.apache.pekko.persistence.cassandra.TestTaggingActor
+import pekko.persistence.cassandra.TestTaggingActor
 
 class TruncateAllSpec extends CassandraSpec with Eventually {
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/sharding/ClusterShardingQuickTerminationSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/sharding/ClusterShardingQuickTerminationSpec.scala
index 966078b..b3923c4 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/sharding/ClusterShardingQuickTerminationSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/sharding/ClusterShardingQuickTerminationSpec.scala
@@ -13,12 +13,13 @@
 
 package org.apache.pekko.persistence.cassandra.sharding
 
-import org.apache.pekko.actor.{ ActorLogging, ActorRef, Props, ReceiveTimeout }
-import org.apache.pekko.cluster.sharding.{ ClusterSharding, ClusterShardingSettings, ShardRegion }
-import org.apache.pekko.cluster.{ Cluster, MemberStatus }
-import org.apache.pekko.persistence.PersistentActor
-import org.apache.pekko.persistence.cassandra.CassandraSpec
-import org.apache.pekko.testkit.TestProbe
+import org.apache.pekko
+import pekko.actor.{ ActorLogging, ActorRef, Props, ReceiveTimeout }
+import pekko.cluster.sharding.{ ClusterSharding, ClusterShardingSettings, ShardRegion }
+import pekko.cluster.{ Cluster, MemberStatus }
+import pekko.persistence.PersistentActor
+import pekko.persistence.cassandra.CassandraSpec
+import pekko.testkit.TestProbe
 
 import scala.concurrent.duration._
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStoreSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStoreSpec.scala
index 86606be..0efe04b 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStoreSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/snapshot/CassandraSnapshotStoreSpec.scala
@@ -17,12 +17,13 @@ import java.lang.{ Long => JLong }
 import java.lang.{ Integer => JInteger }
 import java.nio.ByteBuffer
 
-import org.apache.pekko.persistence.SnapshotProtocol._
-import org.apache.pekko.persistence._
-import org.apache.pekko.persistence.cassandra.CassandraLifecycle
-import org.apache.pekko.persistence.snapshot.SnapshotStoreSpec
-import org.apache.pekko.stream.connectors.cassandra.CassandraMetricsRegistry
-import org.apache.pekko.testkit.TestProbe
+import org.apache.pekko
+import pekko.persistence.SnapshotProtocol._
+import pekko.persistence._
+import pekko.persistence.cassandra.CassandraLifecycle
+import pekko.persistence.snapshot.SnapshotStoreSpec
+import pekko.stream.connectors.cassandra.CassandraMetricsRegistry
+import pekko.testkit.TestProbe
 import com.datastax.oss.driver.api.core.cql.SimpleStatement
 import com.typesafe.config.ConfigFactory
 
diff --git a/core/src/test/scala/org/apache/pekko/persistence/cassandra/testkit/CassandraLauncherSpec.scala b/core/src/test/scala/org/apache/pekko/persistence/cassandra/testkit/CassandraLauncherSpec.scala
index 4069ec7..ff6fac0 100644
--- a/core/src/test/scala/org/apache/pekko/persistence/cassandra/testkit/CassandraLauncherSpec.scala
+++ b/core/src/test/scala/org/apache/pekko/persistence/cassandra/testkit/CassandraLauncherSpec.scala
@@ -16,8 +16,9 @@ package org.apache.pekko.persistence.cassandra.testkit
 import java.io.File
 import java.net.InetSocketAddress
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.testkit.TestKit
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.testkit.TestKit
 import com.datastax.oss.driver.api.core.CqlSession
 import org.scalatest.wordspec.AnyWordSpecLike
 import org.scalatest.matchers.should.Matchers
diff --git a/docs/src/test/scala/doc/cleanup/CleanupDocExample.scala b/docs/src/test/scala/doc/cleanup/CleanupDocExample.scala
index 9e776f5..448d6d8 100644
--- a/docs/src/test/scala/doc/cleanup/CleanupDocExample.scala
+++ b/docs/src/test/scala/doc/cleanup/CleanupDocExample.scala
@@ -9,10 +9,11 @@
 
 package doc.cleanup
 
-import org.apache.pekko.actor.ActorSystem
-import org.apache.pekko.persistence.cassandra.cleanup.Cleanup
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.persistence.query.PersistenceQuery
+import org.apache.pekko
+import pekko.actor.ActorSystem
+import pekko.persistence.cassandra.cleanup.Cleanup
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.persistence.query.PersistenceQuery
 
 import java.time.ZonedDateTime
 import java.time.temporal.ChronoUnit
diff --git a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ConfigurablePersistentActor.scala b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ConfigurablePersistentActor.scala
index 627f78f..68acab9 100644
--- a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ConfigurablePersistentActor.scala
+++ b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ConfigurablePersistentActor.scala
@@ -9,12 +9,13 @@
 
 package org.apache.pekko.persistence.cassandra.example
 
-import org.apache.pekko.actor.typed.scaladsl.Behaviors
-import org.apache.pekko.actor.typed.{ ActorRef, ActorSystem, Behavior }
-import org.apache.pekko.cluster.sharding.typed.ShardingEnvelope
-import org.apache.pekko.cluster.sharding.typed.scaladsl.{ ClusterSharding, Entity, EntityTypeKey }
-import org.apache.pekko.persistence.typed.PersistenceId
-import org.apache.pekko.persistence.typed.scaladsl.{ Effect, EventSourcedBehavior }
+import org.apache.pekko
+import pekko.actor.typed.scaladsl.Behaviors
+import pekko.actor.typed.{ ActorRef, ActorSystem, Behavior }
+import pekko.cluster.sharding.typed.ShardingEnvelope
+import pekko.cluster.sharding.typed.scaladsl.{ ClusterSharding, Entity, EntityTypeKey }
+import pekko.persistence.typed.PersistenceId
+import pekko.persistence.typed.scaladsl.{ Effect, EventSourcedBehavior }
 
 object ConfigurablePersistentActor {
 
diff --git a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/EventProcessorStream.scala b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/EventProcessorStream.scala
index 35d2359..2673a99 100644
--- a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/EventProcessorStream.scala
+++ b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/EventProcessorStream.scala
@@ -9,17 +9,18 @@
 
 package org.apache.pekko.persistence.cassandra.example
 
-import org.apache.pekko.{ Done, NotUsed }
-import org.apache.pekko.actor.typed.ActorSystem
-import org.apache.pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
-import org.apache.pekko.persistence.query.{ Offset, PersistenceQuery, TimeBasedUUID }
-import org.apache.pekko.persistence.typed.PersistenceId
-import org.apache.pekko.stream.SharedKillSwitch
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSessionRegistry
-import org.apache.pekko.stream.scaladsl.{ RestartSource, Sink, Source }
+import org.apache.pekko
+import pekko.{ Done, NotUsed }
+import pekko.actor.typed.ActorSystem
+import pekko.persistence.cassandra.query.scaladsl.CassandraReadJournal
+import pekko.persistence.query.{ Offset, PersistenceQuery, TimeBasedUUID }
+import pekko.persistence.typed.PersistenceId
+import pekko.stream.SharedKillSwitch
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSessionRegistry
+import pekko.stream.scaladsl.{ RestartSource, Sink, Source }
 import com.datastax.oss.driver.api.core.cql.{ PreparedStatement, Row }
 import org.slf4j.{ Logger, LoggerFactory }
-import org.apache.pekko.actor.typed.scaladsl.LoggerOps
+import pekko.actor.typed.scaladsl.LoggerOps
 import org.HdrHistogram.Histogram
 
 import scala.concurrent.{ ExecutionContext, Future }
diff --git a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/LoadGenerator.scala b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/LoadGenerator.scala
index c07e321..855dedb 100644
--- a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/LoadGenerator.scala
+++ b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/LoadGenerator.scala
@@ -9,14 +9,15 @@
 
 package org.apache.pekko.persistence.cassandra.example
 
-import org.apache.pekko.actor.typed.{ ActorRef, Behavior }
-import org.apache.pekko.actor.typed.scaladsl.Behaviors
-import org.apache.pekko.cluster.sharding.typed.ShardingEnvelope
+import org.apache.pekko
+import pekko.actor.typed.{ ActorRef, Behavior }
+import pekko.actor.typed.scaladsl.Behaviors
+import pekko.cluster.sharding.typed.ShardingEnvelope
+import pekko.util.JavaDurationConverters._
 import com.typesafe.config.Config
 
 import scala.concurrent.duration.FiniteDuration
 import scala.util.Random
-import org.apache.pekko.util.JavaDurationConverters._
 
 object LoadGenerator {
 
diff --git a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/Main.scala b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/Main.scala
index 2447543..8af19d3 100644
--- a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/Main.scala
+++ b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/Main.scala
@@ -9,13 +9,14 @@
 
 package org.apache.pekko.persistence.cassandra.example
 
-import org.apache.pekko.actor.typed.ActorSystem
-import org.apache.pekko.actor.typed.scaladsl.{ Behaviors, LoggerOps }
-import org.apache.pekko.cluster.typed.{ Cluster, SelfUp, Subscribe }
-import org.apache.pekko.management.cluster.bootstrap.ClusterBootstrap
-import org.apache.pekko.management.scaladsl.PekkoManagement
-import org.apache.pekko.persistence.cassandra.example.LoadGenerator.Start
-import org.apache.pekko.stream.connectors.cassandra.scaladsl.CassandraSessionRegistry
+import org.apache.pekko
+import pekko.actor.typed.ActorSystem
+import pekko.actor.typed.scaladsl.{ Behaviors, LoggerOps }
+import pekko.cluster.typed.{ Cluster, SelfUp, Subscribe }
+import pekko.management.cluster.bootstrap.ClusterBootstrap
+import pekko.management.scaladsl.PekkoManagement
+import pekko.persistence.cassandra.example.LoadGenerator.Start
+import pekko.stream.connectors.cassandra.scaladsl.CassandraSessionRegistry
 
 import scala.concurrent.Await
 import scala.concurrent.duration._
diff --git a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ReadSide.scala b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ReadSide.scala
index cb57347..e6e6a0b 100644
--- a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ReadSide.scala
+++ b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ReadSide.scala
@@ -9,15 +9,16 @@
 
 package org.apache.pekko.persistence.cassandra.example
 
-import org.apache.pekko.actor.typed.pubsub.Topic
-import org.apache.pekko.actor.typed.scaladsl.Behaviors
-import org.apache.pekko.actor.typed.{ ActorRef, ActorSystem, Behavior, PostStop }
-import org.apache.pekko.cluster.sharding.typed.{ ClusterShardingSettings, ShardedDaemonProcessSettings }
-import org.apache.pekko.cluster.sharding.typed.scaladsl.ShardedDaemonProcess
-import org.apache.pekko.stream.{ KillSwitches, SharedKillSwitch }
+import org.apache.pekko
+import pekko.actor.typed.pubsub.Topic
+import pekko.actor.typed.scaladsl.Behaviors
+import pekko.actor.typed.{ ActorRef, ActorSystem, Behavior, PostStop }
+import pekko.cluster.sharding.typed.{ ClusterShardingSettings, ShardedDaemonProcessSettings }
+import pekko.cluster.sharding.typed.scaladsl.ShardedDaemonProcess
+import pekko.stream.{ KillSwitches, SharedKillSwitch }
 import com.typesafe.config.Config
 import org.HdrHistogram.Histogram
-import org.apache.pekko.actor.typed.scaladsl.LoggerOps
+import pekko.actor.typed.scaladsl.LoggerOps
 import scala.concurrent.duration._
 
 object ReadSide {
diff --git a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ReadSideTopic.scala b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ReadSideTopic.scala
index bbbb49a..74f5180 100644
--- a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ReadSideTopic.scala
+++ b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/ReadSideTopic.scala
@@ -9,9 +9,10 @@
 
 package org.apache.pekko.persistence.cassandra.example
 
-import org.apache.pekko.actor.typed.pubsub.Topic
-import org.apache.pekko.actor.typed.scaladsl.ActorContext
-import org.apache.pekko.actor.typed.ActorRef
+import org.apache.pekko
+import pekko.actor.typed.pubsub.Topic
+import pekko.actor.typed.scaladsl.ActorContext
+import pekko.actor.typed.ActorRef
 
 object ReadSideTopic {
 
diff --git a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/Reporter.scala b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/Reporter.scala
index 449bd69..0e74a8c 100644
--- a/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/Reporter.scala
+++ b/example/src/main/scala/org/apache/pekko/persistence/cassandra/example/Reporter.scala
@@ -9,11 +9,12 @@
 
 package org.apache.pekko.persistence.cassandra.example
 
-import org.apache.pekko.actor.typed.{ ActorRef, Behavior }
-import org.apache.pekko.actor.typed.pubsub.Topic
-import org.apache.pekko.actor.typed.scaladsl.Behaviors
+import org.apache.pekko
+import pekko.actor.typed.{ ActorRef, Behavior }
+import pekko.actor.typed.pubsub.Topic
+import pekko.actor.typed.scaladsl.Behaviors
 import ReadSideTopic.ReadSideMetrics
-import org.apache.pekko.actor.typed.scaladsl.LoggerOps
+import pekko.actor.typed.scaladsl.LoggerOps
 
 object Reporter {
   def apply(topic: ActorRef[Topic.Command[ReadSideTopic.ReadSideMetrics]]): Behavior[ReadSideMetrics] =


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