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

[incubator-pekko] branch main updated: use `pekko:` in urls and fix other branding issues (#184)

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

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


The following commit(s) were added to refs/heads/main by this push:
     new 7e653454a9 use `pekko:` in urls and fix other branding issues (#184)
7e653454a9 is described below

commit 7e653454a9613c815c720d65859895e7abfee0d4
Author: PJ Fanning <pj...@users.noreply.github.com>
AuthorDate: Wed Feb 22 12:48:15 2023 +0100

    use `pekko:` in urls and fix other branding issues (#184)
    
    * use pekko: in urls and fix other branding issues
    
    * update comments
    
    * fix artery test
    
    * test changes
    
    * scalafmt
    
    * try to fix some tests and fixing more akka refs
    
    * more akka refs
    
    * more changes
    
    * more akka refs
    
    * Update LeaseMajoritySpec.scala
    
    * Update docs/src/main/paradox/testing.md
    
    Co-authored-by: Johannes Rudolph <jo...@gmail.com>
    
    * Update docs/src/main/paradox/project/migration-guides.md
    
    Co-authored-by: Johannes Rudolph <jo...@gmail.com>
    
    * Update actor/src/main/scala/org/apache/pekko/serialization/Serialization.scala
    
    Co-authored-by: Johannes Rudolph <jo...@gmail.com>
    
    * Update scripts/release-train-issue-template.md
    
    Co-authored-by: Johannes Rudolph <jo...@gmail.com>
    
    * revert link-validation change
    
    * Update JacksonModule.scala
    
    * revert key name changes to fix 2 tests
    
    * fix one test
    
    * more test trouble
    
    * more test issues
    
    * fix hashing test
    
    * Update RouterTest.java
    
    * update code comment
    
    ---------
    
    Co-authored-by: Johannes Rudolph <jo...@gmail.com>
---
 .../testkit/typed/internal/ActorSystemStub.scala   |   2 +-
 .../actor/testkit/typed/scaladsl/TestInbox.scala   |   2 +-
 .../typed/scaladsl/BehaviorTestKitSpec.scala       |   2 +-
 .../typed/scaladsl/LoggingEventFilterSpec.scala    |   4 +-
 .../java/org/apache/pekko/actor/AddressTest.java   |   2 +-
 .../test/java/org/apache/pekko/actor/JavaAPI.java  |   2 +-
 .../org/apache/pekko/actor/ActorPathSpec.scala     |  74 ++++++-------
 .../apache/pekko/actor/ActorSelectionSpec.scala    |  19 ++--
 .../org/apache/pekko/actor/ActorSystemSpec.scala   |   4 +-
 .../pekko/actor/LocalActorRefProviderSpec.scala    |   2 +-
 .../apache/pekko/actor/RelativeActorPathSpec.scala |   2 +-
 .../jdocs/org/apache/pekko/typed/RouterTest.java   |  14 ++-
 .../pekko/actor/typed/ActorRefResolverSpec.scala   |   4 +-
 .../LocalActorRefProviderLogMessagesSpec.scala     |   2 +-
 .../actor/typed/internal/ActorSystemSpec.scala     |   2 +-
 .../actor/typed/internal/ActorContextImpl.scala    |   2 +-
 .../internal/adapter/ActorSystemAdapter.scala      |   2 +-
 .../scala/org/apache/pekko/actor/ActorRef.scala    |   4 +-
 .../org/apache/pekko/actor/ActorRefProvider.scala  |   2 +-
 .../scala/org/apache/pekko/actor/ActorSystem.scala |   2 +-
 .../scala/org/apache/pekko/actor/Address.scala     |   4 +-
 .../scala/org/apache/pekko/event/Logging.scala     |   4 +-
 .../apache/pekko/io/InetAddressDnsResolver.scala   |   2 +-
 .../pekko/io/dns/internal/AsyncDnsManager.scala    |   2 +-
 .../pekko/serialization/AsyncSerializer.scala      |   2 +-
 .../pekko/cluster/ddata/ORSetMergeBenchmark.scala  |   2 +-
 .../cluster/ddata/VersionVectorBenchmark.scala     |   2 +-
 .../remote/artery/LiteralEncodingBenchmark.scala   |   2 +-
 .../metrics/ClusterMetricsRoutingSpec.scala        |   8 +-
 .../apache/pekko/cluster/metrics/MetricSpec.scala  |  32 +++---
 .../apache/pekko/cluster/metrics/TestUtil.scala    |   2 +-
 .../cluster/metrics/WeightedRouteesSpec.scala      |   4 +-
 .../metrics/protobuf/MessageSerializerSpec.scala   |  12 +--
 .../ExternalShardAllocationCompileOnlyTest.java    |   2 +-
 .../ExternalShardAllocationCompileOnlySpec.scala   |   2 +-
 ...eprecatedLeastShardAllocationStrategySpec.scala |   2 +-
 .../LeastShardAllocationStrategySpec.scala         |   6 +-
 .../pekko/cluster/sharding/ProxyShardingSpec.scala |   4 +-
 ...ememberEntitiesShardIdExtractorChangeSpec.scala |   4 +-
 .../ClusterShardingMessageSerializerSpec.scala     |   6 +-
 cluster-tools/src/main/resources/reference.conf    |   2 +-
 .../pekko/cluster/client/ClusterClient.scala       |   2 +-
 .../pekko/cluster/client/ClusterClientSpec.scala   |   4 +-
 .../pekko/cluster/client/ClusterClientTest.java    |   4 +-
 .../ClusterClientMessageSerializerSpec.scala       |   6 +-
 .../DistributedPubSubMessageSerializerSpec.scala   |   6 +-
 .../singleton/ClusterSingletonLeaseSpec.scala      |   2 +-
 .../cluster/typed/BasicClusterExampleTest.java     |   4 +-
 .../cluster/typed/BasicClusterExampleSpec.scala    |   9 +-
 .../pekko/cluster/typed/ClusterApiSpec.scala       |   2 +-
 .../cluster/typed/RemoteDeployNotAllowedSpec.scala |   2 +-
 cluster/src/main/resources/reference.conf          |   2 +-
 .../org/apache/pekko/cluster/ClusterJmx.scala      |  38 +++----
 .../scala/org/apache/pekko/cluster/MBeanSpec.scala |   2 +-
 .../cluster/RemoteFeaturesWithClusterSpec.scala    |   2 +-
 .../org/apache/pekko/cluster/StressSpec.scala      |   2 +-
 .../pekko/cluster/ClusterJavaCompileTest.java      |   2 +-
 .../cluster/ClusterDomainEventPublisherSpec.scala  |   4 +-
 .../pekko/cluster/ClusterDomainEventSpec.scala     |  50 ++++-----
 .../pekko/cluster/ClusterHeartbeatSenderSpec.scala |   2 +-
 .../cluster/ClusterHeartbeatSenderStateSpec.scala  |  12 +--
 .../org/apache/pekko/cluster/ClusterSpec.scala     |  16 +--
 .../pekko/cluster/CrossDcHeartbeatSenderSpec.scala |   2 +-
 .../org/apache/pekko/cluster/GossipSpec.scala      |  22 ++--
 .../pekko/cluster/GossipTargetSelectorSpec.scala   |  16 +--
 .../pekko/cluster/HeartbeatNodeRingPerfSpec.scala  |   2 +-
 .../pekko/cluster/HeartbeatNodeRingSpec.scala      |  12 +--
 .../cluster/JoinConfigCompatCheckerSpec.scala      |   4 +-
 .../apache/pekko/cluster/MemberOrderingSpec.scala  |  72 ++++++-------
 .../apache/pekko/cluster/MembershipStateSpec.scala |  30 +++---
 .../pekko/cluster/ReachabilityPerfSpec.scala       |   4 +-
 .../apache/pekko/cluster/ReachabilitySpec.scala    |  10 +-
 .../protobuf/ClusterMessageSerializerSpec.scala    |  20 ++--
 .../apache/pekko/cluster/sbr/TestAddresses.scala   |   4 +-
 .../pekko/cluster/testkit/AutoDownSpec.scala       |   4 +-
 .../pekko/cluster/ddata/DataEnvelopeSpec.scala     |   2 +-
 .../ddata/DeltaPropagationSelectorSpec.scala       |   4 +-
 .../apache/pekko/cluster/ddata/GCounterSpec.scala  |   2 +-
 .../apache/pekko/cluster/ddata/LWWMapSpec.scala    |   2 +-
 .../pekko/cluster/ddata/LWWRegisterSpec.scala      |   2 +-
 .../apache/pekko/cluster/ddata/LotsOfDataBot.scala |   4 +-
 .../org/apache/pekko/cluster/ddata/ORMapSpec.scala |   2 +-
 .../pekko/cluster/ddata/ORMultiMapSpec.scala       |   2 +-
 .../org/apache/pekko/cluster/ddata/ORSetSpec.scala |   4 +-
 .../pekko/cluster/ddata/PNCounterMapSpec.scala     |   2 +-
 .../apache/pekko/cluster/ddata/PNCounterSpec.scala |   2 +-
 .../pekko/cluster/ddata/PruningStateSpec.scala     |   2 +-
 .../pekko/cluster/ddata/VersionVectorSpec.scala    |   2 +-
 .../pekko/cluster/ddata/WriteAggregatorSpec.scala  |   4 +-
 .../protobuf/ReplicatedDataSerializerSpec.scala    |   2 +-
 .../protobuf/ReplicatorMessageSerializerSpec.scala |   2 +-
 docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java |   2 +-
 .../jdocs/remoting/RemoteDeploymentDocTest.java    |   8 +-
 .../test/java/jdocs/testkit/TestKitDocTest.java    |   2 +-
 .../pekko/remote/testkit/MultiNodeSpec.scala       |   2 +-
 .../persistence/serialization/SerializerSpec.scala |   2 +-
 .../typed/internal/JournalFailureException.scala   |   2 +-
 .../internal/DurableStateStoreException.scala      |   2 +-
 persistence/src/main/resources/reference.conf      |   3 -
 project/Doc.scala                                  |   2 +-
 project/MultiNode.scala                            |   4 +-
 project/Paradox.scala                              |   4 +-
 project/PekkoDisciplinePlugin.scala                |   2 +-
 .../pekko/remote/testconductor/BarrierSpec.scala   | 114 ++++++++++-----------
 .../remote/testconductor/ControllerSpec.scala      |   4 +-
 remote/src/main/resources/reference.conf           |   6 +-
 .../pekko/remote/RemoteActorRefProvider.scala      |  10 +-
 .../pekko/remote/artery/ArteryTransport.scala      |   2 +-
 .../remote/transport/PekkoProtocolTransport.scala  |  10 +-
 remote/src/test/resources/Makefile                 |   2 +-
 .../org/apache/pekko/remote/DaemonicSpec.scala     |   2 +-
 .../remote/RemoteConsistentHashingRouterSpec.scala |  10 +-
 .../apache/pekko/remote/RemoteDeployerSpec.scala   |   6 +-
 .../apache/pekko/remote/RemoteFeaturesSpec.scala   |   6 +-
 .../org/apache/pekko/remote/RemoteRouterSpec.scala |   8 +-
 .../remote/TransientSerializationErrorSpec.scala   |   4 +-
 .../remote/artery/BindCanonicalAddressSpec.scala   |   8 +-
 .../pekko/remote/artery/DuplicateFlushSpec.scala   |   4 +-
 .../remote/artery/DuplicateHandshakeSpec.scala     |   4 +-
 .../pekko/remote/artery/EnvelopeBufferSpec.scala   |  20 ++--
 .../pekko/remote/artery/HandshakeFailureSpec.scala |   2 +-
 .../pekko/remote/artery/HandshakeRetrySpec.scala   |   2 +-
 .../remote/artery/InboundControlJunctionSpec.scala |   4 +-
 .../pekko/remote/artery/InboundHandshakeSpec.scala |   4 +-
 .../pekko/remote/artery/LateConnectSpec.scala      |   2 +-
 .../artery/OutboundControlJunctionSpec.scala       |   4 +-
 .../remote/artery/OutboundHandshakeSpec.scala      |   4 +-
 .../remote/artery/RemoteActorRefProviderSpec.scala |  12 +--
 .../remote/artery/RemoteActorSelectionSpec.scala   |   4 +-
 .../pekko/remote/artery/RemoteConnectionSpec.scala |   6 +-
 .../pekko/remote/artery/RemoteDeathWatchSpec.scala |   8 +-
 .../pekko/remote/artery/RemoteDeployerSpec.scala   |   6 +-
 .../pekko/remote/artery/RemoteDeploymentSpec.scala |  10 +-
 .../artery/RemoteMessageSerializationSpec.scala    |   2 +-
 .../pekko/remote/artery/RemoteRouterSpec.scala     |  52 +++++-----
 .../remote/artery/SystemMessageAckerSpec.scala     |   6 +-
 .../HandshakeShouldDropCompressionTableSpec.scala  |   4 +-
 .../pekko/remote/artery/tcp/TlsTcpSpec.scala       |   2 +-
 .../remote/classic/RemoteDeathWatchSpec.scala      |   6 +-
 .../classic/RemoteDeploymentAllowListSpec.scala    |   8 +-
 .../apache/pekko/remote/classic/RemotingSpec.scala |  54 +++++-----
 .../classic/transport/PekkoProtocolSpec.scala      |   4 +-
 .../transport/PekkoProtocolStressTest.scala        |   2 +-
 .../SystemMessageDeliveryStressTest.scala          |   2 +-
 .../transport/ThrottlerTransportAdapterSpec.scala  |   8 +-
 .../transport/netty/NettyTransportSpec.scala       |   8 +-
 ...reateSerializerAllowJavaSerializationSpec.scala |   8 +-
 .../serialization/MiscMessageSerializerSpec.scala  |   8 +-
 .../SerializationTransportInformationSpec.scala    |   4 +-
 scripts/release-train-issue-template.md            |   2 +-
 .../jackson/JacksonSerializerSpec.scala            |   4 +-
 .../apache/pekko/event/slf4j/Slf4jLoggerSpec.scala |  18 ++--
 .../apache/pekko/stream/scaladsl/FlowAskSpec.scala |   4 +-
 .../apache/pekko/stream/scaladsl/FlowLogSpec.scala |   2 +-
 .../stream/scaladsl/FlowLogWithMarkerSpec.scala    |   2 +-
 .../pekko/stream/scaladsl/FlowWatchSpec.scala      |   2 +-
 .../test/scala/docs/scaladsl/ActorFlowSpec.scala   |   2 +-
 157 files changed, 606 insertions(+), 601 deletions(-)

diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ActorSystemStub.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ActorSystemStub.scala
index 3302d8368c..f3bace528d 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ActorSystemStub.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ActorSystemStub.scala
@@ -51,7 +51,7 @@ import pekko.annotation.InternalApi
     with ActorRefImpl[Nothing]
     with InternalRecipientRef[Nothing] {
 
-  private val rootPath: ActorPath = classic.RootActorPath(classic.Address("akka", name))
+  private val rootPath: ActorPath = classic.RootActorPath(classic.Address("pekko", name))
 
   override val path: classic.ActorPath = rootPath / "user"
 
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestInbox.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestInbox.scala
index 6be8c2df69..0da00f56a0 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestInbox.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestInbox.scala
@@ -30,7 +30,7 @@ object TestInbox {
     new TestInboxImpl((address / name).withUid(uid))
   }
 
-  private[pekko] val address = RootActorPath(Address("akka.actor.typed.inbox", "anonymous"))
+  private[pekko] val address = RootActorPath(Address("pekko.actor.typed.inbox", "anonymous"))
 }
 
 /**
diff --git a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKitSpec.scala b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKitSpec.scala
index fec7920379..70c051352a 100644
--- a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKitSpec.scala
+++ b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKitSpec.scala
@@ -179,7 +179,7 @@ class BehaviorTestKitSpec extends AnyWordSpec with Matchers with LogCapturing {
 
   private val props = Props.empty.withDispatcherFromConfig("cat")
 
-  private val testKitAddress = Address("akka", "StubbedActorContext")
+  private val testKitAddress = Address("pekko", "StubbedActorContext")
 
   "BehaviorTestKit" must {
 
diff --git a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingEventFilterSpec.scala b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingEventFilterSpec.scala
index ae9f734f10..5d1a93f2fd 100644
--- a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingEventFilterSpec.scala
+++ b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingEventFilterSpec.scala
@@ -134,12 +134,12 @@ class LoggingTestKitSpec extends ScalaTestWithActorTestKit with AnyWordSpecLike
       LoggingTestKit.warn("this is another warning").matches(warningWithCause(new AnError)) should ===(false)
     }
     "filter warning with matching source" in {
-      val source = "akka://Sys/user/foo"
+      val source = "pekko://Sys/user/foo"
       LoggingTestKit.empty.withLogLevel(Level.WARN).withSource(source).matches(warningWithSource(source)) should ===(
         true)
       LoggingTestKit.empty
         .withLogLevel(Level.WARN)
-        .withSource("akka://Sys/user/bar")
+        .withSource("pekko://Sys/user/bar")
         .matches(warningWithSource(source)) should ===(false)
     }
 
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/AddressTest.java b/actor-tests/src/test/java/org/apache/pekko/actor/AddressTest.java
index 22911e0e20..7d8043d4fc 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/AddressTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/AddressTest.java
@@ -24,7 +24,7 @@ public class AddressTest extends JUnitSuite {
 
   @Test
   public void portAddressAccessible() {
-    Address address = new Address("akka", "MySystem", "localhost", 2525);
+    Address address = new Address("pekko", "MySystem", "localhost", 2525);
     assertEquals(Optional.of(2525), address.getPort());
     assertEquals(Optional.of("localhost"), address.getHost());
   }
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPI.java b/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPI.java
index 2889c5fb0a..4fcfcc70a0 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPI.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPI.java
@@ -60,7 +60,7 @@ public class JavaAPI extends JUnitSuite {
     final NoRouter nr = NoRouter.getInstance();
     final FromConfig fc = FromConfig.getInstance();
 
-    final ActorPath p = ActorPaths.fromString("akka://Sys@localhost:1234/user/abc");
+    final ActorPath p = ActorPaths.fromString("pekko://Sys@localhost:1234/user/abc");
   }
 
   @Test
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorPathSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorPathSpec.scala
index 5e5a82f442..ce2db777d1 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorPathSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorPathSpec.scala
@@ -23,12 +23,12 @@ class ActorPathSpec extends AnyWordSpec with Matchers {
   "An ActorPath" must {
 
     "support parsing its String rep" in {
-      val path = RootActorPath(Address("akka", "mysys")) / "user"
+      val path = RootActorPath(Address("pekko", "mysys")) / "user"
       ActorPath.fromString(path.toString) should ===(path)
     }
 
     "support parsing remote paths" in {
-      val remote = "akka://my_sys@host:1234/some/ref"
+      val remote = "pekko://my_sys@host:1234/some/ref"
       ActorPath.fromString(remote).toString should ===(remote)
     }
 
@@ -41,20 +41,20 @@ class ActorPathSpec extends AnyWordSpec with Matchers {
     }
 
     "create correct toString" in {
-      val a = Address("akka", "mysys")
-      RootActorPath(a).toString should ===("akka://mysys/")
-      (RootActorPath(a) / "user").toString should ===("akka://mysys/user")
-      (RootActorPath(a) / "user" / "foo").toString should ===("akka://mysys/user/foo")
-      (RootActorPath(a) / "user" / "foo" / "bar").toString should ===("akka://mysys/user/foo/bar")
+      val a = Address("pekko", "mysys")
+      RootActorPath(a).toString should ===("pekko://mysys/")
+      (RootActorPath(a) / "user").toString should ===("pekko://mysys/user")
+      (RootActorPath(a) / "user" / "foo").toString should ===("pekko://mysys/user/foo")
+      (RootActorPath(a) / "user" / "foo" / "bar").toString should ===("pekko://mysys/user/foo/bar")
     }
 
     "have correct path elements" in {
-      (RootActorPath(Address("akka", "mysys")) / "user" / "foo" / "bar").elements.toSeq should ===(
+      (RootActorPath(Address("pekko", "mysys")) / "user" / "foo" / "bar").elements.toSeq should ===(
         Seq("user", "foo", "bar"))
     }
 
     "create correct toStringWithoutAddress" in {
-      val a = Address("akka", "mysys")
+      val a = Address("pekko", "mysys")
       RootActorPath(a).toStringWithoutAddress should ===("/")
       (RootActorPath(a) / "user").toStringWithoutAddress should ===("/user")
       (RootActorPath(a) / "user" / "foo").toStringWithoutAddress should ===("/user/foo")
@@ -67,65 +67,65 @@ class ActorPathSpec extends AnyWordSpec with Matchers {
     }
 
     "create correct toStringWithAddress" in {
-      val local = Address("akka", "mysys")
+      val local = Address("pekko", "mysys")
       val a = local.copy(host = Some("aaa"), port = Some(2552))
       val b = a.copy(host = Some("bb"))
       val c = a.copy(host = Some("cccc"))
       val root = RootActorPath(local)
-      root.toStringWithAddress(a) should ===("akka://mysys@aaa:2552/")
-      (root / "user").toStringWithAddress(a) should ===("akka://mysys@aaa:2552/user")
-      (root / "user" / "foo").toStringWithAddress(a) should ===("akka://mysys@aaa:2552/user/foo")
+      root.toStringWithAddress(a) should ===("pekko://mysys@aaa:2552/")
+      (root / "user").toStringWithAddress(a) should ===("pekko://mysys@aaa:2552/user")
+      (root / "user" / "foo").toStringWithAddress(a) should ===("pekko://mysys@aaa:2552/user/foo")
 
-      //      root.toStringWithAddress(b) should ===("akka://mysys@bb:2552/")
-      (root / "user").toStringWithAddress(b) should ===("akka://mysys@bb:2552/user")
-      (root / "user" / "foo").toStringWithAddress(b) should ===("akka://mysys@bb:2552/user/foo")
+      //      root.toStringWithAddress(b) should ===("pekko://mysys@bb:2552/")
+      (root / "user").toStringWithAddress(b) should ===("pekko://mysys@bb:2552/user")
+      (root / "user" / "foo").toStringWithAddress(b) should ===("pekko://mysys@bb:2552/user/foo")
 
-      root.toStringWithAddress(c) should ===("akka://mysys@cccc:2552/")
-      (root / "user").toStringWithAddress(c) should ===("akka://mysys@cccc:2552/user")
-      (root / "user" / "foo").toStringWithAddress(c) should ===("akka://mysys@cccc:2552/user/foo")
+      root.toStringWithAddress(c) should ===("pekko://mysys@cccc:2552/")
+      (root / "user").toStringWithAddress(c) should ===("pekko://mysys@cccc:2552/user")
+      (root / "user" / "foo").toStringWithAddress(c) should ===("pekko://mysys@cccc:2552/user/foo")
 
       val rootA = RootActorPath(a)
-      rootA.toStringWithAddress(b) should ===("akka://mysys@aaa:2552/")
-      (rootA / "user").toStringWithAddress(b) should ===("akka://mysys@aaa:2552/user")
-      (rootA / "user" / "foo").toStringWithAddress(b) should ===("akka://mysys@aaa:2552/user/foo")
+      rootA.toStringWithAddress(b) should ===("pekko://mysys@aaa:2552/")
+      (rootA / "user").toStringWithAddress(b) should ===("pekko://mysys@aaa:2552/user")
+      (rootA / "user" / "foo").toStringWithAddress(b) should ===("pekko://mysys@aaa:2552/user/foo")
     }
 
     "not allow path separators in RootActorPath's name" in {
       intercept[IllegalArgumentException] {
-        RootActorPath(Address("akka", "mysys"), "/user/boom/*") // illegally pass in a path where name is expected
+        RootActorPath(Address("pekko", "mysys"), "/user/boom/*") // illegally pass in a path where name is expected
       }.getMessage should include("is a path separator")
 
       // check that creating such path still works
-      ActorPath.fromString("akka://mysys/user/boom/*")
+      ActorPath.fromString("pekko://mysys/user/boom/*")
     }
 
     "detect valid and invalid chars in host names when not using AddressFromURIString, e.g. docker host given name" in {
       Seq(
-        Address("akka", "sys", "valid", 0),
-        Address("akka", "sys", "is_valid.org", 0),
-        Address("akka", "sys", "fu.is_valid.org", 0)).forall(_.hasInvalidHostCharacters) shouldBe false
+        Address("pekko", "sys", "valid", 0),
+        Address("pekko", "sys", "is_valid.org", 0),
+        Address("pekko", "sys", "fu.is_valid.org", 0)).forall(_.hasInvalidHostCharacters) shouldBe false
 
-      Seq(Address("akka", "sys", "in_valid", 0), Address("akka", "sys", "invalid._org", 0))
+      Seq(Address("pekko", "sys", "in_valid", 0), Address("pekko", "sys", "invalid._org", 0))
         .forall(_.hasInvalidHostCharacters) shouldBe true
 
-      intercept[MalformedURLException](AddressFromURIString("akka://sys@in_valid:5001"))
+      intercept[MalformedURLException](AddressFromURIString("pekko://sys@in_valid:5001"))
     }
 
     "not fail fast if the check is called on valid chars in host names" in {
       Seq(
-        Address("akka", "sys", "localhost", 0),
-        Address("akka", "sys", "is_valid.org", 0),
-        Address("akka", "sys", "fu.is_valid.org", 0)).foreach(_.checkHostCharacters())
+        Address("pekko", "sys", "localhost", 0),
+        Address("pekko", "sys", "is_valid.org", 0),
+        Address("pekko", "sys", "fu.is_valid.org", 0)).foreach(_.checkHostCharacters())
     }
 
     "fail fast if the check is called when invalid chars are in host names" in {
       Seq(
-        Address("akka", "sys", "localhost", 0),
-        Address("akka", "sys", "is_valid.org", 0),
-        Address("akka", "sys", "fu.is_valid.org", 0)).foreach(_.checkHostCharacters())
+        Address("pekko", "sys", "localhost", 0),
+        Address("pekko", "sys", "is_valid.org", 0),
+        Address("pekko", "sys", "fu.is_valid.org", 0)).foreach(_.checkHostCharacters())
 
-      intercept[IllegalArgumentException](Address("akka", "sys", "in_valid", 0).checkHostCharacters())
-      intercept[IllegalArgumentException](Address("akka", "sys", "invalid._org", 0).checkHostCharacters())
+      intercept[IllegalArgumentException](Address("pekko", "sys", "in_valid", 0).checkHostCharacters())
+      intercept[IllegalArgumentException](Address("pekko", "sys", "invalid._org", 0).checkHostCharacters())
     }
   }
 }
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSelectionSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSelectionSpec.scala
index 048853c245..5eacaf1fd8 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSelectionSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSelectionSpec.scala
@@ -179,8 +179,8 @@ class ActorSelectionSpec extends PekkoSpec with DefaultTimeout {
     "return ActorIdentity(None), respectively, for non-existing paths, and deadLetters" in {
       identify("a/b/c") should ===(None)
       identify("a/b/c") should ===(None)
-      identify("akka://all-systems/Nobody") should ===(None)
-      identify("akka://all-systems/user") should ===(None)
+      identify("pekko://all-systems/Nobody") should ===(None)
+      identify("pekko://all-systems/user") should ===(None)
       identify(system / "hallo") should ===(None)
       identify("foo://user") should ===(None)
       identify("/deadLetters") should ===(None)
@@ -265,7 +265,7 @@ class ActorSelectionSpec extends PekkoSpec with DefaultTimeout {
       def check(looker: ActorRef): Unit = {
         for ((l, r) <- Seq(
             SelectString("a/b/c") -> None,
-            SelectString("akka://all-systems/Nobody") -> None,
+            SelectString("pekko://all-systems/Nobody") -> None,
             SelectPath(system / "hallo") -> None,
             SelectPath(looker.path.child("hallo")) -> None, // test Java API
             SelectPath(looker.path.descendant(Seq("a", "b").asJava)) -> None) // test Java API
@@ -345,16 +345,17 @@ class ActorSelectionSpec extends PekkoSpec with DefaultTimeout {
 
     "print nicely" in {
       ActorSelection(c21, "../*/hello").toString should ===(
-        s"ActorSelection[Anchor(akka://ActorSelectionSpec/user/c2/c21#${c21.path.uid}), Path(/../*/hello)]")
+        s"ActorSelection[Anchor(pekko://ActorSelectionSpec/user/c2/c21#${c21.path.uid}), Path(/../*/hello)]")
     }
 
     "have a stringly serializable path" in {
-      system.actorSelection(system / "c2").toSerializationFormat should ===("akka://ActorSelectionSpec/user/c2")
+      system.actorSelection(system / "c2").toSerializationFormat should ===("pekko://ActorSelectionSpec/user/c2")
       system.actorSelection(system / "c2" / "c21").toSerializationFormat should ===(
-        "akka://ActorSelectionSpec/user/c2/c21")
-      ActorSelection(c2, "/").toSerializationFormat should ===("akka://ActorSelectionSpec/user/c2")
-      ActorSelection(c2, "../*/hello").toSerializationFormat should ===("akka://ActorSelectionSpec/user/c2/../*/hello")
-      ActorSelection(c2, "/../*/hello").toSerializationFormat should ===("akka://ActorSelectionSpec/user/c2/../*/hello")
+        "pekko://ActorSelectionSpec/user/c2/c21")
+      ActorSelection(c2, "/").toSerializationFormat should ===("pekko://ActorSelectionSpec/user/c2")
+      ActorSelection(c2, "../*/hello").toSerializationFormat should ===("pekko://ActorSelectionSpec/user/c2/../*/hello")
+      ActorSelection(c2, "/../*/hello").toSerializationFormat should ===(
+        "pekko://ActorSelectionSpec/user/c2/../*/hello")
     }
 
     "send ActorSelection targeted to missing actor to deadLetters" in {
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemSpec.scala
index 134d542f14..d845db6d35 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemSpec.scala
@@ -159,11 +159,11 @@ class ActorSystemSpec extends PekkoSpec(ActorSystemSpec.config) with ImplicitSen
         a.tell("run", probe.ref)
         probe.expectTerminated(a)
         EventFilter
-          .info(pattern = """from Actor\[akka://LogDeadLetters/system/testProbe.*not delivered""", occurrences = 1)
+          .info(pattern = """from Actor\[pekko://LogDeadLetters/system/testProbe.*not delivered""", occurrences = 1)
           .intercept {
             EventFilter
               .warning(
-                pattern = """received dead letter from Actor\[akka://LogDeadLetters/system/testProbe""",
+                pattern = """received dead letter from Actor\[pekko://LogDeadLetters/system/testProbe""",
                 occurrences = 1)
               .intercept {
                 a.tell("boom", probe.ref)
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/LocalActorRefProviderSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/LocalActorRefProviderSpec.scala
index 6098a5ea84..1a54df0821 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/LocalActorRefProviderSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/LocalActorRefProviderSpec.scala
@@ -48,7 +48,7 @@ class LocalActorRefProviderSpec extends PekkoSpec(LocalActorRefProviderSpec.conf
   "An LocalActorRefProvider" must {
 
     "find child actor with URL encoded name" in {
-      val childName = "akka%3A%2F%2FClusterSystem%40127.0.0.1%3A2552"
+      val childName = "pekko%3A%2F%2FClusterSystem%40127.0.0.1%3A2552"
       val a = system.actorOf(Props(new Actor {
         val child = context.actorOf(Props.empty, name = childName)
         def receive = {
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/RelativeActorPathSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/RelativeActorPathSpec.scala
index 2de52a4e48..822965eaeb 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/RelativeActorPathSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/RelativeActorPathSpec.scala
@@ -32,7 +32,7 @@ class RelativeActorPathSpec extends AnyWordSpec with Matchers {
       elements("foo/bar/baz") should ===(List("foo", "bar", "baz"))
     }
     "match url encoded name" in {
-      val name = URLEncoder.encode("akka://ClusterSystem@127.0.0.1:2552", "UTF-8")
+      val name = URLEncoder.encode("pekko://ClusterSystem@127.0.0.1:2552", "UTF-8")
       elements(name) should ===(List(name))
     }
     "match path with uid fragment" in {
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/RouterTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/RouterTest.java
index de46e17304..572c5efa85 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/RouterTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/RouterTest.java
@@ -228,16 +228,22 @@ public class RouterTest extends JUnitSuite {
             Routers.group(proxy.registeringKey)
                 .withConsistentHashingRouting(10, command -> proxy.mapping(command)));
 
-    router.tell(new Proxy.Message("123", "Text1"));
-    router.tell(new Proxy.Message("123", "Text2"));
+    final String id1 = "123";
+    router.tell(new Proxy.Message(id1, "Text1"));
+    router.tell(new Proxy.Message(id1, "Text2"));
 
-    router.tell(new Proxy.Message("zh3", "Text3"));
-    router.tell(new Proxy.Message("zh3", "Text4"));
+    final String id2 = "abcdef";
+    router.tell(new Proxy.Message(id2, "Text3"));
+    router.tell(new Proxy.Message(id2, "Text4"));
     // the hash is calculated over the Proxy.Message first parameter obtained through the
     // Proxy.mapping function
     // #consistent-hashing
     // Then messages with equal Message.id reach the same actor
     // so the first message in each probe queue is equal to its second
+    // NB: this test can start failing if you change the actor path (eg the URL scheme) due to
+    // these values being hashed (and depending on the resulting hash output its possible to
+    // change the distribution of actors in the ring which the test relies on)
+    // - to fix you will need to change id2 value until it starts passing again
     probe1.expectMessage(probe1.receiveMessage());
     probe2.expectMessage(probe2.receiveMessage());
   }
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefResolverSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefResolverSpec.scala
index edcff07e0d..e53e04a717 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefResolverSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefResolverSpec.scala
@@ -33,7 +33,7 @@ class ActorRefResolverSpec extends AnyWordSpec with ScalaFutures with Matchers {
       try {
         val ref1 = system1.systemActorOf(Behaviors.empty, "ref1")
         val serialized = ActorRefResolver(system1).toSerializationFormat(ref1)
-        serialized should startWith("akka://sys1/")
+        serialized should startWith("pekko://sys1/")
 
         intercept[IllegalArgumentException] {
           // wrong system
@@ -49,7 +49,7 @@ class ActorRefResolverSpec extends AnyWordSpec with ScalaFutures with Matchers {
         }
 
         val minRef1Serialized = ActorRefResolver(system2).toSerializationFormat(minRef1)
-        minRef1Serialized should startWith("akka://sys2/")
+        minRef1Serialized should startWith("pekko://sys2/")
 
       } finally {
         system1.terminate()
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LocalActorRefProviderLogMessagesSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LocalActorRefProviderLogMessagesSpec.scala
index cdfc6db1ed..e1b08ea5a2 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LocalActorRefProviderLogMessagesSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LocalActorRefProviderLogMessagesSpec.scala
@@ -68,7 +68,7 @@ class LocalActorRefProviderLogMessagesSpec
       val provider = system.asInstanceOf[ActorSystemAdapter[_]].provider
       try {
         LoggingTestKit
-          .debug("Resolve (deserialization) of foreign path [akka://otherSystem/user/foo]")
+          .debug("Resolve (deserialization) of foreign path [pekko://otherSystem/user/foo]")
           .withLoggerName("org.apache.pekko.actor.LocalActorRefProvider.Deserialization")
           .expect {
             provider.resolveActorRef(invalidPath)
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorSystemSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorSystemSpec.scala
index d716e006cd..ab50aaa1ad 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorSystemSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorSystemSpec.scala
@@ -181,7 +181,7 @@ class ActorSystemSpec
 
     "return default address " in {
       withSystem("address", Behaviors.empty[String]) { sys =>
-        sys.address shouldBe Address("akka", "adapter-address")
+        sys.address shouldBe Address("pekko", "adapter-address")
       }
     }
 
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorContextImpl.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorContextImpl.scala
index 35d3aeb6cd..b0e7045010 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorContextImpl.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorContextImpl.scala
@@ -60,7 +60,7 @@ import scala.util.Success
       val pekkoAddress =
         ctx.system match {
           case adapter: ActorSystemAdapter[_] => adapter.provider.addressString
-          case _                              => Address("akka", ctx.system.name).toString
+          case _                              => Address("pekko", ctx.system.name).toString
         }
 
       val sourceActorSystem = ctx.system.name
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/adapter/ActorSystemAdapter.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/adapter/ActorSystemAdapter.scala
index 229c042937..70ab7a8b03 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/adapter/ActorSystemAdapter.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/adapter/ActorSystemAdapter.scala
@@ -82,7 +82,7 @@ import pekko.annotation.InternalApi
   def isTerminated: Boolean = whenTerminated.isCompleted
 
   final override val path: classic.ActorPath =
-    classic.RootActorPath(classic.Address("akka", system.name)) / "user"
+    classic.RootActorPath(classic.Address("pekko", system.name)) / "user"
 
   override def toString: String = system.toString
 
diff --git a/actor/src/main/scala/org/apache/pekko/actor/ActorRef.scala b/actor/src/main/scala/org/apache/pekko/actor/ActorRef.scala
index d91593b6d1..b6aa55bc65 100644
--- a/actor/src/main/scala/org/apache/pekko/actor/ActorRef.scala
+++ b/actor/src/main/scala/org/apache/pekko/actor/ActorRef.scala
@@ -325,7 +325,7 @@ private[pekko] abstract class ActorRefWithCell extends InternalActorRef { this:
  * This is an internal look-up failure token, not useful for anything else.
  */
 private[pekko] case object Nobody extends MinimalActorRef {
-  override val path: RootActorPath = new RootActorPath(Address("akka", "all-systems"), "/Nobody")
+  override val path: RootActorPath = new RootActorPath(Address("pekko", "all-systems"), "/Nobody")
   override def provider = throw new UnsupportedOperationException("Nobody does not provide")
 
   private val serialized = new SerializedNobody
@@ -543,7 +543,7 @@ private[pekko] trait MinimalActorRef extends InternalActorRef with LocalRef {
   private val fakeSystemName = "local"
 
   val path: ActorPath =
-    RootActorPath(Address("akka", IgnoreActorRef.fakeSystemName)) / "ignore"
+    RootActorPath(Address("pekko", IgnoreActorRef.fakeSystemName)) / "ignore"
 
   private val pathString = path.toString
 
diff --git a/actor/src/main/scala/org/apache/pekko/actor/ActorRefProvider.scala b/actor/src/main/scala/org/apache/pekko/actor/ActorRefProvider.scala
index 21119de35b..2b5a0ff642 100644
--- a/actor/src/main/scala/org/apache/pekko/actor/ActorRefProvider.scala
+++ b/actor/src/main/scala/org/apache/pekko/actor/ActorRefProvider.scala
@@ -399,7 +399,7 @@ private[pekko] class LocalActorRefProvider private[pekko] (
       dynamicAccess: DynamicAccess) =
     this(_systemName, settings, eventStream, dynamicAccess, new Deployer(settings, dynamicAccess), None)
 
-  override val rootPath: ActorPath = RootActorPath(Address("akka", _systemName))
+  override val rootPath: ActorPath = RootActorPath(Address("pekko", _systemName))
 
   private[pekko] val log: MarkerLoggingAdapter =
     Logging.withMarker(eventStream, classOf[LocalActorRefProvider])
diff --git a/actor/src/main/scala/org/apache/pekko/actor/ActorSystem.scala b/actor/src/main/scala/org/apache/pekko/actor/ActorSystem.scala
index 6bc5e588b0..39b2a8ca2f 100644
--- a/actor/src/main/scala/org/apache/pekko/actor/ActorSystem.scala
+++ b/actor/src/main/scala/org/apache/pekko/actor/ActorSystem.scala
@@ -395,7 +395,7 @@ object ActorSystem {
         ConfigFactory
           .defaultReference(classLoader)
           .withoutPath(Dispatchers.InternalDispatcherId), // allow this to be both string and config object
-        "akka")
+        "pekko")
       cfg
     }
 
diff --git a/actor/src/main/scala/org/apache/pekko/actor/Address.scala b/actor/src/main/scala/org/apache/pekko/actor/Address.scala
index f8e8f104b9..bc740eaf9f 100644
--- a/actor/src/main/scala/org/apache/pekko/actor/Address.scala
+++ b/actor/src/main/scala/org/apache/pekko/actor/Address.scala
@@ -189,10 +189,10 @@ object AddressFromURIString {
   def unapply(uri: URI): Option[Address] =
     if (uri eq null) None
     else if (uri.getScheme == null || (uri.getUserInfo == null && uri.getHost == null)) None
-    else if (uri.getUserInfo == null) { // case 1: “akka://system”
+    else if (uri.getUserInfo == null) { // case 1: “pekko://system”
       if (uri.getPort != -1) None
       else Some(Address(uri.getScheme, uri.getHost))
-    } else { // case 2: “akka://system@host:port”
+    } else { // case 2: “pekko://system@host:port”
       if (uri.getHost == null || uri.getPort == -1) None
       else
         Some(
diff --git a/actor/src/main/scala/org/apache/pekko/event/Logging.scala b/actor/src/main/scala/org/apache/pekko/event/Logging.scala
index eb44eea24b..179a88e778 100644
--- a/actor/src/main/scala/org/apache/pekko/event/Logging.scala
+++ b/actor/src/main/scala/org/apache/pekko/event/Logging.scala
@@ -269,7 +269,7 @@ trait LoggingBus extends ActorEventBus {
  *
  * class MyClass extends MyType {
  *   val sys = ActorSystem("sys")
- *   val log = Logging(sys, this) // will use "hallo,akka://sys" as logSource
+ *   val log = Logging(sys, this) // will use "hallo,pekko://sys" as logSource
  *   def name = "hallo"
  * }
  * }}}
@@ -1113,7 +1113,7 @@ object Logging {
    * <code>pekko.stdout-loglevel</code>.
    */
   class StandardOutLogger extends MinimalActorRef with StdOutLogger {
-    val path: ActorPath = RootActorPath(Address("akka", "all-systems"), "/StandardOutLogger")
+    val path: ActorPath = RootActorPath(Address("pekko", "all-systems"), "/StandardOutLogger")
     def provider: ActorRefProvider = throw new UnsupportedOperationException("StandardOutLogger does not provide")
     override val toString = "StandardOutLogger"
     override def !(message: Any)(implicit sender: ActorRef = Actor.noSender): Unit =
diff --git a/actor/src/main/scala/org/apache/pekko/io/InetAddressDnsResolver.scala b/actor/src/main/scala/org/apache/pekko/io/InetAddressDnsResolver.scala
index 26e2cc7015..e8bd5eaf91 100644
--- a/actor/src/main/scala/org/apache/pekko/io/InetAddressDnsResolver.scala
+++ b/actor/src/main/scala/org/apache/pekko/io/InetAddressDnsResolver.scala
@@ -150,7 +150,7 @@ class InetAddressDnsResolver(cache: SimpleDnsCache, config: Config) extends Acto
       }
       sender() ! answer
     case Dns.Resolve(name) =>
-      // no where in akka now sends this message, but supported until Dns.Resolve/Resolved have been removed
+      // no where in pekko now sends this message, but supported until Dns.Resolve/Resolved have been removed
       val answer: Dns.Resolved = cache.cached(name) match {
         case Some(a) => a
         case None =>
diff --git a/actor/src/main/scala/org/apache/pekko/io/dns/internal/AsyncDnsManager.scala b/actor/src/main/scala/org/apache/pekko/io/dns/internal/AsyncDnsManager.scala
index 7d0409d34d..24463937b5 100644
--- a/actor/src/main/scala/org/apache/pekko/io/dns/internal/AsyncDnsManager.scala
+++ b/actor/src/main/scala/org/apache/pekko/io/dns/internal/AsyncDnsManager.scala
@@ -109,7 +109,7 @@ private[io] final class AsyncDnsManager(
       resolver.forward(r)
 
     case Dns.Resolve(name) =>
-      // adapt legacy protocol to new protocol and back again, no where in akka
+      // adapt legacy protocol to new protocol and back again, no where in pekko
       // sends this message but supported until the old messages are removed
       log.debug("(deprecated) Resolution request for {} from {}", name, sender())
       val adapted = DnsProtocol.Resolve(name)
diff --git a/actor/src/main/scala/org/apache/pekko/serialization/AsyncSerializer.scala b/actor/src/main/scala/org/apache/pekko/serialization/AsyncSerializer.scala
index 30f469fa57..e396d44df9 100644
--- a/actor/src/main/scala/org/apache/pekko/serialization/AsyncSerializer.scala
+++ b/actor/src/main/scala/org/apache/pekko/serialization/AsyncSerializer.scala
@@ -57,7 +57,7 @@ abstract class AsyncSerializerWithStringManifest(system: ExtendedActorSystem)
 
   final override def toBinary(o: AnyRef): Array[Byte] = {
     log.warning(
-      "Async serializer called synchronously. This will block. Async serializers should only be used for akka persistence plugins that support them. Class: {}",
+      "Async serializer called synchronously. This will block. Async serializers should only be used for pekko persistence plugins that support them. Class: {}",
       o.getClass)
     Await.result(toBinaryAsync(o), Duration.Inf)
   }
diff --git a/bench-jmh/src/main/scala/org/apache/pekko/cluster/ddata/ORSetMergeBenchmark.scala b/bench-jmh/src/main/scala/org/apache/pekko/cluster/ddata/ORSetMergeBenchmark.scala
index 3ab4ebfa79..0072f4d263 100644
--- a/bench-jmh/src/main/scala/org/apache/pekko/cluster/ddata/ORSetMergeBenchmark.scala
+++ b/bench-jmh/src/main/scala/org/apache/pekko/cluster/ddata/ORSetMergeBenchmark.scala
@@ -43,7 +43,7 @@ class ORSetMergeBenchmark {
   @Param(Array("1", "10", "20", "100"))
   var set1Size = 0
 
-  val nodeA = UniqueAddress(Address("akka", "Sys", "aaaa", 2552), 1L)
+  val nodeA = UniqueAddress(Address("pekko", "Sys", "aaaa", 2552), 1L)
   val nodeB = UniqueAddress(nodeA.address.copy(host = Some("bbbb")), 2L)
   val nodeC = UniqueAddress(nodeA.address.copy(host = Some("cccc")), 3L)
   val nodeD = UniqueAddress(nodeA.address.copy(host = Some("dddd")), 4L)
diff --git a/bench-jmh/src/main/scala/org/apache/pekko/cluster/ddata/VersionVectorBenchmark.scala b/bench-jmh/src/main/scala/org/apache/pekko/cluster/ddata/VersionVectorBenchmark.scala
index 99786299be..e466bb2e45 100644
--- a/bench-jmh/src/main/scala/org/apache/pekko/cluster/ddata/VersionVectorBenchmark.scala
+++ b/bench-jmh/src/main/scala/org/apache/pekko/cluster/ddata/VersionVectorBenchmark.scala
@@ -43,7 +43,7 @@ class VersionVectorBenchmark {
   @Param(Array("1", "2", "5"))
   var size = 0
 
-  val nodeA = UniqueAddress(Address("akka", "Sys", "aaaa", 2552), 1L)
+  val nodeA = UniqueAddress(Address("pekko", "Sys", "aaaa", 2552), 1L)
   val nodeB = UniqueAddress(nodeA.address.copy(host = Some("bbbb")), 2L)
   val nodeC = UniqueAddress(nodeA.address.copy(host = Some("cccc")), 3L)
   val nodeD = UniqueAddress(nodeA.address.copy(host = Some("dddd")), 4L)
diff --git a/bench-jmh/src/main/scala/org/apache/pekko/remote/artery/LiteralEncodingBenchmark.scala b/bench-jmh/src/main/scala/org/apache/pekko/remote/artery/LiteralEncodingBenchmark.scala
index 8afda3d082..a30048f710 100644
--- a/bench-jmh/src/main/scala/org/apache/pekko/remote/artery/LiteralEncodingBenchmark.scala
+++ b/bench-jmh/src/main/scala/org/apache/pekko/remote/artery/LiteralEncodingBenchmark.scala
@@ -31,7 +31,7 @@ import org.apache.pekko.util.Unsafe
 class LiteralEncodingBenchmark {
 
   private val UsAscii = Charset.forName("US-ASCII")
-  private val str = "akka://SomeSystem@host12:1234/user/foo"
+  private val str = "pekko://SomeSystem@host12:1234/user/foo"
   private val buffer = ByteBuffer.allocate(128).order(ByteOrder.LITTLE_ENDIAN)
   private val literalChars = Array.ofDim[Char](64)
   private val literalBytes = Array.ofDim[Byte](64)
diff --git a/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/ClusterMetricsRoutingSpec.scala b/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/ClusterMetricsRoutingSpec.scala
index f5e7ebfb23..29547b593f 100644
--- a/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/ClusterMetricsRoutingSpec.scala
+++ b/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/ClusterMetricsRoutingSpec.scala
@@ -28,10 +28,10 @@ class MetricsSelectorSpec extends AnyWordSpec with Matchers {
     override def capacity(nodeMetrics: Set[NodeMetrics]): Map[Address, Double] = Map.empty
   }
 
-  val a1 = Address("akka", "sys", "a1", 2551)
-  val b1 = Address("akka", "sys", "b1", 2551)
-  val c1 = Address("akka", "sys", "c1", 2551)
-  val d1 = Address("akka", "sys", "d1", 2551)
+  val a1 = Address("pekko", "sys", "a1", 2551)
+  val b1 = Address("pekko", "sys", "b1", 2551)
+  val c1 = Address("pekko", "sys", "c1", 2551)
+  val d1 = Address("pekko", "sys", "d1", 2551)
 
   val decayFactor = Some(0.18)
 
diff --git a/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/MetricSpec.scala b/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/MetricSpec.scala
index cd50994533..eecb2274a4 100644
--- a/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/MetricSpec.scala
+++ b/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/MetricSpec.scala
@@ -69,8 +69,8 @@ class MetricNumericConverterSpec extends AnyWordSpec with Matchers with MetricNu
 @nowarn
 class NodeMetricsSpec extends AnyWordSpec with Matchers {
 
-  val node1 = Address("akka", "sys", "a", 2554)
-  val node2 = Address("akka", "sys", "a", 2555)
+  val node1 = Address("pekko", "sys", "a", 2554)
+  val node2 = Address("pekko", "sys", "a", 2555)
 
   "NodeMetrics must" must {
 
@@ -162,8 +162,8 @@ class MetricsGossipSpec
 
   "A MetricsGossip" must {
     "add new NodeMetrics" in {
-      val m1 = NodeMetrics(Address("akka", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
-      val m2 = NodeMetrics(Address("akka", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
+      val m1 = NodeMetrics(Address("pekko", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
+      val m2 = NodeMetrics(Address("pekko", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
 
       m1.metrics.size should be > 3
       m2.metrics.size should be > 3
@@ -179,8 +179,8 @@ class MetricsGossipSpec
     }
 
     "merge peer metrics" in {
-      val m1 = NodeMetrics(Address("akka", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
-      val m2 = NodeMetrics(Address("akka", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
+      val m1 = NodeMetrics(Address("pekko", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
+      val m2 = NodeMetrics(Address("pekko", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
 
       val g1 = MetricsGossip.empty :+ m1 :+ m2
       g1.nodes.size should ===(2)
@@ -194,9 +194,9 @@ class MetricsGossipSpec
     }
 
     "merge an existing metric set for a node and update node ring" in {
-      val m1 = NodeMetrics(Address("akka", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
-      val m2 = NodeMetrics(Address("akka", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
-      val m3 = NodeMetrics(Address("akka", "sys", "a", 2556), newTimestamp, collector.sample().metrics)
+      val m1 = NodeMetrics(Address("pekko", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
+      val m2 = NodeMetrics(Address("pekko", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
+      val m3 = NodeMetrics(Address("pekko", "sys", "a", 2556), newTimestamp, collector.sample().metrics)
       val m2Updated = m2.copy(metrics = newSample(m2.metrics), timestamp = m2.timestamp + 1000)
 
       val g1 = MetricsGossip.empty :+ m1 :+ m2
@@ -215,14 +215,14 @@ class MetricsGossipSpec
     }
 
     "get the current NodeMetrics if it exists in the local nodes" in {
-      val m1 = NodeMetrics(Address("akka", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
+      val m1 = NodeMetrics(Address("pekko", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
       val g1 = MetricsGossip.empty :+ m1
       g1.nodeMetricsFor(m1.address).map(_.metrics) should ===(Some(m1.metrics))
     }
 
     "remove a node if it is no longer Up" in {
-      val m1 = NodeMetrics(Address("akka", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
-      val m2 = NodeMetrics(Address("akka", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
+      val m1 = NodeMetrics(Address("pekko", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
+      val m2 = NodeMetrics(Address("pekko", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
 
       val g1 = MetricsGossip.empty :+ m1 :+ m2
       g1.nodes.size should ===(2)
@@ -234,8 +234,8 @@ class MetricsGossipSpec
     }
 
     "filter nodes" in {
-      val m1 = NodeMetrics(Address("akka", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
-      val m2 = NodeMetrics(Address("akka", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
+      val m1 = NodeMetrics(Address("pekko", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
+      val m2 = NodeMetrics(Address("pekko", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
 
       val g1 = MetricsGossip.empty :+ m1 :+ m2
       g1.nodes.size should ===(2)
@@ -254,8 +254,8 @@ class MetricValuesSpec extends PekkoSpec(MetricsConfig.defaultEnabled) with Metr
 
   val collector = createMetricsCollector
 
-  val node1 = NodeMetrics(Address("akka", "sys", "a", 2554), 1, collector.sample().metrics)
-  val node2 = NodeMetrics(Address("akka", "sys", "a", 2555), 1, collector.sample().metrics)
+  val node1 = NodeMetrics(Address("pekko", "sys", "a", 2554), 1, collector.sample().metrics)
+  val node2 = NodeMetrics(Address("pekko", "sys", "a", 2555), 1, collector.sample().metrics)
 
   val nodes: Seq[NodeMetrics] = {
     (1 to 100).foldLeft(List(node1, node2)) { (nodes, _) =>
diff --git a/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/TestUtil.scala b/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/TestUtil.scala
index f4a69ce365..32ce9d17c4 100644
--- a/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/TestUtil.scala
+++ b/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/TestUtil.scala
@@ -147,7 +147,7 @@ trait MetricsCollectorFactory { this: PekkoSpec =>
  */
 class MockitoSigarMetricsCollector(system: ActorSystem)
     extends SigarMetricsCollector(
-      Address(if (RARP(system).provider.remoteSettings.Artery.Enabled) "akka" else "akka.tcp", system.name),
+      Address(if (RARP(system).provider.remoteSettings.Artery.Enabled) "pekko" else "pekko.tcp", system.name),
       MetricsConfig.defaultDecayFactor,
       MockitoSigarProvider().createSigarInstance) {}
 
diff --git a/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/WeightedRouteesSpec.scala b/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/WeightedRouteesSpec.scala
index 67947c886f..ccf8b40f88 100644
--- a/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/WeightedRouteesSpec.scala
+++ b/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/WeightedRouteesSpec.scala
@@ -32,8 +32,8 @@ class WeightedRouteesSpec extends PekkoSpec(ConfigFactory.parseString("""
       """)) {
 
   val protocol =
-    if (RARP(system).provider.remoteSettings.Artery.Enabled) "akka"
-    else "akka.tcp"
+    if (RARP(system).provider.remoteSettings.Artery.Enabled) "pekko"
+    else "pekko.tcp"
 
   val a1 = Address(protocol, "sys", "a1", 2551)
   val b1 = Address(protocol, "sys", "b1", 2551)
diff --git a/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/protobuf/MessageSerializerSpec.scala b/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/protobuf/MessageSerializerSpec.scala
index 091feab020..4cbc3ab09d 100644
--- a/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/protobuf/MessageSerializerSpec.scala
+++ b/cluster-metrics/src/test/scala/org/apache/pekko/cluster/metrics/protobuf/MessageSerializerSpec.scala
@@ -40,12 +40,12 @@ class MessageSerializerSpec extends PekkoSpec("""
 
   import MemberStatus._
 
-  val a1 = TestMember(Address("akka", "sys", "a", 2552), Joining, Set.empty)
-  val b1 = TestMember(Address("akka", "sys", "b", 2552), Up, Set("r1"))
-  val c1 = TestMember(Address("akka", "sys", "c", 2552), Leaving, Set("r2"))
-  val d1 = TestMember(Address("akka", "sys", "d", 2552), Exiting, Set("r1", "r2"))
-  val e1 = TestMember(Address("akka", "sys", "e", 2552), Down, Set("r3"))
-  val f1 = TestMember(Address("akka", "sys", "f", 2552), Removed, Set("r2", "r3"))
+  val a1 = TestMember(Address("pekko", "sys", "a", 2552), Joining, Set.empty)
+  val b1 = TestMember(Address("pekko", "sys", "b", 2552), Up, Set("r1"))
+  val c1 = TestMember(Address("pekko", "sys", "c", 2552), Leaving, Set("r2"))
+  val d1 = TestMember(Address("pekko", "sys", "d", 2552), Exiting, Set("r1", "r2"))
+  val e1 = TestMember(Address("pekko", "sys", "e", 2552), Down, Set("r3"))
+  val f1 = TestMember(Address("pekko", "sys", "f", 2552), Removed, Set("r2", "r3"))
 
   "ClusterMessages" must {
 
diff --git a/cluster-sharding-typed/src/test/java/jdocs/org/apache/pekko/cluster/sharding/typed/ExternalShardAllocationCompileOnlyTest.java b/cluster-sharding-typed/src/test/java/jdocs/org/apache/pekko/cluster/sharding/typed/ExternalShardAllocationCompileOnlyTest.java
index 88c5d8e767..6308f0a0d8 100644
--- a/cluster-sharding-typed/src/test/java/jdocs/org/apache/pekko/cluster/sharding/typed/ExternalShardAllocationCompileOnlyTest.java
+++ b/cluster-sharding-typed/src/test/java/jdocs/org/apache/pekko/cluster/sharding/typed/ExternalShardAllocationCompileOnlyTest.java
@@ -46,7 +46,7 @@ public class ExternalShardAllocationCompileOnlyTest {
     ExternalShardAllocationClient client =
         ExternalShardAllocation.get(system).getClient(typeKey.name());
     CompletionStage<Done> done =
-        client.setShardLocation("shard-id-1", new Address("akka", "system", "127.0.0.1", 2552));
+        client.setShardLocation("shard-id-1", new Address("pekko", "system", "127.0.0.1", 2552));
     // #client
 
   }
diff --git a/cluster-sharding-typed/src/test/scala/docs/org/apache/pekko/cluster/sharding/typed/ExternalShardAllocationCompileOnlySpec.scala b/cluster-sharding-typed/src/test/scala/docs/org/apache/pekko/cluster/sharding/typed/ExternalShardAllocationCompileOnlySpec.scala
index cf1640f54d..40fb31e225 100644
--- a/cluster-sharding-typed/src/test/scala/docs/org/apache/pekko/cluster/sharding/typed/ExternalShardAllocationCompileOnlySpec.scala
+++ b/cluster-sharding-typed/src/test/scala/docs/org/apache/pekko/cluster/sharding/typed/ExternalShardAllocationCompileOnlySpec.scala
@@ -46,7 +46,7 @@ class ExternalShardAllocationCompileOnlySpec {
 
   // #client
   val client: ExternalShardAllocationClient = ExternalShardAllocation(system).clientFor(TypeKey.name)
-  val done: Future[Done] = client.updateShardLocation("shard-id-1", Address("akka", "system", "127.0.0.1", 2552))
+  val done: Future[Done] = client.updateShardLocation("shard-id-1", Address("pekko", "system", "127.0.0.1", 2552))
   // #client
 
 }
diff --git a/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/DeprecatedLeastShardAllocationStrategySpec.scala b/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/DeprecatedLeastShardAllocationStrategySpec.scala
index 3a79433fde..ae88b6b9e3 100644
--- a/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/DeprecatedLeastShardAllocationStrategySpec.scala
+++ b/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/DeprecatedLeastShardAllocationStrategySpec.scala
@@ -259,7 +259,7 @@ class DeprecatedLeastShardAllocationStrategySpec extends PekkoSpec {
           val member1 = newUpMember("127.0.0.1")
           val member2 =
             Member(
-              UniqueAddress(Address("akka", "myapp", "127.0.0.2", 252525), 1L),
+              UniqueAddress(Address("pekko", "myapp", "127.0.0.2", 252525), 1L),
               Set(ClusterSettings.DcRolePrefix + ClusterSettings.DefaultDataCenter),
               member1.appVersion)
 
diff --git a/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/LeastShardAllocationStrategySpec.scala b/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/LeastShardAllocationStrategySpec.scala
index 0145241c9e..bab1e12095 100644
--- a/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/LeastShardAllocationStrategySpec.scala
+++ b/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/LeastShardAllocationStrategySpec.scala
@@ -40,7 +40,7 @@ import scala.collection.immutable.SortedSet
 object LeastShardAllocationStrategySpec {
 
   private object DummyActorRef extends MinimalActorRef {
-    override val path: ActorPath = RootActorPath(Address("akka", "myapp")) / "system" / "fake"
+    override val path: ActorPath = RootActorPath(Address("pekko", "myapp")) / "system" / "fake"
 
     override def provider: ActorRefProvider = ???
   }
@@ -81,7 +81,7 @@ object LeastShardAllocationStrategySpec {
 
   def newUpMember(host: String, port: Int = 252525, version: Version = Version("1.0.0")) =
     Member(
-      UniqueAddress(Address("akka", "myapp", host, port), 1L),
+      UniqueAddress(Address("pekko", "myapp", host, port), 1L),
       Set(ClusterSettings.DcRolePrefix + ClusterSettings.DefaultDataCenter),
       version).copy(MemberStatus.Up)
 
@@ -314,7 +314,7 @@ class LeastShardAllocationStrategySpec extends PekkoSpec {
           val member1 = newUpMember("127.0.0.1")
           val member2 =
             Member(
-              UniqueAddress(Address("akka", "myapp", "127.0.0.2", 252525), 1L),
+              UniqueAddress(Address("pekko", "myapp", "127.0.0.2", 252525), 1L),
               Set(ClusterSettings.DcRolePrefix + ClusterSettings.DefaultDataCenter),
               member1.appVersion)
 
diff --git a/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/ProxyShardingSpec.scala b/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/ProxyShardingSpec.scala
index b63e77e9c7..11f9278a92 100644
--- a/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/ProxyShardingSpec.scala
+++ b/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/ProxyShardingSpec.scala
@@ -60,7 +60,7 @@ class ProxyShardingSpec extends PekkoSpec(ProxyShardingSpec.config) with WithLog
   "Proxy should be found" in {
     val proxyActor: ActorRef = Await.result(
       system
-        .actorSelection("akka://ProxyShardingSpec/system/sharding/myTypeProxy")
+        .actorSelection("pekko://ProxyShardingSpec/system/sharding/myTypeProxy")
         .resolveOne(FiniteDuration(5, SECONDS)),
       3.seconds)
 
@@ -80,7 +80,7 @@ class ProxyShardingSpec extends PekkoSpec(ProxyShardingSpec.config) with WithLog
     val shardCoordinator: ActorRef =
       Await.result(
         system
-          .actorSelection("akka://ProxyShardingSpec/system/sharding/myTypeCoordinator")
+          .actorSelection("pekko://ProxyShardingSpec/system/sharding/myTypeCoordinator")
           .resolveOne(FiniteDuration(5, SECONDS)),
         3.seconds)
 
diff --git a/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/RememberEntitiesShardIdExtractorChangeSpec.scala b/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/RememberEntitiesShardIdExtractorChangeSpec.scala
index 820fd3ef95..43c11e16ea 100644
--- a/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/RememberEntitiesShardIdExtractorChangeSpec.scala
+++ b/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/RememberEntitiesShardIdExtractorChangeSpec.scala
@@ -124,8 +124,8 @@ class RememberEntitiesShardIdExtractorChangeSpec
       withSystem("ThirdIncarnation", secondExtractShardId) { (system, region) =>
         val probe = TestProbe()(system)
         // Only way to verify that they were "normal"-remember-started here is to look at debug logs, will show
-        // [akka://ThirdIncarnation@127.0.0.1:51533/system/sharding/ShardIdExtractorChange/1/RememberEntitiesStore] Recovery completed for shard [1] with [0] entities
-        // [akka://ThirdIncarnation@127.0.0.1:51533/system/sharding/ShardIdExtractorChange/2/RememberEntitiesStore] Recovery completed for shard [2] with [3] entities
+        // [pekko://ThirdIncarnation@127.0.0.1:51533/system/sharding/ShardIdExtractorChange/1/RememberEntitiesStore] Recovery completed for shard [1] with [0] entities
+        // [pekko://ThirdIncarnation@127.0.0.1:51533/system/sharding/ShardIdExtractorChange/2/RememberEntitiesStore] Recovery completed for shard [2] with [3] entities
         awaitAssert {
           region.tell(ShardRegion.GetShardRegionState, probe.ref)
           val state = probe.expectMsgType[ShardRegion.CurrentShardRegionState]
diff --git a/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/protobuf/ClusterShardingMessageSerializerSpec.scala b/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/protobuf/ClusterShardingMessageSerializerSpec.scala
index 6bc21da528..7e0e9eed2e 100644
--- a/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/protobuf/ClusterShardingMessageSerializerSpec.scala
+++ b/cluster-sharding/src/test/scala/org/apache/pekko/cluster/sharding/protobuf/ClusterShardingMessageSerializerSpec.scala
@@ -121,15 +121,15 @@ class ClusterShardingMessageSerializerSpec extends PekkoSpec {
     "be able to serialize GetCurrentRegions" in {
       checkSerialization(ShardRegion.GetCurrentRegions)
       checkSerialization(
-        ShardRegion.CurrentRegions(Set(Address("akka", "sys", "a", 2552), Address("akka", "sys", "b", 2552))))
+        ShardRegion.CurrentRegions(Set(Address("pekko", "sys", "a", 2552), Address("pekko", "sys", "b", 2552))))
     }
 
     "be able to serialize GetClusterShardingStats" in {
       checkSerialization(ShardRegion.GetClusterShardingStats(3.seconds))
       checkSerialization(
         ShardRegion.ClusterShardingStats(Map(
-          Address("akka", "sys", "a", 2552) -> ShardRegion.ShardRegionStats(Map[ShardId, Int]("a" -> 23), Set("b")),
-          Address("akka", "sys", "b", 2552) -> ShardRegion.ShardRegionStats(Map[ShardId, Int]("a" -> 23), Set("b")))))
+          Address("pekko", "sys", "a", 2552) -> ShardRegion.ShardRegionStats(Map[ShardId, Int]("a" -> 23), Set("b")),
+          Address("pekko", "sys", "b", 2552) -> ShardRegion.ShardRegionStats(Map[ShardId, Int]("a" -> 23), Set("b")))))
     }
   }
 }
diff --git a/cluster-tools/src/main/resources/reference.conf b/cluster-tools/src/main/resources/reference.conf
index f3c5b1e464..b6cc8e9388 100644
--- a/cluster-tools/src/main/resources/reference.conf
+++ b/cluster-tools/src/main/resources/reference.conf
@@ -98,7 +98,7 @@ pekko.cluster.client {
   # that the client will try to contact initially. It is mandatory to specify
   # at least one initial contact. 
   # Comma separated full actor paths defined by a string on the form of
-  # "akka://system@hostname:port/system/receptionist"
+  # "pekko://system@hostname:port/system/receptionist"
   initial-contacts = []
   
   # Interval at which the client retries to establish contact with one of 
diff --git a/cluster-tools/src/main/scala/org/apache/pekko/cluster/client/ClusterClient.scala b/cluster-tools/src/main/scala/org/apache/pekko/cluster/client/ClusterClient.scala
index 9ec44c4ccf..5df02bb25c 100644
--- a/cluster-tools/src/main/scala/org/apache/pekko/cluster/client/ClusterClient.scala
+++ b/cluster-tools/src/main/scala/org/apache/pekko/cluster/client/ClusterClient.scala
@@ -105,7 +105,7 @@ object ClusterClientSettings {
  *   the servers (cluster nodes) that the client will try to contact initially.
  *   It is mandatory to specify at least one initial contact. The path of the
  *   default receptionist is
- *   "akka://system@hostname:port/system/receptionist"
+ *   "pekko://system@hostname:port/system/receptionist"
  * @param establishingGetContactsInterval Interval at which the client retries
  *   to establish contact with one of ClusterReceptionist on the servers (cluster nodes)
  * @param refreshContactsInterval Interval at which the client will ask the
diff --git a/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala b/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala
index e5157c705d..5ca698c9ed 100644
--- a/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala
+++ b/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala
@@ -205,8 +205,8 @@ class ClusterClientSpec extends MultiNodeSpec(ClusterClientSpec) with STMultiNod
   def docOnly = { // not used, only demo
     // #initialContacts
     val initialContacts = Set(
-      ActorPath.fromString("akka://OtherSys@host1:2552/system/receptionist"),
-      ActorPath.fromString("akka://OtherSys@host2:2552/system/receptionist"))
+      ActorPath.fromString("pekko://OtherSys@host1:2552/system/receptionist"),
+      ActorPath.fromString("pekko://OtherSys@host2:2552/system/receptionist"))
     val settings = ClusterClientSettings(system).withInitialContacts(initialContacts)
     // #initialContacts
 
diff --git a/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java b/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java
index 241e08c4ac..974c1ac42c 100644
--- a/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java
+++ b/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java
@@ -41,8 +41,8 @@ public class ClusterClientTest extends JUnitSuite {
   Set<ActorPath> initialContacts() {
     return new HashSet<ActorPath>(
         Arrays.asList(
-            ActorPaths.fromString("akka://OtherSys@host1:2552/system/receptionist"),
-            ActorPaths.fromString("akka://OtherSys@host2:2552/system/receptionist")));
+            ActorPaths.fromString("pekko://OtherSys@host1:2552/system/receptionist"),
+            ActorPaths.fromString("pekko://OtherSys@host2:2552/system/receptionist")));
   }
   // #initialContacts
 
diff --git a/cluster-tools/src/test/scala/org/apache/pekko/cluster/client/protobuf/ClusterClientMessageSerializerSpec.scala b/cluster-tools/src/test/scala/org/apache/pekko/cluster/client/protobuf/ClusterClientMessageSerializerSpec.scala
index e1f683bf1f..65879d790a 100644
--- a/cluster-tools/src/test/scala/org/apache/pekko/cluster/client/protobuf/ClusterClientMessageSerializerSpec.scala
+++ b/cluster-tools/src/test/scala/org/apache/pekko/cluster/client/protobuf/ClusterClientMessageSerializerSpec.scala
@@ -35,9 +35,9 @@ class ClusterClientMessageSerializerSpec extends PekkoSpec {
 
     "be serializable" in {
       val contactPoints = Vector(
-        "akka://system@node-1:2552/system/receptionist",
-        "akka://system@node-2:2552/system/receptionist",
-        "akka://system@node-3:2552/system/receptionist")
+        "pekko://system@node-1:2552/system/receptionist",
+        "pekko://system@node-2:2552/system/receptionist",
+        "pekko://system@node-3:2552/system/receptionist")
       checkSerialization(Contacts(contactPoints))
       checkSerialization(GetContacts)
       checkSerialization(Heartbeat)
diff --git a/cluster-tools/src/test/scala/org/apache/pekko/cluster/pubsub/protobuf/DistributedPubSubMessageSerializerSpec.scala b/cluster-tools/src/test/scala/org/apache/pekko/cluster/pubsub/protobuf/DistributedPubSubMessageSerializerSpec.scala
index f4d2f58c6b..993995fc28 100644
--- a/cluster-tools/src/test/scala/org/apache/pekko/cluster/pubsub/protobuf/DistributedPubSubMessageSerializerSpec.scala
+++ b/cluster-tools/src/test/scala/org/apache/pekko/cluster/pubsub/protobuf/DistributedPubSubMessageSerializerSpec.scala
@@ -35,9 +35,9 @@ class DistributedPubSubMessageSerializerSpec extends PekkoSpec {
   " DistributedPubSubMessages" must {
 
     "be serializable" in {
-      val address1 = Address("akka", "system", "some.host.org", 4711)
-      val address2 = Address("akka", "system", "other.host.org", 4711)
-      val address3 = Address("akka", "system", "some.host.org", 4712)
+      val address1 = Address("pekko", "system", "some.host.org", 4711)
+      val address2 = Address("pekko", "system", "other.host.org", 4711)
+      val address3 = Address("pekko", "system", "some.host.org", 4712)
       val u1 = system.actorOf(Props.empty, "u1")
       val u2 = system.actorOf(Props.empty, "u2")
       val u3 = system.actorOf(Props.empty, "u3")
diff --git a/cluster-tools/src/test/scala/org/apache/pekko/cluster/singleton/ClusterSingletonLeaseSpec.scala b/cluster-tools/src/test/scala/org/apache/pekko/cluster/singleton/ClusterSingletonLeaseSpec.scala
index 1d93c9c15d..8b8221fc2b 100644
--- a/cluster-tools/src/test/scala/org/apache/pekko/cluster/singleton/ClusterSingletonLeaseSpec.scala
+++ b/cluster-tools/src/test/scala/org/apache/pekko/cluster/singleton/ClusterSingletonLeaseSpec.scala
@@ -88,7 +88,7 @@ class ClusterSingletonLeaseSpec extends PekkoSpec(ConfigFactory.parseString("""
   def nextSettings() = ClusterSingletonManagerSettings(system).withSingletonName(nextName())
 
   def leaseNameFor(settings: ClusterSingletonManagerSettings): String =
-    s"ClusterSingletonLeaseSpec-singleton-akka://ClusterSingletonLeaseSpec/user/${settings.singletonName}"
+    s"ClusterSingletonLeaseSpec-singleton-pekko://ClusterSingletonLeaseSpec/user/${settings.singletonName}"
 
   "A singleton with lease" should {
 
diff --git a/cluster-typed/src/test/java/jdocs/org/apache/pekko/cluster/typed/BasicClusterExampleTest.java b/cluster-typed/src/test/java/jdocs/org/apache/pekko/cluster/typed/BasicClusterExampleTest.java
index fdf7016ad9..1031e2a313 100644
--- a/cluster-typed/src/test/java/jdocs/org/apache/pekko/cluster/typed/BasicClusterExampleTest.java
+++ b/cluster-typed/src/test/java/jdocs/org/apache/pekko/cluster/typed/BasicClusterExampleTest.java
@@ -131,8 +131,8 @@ public class BasicClusterExampleTest { // extends JUnitSuite {
 
     // #join-seed-nodes
     List<Address> seedNodes = new ArrayList<>();
-    seedNodes.add(AddressFromURIString.parse("akka://ClusterSystem@127.0.0.1:2551"));
-    seedNodes.add(AddressFromURIString.parse("akka://ClusterSystem@127.0.0.1:2552"));
+    seedNodes.add(AddressFromURIString.parse("pekko://ClusterSystem@127.0.0.1:2551"));
+    seedNodes.add(AddressFromURIString.parse("pekko://ClusterSystem@127.0.0.1:2552"));
 
     Cluster.get(system).manager().tell(new JoinSeedNodes(seedNodes));
     // #join-seed-nodes
diff --git a/cluster-typed/src/test/scala/docs/org/apache/pekko/cluster/typed/BasicClusterExampleSpec.scala b/cluster-typed/src/test/scala/docs/org/apache/pekko/cluster/typed/BasicClusterExampleSpec.scala
index 80371238fd..a1a5846c0e 100644
--- a/cluster-typed/src/test/scala/docs/org/apache/pekko/cluster/typed/BasicClusterExampleSpec.scala
+++ b/cluster-typed/src/test/scala/docs/org/apache/pekko/cluster/typed/BasicClusterExampleSpec.scala
@@ -52,8 +52,8 @@ pekko {
 
   cluster {
     seed-nodes = [
-      "akka://ClusterSystem@127.0.0.1:2551",
-      "akka://ClusterSystem@127.0.0.1:2552"]
+      "pekko://ClusterSystem@127.0.0.1:2551",
+      "pekko://ClusterSystem@127.0.0.1:2552"]
     
     downing-provider-class = "org.apache.pekko.cluster.sbr.SplitBrainResolverProvider"
   }
@@ -75,7 +75,8 @@ pekko {
     import pekko.cluster.typed.JoinSeedNodes
 
     val seedNodes: List[Address] =
-      List("akka://ClusterSystem@127.0.0.1:2551", "akka://ClusterSystem@127.0.0.1:2552").map(AddressFromURIString.parse)
+      List("pekko://ClusterSystem@127.0.0.1:2551", "pekko://ClusterSystem@127.0.0.1:2552").map(
+        AddressFromURIString.parse)
     Cluster(system).manager ! JoinSeedNodes(seedNodes)
     // #join-seed-nodes
   }
@@ -133,7 +134,7 @@ class BasicClusterConfigSpec extends AnyWordSpec with ScalaFutures with Eventual
           pekko.remote.classic.netty.tcp.port = $port
           pekko.remote.artery.canonical.port = $port
           pekko.cluster.jmx.multi-mbeans-in-same-jvm = on
-          pekko.cluster.seed-nodes = [ "akka://ClusterSystem@127.0.0.1:$sys1Port", "akka://ClusterSystem@127.0.0.1:$sys2Port" ]
+          pekko.cluster.seed-nodes = [ "pekko://ClusterSystem@127.0.0.1:$sys1Port", "pekko://ClusterSystem@127.0.0.1:$sys2Port" ]
         """)
 
       val system1 =
diff --git a/cluster-typed/src/test/scala/org/apache/pekko/cluster/typed/ClusterApiSpec.scala b/cluster-typed/src/test/scala/org/apache/pekko/cluster/typed/ClusterApiSpec.scala
index 8f5e335a9e..13237445d4 100644
--- a/cluster-typed/src/test/scala/org/apache/pekko/cluster/typed/ClusterApiSpec.scala
+++ b/cluster-typed/src/test/scala/org/apache/pekko/cluster/typed/ClusterApiSpec.scala
@@ -53,7 +53,7 @@ class ClusterApiSpec extends ScalaTestWithActorTestKit(ClusterApiSpec.config) wi
   "A typed Cluster" must {
 
     "fail fast in a join attempt if invalid chars are in host names, e.g. docker host given name" in {
-      val address = Address("akka", "sys", Some("in_valid"), Some(0))
+      val address = Address("pekko", "sys", Some("in_valid"), Some(0))
       intercept[IllegalArgumentException](Join(address))
       intercept[IllegalArgumentException](JoinSeedNodes(scala.collection.immutable.Seq(address)))
     }
diff --git a/cluster-typed/src/test/scala/org/apache/pekko/cluster/typed/RemoteDeployNotAllowedSpec.scala b/cluster-typed/src/test/scala/org/apache/pekko/cluster/typed/RemoteDeployNotAllowedSpec.scala
index 92fdecb7cd..95f395f804 100644
--- a/cluster-typed/src/test/scala/org/apache/pekko/cluster/typed/RemoteDeployNotAllowedSpec.scala
+++ b/cluster-typed/src/test/scala/org/apache/pekko/cluster/typed/RemoteDeployNotAllowedSpec.scala
@@ -45,7 +45,7 @@ object RemoteDeployNotAllowedSpec {
   def configWithRemoteDeployment(otherSystemPort: Int) = ConfigFactory.parseString(s"""
       pekko.actor.deployment {
         "/*" {
-          remote = "akka://sampleActorSystem@127.0.0.1:$otherSystemPort"
+          remote = "pekko://sampleActorSystem@127.0.0.1:$otherSystemPort"
         }
       }
     """).withFallback(config)
diff --git a/cluster/src/main/resources/reference.conf b/cluster/src/main/resources/reference.conf
index 1073a62d09..a5793c2737 100644
--- a/cluster/src/main/resources/reference.conf
+++ b/cluster/src/main/resources/reference.conf
@@ -11,7 +11,7 @@ pekko {
     # Initial contact points of the cluster.
     # The nodes to join automatically at startup.
     # Comma separated full URIs defined by a string on the form of
-    # "akka://system@hostname:port"
+    # "pekko://system@hostname:port"
     # Leave as empty if the node is supposed to be joined manually.
     seed-nodes = []
 
diff --git a/cluster/src/main/scala/org/apache/pekko/cluster/ClusterJmx.scala b/cluster/src/main/scala/org/apache/pekko/cluster/ClusterJmx.scala
index 5e4da3722c..0ddafa3dfd 100644
--- a/cluster/src/main/scala/org/apache/pekko/cluster/ClusterJmx.scala
+++ b/cluster/src/main/scala/org/apache/pekko/cluster/ClusterJmx.scala
@@ -35,13 +35,13 @@ trait ClusterNodeMBean {
 
   /**
    * Comma separated addresses of member nodes, sorted in the cluster ring order.
-   * The address format is `akka://actor-system-name@hostname:port`
+   * The address format is `pekko://actor-system-name@hostname:port`
    */
   def getMembers: String
 
   /**
    * Comma separated addresses of unreachable member nodes.
-   * The address format is `akka://actor-system-name@hostname:port`
+   * The address format is `pekko://actor-system-name@hostname:port`
    */
   def getUnreachable: String
 
@@ -49,10 +49,10 @@ trait ClusterNodeMBean {
    * JSON format of the status of all nodes in the cluster as follows:
    * {{{
    * {
-   *   "self-address": "akka://system@host1:2552",
+   *   "self-address": "pekko://system@host1:2552",
    *   "members": [
    *     {
-   *       "address": "akka://system@host1:2552",
+   *       "address": "pekko://system@host1:2552",
    *       "status": "Up",
    *       "app-version": "1.0.0",
    *       "roles": [
@@ -60,7 +60,7 @@ trait ClusterNodeMBean {
    *       ]
    *     },
    *     {
-   *       "address": "akka://system@host2:2552",
+   *       "address": "pekko://system@host2:2552",
    *       "status": "Up",
    *       "app-version": "1.0.0",
    *       "roles": [
@@ -68,7 +68,7 @@ trait ClusterNodeMBean {
    *       ]
    *     },
    *     {
-   *       "address": "akka://system@host3:2552",
+   *       "address": "pekko://system@host3:2552",
    *       "status": "Down",
    *       "app-version": "1.0.0",
    *       "roles": [
@@ -76,7 +76,7 @@ trait ClusterNodeMBean {
    *       ]
    *     },
    *     {
-   *       "address": "akka://system@host4:2552",
+   *       "address": "pekko://system@host4:2552",
    *       "status": "Joining",
    *       "app-version": "1.1.0",
    *       "roles": [
@@ -86,17 +86,17 @@ trait ClusterNodeMBean {
    *   ],
    *   "unreachable": [
    *     {
-   *       "node": "akka://system@host2:2552",
+   *       "node": "pekko://system@host2:2552",
    *       "observed-by": [
-   *         "akka://system@host1:2552",
-   *         "akka://system@host3:2552"
+   *         "pekko://system@host1:2552",
+   *         "pekko://system@host3:2552"
    *       ]
    *     },
    *     {
-   *       "node": "akka://system@host3:2552",
+   *       "node": "pekko://system@host3:2552",
    *       "observed-by": [
-   *         "akka://system@host1:2552",
-   *         "akka://system@host2:2552"
+   *         "pekko://system@host1:2552",
+   *         "pekko://system@host2:2552"
    *       ]
    *     }
    *   ]
@@ -107,7 +107,7 @@ trait ClusterNodeMBean {
 
   /**
    * Get the address of the current leader.
-   * The address format is `akka://actor-system-name@hostname:port`
+   * The address format is `pekko://actor-system-name@hostname:port`
    */
   def getLeader: String
 
@@ -124,20 +124,20 @@ trait ClusterNodeMBean {
 
   /**
    * Try to join this cluster node with the node specified by 'address'.
-   * The address format is `akka://actor-system-name@hostname:port`.
+   * The address format is `pekko://actor-system-name@hostname:port`.
    * A 'Join(thisNodeAddress)' command is sent to the node to join.
    */
   def join(address: String): Unit
 
   /**
    * Send command to issue state transition to LEAVING for the node specified by 'address'.
-   * The address format is `akka://actor-system-name@hostname:port`
+   * The address format is `pekko://actor-system-name@hostname:port`
    */
   def leave(address: String): Unit
 
   /**
    * Send command to DOWN the node specified by 'address'.
-   * The address format is `akka://actor-system-name@hostname:port`
+   * The address format is `pekko://actor-system-name@hostname:port`
    */
   def down(address: String): Unit
 }
@@ -150,9 +150,9 @@ private[pekko] class ClusterJmx(cluster: Cluster, log: LoggingAdapter) {
   private val mBeanServer = ManagementFactory.getPlatformMBeanServer
   private val clusterMBeanName =
     if (cluster.settings.JmxMultiMbeansInSameEnabled)
-      new ObjectName("akka:type=Cluster,port=" + cluster.selfUniqueAddress.address.port.getOrElse(""))
+      new ObjectName("pekko:type=Cluster,port=" + cluster.selfUniqueAddress.address.port.getOrElse(""))
     else
-      new ObjectName("akka:type=Cluster")
+      new ObjectName("pekko:type=Cluster")
 
   private def clusterView = cluster.readView
   import cluster.ClusterLogger._
diff --git a/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/MBeanSpec.scala b/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/MBeanSpec.scala
index 83e77e07fc..a4f4b2dc6b 100644
--- a/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/MBeanSpec.scala
+++ b/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/MBeanSpec.scala
@@ -49,7 +49,7 @@ abstract class MBeanSpec extends MultiNodeClusterSpec(MBeanMultiJvmSpec) {
 
   import MBeanMultiJvmSpec._
 
-  val mbeanName = new ObjectName("akka:type=Cluster")
+  val mbeanName = new ObjectName("pekko:type=Cluster")
   lazy val mbeanServer = ManagementFactory.getPlatformMBeanServer
 
   "Cluster MBean" must {
diff --git a/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/RemoteFeaturesWithClusterSpec.scala b/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/RemoteFeaturesWithClusterSpec.scala
index 57c44c7cd7..e1a2676398 100644
--- a/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/RemoteFeaturesWithClusterSpec.scala
+++ b/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/RemoteFeaturesWithClusterSpec.scala
@@ -124,7 +124,7 @@ abstract class ClusterRemoteFeaturesSpec(multiNodeConfig: ClusterRemoteFeaturesC
       def assertIsLocalRef(): Unit = {
         val actor = system.actorOf(Props[AddressPing](), "kattdjur")
         actor.isInstanceOf[RepointableActorRef] shouldBe true
-        val localAddress = AddressFromURIString(s"akka://${system.name}")
+        val localAddress = AddressFromURIString(s"pekko://${system.name}")
         actor.path.address shouldEqual localAddress
         actor.path.address.hasLocalScope shouldBe true
 
diff --git a/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/StressSpec.scala b/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/StressSpec.scala
index 3fd5d0beb6..b4fe55f04a 100644
--- a/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/StressSpec.scala
+++ b/cluster/src/multi-jvm/scala/org/apache/pekko/cluster/StressSpec.scala
@@ -66,7 +66,7 @@ import pekko.util.Helpers.Requiring
  *
  * By default it uses 13 nodes.
  * Example of sbt command line parameters to double that:
- * `-DMultiJvm.pekko.cluster.Stress.nrOfNodes=26 -Dmultinode.Dakka.test.cluster-stress-spec.nr-of-nodes-factor=2`
+ * `-DMultiJvm.pekko.cluster.Stress.nrOfNodes=26 -Dmultinode.pekko.test.cluster-stress-spec.nr-of-nodes-factor=2`
  */
 private[cluster] object StressMultiJvmSpec extends MultiNodeConfig {
 
diff --git a/cluster/src/test/java/org/apache/pekko/cluster/ClusterJavaCompileTest.java b/cluster/src/test/java/org/apache/pekko/cluster/ClusterJavaCompileTest.java
index cac486966b..1929359497 100644
--- a/cluster/src/test/java/org/apache/pekko/cluster/ClusterJavaCompileTest.java
+++ b/cluster/src/test/java/org/apache/pekko/cluster/ClusterJavaCompileTest.java
@@ -27,7 +27,7 @@ public class ClusterJavaCompileTest {
   final Cluster cluster = null;
 
   public void compileJoinSeedNodesInJava() {
-    final List<Address> addresses = Collections.singletonList(new Address("akka", "MySystem"));
+    final List<Address> addresses = Collections.singletonList(new Address("pekko", "MySystem"));
     cluster.joinSeedNodes(addresses);
   }
 }
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/ClusterDomainEventPublisherSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/ClusterDomainEventPublisherSpec.scala
index 052b2eab6d..ebd02a1b5f 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/ClusterDomainEventPublisherSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/ClusterDomainEventPublisherSpec.scala
@@ -45,8 +45,8 @@ class ClusterDomainEventPublisherSpec
     with ImplicitSender {
 
   val protocol =
-    if (RARP(system).provider.remoteSettings.Artery.Enabled) "akka"
-    else "akka.tcp"
+    if (RARP(system).provider.remoteSettings.Artery.Enabled) "pekko"
+    else "pekko.tcp"
 
   var publisher: ActorRef = _
 
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/ClusterDomainEventSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/ClusterDomainEventSpec.scala
index 3374312d64..6b28d342e1 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/ClusterDomainEventSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/ClusterDomainEventSpec.scala
@@ -25,25 +25,25 @@ class ClusterDomainEventSpec extends AnyWordSpec with Matchers with BeforeAndAft
   import MemberStatus._
 
   val aRoles = Set("AA", "AB")
-  val aJoining = TestMember(Address("akka", "sys", "a", 2552), Joining, aRoles)
-  val aUp = TestMember(Address("akka", "sys", "a", 2552), Up, aRoles)
-  val aRemoved = TestMember(Address("akka", "sys", "a", 2552), Removed, aRoles)
+  val aJoining = TestMember(Address("pekko", "sys", "a", 2552), Joining, aRoles)
+  val aUp = TestMember(Address("pekko", "sys", "a", 2552), Up, aRoles)
+  val aRemoved = TestMember(Address("pekko", "sys", "a", 2552), Removed, aRoles)
   val bRoles = Set("AB", "BB")
-  val bUp = TestMember(Address("akka", "sys", "b", 2552), Up, bRoles)
-  val bDown = TestMember(Address("akka", "sys", "b", 2552), Down, bRoles)
-  val bRemoved = TestMember(Address("akka", "sys", "b", 2552), Removed, bRoles)
+  val bUp = TestMember(Address("pekko", "sys", "b", 2552), Up, bRoles)
+  val bDown = TestMember(Address("pekko", "sys", "b", 2552), Down, bRoles)
+  val bRemoved = TestMember(Address("pekko", "sys", "b", 2552), Removed, bRoles)
   val cRoles = Set.empty[String]
-  val cUp = TestMember(Address("akka", "sys", "c", 2552), Up, cRoles)
-  val cLeaving = TestMember(Address("akka", "sys", "c", 2552), Leaving, cRoles)
+  val cUp = TestMember(Address("pekko", "sys", "c", 2552), Up, cRoles)
+  val cLeaving = TestMember(Address("pekko", "sys", "c", 2552), Leaving, cRoles)
   val dRoles = Set("DD", "DE")
-  val dLeaving = TestMember(Address("akka", "sys", "d", 2552), Leaving, dRoles)
-  val dExiting = TestMember(Address("akka", "sys", "d", 2552), Exiting, dRoles)
-  val dRemoved = TestMember(Address("akka", "sys", "d", 2552), Removed, dRoles)
+  val dLeaving = TestMember(Address("pekko", "sys", "d", 2552), Leaving, dRoles)
+  val dExiting = TestMember(Address("pekko", "sys", "d", 2552), Exiting, dRoles)
+  val dRemoved = TestMember(Address("pekko", "sys", "d", 2552), Removed, dRoles)
   val eRoles = Set("EE", "DE")
-  val eJoining = TestMember(Address("akka", "sys", "e", 2552), Joining, eRoles)
-  val eUp = TestMember(Address("akka", "sys", "e", 2552), Up, eRoles)
-  val eDown = TestMember(Address("akka", "sys", "e", 2552), Down, eRoles)
-  val selfDummyAddress = UniqueAddress(Address("akka", "sys", "selfDummy", 2552), 17L)
+  val eJoining = TestMember(Address("pekko", "sys", "e", 2552), Joining, eRoles)
+  val eUp = TestMember(Address("pekko", "sys", "e", 2552), Up, eRoles)
+  val eDown = TestMember(Address("pekko", "sys", "e", 2552), Down, eRoles)
+  val selfDummyAddress = UniqueAddress(Address("pekko", "sys", "selfDummy", 2552), 17L)
 
   private val originalClusterAssert = sys.props.get("pekko.cluster.assert").getOrElse("false")
   override protected def beforeAll(): Unit = {
@@ -109,12 +109,12 @@ class ClusterDomainEventSpec extends AnyWordSpec with Matchers with BeforeAndAft
     }
 
     "be produced for reachability observations between data centers" in {
-      val dc2AMemberUp = TestMember(Address("akka", "sys", "dc2A", 2552), Up, Set.empty[String], "dc2")
-      val dc2AMemberDown = TestMember(Address("akka", "sys", "dc2A", 2552), Down, Set.empty[String], "dc2")
-      val dc2BMemberUp = TestMember(Address("akka", "sys", "dc2B", 2552), Up, Set.empty[String], "dc2")
+      val dc2AMemberUp = TestMember(Address("pekko", "sys", "dc2A", 2552), Up, Set.empty[String], "dc2")
+      val dc2AMemberDown = TestMember(Address("pekko", "sys", "dc2A", 2552), Down, Set.empty[String], "dc2")
+      val dc2BMemberUp = TestMember(Address("pekko", "sys", "dc2B", 2552), Up, Set.empty[String], "dc2")
 
-      val dc3AMemberUp = TestMember(Address("akka", "sys", "dc3A", 2552), Up, Set.empty[String], "dc3")
-      val dc3BMemberUp = TestMember(Address("akka", "sys", "dc3B", 2552), Up, Set.empty[String], "dc3")
+      val dc3AMemberUp = TestMember(Address("pekko", "sys", "dc3A", 2552), Up, Set.empty[String], "dc3")
+      val dc3BMemberUp = TestMember(Address("pekko", "sys", "dc3B", 2552), Up, Set.empty[String], "dc3")
 
       val reachability1 = Reachability.empty
       val g1 = Gossip(
@@ -146,8 +146,8 @@ class ClusterDomainEventSpec extends AnyWordSpec with Matchers with BeforeAndAft
     }
 
     "not be produced for same reachability observations between data centers" in {
-      val dc2AMemberUp = TestMember(Address("akka", "sys", "dc2A", 2552), Up, Set.empty[String], "dc2")
-      val dc2AMemberDown = TestMember(Address("akka", "sys", "dc2A", 2552), Down, Set.empty[String], "dc2")
+      val dc2AMemberUp = TestMember(Address("pekko", "sys", "dc2A", 2552), Up, Set.empty[String], "dc2")
+      val dc2AMemberDown = TestMember(Address("pekko", "sys", "dc2A", 2552), Down, Set.empty[String], "dc2")
 
       val reachability1 = Reachability.empty
       val g1 = Gossip(members = SortedSet(aUp, dc2AMemberUp), overview = GossipOverview(reachability = reachability1))
@@ -181,9 +181,9 @@ class ClusterDomainEventSpec extends AnyWordSpec with Matchers with BeforeAndAft
       // - empty
       // - B --unreachable--> C
 
-      val dc1MemberA = TestMember(Address("akka", "sys", "dc2A", 2552), Up, Set.empty[String], "dc2")
-      val dc1MemberB = TestMember(Address("akka", "sys", "dc2B", 2552), Up, Set.empty[String], "dc2")
-      val dc2MemberC = TestMember(Address("akka", "sys", "dc3A", 2552), Up, Set.empty[String], "dc3")
+      val dc1MemberA = TestMember(Address("pekko", "sys", "dc2A", 2552), Up, Set.empty[String], "dc2")
+      val dc1MemberB = TestMember(Address("pekko", "sys", "dc2B", 2552), Up, Set.empty[String], "dc2")
+      val dc2MemberC = TestMember(Address("pekko", "sys", "dc3A", 2552), Up, Set.empty[String], "dc3")
 
       val members = SortedSet(dc1MemberA, dc1MemberB, dc2MemberC)
 
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/ClusterHeartbeatSenderSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/ClusterHeartbeatSenderSpec.scala
index d69fd4d77f..e88a15db07 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/ClusterHeartbeatSenderSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/ClusterHeartbeatSenderSpec.scala
@@ -45,7 +45,7 @@ class ClusterHeartbeatSenderSpec extends PekkoSpec("""
       val underTest = system.actorOf(Props(new TestClusterHeartBeatSender(probe)))
       underTest ! CurrentClusterState()
       underTest ! MemberUp(
-        Member(UniqueAddress(Address("akka", system.name), 1L), Set("dc-default"), Version.Zero)
+        Member(UniqueAddress(Address("pekko", system.name), 1L), Set("dc-default"), Version.Zero)
           .copy(status = MemberStatus.Up))
 
       probe.expectMsgType[Heartbeat].sequenceNr shouldEqual 1
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/ClusterHeartbeatSenderStateSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/ClusterHeartbeatSenderStateSpec.scala
index 2245668d0c..afc556ce02 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/ClusterHeartbeatSenderStateSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/ClusterHeartbeatSenderStateSpec.scala
@@ -52,11 +52,11 @@ object ClusterHeartbeatSenderStateSpec {
 class ClusterHeartbeatSenderStateSpec extends AnyWordSpec with Matchers {
   import ClusterHeartbeatSenderStateSpec._
 
-  val aa = UniqueAddress(Address("akka", "sys", "aa", 2552), 1L)
-  val bb = UniqueAddress(Address("akka", "sys", "bb", 2552), 2L)
-  val cc = UniqueAddress(Address("akka", "sys", "cc", 2552), 3L)
-  val dd = UniqueAddress(Address("akka", "sys", "dd", 2552), 4L)
-  val ee = UniqueAddress(Address("akka", "sys", "ee", 2552), 5L)
+  val aa = UniqueAddress(Address("pekko", "sys", "aa", 2552), 1L)
+  val bb = UniqueAddress(Address("pekko", "sys", "bb", 2552), 2L)
+  val cc = UniqueAddress(Address("pekko", "sys", "cc", 2552), 3L)
+  val dd = UniqueAddress(Address("pekko", "sys", "dd", 2552), 4L)
+  val ee = UniqueAddress(Address("pekko", "sys", "ee", 2552), 5L)
 
   private def emptyState: ClusterHeartbeatSenderState = emptyState(aa)
 
@@ -164,7 +164,7 @@ class ClusterHeartbeatSenderStateSpec extends AnyWordSpec with Matchers {
     "behave correctly for random operations" in {
       val rnd = ThreadLocalRandom.current
       val nodes =
-        (1 to rnd.nextInt(10, 200)).map(n => UniqueAddress(Address("akka", "sys", "n" + n, 2552), n.toLong)).toVector
+        (1 to rnd.nextInt(10, 200)).map(n => UniqueAddress(Address("pekko", "sys", "n" + n, 2552), n.toLong)).toVector
       def rndNode() = nodes(rnd.nextInt(0, nodes.size))
       val selfUniqueAddress = rndNode()
       var state = emptyState(selfUniqueAddress)
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/ClusterSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/ClusterSpec.scala
index 8c175708c0..368e1ddd81 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/ClusterSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/ClusterSpec.scala
@@ -75,7 +75,7 @@ class ClusterSpec extends PekkoSpec(ClusterSpec.config) with ImplicitSender {
     }
 
     "register jmx mbean" in {
-      val name = new ObjectName("akka:type=Cluster")
+      val name = new ObjectName("pekko:type=Cluster")
       val info = ManagementFactory.getPlatformMBeanServer.getMBeanInfo(name)
       info.getAttributes.length should be > 0
       info.getOperations.length should be > 0
@@ -88,7 +88,7 @@ class ClusterSpec extends PekkoSpec(ClusterSpec.config) with ImplicitSender {
 
     "fail fast in a join if invalid chars in host names, e.g. docker host given name" in {
       val addresses = scala.collection.immutable
-        .Seq(Address("akka", "sys", Some("in_valid"), Some(0)), Address("akka", "sys", Some("invalid._org"), Some(0)))
+        .Seq(Address("pekko", "sys", Some("in_valid"), Some(0)), Address("pekko", "sys", Some("invalid._org"), Some(0)))
 
       addresses.foreach(a => intercept[IllegalArgumentException](cluster.join(a)))
       intercept[IllegalArgumentException](cluster.joinSeedNodes(addresses))
@@ -96,10 +96,10 @@ class ClusterSpec extends PekkoSpec(ClusterSpec.config) with ImplicitSender {
 
     "not fail fast to attempt a join with valid chars in host names" in {
       val addresses = scala.collection.immutable.Seq(
-        Address("akka", "sys", Some("localhost"), Some(0)),
-        Address("akka", "sys", Some("is_valid.org"), Some(0)),
-        Address("akka", "sys", Some("fu.is_valid.org"), Some(0)),
-        Address("akka", "sys", Some("fu_.is_valid.org"), Some(0)))
+        Address("pekko", "sys", Some("localhost"), Some(0)),
+        Address("pekko", "sys", Some("is_valid.org"), Some(0)),
+        Address("pekko", "sys", Some("fu.is_valid.org"), Some(0)),
+        Address("pekko", "sys", Some("fu_.is_valid.org"), Some(0)))
 
       addresses.foreach(cluster.join)
       cluster.joinSeedNodes(addresses)
@@ -364,12 +364,12 @@ class ClusterSpec extends PekkoSpec(ClusterSpec.config) with ImplicitSender {
         Cluster(sys1)
         Cluster(sys2)
 
-        val name1 = new ObjectName(s"akka:type=Cluster,port=2552")
+        val name1 = new ObjectName(s"pekko:type=Cluster,port=2552")
         val info1 = ManagementFactory.getPlatformMBeanServer.getMBeanInfo(name1)
         info1.getAttributes.length should be > 0
         info1.getOperations.length should be > 0
 
-        val name2 = new ObjectName(s"akka:type=Cluster,port=2553")
+        val name2 = new ObjectName(s"pekko:type=Cluster,port=2553")
         val info2 = ManagementFactory.getPlatformMBeanServer.getMBeanInfo(name2)
         info2.getAttributes.length should be > 0
         info2.getOperations.length should be > 0
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/CrossDcHeartbeatSenderSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/CrossDcHeartbeatSenderSpec.scala
index 094c9a957e..87ea648093 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/CrossDcHeartbeatSenderSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/CrossDcHeartbeatSenderSpec.scala
@@ -60,7 +60,7 @@ class CrossDcHeartbeatSenderSpec extends PekkoSpec("""
       underTest ! CurrentClusterState(
         members = SortedSet(
           Cluster(system).selfMember,
-          Member(UniqueAddress(Address("akka", system.name), 2L), Set("dc-dc2"), Version.Zero)
+          Member(UniqueAddress(Address("pekko", system.name), 2L), Set("dc-dc2"), Version.Zero)
             .copy(status = MemberStatus.Up)))
 
       awaitAssert {
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/GossipSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/GossipSpec.scala
index 2835e6fcba..089a75a619 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/GossipSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/GossipSpec.scala
@@ -27,23 +27,23 @@ class GossipSpec extends AnyWordSpec with Matchers {
 
   import MemberStatus._
 
-  val a1 = TestMember(Address("akka", "sys", "a", 2552), Up)
+  val a1 = TestMember(Address("pekko", "sys", "a", 2552), Up)
   val a2 = TestMember(a1.address, Joining)
-  val b1 = TestMember(Address("akka", "sys", "b", 2552), Up)
+  val b1 = TestMember(Address("pekko", "sys", "b", 2552), Up)
   val b2 = TestMember(b1.address, Removed)
-  val c1 = TestMember(Address("akka", "sys", "c", 2552), Leaving)
+  val c1 = TestMember(Address("pekko", "sys", "c", 2552), Leaving)
   val c2 = TestMember(c1.address, Up)
   val c3 = TestMember(c1.address, Exiting)
-  val d1 = TestMember(Address("akka", "sys", "d", 2552), Leaving)
-  val e1 = TestMember(Address("akka", "sys", "e", 2552), Joining)
+  val d1 = TestMember(Address("pekko", "sys", "d", 2552), Leaving)
+  val e1 = TestMember(Address("pekko", "sys", "e", 2552), Joining)
   val e2 = TestMember(e1.address, Up)
   val e3 = TestMember(e1.address, Down)
-  val f1 = TestMember(Address("akka", "sys", "f", 2552), Joining)
+  val f1 = TestMember(Address("pekko", "sys", "f", 2552), Joining)
 
-  val dc1a1 = TestMember(Address("akka", "sys", "a", 2552), Up, Set.empty, dataCenter = "dc1")
-  val dc1b1 = TestMember(Address("akka", "sys", "b", 2552), Up, Set.empty, dataCenter = "dc1")
-  val dc2c1 = TestMember(Address("akka", "sys", "c", 2552), Up, Set.empty, dataCenter = "dc2")
-  val dc2d1 = TestMember(Address("akka", "sys", "d", 2552), Up, Set.empty, dataCenter = "dc2")
+  val dc1a1 = TestMember(Address("pekko", "sys", "a", 2552), Up, Set.empty, dataCenter = "dc1")
+  val dc1b1 = TestMember(Address("pekko", "sys", "b", 2552), Up, Set.empty, dataCenter = "dc1")
+  val dc2c1 = TestMember(Address("pekko", "sys", "c", 2552), Up, Set.empty, dataCenter = "dc2")
+  val dc2d1 = TestMember(Address("pekko", "sys", "d", 2552), Up, Set.empty, dataCenter = "dc2")
   val dc2d2 = TestMember(dc2d1.address, status = Down, roles = Set.empty, dataCenter = dc2d1.dataCenter)
   // restarted with another uid
   val dc2d3 =
@@ -533,7 +533,7 @@ class GossipSpec extends AnyWordSpec with Matchers {
     }
 
     "update members" in {
-      val joining = TestMember(Address("akka", "sys", "d", 2552), Joining, Set.empty, dataCenter = "dc2")
+      val joining = TestMember(Address("pekko", "sys", "d", 2552), Joining, Set.empty, dataCenter = "dc2")
       val g = Gossip(members = SortedSet(dc1a1, joining))
 
       g.member(joining.uniqueAddress).status should ===(Joining)
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/GossipTargetSelectorSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/GossipTargetSelectorSpec.scala
index 242bd68de9..9da93fbfd7 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/GossipTargetSelectorSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/GossipTargetSelectorSpec.scala
@@ -25,17 +25,17 @@ import pekko.cluster.MemberStatus.Up
 
 class GossipTargetSelectorSpec extends AnyWordSpec with Matchers {
 
-  val aDc1 = TestMember(Address("akka", "sys", "a", 2552), Up, Set.empty, dataCenter = "dc1")
-  val bDc1 = TestMember(Address("akka", "sys", "b", 2552), Up, Set.empty, dataCenter = "dc1")
-  val cDc1 = TestMember(Address("akka", "sys", "c", 2552), Up, Set.empty, dataCenter = "dc1")
+  val aDc1 = TestMember(Address("pekko", "sys", "a", 2552), Up, Set.empty, dataCenter = "dc1")
+  val bDc1 = TestMember(Address("pekko", "sys", "b", 2552), Up, Set.empty, dataCenter = "dc1")
+  val cDc1 = TestMember(Address("pekko", "sys", "c", 2552), Up, Set.empty, dataCenter = "dc1")
 
-  val eDc2 = TestMember(Address("akka", "sys", "e", 2552), Up, Set.empty, dataCenter = "dc2")
-  val fDc2 = TestMember(Address("akka", "sys", "f", 2552), Up, Set.empty, dataCenter = "dc2")
+  val eDc2 = TestMember(Address("pekko", "sys", "e", 2552), Up, Set.empty, dataCenter = "dc2")
+  val fDc2 = TestMember(Address("pekko", "sys", "f", 2552), Up, Set.empty, dataCenter = "dc2")
 
-  val gDc3 = TestMember(Address("akka", "sys", "g", 2552), Up, Set.empty, dataCenter = "dc3")
-  val hDc3 = TestMember(Address("akka", "sys", "h", 2552), Up, Set.empty, dataCenter = "dc3")
+  val gDc3 = TestMember(Address("pekko", "sys", "g", 2552), Up, Set.empty, dataCenter = "dc3")
+  val hDc3 = TestMember(Address("pekko", "sys", "h", 2552), Up, Set.empty, dataCenter = "dc3")
 
-  val iDc4 = TestMember(Address("akka", "sys", "i", 2552), Up, Set.empty, dataCenter = "dc4")
+  val iDc4 = TestMember(Address("pekko", "sys", "i", 2552), Up, Set.empty, dataCenter = "dc4")
 
   val defaultSelector =
     new GossipTargetSelector(reduceGossipDifferentViewProbability = 400, crossDcGossipProbability = 0.2)
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/HeartbeatNodeRingPerfSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/HeartbeatNodeRingPerfSpec.scala
index b893e4c9aa..ac1d8ea596 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/HeartbeatNodeRingPerfSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/HeartbeatNodeRingPerfSpec.scala
@@ -26,7 +26,7 @@ class HeartbeatNodeRingPerfSpec extends AnyWordSpec with Matchers {
     sys.props.get("org.apache.pekko.cluster.HeartbeatNodeRingPerfSpec.iterations").getOrElse("1000").toInt
 
   def createHeartbeatNodeRingOfSize(size: Int): HeartbeatNodeRing = {
-    val nodes = (1 to size).map(n => UniqueAddress(Address("akka", "sys", "node-" + n, 2552), n.toLong))
+    val nodes = (1 to size).map(n => UniqueAddress(Address("pekko", "sys", "node-" + n, 2552), n.toLong))
     val selfAddress = nodes(size / 2)
     HeartbeatNodeRing(selfAddress, nodes.toSet, Set.empty, 5)
   }
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/HeartbeatNodeRingSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/HeartbeatNodeRingSpec.scala
index feb550ea44..46114e75b8 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/HeartbeatNodeRingSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/HeartbeatNodeRingSpec.scala
@@ -20,12 +20,12 @@ import org.apache.pekko.actor.Address
 
 class HeartbeatNodeRingSpec extends AnyWordSpec with Matchers {
 
-  val aa = UniqueAddress(Address("akka", "sys", "aa", 2552), 1L)
-  val bb = UniqueAddress(Address("akka", "sys", "bb", 2552), 2L)
-  val cc = UniqueAddress(Address("akka", "sys", "cc", 2552), 3L)
-  val dd = UniqueAddress(Address("akka", "sys", "dd", 2552), 4L)
-  val ee = UniqueAddress(Address("akka", "sys", "ee", 2552), 5L)
-  val ff = UniqueAddress(Address("akka", "sys", "ff", 2552), 6L)
+  val aa = UniqueAddress(Address("pekko", "sys", "aa", 2552), 1L)
+  val bb = UniqueAddress(Address("pekko", "sys", "bb", 2552), 2L)
+  val cc = UniqueAddress(Address("pekko", "sys", "cc", 2552), 3L)
+  val dd = UniqueAddress(Address("pekko", "sys", "dd", 2552), 4L)
+  val ee = UniqueAddress(Address("pekko", "sys", "ee", 2552), 5L)
+  val ff = UniqueAddress(Address("pekko", "sys", "ff", 2552), 6L)
 
   val nodes = Set(aa, bb, cc, dd, ee, ff)
 
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/JoinConfigCompatCheckerSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/JoinConfigCompatCheckerSpec.scala
index 5a7d16a382..74f7a75969 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/JoinConfigCompatCheckerSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/JoinConfigCompatCheckerSpec.scala
@@ -47,7 +47,7 @@ object JoinConfigCompatCheckerSpec {
            pekko-cluster-test = "org.apache.pekko.cluster.JoinConfigCompatCheckerTest"
           }
           sensitive-config-paths {
-            akka = [ "pekko.cluster.sensitive.properties" ]
+            pekko = [ "pekko.cluster.sensitive.properties" ]
           }
         }
       }
@@ -586,7 +586,7 @@ class JoinConfigCompatCheckerSpec extends PekkoSpec with ClusterTestKit {
                 # this will allow the joining node to leak sensitive info and try
                 # get back these same properties from the cluster
                 sensitive-config-paths {
-                  akka = []
+                  pekko = []
                 }
               }
             }
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/MemberOrderingSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/MemberOrderingSpec.scala
index 2909b00fdf..a62d1d2f79 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/MemberOrderingSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/MemberOrderingSpec.scala
@@ -35,22 +35,22 @@ class MemberOrderingSpec extends AnyWordSpec with Matchers {
 
     "order members by host:port" in {
       val members = SortedSet.empty[Member] +
-        m(AddressFromURIString("akka://sys@darkstar:1112"), Up) +
-        m(AddressFromURIString("akka://sys@darkstar:1113"), Joining) +
-        m(AddressFromURIString("akka://sys@darkstar:1111"), Up)
+        m(AddressFromURIString("pekko://sys@darkstar:1112"), Up) +
+        m(AddressFromURIString("pekko://sys@darkstar:1113"), Joining) +
+        m(AddressFromURIString("pekko://sys@darkstar:1111"), Up)
 
       val seq = members.toSeq
       seq.size should ===(3)
-      seq(0) should ===(m(AddressFromURIString("akka://sys@darkstar:1111"), Up))
-      seq(1) should ===(m(AddressFromURIString("akka://sys@darkstar:1112"), Up))
-      seq(2) should ===(m(AddressFromURIString("akka://sys@darkstar:1113"), Joining))
+      seq(0) should ===(m(AddressFromURIString("pekko://sys@darkstar:1111"), Up))
+      seq(1) should ===(m(AddressFromURIString("pekko://sys@darkstar:1112"), Up))
+      seq(2) should ===(m(AddressFromURIString("pekko://sys@darkstar:1113"), Joining))
     }
 
     "be sorted by address correctly" in {
       import Member.ordering
       // sorting should be done on host and port, only
-      val m1 = m(Address("akka", "sys1", "host1", 9000), Up)
-      val m2 = m(Address("akka", "sys1", "host1", 10000), Up)
+      val m1 = m(Address("pekko", "sys1", "host1", 9000), Up)
+      val m2 = m(Address("pekko", "sys1", "host1", 10000), Up)
       val m3 = m(Address("cluster", "sys2", "host2", 8000), Up)
       val m4 = m(Address("cluster", "sys2", "host2", 9000), Up)
       val m5 = m(Address("cluster", "sys1", "host2", 10000), Up)
@@ -62,7 +62,7 @@ class MemberOrderingSpec extends AnyWordSpec with Matchers {
     }
 
     "have stable equals and hashCode" in {
-      val address = Address("akka", "sys1", "host1", 9000)
+      val address = Address("pekko", "sys1", "host1", 9000)
       val m1 = m(address, Joining)
       val m11 = Member(UniqueAddress(address, -3L), Set.empty, Version.Zero)
       val m2 = m1.copy(status = Up)
@@ -84,7 +84,7 @@ class MemberOrderingSpec extends AnyWordSpec with Matchers {
     }
 
     "have consistent ordering and equals" in {
-      val address1 = Address("akka", "sys1", "host1", 9001)
+      val address1 = Address("pekko", "sys1", "host1", 9001)
       val address2 = address1.copy(port = Some(9002))
 
       val x = m(address1, Exiting)
@@ -102,7 +102,7 @@ class MemberOrderingSpec extends AnyWordSpec with Matchers {
     }
 
     "work with SortedSet" in {
-      val address1 = Address("akka", "sys1", "host1", 9001)
+      val address1 = Address("pekko", "sys1", "host1", 9001)
       val address2 = address1.copy(port = Some(9002))
       val address3 = address1.copy(port = Some(9003))
 
@@ -119,54 +119,54 @@ class MemberOrderingSpec extends AnyWordSpec with Matchers {
 
     "order addresses by port" in {
       val addresses = SortedSet.empty[Address] +
-        AddressFromURIString("akka://sys@darkstar:1112") +
-        AddressFromURIString("akka://sys@darkstar:1113") +
-        AddressFromURIString("akka://sys@darkstar:1110") +
-        AddressFromURIString("akka://sys@darkstar:1111")
+        AddressFromURIString("pekko://sys@darkstar:1112") +
+        AddressFromURIString("pekko://sys@darkstar:1113") +
+        AddressFromURIString("pekko://sys@darkstar:1110") +
+        AddressFromURIString("pekko://sys@darkstar:1111")
 
       val seq = addresses.toSeq
       seq.size should ===(4)
-      seq(0) should ===(AddressFromURIString("akka://sys@darkstar:1110"))
-      seq(1) should ===(AddressFromURIString("akka://sys@darkstar:1111"))
-      seq(2) should ===(AddressFromURIString("akka://sys@darkstar:1112"))
-      seq(3) should ===(AddressFromURIString("akka://sys@darkstar:1113"))
+      seq(0) should ===(AddressFromURIString("pekko://sys@darkstar:1110"))
+      seq(1) should ===(AddressFromURIString("pekko://sys@darkstar:1111"))
+      seq(2) should ===(AddressFromURIString("pekko://sys@darkstar:1112"))
+      seq(3) should ===(AddressFromURIString("pekko://sys@darkstar:1113"))
     }
 
     "order addresses by hostname" in {
       val addresses = SortedSet.empty[Address] +
-        AddressFromURIString("akka://sys@darkstar2:1110") +
-        AddressFromURIString("akka://sys@darkstar1:1110") +
-        AddressFromURIString("akka://sys@darkstar3:1110") +
-        AddressFromURIString("akka://sys@darkstar0:1110")
+        AddressFromURIString("pekko://sys@darkstar2:1110") +
+        AddressFromURIString("pekko://sys@darkstar1:1110") +
+        AddressFromURIString("pekko://sys@darkstar3:1110") +
+        AddressFromURIString("pekko://sys@darkstar0:1110")
 
       val seq = addresses.toSeq
       seq.size should ===(4)
-      seq(0) should ===(AddressFromURIString("akka://sys@darkstar0:1110"))
-      seq(1) should ===(AddressFromURIString("akka://sys@darkstar1:1110"))
-      seq(2) should ===(AddressFromURIString("akka://sys@darkstar2:1110"))
-      seq(3) should ===(AddressFromURIString("akka://sys@darkstar3:1110"))
+      seq(0) should ===(AddressFromURIString("pekko://sys@darkstar0:1110"))
+      seq(1) should ===(AddressFromURIString("pekko://sys@darkstar1:1110"))
+      seq(2) should ===(AddressFromURIString("pekko://sys@darkstar2:1110"))
+      seq(3) should ===(AddressFromURIString("pekko://sys@darkstar3:1110"))
     }
 
     "order addresses by hostname and port" in {
       val addresses = SortedSet.empty[Address] +
-        AddressFromURIString("akka://sys@darkstar2:1110") +
-        AddressFromURIString("akka://sys@darkstar0:1111") +
-        AddressFromURIString("akka://sys@darkstar2:1111") +
-        AddressFromURIString("akka://sys@darkstar0:1110")
+        AddressFromURIString("pekko://sys@darkstar2:1110") +
+        AddressFromURIString("pekko://sys@darkstar0:1111") +
+        AddressFromURIString("pekko://sys@darkstar2:1111") +
+        AddressFromURIString("pekko://sys@darkstar0:1110")
 
       val seq = addresses.toSeq
       seq.size should ===(4)
-      seq(0) should ===(AddressFromURIString("akka://sys@darkstar0:1110"))
-      seq(1) should ===(AddressFromURIString("akka://sys@darkstar0:1111"))
-      seq(2) should ===(AddressFromURIString("akka://sys@darkstar2:1110"))
-      seq(3) should ===(AddressFromURIString("akka://sys@darkstar2:1111"))
+      seq(0) should ===(AddressFromURIString("pekko://sys@darkstar0:1110"))
+      seq(1) should ===(AddressFromURIString("pekko://sys@darkstar0:1111"))
+      seq(2) should ===(AddressFromURIString("pekko://sys@darkstar2:1110"))
+      seq(3) should ===(AddressFromURIString("pekko://sys@darkstar2:1111"))
     }
   }
 
   "Leader status ordering" must {
 
     "order members with status Joining, Exiting and Down last" in {
-      val address = Address("akka", "sys1", "host1", 5000)
+      val address = Address("pekko", "sys1", "host1", 5000)
       val m1 = m(address, Joining)
       val m2 = m(address.copy(port = Some(7000)), Joining)
       val m3 = m(address.copy(port = Some(3000)), Exiting)
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/MembershipStateSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/MembershipStateSpec.scala
index 556032cb70..399080f4b0 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/MembershipStateSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/MembershipStateSpec.scala
@@ -24,18 +24,18 @@ import pekko.cluster.MemberStatus.Up
 
 class MembershipStateSpec extends AnyWordSpec with Matchers {
   // DC-a is in reverse age order
-  val a1 = TestMember(Address("akka", "sys", "a4", 2552), Up, 1, "dc-a")
-  val a2 = TestMember(Address("akka", "sys", "a3", 2552), Up, 2, "dc-a")
-  val a3 = TestMember(Address("akka", "sys", "a2", 2552), Up, 3, "dc-a")
-  val a4 = TestMember(Address("akka", "sys", "a1", 2552), Up, 4, "dc-a")
+  val a1 = TestMember(Address("pekko", "sys", "a4", 2552), Up, 1, "dc-a")
+  val a2 = TestMember(Address("pekko", "sys", "a3", 2552), Up, 2, "dc-a")
+  val a3 = TestMember(Address("pekko", "sys", "a2", 2552), Up, 3, "dc-a")
+  val a4 = TestMember(Address("pekko", "sys", "a1", 2552), Up, 4, "dc-a")
 
   // DC-b it is the first and the last that are the oldest
-  val b1 = TestMember(Address("akka", "sys", "b3", 2552), Up, 1, "dc-b")
-  val b3 = TestMember(Address("akka", "sys", "b2", 2552), Up, 3, "dc-b")
+  val b1 = TestMember(Address("pekko", "sys", "b3", 2552), Up, 1, "dc-b")
+  val b3 = TestMember(Address("pekko", "sys", "b2", 2552), Up, 3, "dc-b")
   // Won't be replaced by b3
-  val b2 = TestMember(Address("akka", "sys", "b1", 2552), Up, 2, "dc-b")
+  val b2 = TestMember(Address("pekko", "sys", "b1", 2552), Up, 2, "dc-b")
   // for the case that we don't replace it ever
-  val bOldest = TestMember(Address("akka", "sys", "b0", 2552), Up, 0, "dc-b")
+  val bOldest = TestMember(Address("pekko", "sys", "b0", 2552), Up, 0, "dc-b")
 
   "Membership state" must {
     "sort by upNumber for oldest top members" in {
@@ -64,43 +64,43 @@ class MembershipStateSpec extends AnyWordSpec with Matchers {
 
     "find two oldest per role as targets for Exiting change" in {
       val a5 = TestMember(
-        Address("akka", "sys", "a5", 2552),
+        Address("pekko", "sys", "a5", 2552),
         MemberStatus.Exiting,
         roles = Set("role1", "role2"),
         upNumber = 5,
         dataCenter = "dc-a")
       val a6 = TestMember(
-        Address("akka", "sys", "a6", 2552),
+        Address("pekko", "sys", "a6", 2552),
         MemberStatus.Exiting,
         roles = Set("role1", "role3"),
         upNumber = 6,
         dataCenter = "dc-a")
       val a7 = TestMember(
-        Address("akka", "sys", "a7", 2552),
+        Address("pekko", "sys", "a7", 2552),
         MemberStatus.Exiting,
         roles = Set("role1"),
         upNumber = 7,
         dataCenter = "dc-a")
       val a8 = TestMember(
-        Address("akka", "sys", "a8", 2552),
+        Address("pekko", "sys", "a8", 2552),
         MemberStatus.Exiting,
         roles = Set("role1"),
         upNumber = 8,
         dataCenter = "dc-a")
       val a9 = TestMember(
-        Address("akka", "sys", "a9", 2552),
+        Address("pekko", "sys", "a9", 2552),
         MemberStatus.Exiting,
         roles = Set("role2"),
         upNumber = 9,
         dataCenter = "dc-a")
       val b5 = TestMember(
-        Address("akka", "sys", "b5", 2552),
+        Address("pekko", "sys", "b5", 2552),
         MemberStatus.Exiting,
         roles = Set("role1"),
         upNumber = 5,
         dataCenter = "dc-b")
       val b6 = TestMember(
-        Address("akka", "sys", "b6", 2552),
+        Address("pekko", "sys", "b6", 2552),
         MemberStatus.Exiting,
         roles = Set("role2"),
         upNumber = 6,
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/ReachabilityPerfSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/ReachabilityPerfSpec.scala
index 2591ad1633..b6d8eff1be 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/ReachabilityPerfSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/ReachabilityPerfSpec.scala
@@ -25,8 +25,8 @@ class ReachabilityPerfSpec extends AnyWordSpec with Matchers {
   // increase for serious measurements
   val iterations = sys.props.get("org.apache.pekko.cluster.ReachabilityPerfSpec.iterations").getOrElse("100").toInt
 
-  val address = Address("akka", "sys", "a", 2552)
-  val node = Address("akka", "sys", "a", 2552)
+  val address = Address("pekko", "sys", "a", 2552)
+  val node = Address("pekko", "sys", "a", 2552)
 
   private def createReachabilityOfSize(base: Reachability, size: Int): Reachability =
     (1 to size).foldLeft(base) {
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/ReachabilitySpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/ReachabilitySpec.scala
index 13a0907935..2884bcdb1b 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/ReachabilitySpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/ReachabilitySpec.scala
@@ -22,11 +22,11 @@ class ReachabilitySpec extends AnyWordSpec with Matchers {
 
   import Reachability.{ Reachable, Record, Terminated, Unreachable }
 
-  val nodeA = UniqueAddress(Address("akka", "sys", "a", 2552), 1L)
-  val nodeB = UniqueAddress(Address("akka", "sys", "b", 2552), 2L)
-  val nodeC = UniqueAddress(Address("akka", "sys", "c", 2552), 3L)
-  val nodeD = UniqueAddress(Address("akka", "sys", "d", 2552), 4L)
-  val nodeE = UniqueAddress(Address("akka", "sys", "e", 2552), 5L)
+  val nodeA = UniqueAddress(Address("pekko", "sys", "a", 2552), 1L)
+  val nodeB = UniqueAddress(Address("pekko", "sys", "b", 2552), 2L)
+  val nodeC = UniqueAddress(Address("pekko", "sys", "c", 2552), 3L)
+  val nodeD = UniqueAddress(Address("pekko", "sys", "d", 2552), 4L)
+  val nodeE = UniqueAddress(Address("pekko", "sys", "e", 2552), 5L)
 
   "Reachability table" must {
 
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/protobuf/ClusterMessageSerializerSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/protobuf/ClusterMessageSerializerSpec.scala
index 95c08c0272..6a810846bf 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/protobuf/ClusterMessageSerializerSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/protobuf/ClusterMessageSerializerSpec.scala
@@ -81,20 +81,20 @@ class ClusterMessageSerializerSpec extends PekkoSpec("pekko.actor.provider = clu
   import MemberStatus._
 
   val a1 =
-    TestMember(Address("akka", "sys", "a", 2552), Joining, Set.empty[String], appVersion = Version("1.0.0"))
-  val b1 = TestMember(Address("akka", "sys", "b", 2552), Up, Set("r1"), appVersion = Version("1.1.0"))
+    TestMember(Address("pekko", "sys", "a", 2552), Joining, Set.empty[String], appVersion = Version("1.0.0"))
+  val b1 = TestMember(Address("pekko", "sys", "b", 2552), Up, Set("r1"), appVersion = Version("1.1.0"))
   val c1 =
-    TestMember(Address("akka", "sys", "c", 2552), Leaving, Set.empty[String], "foo", appVersion = Version("1.1.0"))
-  val d1 = TestMember(Address("akka", "sys", "d", 2552), Exiting, Set("r1"), "foo")
-  val e1 = TestMember(Address("akka", "sys", "e", 2552), Down, Set("r3"))
-  val f1 = TestMember(Address("akka", "sys", "f", 2552), Removed, Set("r3"), "foo")
+    TestMember(Address("pekko", "sys", "c", 2552), Leaving, Set.empty[String], "foo", appVersion = Version("1.1.0"))
+  val d1 = TestMember(Address("pekko", "sys", "d", 2552), Exiting, Set("r1"), "foo")
+  val e1 = TestMember(Address("pekko", "sys", "e", 2552), Down, Set("r3"))
+  val f1 = TestMember(Address("pekko", "sys", "f", 2552), Removed, Set("r3"), "foo")
 
   "ClusterMessages" must {
 
     "be serializable" in {
-      val address = Address("akka", "system", "some.host.org", 4711)
+      val address = Address("pekko", "system", "some.host.org", 4711)
       val uniqueAddress = UniqueAddress(address, 17L)
-      val address2 = Address("akka", "system", "other.host.org", 4711)
+      val address2 = Address("pekko", "system", "other.host.org", 4711)
       val uniqueAddress2 = UniqueAddress(address2, 18L)
       checkSerialization(InternalClusterAction.Join(uniqueAddress, Set("foo", "bar", "dc-A"), Version.Zero))
       checkSerialization(InternalClusterAction.Join(uniqueAddress, Set("dc-A"), Version("1.2.3")))
@@ -133,9 +133,9 @@ class ClusterMessageSerializerSpec extends PekkoSpec("pekko.actor.provider = clu
 
     // can be removed in 2.6.3 only checks deserialization with new not yet in effect manifests for 2.6.2
     "be de-serializable with class manifests from 2.6.4 and earlier nodes" in {
-      val address = Address("akka", "system", "some.host.org", 4711)
+      val address = Address("pekko", "system", "some.host.org", 4711)
       val uniqueAddress = UniqueAddress(address, 17L)
-      val address2 = Address("akka", "system", "other.host.org", 4711)
+      val address2 = Address("pekko", "system", "other.host.org", 4711)
       val uniqueAddress2 = UniqueAddress(address2, 18L)
       checkDeserializationWithManifest(
         InternalClusterAction.Join(uniqueAddress, Set("foo", "bar", "dc-A"), Version.Zero),
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/sbr/TestAddresses.scala b/cluster/src/test/scala/org/apache/pekko/cluster/sbr/TestAddresses.scala
index 9728b74d8f..50110ab1ed 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/sbr/TestAddresses.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/sbr/TestAddresses.scala
@@ -24,7 +24,7 @@ import pekko.cluster.UniqueAddress
 import pekko.util.Version
 
 /**
- * Needed since the Member constructor is akka private
+ * Needed since the Member constructor is pekko private
  */
 object TestAddresses {
   private def dcRole(dc: ClusterSettings.DataCenter): String =
@@ -32,7 +32,7 @@ object TestAddresses {
   val defaultDataCenter = ClusterSettings.DefaultDataCenter
   private def defaultDcRole = dcRole(defaultDataCenter)
 
-  val addressA = Address("akka.tcp", "sys", "a", 2552)
+  val addressA = Address("pekko.tcp", "sys", "a", 2552)
   val memberA = new Member(UniqueAddress(addressA, 0L), 5, Up, Set("role3", defaultDcRole), Version.Zero)
   val memberB =
     new Member(
diff --git a/cluster/src/test/scala/org/apache/pekko/cluster/testkit/AutoDownSpec.scala b/cluster/src/test/scala/org/apache/pekko/cluster/testkit/AutoDownSpec.scala
index eafc548f22..3a604071fe 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/testkit/AutoDownSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/testkit/AutoDownSpec.scala
@@ -55,8 +55,8 @@ class AutoDownSpec extends PekkoSpec("""
   import AutoDownSpec._
 
   val protocol =
-    if (RARP(system).provider.remoteSettings.Artery.Enabled) "akka"
-    else "akka.tcp"
+    if (RARP(system).provider.remoteSettings.Artery.Enabled) "pekko"
+    else "pekko.tcp"
 
   val memberA = TestMember(Address(protocol, "sys", "a", 2552), Up)
   val memberB = TestMember(Address(protocol, "sys", "b", 2552), Up)
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/DataEnvelopeSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/DataEnvelopeSpec.scala
index 6ca189e09a..0fa0fc878a 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/DataEnvelopeSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/DataEnvelopeSpec.scala
@@ -24,7 +24,7 @@ import pekko.cluster.ddata.Replicator.Internal.DataEnvelope
 class DataEnvelopeSpec extends AnyWordSpec with Matchers {
   import PruningState._
 
-  val node1 = UniqueAddress(Address("akka", "Sys", "localhost", 2551), 1L)
+  val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(2552)), 2L)
   val node3 = UniqueAddress(node1.address.copy(port = Some(2553)), 3L)
   val node4 = UniqueAddress(node1.address.copy(port = Some(2554)), 4L)
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/DeltaPropagationSelectorSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/DeltaPropagationSelectorSpec.scala
index 7993f1cbe3..01783ab106 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/DeltaPropagationSelectorSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/DeltaPropagationSelectorSpec.scala
@@ -45,8 +45,8 @@ object DeltaPropagationSelectorSpec {
 
 class DeltaPropagationSelectorSpec extends AnyWordSpec with Matchers with TypeCheckedTripleEquals {
   import DeltaPropagationSelectorSpec._
-  val selfUniqueAddress = UniqueAddress(Address("akka", "Sys", "localhost", 4999), 17L)
-  val nodes = (2500 until 2600).map(n => UniqueAddress(Address("akka", "Sys", "localhost", n), 17L)).toVector
+  val selfUniqueAddress = UniqueAddress(Address("pekko", "Sys", "localhost", 4999), 17L)
+  val nodes = (2500 until 2600).map(n => UniqueAddress(Address("pekko", "Sys", "localhost", n), 17L)).toVector
 
   "DeltaPropagationSelector" must {
     "collect none when no nodes" in {
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/GCounterSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/GCounterSpec.scala
index ea298581f0..e9471d111c 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/GCounterSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/GCounterSpec.scala
@@ -22,7 +22,7 @@ import pekko.cluster.UniqueAddress
 import pekko.cluster.ddata.Replicator.Changed
 
 class GCounterSpec extends AnyWordSpec with Matchers {
-  val node1 = UniqueAddress(Address("akka", "Sys", "localhost", 2551), 1L)
+  val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(2552)), 2L)
   val node3 = UniqueAddress(node1.address.copy(port = Some(2553)), 3L)
 
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LWWMapSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LWWMapSpec.scala
index 152662032c..1079ca5a03 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LWWMapSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LWWMapSpec.scala
@@ -24,7 +24,7 @@ import pekko.cluster.ddata.Replicator.Changed
 class LWWMapSpec extends AnyWordSpec with Matchers {
   import LWWRegister.defaultClock
 
-  val node1 = UniqueAddress(Address("akka", "Sys", "localhost", 2551), 1L)
+  val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(2552)), 2L)
 
   "A LWWMap" must {
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LWWRegisterSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LWWRegisterSpec.scala
index d5eac40e1b..ea0d8076ba 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LWWRegisterSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LWWRegisterSpec.scala
@@ -24,7 +24,7 @@ import pekko.cluster.ddata.Replicator.Changed
 class LWWRegisterSpec extends AnyWordSpec with Matchers {
   import LWWRegister.defaultClock
 
-  val node1 = UniqueAddress(Address("akka", "Sys", "localhost", 2551), 1L)
+  val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(2552)), 2L)
 
   "A LWWRegister" must {
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LotsOfDataBot.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LotsOfDataBot.scala
index 6b2269c4fe..0df631d97f 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LotsOfDataBot.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/LotsOfDataBot.scala
@@ -57,8 +57,8 @@ object LotsOfDataBot {
 
             pekko.cluster {
               seed-nodes = [
-                "akka://ClusterSystem@127.0.0.1:2551",
-                "akka://ClusterSystem@127.0.0.1:2552"]
+                "pekko://ClusterSystem@127.0.0.1:2551",
+                "pekko://ClusterSystem@127.0.0.1:2552"]
 
               downing-provider-class = org.apache.pekko.cluster.testkit.AutoDowning
               testkit.auto-down-unreachable-after = 10s
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORMapSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORMapSpec.scala
index 112f127ab8..2da1bb73c2 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORMapSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORMapSpec.scala
@@ -24,7 +24,7 @@ import pekko.cluster.ddata.Replicator.Changed
 
 class ORMapSpec extends AnyWordSpec with Matchers {
 
-  val node1 = UniqueAddress(Address("akka", "Sys", "localhost", 2551), 1L)
+  val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(2552)), 2L)
 
   "A ORMap" must {
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORMultiMapSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORMultiMapSpec.scala
index e943f3dd37..2b6c2e1946 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORMultiMapSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORMultiMapSpec.scala
@@ -23,7 +23,7 @@ import pekko.cluster.ddata.Replicator.Changed
 
 class ORMultiMapSpec extends AnyWordSpec with Matchers {
 
-  val node1 = UniqueAddress(Address("akka", "Sys", "localhost", 2551), 1L)
+  val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(2552)), 2L)
 
   "A ORMultiMap" must {
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORSetSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORSetSpec.scala
index ab3b7442cb..1496bec5ca 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORSetSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/ORSetSpec.scala
@@ -25,11 +25,11 @@ import pekko.cluster.ddata.Replicator.Changed
 
 class ORSetSpec extends AnyWordSpec with Matchers {
 
-  val node1 = UniqueAddress(Address("akka", "Sys", "localhost", 2551), 1L)
+  val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(2552)), 2L)
   val node3 = UniqueAddress(node1.address.copy(port = Some(2553)), 3L)
 
-  val nodeA = UniqueAddress(Address("akka", "Sys", "a", 2552), 1L)
+  val nodeA = UniqueAddress(Address("pekko", "Sys", "a", 2552), 1L)
   val nodeB = UniqueAddress(nodeA.address.copy(host = Some("b")), 2L)
   val nodeC = UniqueAddress(nodeA.address.copy(host = Some("c")), 3L)
   val nodeD = UniqueAddress(nodeA.address.copy(host = Some("d")), 4L)
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PNCounterMapSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PNCounterMapSpec.scala
index 0310d9ea68..30ecbbdb2e 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PNCounterMapSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PNCounterMapSpec.scala
@@ -23,7 +23,7 @@ import pekko.cluster.ddata.Replicator.Changed
 
 class PNCounterMapSpec extends AnyWordSpec with Matchers {
 
-  val node1 = UniqueAddress(Address("akka", "Sys", "localhost", 2551), 1L)
+  val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(2552)), 2L)
 
   "A PNCounterMap" must {
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PNCounterSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PNCounterSpec.scala
index 8e89aeadaa..66c83e60c0 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PNCounterSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PNCounterSpec.scala
@@ -22,7 +22,7 @@ import pekko.cluster.UniqueAddress
 import pekko.cluster.ddata.Replicator.Changed
 
 class PNCounterSpec extends AnyWordSpec with Matchers {
-  val node1 = UniqueAddress(Address("akka", "Sys", "localhost", 2551), 1L)
+  val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(2552)), 2L)
 
   "A PNCounter" must {
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PruningStateSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PruningStateSpec.scala
index 8cdc1cb23c..4b0d0f68d6 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PruningStateSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/PruningStateSpec.scala
@@ -23,7 +23,7 @@ import pekko.cluster.UniqueAddress
 class PruningStateSpec extends AnyWordSpec with Matchers {
   import PruningState._
 
-  val node1 = UniqueAddress(Address("akka", "Sys", "localhost", 2551), 1L)
+  val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(2552)), 2L)
   val node3 = UniqueAddress(node1.address.copy(port = Some(2553)), 3L)
   val node4 = UniqueAddress(node1.address.copy(port = Some(2554)), 4L)
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/VersionVectorSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/VersionVectorSpec.scala
index 82c0c5604a..1d24037c77 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/VersionVectorSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/VersionVectorSpec.scala
@@ -29,7 +29,7 @@ class VersionVectorSpec
     with Matchers
     with BeforeAndAfterAll {
 
-  val node1 = UniqueAddress(Address("akka", "Sys", "localhost", 2551), 1L)
+  val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(2552)), 2L)
   val node3 = UniqueAddress(node1.address.copy(port = Some(2553)), 3L)
   val node4 = UniqueAddress(node1.address.copy(port = Some(2554)), 4L)
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/WriteAggregatorSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/WriteAggregatorSpec.scala
index 74f3fcc00d..8b16f22ee3 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/WriteAggregatorSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/WriteAggregatorSpec.scala
@@ -150,8 +150,8 @@ class WriteAggregatorSpec extends PekkoSpec(s"""
   import WriteAggregatorSpec._
 
   val protocol =
-    if (RARP(system).provider.remoteSettings.Artery.Enabled) "akka"
-    else "akka.tcp"
+    if (RARP(system).provider.remoteSettings.Artery.Enabled) "pekko"
+    else "pekko.tcp"
 
   val nodeA = UniqueAddress(Address(protocol, "Sys", "a", 2552), 17L)
   val nodeB = UniqueAddress(Address(protocol, "Sys", "b", 2552), 17L)
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/protobuf/ReplicatedDataSerializerSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/protobuf/ReplicatedDataSerializerSpec.scala
index 3296d524c3..cf560b97bf 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/protobuf/ReplicatedDataSerializerSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/protobuf/ReplicatedDataSerializerSpec.scala
@@ -51,7 +51,7 @@ class ReplicatedDataSerializerSpec
 
   val serializer = new ReplicatedDataSerializer(system.asInstanceOf[ExtendedActorSystem])
 
-  val Protocol = if (RARP(system).provider.remoteSettings.Artery.Enabled) "akka" else "akka.tcp"
+  val Protocol = if (RARP(system).provider.remoteSettings.Artery.Enabled) "pekko" else "pekko.tcp"
 
   val address1 = UniqueAddress(Address(Protocol, system.name, "some.host.org", 4711), 1L)
   val address2 = UniqueAddress(Address(Protocol, system.name, "other.host.org", 4711), 2L)
diff --git a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/protobuf/ReplicatorMessageSerializerSpec.scala b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/protobuf/ReplicatorMessageSerializerSpec.scala
index 57da87c70c..adf8d03eae 100644
--- a/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/protobuf/ReplicatorMessageSerializerSpec.scala
+++ b/distributed-data/src/test/scala/org/apache/pekko/cluster/ddata/protobuf/ReplicatorMessageSerializerSpec.scala
@@ -56,7 +56,7 @@ class ReplicatorMessageSerializerSpec
 
   val serializer = new ReplicatorMessageSerializer(system.asInstanceOf[ExtendedActorSystem])
 
-  val Protocol = if (RARP(system).provider.remoteSettings.Artery.Enabled) "akka" else "akka.tcp"
+  val Protocol = if (RARP(system).provider.remoteSettings.Artery.Enabled) "pekko" else "pekko.tcp"
 
   val address1 = UniqueAddress(Address(Protocol, system.name, "some.host.org", 4711), 1L)
   val address2 = UniqueAddress(Address(Protocol, system.name, "other.host.org", 4711), 2L)
diff --git a/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java b/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java
index 305a48b7df..2c6a314475 100644
--- a/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java
+++ b/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java
@@ -224,7 +224,7 @@ public class FSMDocTest extends AbstractJavaTest {
         expectMsgEquals(Active);
         expectMsgEquals(Data.Foo);
         String msg = expectMsgClass(String.class);
-        assertTrue(msg.startsWith("LogEntry(SomeState,Foo,Actor[akka://FSMDocTest/system/"));
+        assertTrue(msg.startsWith("LogEntry(SomeState,Foo,Actor[pekko://FSMDocTest/system/"));
       }
     };
   }
diff --git a/docs/src/test/java/jdocs/remoting/RemoteDeploymentDocTest.java b/docs/src/test/java/jdocs/remoting/RemoteDeploymentDocTest.java
index 023ffc6e92..0850fa14b2 100644
--- a/docs/src/test/java/jdocs/remoting/RemoteDeploymentDocTest.java
+++ b/docs/src/test/java/jdocs/remoting/RemoteDeploymentDocTest.java
@@ -60,16 +60,16 @@ public class RemoteDeploymentDocTest extends AbstractJavaTest {
   @SuppressWarnings("unused")
   void makeAddress() {
     // #make-address-artery
-    Address addr = new Address("akka", "sys", "host", 1234);
-    addr = AddressFromURIString.parse("akka://sys@host:1234"); // the same
+    Address addr = new Address("pekko", "sys", "host", 1234);
+    addr = AddressFromURIString.parse("pekko://sys@host:1234"); // the same
     // #make-address-artery
   }
 
   @Test
   public void demonstrateDeployment() {
     // #make-address
-    Address addr = new Address("akka", "sys", "host", 1234);
-    addr = AddressFromURIString.parse("akka://sys@host:1234"); // the same
+    Address addr = new Address("pekko", "sys", "host", 1234);
+    addr = AddressFromURIString.parse("pekko://sys@host:1234"); // the same
     // #make-address
     // #deploy
     Props props = Props.create(SampleActor.class).withDeploy(new Deploy(new RemoteScope(addr)));
diff --git a/docs/src/test/java/jdocs/testkit/TestKitDocTest.java b/docs/src/test/java/jdocs/testkit/TestKitDocTest.java
index 15c4d30df9..a335aaeb22 100644
--- a/docs/src/test/java/jdocs/testkit/TestKitDocTest.java
+++ b/docs/src/test/java/jdocs/testkit/TestKitDocTest.java
@@ -518,7 +518,7 @@ public class TestKitDocTest extends AbstractJavaTest {
 
         final int result =
             new EventFilter(ActorKilledException.class, system)
-                .from("akka://TestKitDocTest/user/victim")
+                .from("pekko://TestKitDocTest/user/victim")
                 .occurrences(1)
                 .intercept(
                     () -> {
diff --git a/multi-node-testkit/src/main/scala/org/apache/pekko/remote/testkit/MultiNodeSpec.scala b/multi-node-testkit/src/main/scala/org/apache/pekko/remote/testkit/MultiNodeSpec.scala
index 545cb097fe..0bce9d347d 100644
--- a/multi-node-testkit/src/main/scala/org/apache/pekko/remote/testkit/MultiNodeSpec.scala
+++ b/multi-node-testkit/src/main/scala/org/apache/pekko/remote/testkit/MultiNodeSpec.scala
@@ -515,7 +515,7 @@ abstract class MultiNodeSpec(
                     // might happen if all test cases are ignored (excluded) and
                     // controller node is finished/exited before r.addr is run
                     // on the other nodes
-                    val unresolved = "akka://unresolved-replacement-" + r.role.name
+                    val unresolved = "pekko://unresolved-replacement-" + r.role.name
                     log.warning(unresolved + " due to: " + e.getMessage)
                     unresolved
                 }
diff --git a/persistence-shared/src/test/scala/org/apache/pekko/persistence/serialization/SerializerSpec.scala b/persistence-shared/src/test/scala/org/apache/pekko/persistence/serialization/SerializerSpec.scala
index d33b2ef717..2bd5d4cbf5 100644
--- a/persistence-shared/src/test/scala/org/apache/pekko/persistence/serialization/SerializerSpec.scala
+++ b/persistence-shared/src/test/scala/org/apache/pekko/persistence/serialization/SerializerSpec.scala
@@ -313,7 +313,7 @@ class MessageSerializerPersistenceSpec extends PekkoSpec(customSerializers) {
 object MessageSerializerRemotingSpec {
   class LocalActor(port: Int) extends Actor {
     def receive = {
-      case m => context.actorSelection(s"akka://remote@127.0.0.1:${port}/user/remote").tell(m, Actor.noSender)
+      case m => context.actorSelection(s"pekko://remote@127.0.0.1:${port}/user/remote").tell(m, Actor.noSender)
     }
   }
 
diff --git a/persistence-typed/src/main/scala/org/apache/pekko/persistence/typed/internal/JournalFailureException.scala b/persistence-typed/src/main/scala/org/apache/pekko/persistence/typed/internal/JournalFailureException.scala
index fda256eb6f..c58a3974a0 100644
--- a/persistence-typed/src/main/scala/org/apache/pekko/persistence/typed/internal/JournalFailureException.scala
+++ b/persistence-typed/src/main/scala/org/apache/pekko/persistence/typed/internal/JournalFailureException.scala
@@ -20,7 +20,7 @@ import pekko.persistence.typed.PersistenceId
 /**
  * INTERNAL API
  *
- * Used for journal failures. Private to akka as only internal supervision strategies should use it.
+ * Used for journal failures. Private to pekko as only internal supervision strategies should use it.
  */
 @InternalApi
 final private[pekko] class JournalFailureException(msg: String, cause: Throwable) extends RuntimeException(msg, cause) {
diff --git a/persistence-typed/src/main/scala/org/apache/pekko/persistence/typed/state/internal/DurableStateStoreException.scala b/persistence-typed/src/main/scala/org/apache/pekko/persistence/typed/state/internal/DurableStateStoreException.scala
index 4e6ed16613..8339394a89 100644
--- a/persistence-typed/src/main/scala/org/apache/pekko/persistence/typed/state/internal/DurableStateStoreException.scala
+++ b/persistence-typed/src/main/scala/org/apache/pekko/persistence/typed/state/internal/DurableStateStoreException.scala
@@ -20,7 +20,7 @@ import pekko.persistence.typed.PersistenceId
 /**
  * INTERNAL API
  *
- * Used for store failures. Private to akka as only internal supervision strategies should use it.
+ * Used for store failures. Private to pekko as only internal supervision strategies should use it.
  */
 @InternalApi
 final private[pekko] class DurableStateStoreException(msg: String, cause: Throwable)
diff --git a/persistence/src/main/resources/reference.conf b/persistence/src/main/resources/reference.conf
index 9da0568aac..e332cf913e 100644
--- a/persistence/src/main/resources/reference.conf
+++ b/persistence/src/main/resources/reference.conf
@@ -5,9 +5,6 @@
 # This is the reference config file that contains all the default settings.
 # Make your edits in your application.conf in order to override these settings.
 
-# Directory of persistence journal and snapshot store plugins is available at the
-# Pekko Community Projects page https://akka.io/community/
-
 # Default persistence extension settings.
 pekko.persistence {
 
diff --git a/project/Doc.scala b/project/Doc.scala
index 7af48ca8eb..0ed8ee4bf6 100644
--- a/project/Doc.scala
+++ b/project/Doc.scala
@@ -176,7 +176,7 @@ object UnidocRoot extends AutoPlugin {
         .ifTrue(Seq(JavaUnidoc / unidocAllSources ~= { v =>
           v.map(
             _.filterNot(s =>
-              // akka.stream.scaladsl.GraphDSL.Implicits.ReversePortsOps
+              // org.apache.pekko.stream.scaladsl.GraphDSL.Implicits.ReversePortsOps
               // contains code that genjavadoc turns into (probably
               // incorrect) Java code that in turn confuses the javadoc
               // tool.
diff --git a/project/MultiNode.scala b/project/MultiNode.scala
index 621c8c0ff9..e353bbd027 100644
--- a/project/MultiNode.scala
+++ b/project/MultiNode.scala
@@ -58,9 +58,9 @@ object MultiNode extends AutoPlugin {
     // multinode.D= and multinode.X= makes it possible to pass arbitrary
     // -D or -X arguments to the forked jvm, e.g.
     // -Dmultinode.Djava.net.preferIPv4Stack=true -Dmultinode.Xmx512m -Dmultinode.XX:MaxPermSize=256M
-    // -DMultiJvm.akka.cluster.Stress.nrOfNodes=15
+    // -DMultiJvm.pekko.cluster.Stress.nrOfNodes=15
     val MultinodeJvmArgs = "multinode\\.(D|X)(.*)".r
-    val knownPrefix = Set("akka.", "MultiJvm.", "aeron.")
+    val knownPrefix = Set("pekko.", "akka.", "MultiJvm.", "aeron.")
     val pekkoProperties = System.getProperties.stringPropertyNames.asScala.toList.collect {
       case MultinodeJvmArgs(a, b) =>
         val value = System.getProperty("multinode." + a + b)
diff --git a/project/Paradox.scala b/project/Paradox.scala
index e43650cebf..22902d8bbf 100644
--- a/project/Paradox.scala
+++ b/project/Paradox.scala
@@ -44,8 +44,8 @@ object Paradox {
       "javadoc.java.link_style" -> "direct",
       "javadoc.pekko.base_url" -> s"$pekkoBaseURL/japi/pekko/current/org/apache",
       "javadoc.pekko.link_style" -> "direct",
-      "javadoc.akka.http.base_url" -> s"$pekkoBaseURL/japi/pekko-http/current/org/apache",
-      "javadoc.akka.http.link_style" -> "frames",
+      "javadoc.pekko.http.base_url" -> s"$pekkoBaseURL/japi/pekko-http/current/org/apache",
+      "javadoc.pekko.http.link_style" -> "frames",
       "javadoc.com.fasterxml.jackson.annotation.base_url" -> "https://javadoc.io/doc/com.fasterxml.jackson.core/jackson-annotations/latest/",
       "javadoc.com.fasterxml.jackson.annotation.link_style" -> "direct",
       "javadoc.com.fasterxml.jackson.databind.base_url" -> "https://javadoc.io/doc/com.fasterxml.jackson.core/jackson-databind/latest/",
diff --git a/project/PekkoDisciplinePlugin.scala b/project/PekkoDisciplinePlugin.scala
index 16d24f6b2a..d0656ef101 100644
--- a/project/PekkoDisciplinePlugin.scala
+++ b/project/PekkoDisciplinePlugin.scala
@@ -34,7 +34,7 @@ object PekkoDisciplinePlugin extends AutoPlugin {
     "pekko-actor-typed-tests",
     // references to deprecated PARSER fields in generated message formats?
     "pekko-cluster-typed",
-    // use of deprecated akka.protobuf.GeneratedMessage
+    // use of deprecated org.apache.pekko.protobuf.GeneratedMessage
     "pekko-protobuf",
     "pekko-protobuf-v3",
     // references to deprecated PARSER fields in generated message formats?
diff --git a/remote-tests/src/test/scala/org/apache/pekko/remote/testconductor/BarrierSpec.scala b/remote-tests/src/test/scala/org/apache/pekko/remote/testconductor/BarrierSpec.scala
index 93fe291ad1..6f5c95366d 100644
--- a/remote-tests/src/test/scala/org/apache/pekko/remote/testconductor/BarrierSpec.scala
+++ b/remote-tests/src/test/scala/org/apache/pekko/remote/testconductor/BarrierSpec.scala
@@ -47,7 +47,7 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
 
     "register clients and remove them" taggedAs TimingTest in {
       val b = getBarrier()
-      b ! NodeInfo(A, AddressFromURIString("akka://sys"), system.deadLetters)
+      b ! NodeInfo(A, AddressFromURIString("pekko://sys"), system.deadLetters)
       b ! RemoveClient(B)
       b ! RemoveClient(A)
       EventFilter[BarrierEmpty](occurrences = 1).intercept {
@@ -58,7 +58,7 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
 
     "register clients and disconnect them" taggedAs TimingTest in {
       val b = getBarrier()
-      b ! NodeInfo(A, AddressFromURIString("akka://sys"), system.deadLetters)
+      b ! NodeInfo(A, AddressFromURIString("pekko://sys"), system.deadLetters)
       b ! ClientDisconnected(B)
       expectNoMessage(1 second)
       b ! ClientDisconnected(A)
@@ -74,8 +74,8 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "enter barrier" taggedAs TimingTest in {
       val barrier = getBarrier()
       val a, b = TestProbe()
-      barrier ! NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-      barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+      barrier ! NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+      barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
       a.send(barrier, EnterBarrier("bar2", None))
       noMsg(a, b)
       within(2 seconds) {
@@ -88,10 +88,10 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "enter barrier with joining node" taggedAs TimingTest in {
       val barrier = getBarrier()
       val a, b, c = TestProbe()
-      barrier ! NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-      barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+      barrier ! NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+      barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
       a.send(barrier, EnterBarrier("bar3", None))
-      barrier ! NodeInfo(C, AddressFromURIString("akka://sys"), c.ref)
+      barrier ! NodeInfo(C, AddressFromURIString("pekko://sys"), c.ref)
       b.send(barrier, EnterBarrier("bar3", None))
       noMsg(a, b, c)
       within(2 seconds) {
@@ -105,9 +105,9 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "enter barrier with leaving node" taggedAs TimingTest in {
       val barrier = getBarrier()
       val a, b, c = TestProbe()
-      barrier ! NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-      barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
-      barrier ! NodeInfo(C, AddressFromURIString("akka://sys"), c.ref)
+      barrier ! NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+      barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
+      barrier ! NodeInfo(C, AddressFromURIString("pekko://sys"), c.ref)
       a.send(barrier, EnterBarrier("bar4", None))
       b.send(barrier, EnterBarrier("bar4", None))
       barrier ! RemoveClient(A)
@@ -124,8 +124,8 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "leave barrier when last “arrived” is removed" taggedAs TimingTest in {
       val barrier = getBarrier()
       val a, b = TestProbe()
-      barrier ! NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-      barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+      barrier ! NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+      barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
       a.send(barrier, EnterBarrier("bar5", None))
       barrier ! RemoveClient(A)
       b.send(barrier, EnterBarrier("foo", None))
@@ -135,9 +135,9 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail barrier with disconnecing node" taggedAs TimingTest in {
       val barrier = getBarrier()
       val a, b = TestProbe()
-      val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
+      val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
       barrier ! nodeA
-      barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+      barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
       a.send(barrier, EnterBarrier("bar6", None))
       EventFilter[ClientLost](occurrences = 1).intercept {
         barrier ! ClientDisconnected(B)
@@ -156,10 +156,10 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail barrier with disconnecing node who already arrived" taggedAs TimingTest in {
       val barrier = getBarrier()
       val a, b, c = TestProbe()
-      val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-      val nodeC = NodeInfo(C, AddressFromURIString("akka://sys"), c.ref)
+      val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+      val nodeC = NodeInfo(C, AddressFromURIString("pekko://sys"), c.ref)
       barrier ! nodeA
-      barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+      barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
       barrier ! nodeC
       a.send(barrier, EnterBarrier("bar7", None))
       b.send(barrier, EnterBarrier("bar7", None))
@@ -180,9 +180,9 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail when entering wrong barrier" taggedAs TimingTest in {
       val barrier = getBarrier()
       val a, b = TestProbe()
-      val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
+      val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
       barrier ! nodeA
-      val nodeB = NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+      val nodeB = NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
       barrier ! nodeB
       a.send(barrier, EnterBarrier("bar8", None))
       EventFilter[WrongBarrier](occurrences = 1).intercept {
@@ -218,7 +218,7 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
             BarrierEmpty(Data(Set(), "", Nil, null),
               "cannot remove RoleName(a): no client to remove")) + " but got " + x)
       }
-      barrier ! NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
+      barrier ! NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
       a.send(barrier, EnterBarrier("bar9", None))
       a.expectMsg(ToClient(BarrierResult("bar9", false)))
     }
@@ -226,8 +226,8 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail after barrier timeout" taggedAs TimingTest in {
       val barrier = getBarrier()
       val a, b = TestProbe()
-      val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-      val nodeB = NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+      val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+      val nodeB = NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
       barrier ! nodeA
       barrier ! nodeB
       a.send(barrier, EnterBarrier("bar10", None))
@@ -247,8 +247,8 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail if a node registers twice" taggedAs TimingTest in {
       val barrier = getBarrier()
       val a, b = TestProbe()
-      val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-      val nodeB = NodeInfo(A, AddressFromURIString("akka://sys"), b.ref)
+      val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+      val nodeB = NodeInfo(A, AddressFromURIString("pekko://sys"), b.ref)
       barrier ! nodeA
       EventFilter[DuplicateNode](occurrences = 1).intercept {
         barrier ! nodeB
@@ -272,7 +272,7 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
 
     "register clients and remove them" taggedAs TimingTest in {
       withController(1) { b =>
-        b ! NodeInfo(A, AddressFromURIString("akka://sys"), testActor)
+        b ! NodeInfo(A, AddressFromURIString("pekko://sys"), testActor)
         expectMsg(ToClient(Done))
         b ! Remove(B)
         b ! Remove(A)
@@ -285,7 +285,7 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
 
     "register clients and disconnect them" taggedAs TimingTest in {
       withController(1) { b =>
-        b ! NodeInfo(A, AddressFromURIString("akka://sys"), testActor)
+        b ! NodeInfo(A, AddressFromURIString("pekko://sys"), testActor)
         expectMsg(ToClient(Done))
         b ! ClientDisconnected(B)
         expectNoMessage(1 second)
@@ -304,8 +304,8 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "enter barrier" taggedAs TimingTest in {
       withController(2) { barrier =>
         val a, b = TestProbe()
-        barrier ! NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-        barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+        barrier ! NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+        barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
         a.expectMsg(ToClient(Done))
         b.expectMsg(ToClient(Done))
         a.send(barrier, EnterBarrier("bar11", None))
@@ -321,12 +321,12 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "enter barrier with joining node" taggedAs TimingTest in {
       withController(2) { barrier =>
         val a, b, c = TestProbe()
-        barrier ! NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-        barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+        barrier ! NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+        barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
         a.expectMsg(ToClient(Done))
         b.expectMsg(ToClient(Done))
         a.send(barrier, EnterBarrier("bar12", None))
-        barrier ! NodeInfo(C, AddressFromURIString("akka://sys"), c.ref)
+        barrier ! NodeInfo(C, AddressFromURIString("pekko://sys"), c.ref)
         c.expectMsg(ToClient(Done))
         b.send(barrier, EnterBarrier("bar12", None))
         noMsg(a, b, c)
@@ -342,9 +342,9 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "enter barrier with leaving node" taggedAs TimingTest in {
       withController(3) { barrier =>
         val a, b, c = TestProbe()
-        barrier ! NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-        barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
-        barrier ! NodeInfo(C, AddressFromURIString("akka://sys"), c.ref)
+        barrier ! NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+        barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
+        barrier ! NodeInfo(C, AddressFromURIString("pekko://sys"), c.ref)
         a.expectMsg(ToClient(Done))
         b.expectMsg(ToClient(Done))
         c.expectMsg(ToClient(Done))
@@ -365,8 +365,8 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "leave barrier when last “arrived” is removed" taggedAs TimingTest in {
       withController(2) { barrier =>
         val a, b = TestProbe()
-        barrier ! NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-        barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+        barrier ! NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+        barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
         a.expectMsg(ToClient(Done))
         b.expectMsg(ToClient(Done))
         a.send(barrier, EnterBarrier("bar14", None))
@@ -379,9 +379,9 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail barrier with disconnecing node" taggedAs TimingTest in {
       withController(2) { barrier =>
         val a, b = TestProbe()
-        val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
+        val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
         barrier ! nodeA
-        barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+        barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
         a.expectMsg(ToClient(Done))
         b.expectMsg(ToClient(Done))
         a.send(barrier, EnterBarrier("bar15", None))
@@ -397,10 +397,10 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail barrier with disconnecing node who already arrived" taggedAs TimingTest in {
       withController(3) { barrier =>
         val a, b, c = TestProbe()
-        val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-        val nodeC = NodeInfo(C, AddressFromURIString("akka://sys"), c.ref)
+        val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+        val nodeC = NodeInfo(C, AddressFromURIString("pekko://sys"), c.ref)
         barrier ! nodeA
-        barrier ! NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+        barrier ! NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
         barrier ! nodeC
         a.expectMsg(ToClient(Done))
         b.expectMsg(ToClient(Done))
@@ -417,9 +417,9 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail when entering wrong barrier" taggedAs TimingTest in {
       withController(2) { barrier =>
         val a, b = TestProbe()
-        val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
+        val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
         barrier ! nodeA
-        val nodeB = NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+        val nodeB = NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
         barrier ! nodeB
         a.expectMsg(ToClient(Done))
         b.expectMsg(ToClient(Done))
@@ -435,8 +435,8 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail after barrier timeout" taggedAs TimingTest in {
       withController(2) { barrier =>
         val a, b = TestProbe()
-        val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-        val nodeB = NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+        val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+        val nodeB = NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
         barrier ! nodeA
         barrier ! nodeB
         a.expectMsg(ToClient(Done))
@@ -454,8 +454,8 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail if a node registers twice" taggedAs TimingTest in {
       withController(2) { controller =>
         val a, b = TestProbe()
-        val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-        val nodeB = NodeInfo(A, AddressFromURIString("akka://sys"), b.ref)
+        val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+        val nodeB = NodeInfo(A, AddressFromURIString("pekko://sys"), b.ref)
         controller ! nodeA
         EventFilter[DuplicateNode](occurrences = 1).intercept {
           controller ! nodeB
@@ -468,8 +468,8 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail subsequent barriers if a node registers twice" taggedAs TimingTest in {
       withController(1) { controller =>
         val a, b = TestProbe()
-        val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-        val nodeB = NodeInfo(A, AddressFromURIString("akka://sys"), b.ref)
+        val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+        val nodeB = NodeInfo(A, AddressFromURIString("pekko://sys"), b.ref)
         controller ! nodeA
         a.expectMsg(ToClient(Done))
         EventFilter[DuplicateNode](occurrences = 1).intercept {
@@ -484,8 +484,8 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "fail subsequent barriers after foreced failure" taggedAs TimingTest in {
       withController(2) { barrier =>
         val a, b = TestProbe()
-        val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-        val nodeB = NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
+        val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+        val nodeB = NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
         barrier ! nodeA
         barrier ! nodeB
         a.expectMsg(ToClient(Done))
@@ -506,9 +506,9 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "timeout within the shortest timeout if the new timeout is shorter" taggedAs TimingTest in {
       withController(3) { barrier =>
         val a, b, c = TestProbe()
-        val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-        val nodeB = NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
-        val nodeC = NodeInfo(C, AddressFromURIString("akka://sys"), c.ref)
+        val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+        val nodeB = NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
+        val nodeC = NodeInfo(C, AddressFromURIString("pekko://sys"), c.ref)
         barrier ! nodeA
         barrier ! nodeB
         barrier ! nodeC
@@ -530,9 +530,9 @@ class BarrierSpec extends PekkoSpec(BarrierSpec.config) with ImplicitSender {
     "timeout within the shortest timeout if the new timeout is longer" taggedAs TimingTest in {
       withController(3) { barrier =>
         val a, b, c = TestProbe()
-        val nodeA = NodeInfo(A, AddressFromURIString("akka://sys"), a.ref)
-        val nodeB = NodeInfo(B, AddressFromURIString("akka://sys"), b.ref)
-        val nodeC = NodeInfo(C, AddressFromURIString("akka://sys"), c.ref)
+        val nodeA = NodeInfo(A, AddressFromURIString("pekko://sys"), a.ref)
+        val nodeB = NodeInfo(B, AddressFromURIString("pekko://sys"), b.ref)
+        val nodeC = NodeInfo(C, AddressFromURIString("pekko://sys"), c.ref)
         barrier ! nodeA
         barrier ! nodeB
         barrier ! nodeC
diff --git a/remote-tests/src/test/scala/org/apache/pekko/remote/testconductor/ControllerSpec.scala b/remote-tests/src/test/scala/org/apache/pekko/remote/testconductor/ControllerSpec.scala
index 8d8342437f..de83d67681 100644
--- a/remote-tests/src/test/scala/org/apache/pekko/remote/testconductor/ControllerSpec.scala
+++ b/remote-tests/src/test/scala/org/apache/pekko/remote/testconductor/ControllerSpec.scala
@@ -39,9 +39,9 @@ class ControllerSpec extends PekkoSpec(ControllerSpec.config) with ImplicitSende
 
     "publish its nodes" in {
       val c = system.actorOf(Props(classOf[Controller], 1, new InetSocketAddress(InetAddress.getLocalHost, 0)))
-      c ! NodeInfo(A, AddressFromURIString("akka://sys"), testActor)
+      c ! NodeInfo(A, AddressFromURIString("pekko://sys"), testActor)
       expectMsg(ToClient(Done))
-      c ! NodeInfo(B, AddressFromURIString("akka://sys"), testActor)
+      c ! NodeInfo(B, AddressFromURIString("pekko://sys"), testActor)
       expectMsg(ToClient(Done))
       c ! Controller.GetNodes
       expectMsgType[Iterable[RoleName]].toSet should ===(Set(A, B))
diff --git a/remote/src/main/resources/reference.conf b/remote/src/main/resources/reference.conf
index b5ba64680a..dbaab55fa7 100644
--- a/remote/src/main/resources/reference.conf
+++ b/remote/src/main/resources/reference.conf
@@ -142,14 +142,14 @@ pekko {
       default {
 
         # if this is set to a valid remote address, the named actor will be
-        # deployed at that node e.g. "akka://sys@host:port"
+        # deployed at that node e.g. "pekko://sys@host:port"
         remote = ""
 
         target {
 
           # A list of hostnames and ports for instantiating the children of a
           # router
-          #   The format should be on "akka://sys@host:port", where:
+          #   The format should be on "pekko://sys@host:port", where:
           #    - sys is the remote actor system name
           #    - hostname can be either hostname or IP address the remote actor
           #      should connect to
@@ -239,7 +239,7 @@ pekko {
       # deprecated, use `enable-allow-list`
       enable-whitelist = off
 
-      # If true, will only allow specific classes listed in `allowed-actor-classes` to be instanciated on this
+      # If true, will only allow specific classes listed in `allowed-actor-classes` to be instantiated on this
       # system via remote deployment
       enable-allow-list = ${pekko.remote.deployment.enable-whitelist}
 
diff --git a/remote/src/main/scala/org/apache/pekko/remote/RemoteActorRefProvider.scala b/remote/src/main/scala/org/apache/pekko/remote/RemoteActorRefProvider.scala
index fb0adb207a..b7e99dec84 100644
--- a/remote/src/main/scala/org/apache/pekko/remote/RemoteActorRefProvider.scala
+++ b/remote/src/main/scala/org/apache/pekko/remote/RemoteActorRefProvider.scala
@@ -400,11 +400,11 @@ private[pekko] class RemoteActorRefProvider(
        *
        * Example:
        *
-       * akka://sys@home:1234/remote/akka/sys@remote:6667/remote/akka/sys@other:3333/user/a/b/c
+       * pekko://sys@home:1234/remote/pekko/sys@remote:6667/remote/pekko/sys@other:3333/user/a/b/c
        *
-       * means that the logical parent originates from “akka://sys@other:3333” with
-       * one child (may be “a” or “b”) being deployed on “akka://sys@remote:6667” and
-       * finally either “b” or “c” being created on “akka://sys@home:1234”, where
+       * means that the logical parent originates from “pekko://sys@other:3333” with
+       * one child (may be “a” or “b”) being deployed on “pekko://sys@remote:6667” and
+       * finally either “b” or “c” being created on “pekko://sys@home:1234”, where
        * this whole thing actually resides. Thus, the logical path is
        * “/user/a/b/c” and the physical path contains all remote placement
        * information.
@@ -681,7 +681,7 @@ private[pekko] class RemoteActorRef private[pekko] (
 
   remote match {
     case t: ArteryTransport =>
-      // detect mistakes such as using "akka.tcp" with Artery
+      // detect mistakes such as using "pekko.tcp" with Artery
       if (path.address.protocol != t.localAddress.address.protocol)
         throw new IllegalArgumentException(s"Wrong protocol of [$path], expected [${t.localAddress.address.protocol}]")
     case _ =>
diff --git a/remote/src/main/scala/org/apache/pekko/remote/artery/ArteryTransport.scala b/remote/src/main/scala/org/apache/pekko/remote/artery/ArteryTransport.scala
index 754b39a1d1..7f7623f1de 100644
--- a/remote/src/main/scala/org/apache/pekko/remote/artery/ArteryTransport.scala
+++ b/remote/src/main/scala/org/apache/pekko/remote/artery/ArteryTransport.scala
@@ -954,7 +954,7 @@ private[remote] abstract class ArteryTransport(_system: ExtendedActorSystem, _pr
  */
 private[remote] object ArteryTransport {
 
-  val ProtocolName = "akka"
+  val ProtocolName = "pekko"
 
   // Note that the used version of the header format for outbound messages is defined in
   // `ArterySettings.Version` because that may depend on configuration settings.
diff --git a/remote/src/main/scala/org/apache/pekko/remote/transport/PekkoProtocolTransport.scala b/remote/src/main/scala/org/apache/pekko/remote/transport/PekkoProtocolTransport.scala
index d5619ea121..ba0e15feb3 100644
--- a/remote/src/main/scala/org/apache/pekko/remote/transport/PekkoProtocolTransport.scala
+++ b/remote/src/main/scala/org/apache/pekko/remote/transport/PekkoProtocolTransport.scala
@@ -73,8 +73,8 @@ private[remote] class PekkoProtocolSettings(config: Config) {
 
 @nowarn("msg=deprecated")
 private[remote] object PekkoProtocolTransport { // Couldn't these go into the Remoting Extension/ RemoteSettings instead?
-  val AkkaScheme: String = "akka"
-  val AkkaOverhead: Int = 0 // Don't know yet
+  val PekkoScheme: String = "pekko"
+  val PekkoOverhead: Int = 0 // Don't know yet
   val UniqueId = new java.util.concurrent.atomic.AtomicInteger(0)
 
   final case class AssociateUnderlyingRefuseUid(
@@ -122,7 +122,7 @@ private[remote] class PekkoProtocolTransport(
     private val codec: PekkoPduCodec)
     extends ActorTransportAdapter(wrappedTransport, system) {
 
-  override val addedSchemeIdentifier: String = AkkaScheme
+  override val addedSchemeIdentifier: String = PekkoScheme
 
   override def managementCommand(cmd: Any): Future[Boolean] = wrappedTransport.managementCommand(cmd)
 
@@ -135,7 +135,7 @@ private[remote] class PekkoProtocolTransport(
     statusPromise.future.mapTo[PekkoProtocolHandle]
   }
 
-  override val maximumOverhead: Int = PekkoProtocolTransport.AkkaOverhead
+  override val maximumOverhead: Int = PekkoProtocolTransport.PekkoOverhead
   protected def managerName = s"akkaprotocolmanager.${wrappedTransport.schemeIdentifier}${UniqueId.getAndIncrement}"
   protected def managerProps = {
     val wt = wrappedTransport
@@ -230,7 +230,7 @@ private[remote] class PekkoProtocolHandle(
     val handshakeInfo: HandshakeInfo,
     private val stateActor: ActorRef,
     private val codec: PekkoPduCodec)
-    extends AbstractTransportAdapterHandle(_localAddress, _remoteAddress, _wrappedHandle, AkkaScheme) {
+    extends AbstractTransportAdapterHandle(_localAddress, _remoteAddress, _wrappedHandle, PekkoScheme) {
 
   override def write(payload: ByteString): Boolean = wrappedHandle.write(codec.constructPayload(payload))
 
diff --git a/remote/src/test/resources/Makefile b/remote/src/test/resources/Makefile
index 717b62d640..86edcc4eaf 100644
--- a/remote/src/test/resources/Makefile
+++ b/remote/src/test/resources/Makefile
@@ -17,7 +17,7 @@ domain.cnf:
 	echo "subjectAltName=DNS:localhost" >> domain.cnf
 
 domain.csr: domain.cnf
-	openssl req -new -newkey rsa:2048 -keyout domain.key -subj "/C=ZA/ST=web/O=Lightbend/CN=pekko-remote" -reqexts SAN -config domain.cnf -out domain.csr -passout pass:changeme
+	openssl req -new -newkey rsa:2048 -keyout domain.key -subj "/C=ZA/ST=web/O=Lightbend/CN=akka-remote" -reqexts SAN -config domain.cnf -out domain.csr -passout pass:changeme
 
 .PHONY: clean
 clean:
diff --git a/remote/src/test/scala/org/apache/pekko/remote/DaemonicSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/DaemonicSpec.scala
index a2a715ca18..920e9efafc 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/DaemonicSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/DaemonicSpec.scala
@@ -46,7 +46,7 @@ class DaemonicSpec extends PekkoSpec {
       try {
         val unusedPort = 86 // very unlikely to ever be used, "system port" range reserved for Micro Focus Cobol
 
-        val protocol = if (RARP(daemonicSystem).provider.remoteSettings.Artery.Enabled) "akka" else "akka.tcp"
+        val protocol = if (RARP(daemonicSystem).provider.remoteSettings.Artery.Enabled) "pekko" else "pekko.tcp"
         val unusedAddress =
           RARP(daemonicSystem).provider.getExternalAddressFor(Address(protocol, "", "", unusedPort)).get
         val selection = daemonicSystem.actorSelection(s"$unusedAddress/user/SomeActor")
diff --git a/remote/src/test/scala/org/apache/pekko/remote/RemoteConsistentHashingRouterSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/RemoteConsistentHashingRouterSpec.scala
index a187617bc3..51d76ecf96 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/RemoteConsistentHashingRouterSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/RemoteConsistentHashingRouterSpec.scala
@@ -29,11 +29,11 @@ class RemoteConsistentHashingRouterSpec
 
     "use same hash ring independent of self address" in {
       // simulating running router on two different nodes (a1, a2) with target routees on 3 other nodes (s1, s2, s3)
-      val a1 = Address("akka", "Sys", "client1", 2552)
-      val a2 = Address("akka", "Sys", "client2", 2552)
-      val s1 = ActorSelectionRoutee(system.actorSelection("akka://Sys@server1:2552/user/a/b"))
-      val s2 = ActorSelectionRoutee(system.actorSelection("akka://Sys@server2:2552/user/a/b"))
-      val s3 = ActorSelectionRoutee(system.actorSelection("akka://Sys@server3:2552/user/a/b"))
+      val a1 = Address("pekko", "Sys", "client1", 2552)
+      val a2 = Address("pekko", "Sys", "client2", 2552)
+      val s1 = ActorSelectionRoutee(system.actorSelection("pekko://Sys@server1:2552/user/a/b"))
+      val s2 = ActorSelectionRoutee(system.actorSelection("pekko://Sys@server2:2552/user/a/b"))
+      val s3 = ActorSelectionRoutee(system.actorSelection("pekko://Sys@server3:2552/user/a/b"))
       val nodes1 = List(ConsistentRoutee(s1, a1), ConsistentRoutee(s2, a1), ConsistentRoutee(s3, a1))
       val nodes2 = List(ConsistentRoutee(s1, a2), ConsistentRoutee(s2, a2), ConsistentRoutee(s3, a2))
       val consistentHash1 = ConsistentHash(nodes1, 10)
diff --git a/remote/src/test/scala/org/apache/pekko/remote/RemoteDeployerSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/RemoteDeployerSpec.scala
index 52eacbaeac..0dd517aad2 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/RemoteDeployerSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/RemoteDeployerSpec.scala
@@ -29,7 +29,7 @@ object RemoteDeployerSpec {
         /service2 {
           router = round-robin-pool
           nr-of-instances = 3
-          remote = "akka://sys@wallace:2552"
+          remote = "pekko://sys@wallace:2552"
           dispatcher = mydispatcher
         }
       }
@@ -57,7 +57,7 @@ class RemoteDeployerSpec extends PekkoSpec(RemoteDeployerSpec.deployerConf) {
             service,
             deployment.get.config,
             RoundRobinPool(3),
-            RemoteScope(Address("akka", "sys", "wallace", 2552)),
+            RemoteScope(Address("pekko", "sys", "wallace", 2552)),
             "mydispatcher")))
     }
 
@@ -65,7 +65,7 @@ class RemoteDeployerSpec extends PekkoSpec(RemoteDeployerSpec.deployerConf) {
       intercept[ConfigurationException] {
         system.actorOf(Props.empty.withDeploy(Deploy.local), "service2")
       }.getMessage should ===(
-        "configuration requested remote deployment for local-only Props at [akka://RemoteDeployerSpec/user/service2]")
+        "configuration requested remote deployment for local-only Props at [pekko://RemoteDeployerSpec/user/service2]")
     }
 
   }
diff --git a/remote/src/test/scala/org/apache/pekko/remote/RemoteFeaturesSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/RemoteFeaturesSpec.scala
index ef8db702bd..2fc94e1154 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/RemoteFeaturesSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/RemoteFeaturesSpec.scala
@@ -150,14 +150,14 @@ class RemoteFeaturesDisabledSpec extends RemoteFeaturesSpec(RemoteFeaturesSpec.d
         name = Some("RS2"),
         extraConfig = Some(s"""
       pekko.actor.deployment {
-        /$actorName.remote = "akka://${system.name}@localhost:$port"
-        "/parent*/*".remote = "akka://${system.name}@localhost:$port"
+        /$actorName.remote = "pekko://${system.name}@localhost:$port"
+        "/parent*/*".remote = "pekko://${system.name}@localhost:$port"
       }
     """))
 
       val masterRef = masterSystem.actorOf(Props[RemoteDeploymentSpec.Echo1](), actorName)
       masterRef.path shouldEqual RootActorPath(
-        AddressFromURIString(s"akka://${masterSystem.name}")) / "user" / actorName
+        AddressFromURIString(s"pekko://${masterSystem.name}")) / "user" / actorName
       masterRef.path.address.hasLocalScope shouldBe true
 
       masterSystem.actorSelection(RootActorPath(address(system)) / "user" / actorName) ! Identify(1)
diff --git a/remote/src/test/scala/org/apache/pekko/remote/RemoteRouterSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/RemoteRouterSpec.scala
index f20843b712..0006785e7a 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/RemoteRouterSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/RemoteRouterSpec.scala
@@ -65,8 +65,8 @@ class RemoteRouterSpec extends PekkoSpec(s"""
   val sysName = system.name
   val masterSystemName = "Master" + sysName
   val protocol =
-    if (RARP(system).provider.remoteSettings.Artery.Enabled) "akka"
-    else "akka.tcp"
+    if (RARP(system).provider.remoteSettings.Artery.Enabled) "pekko"
+    else "pekko.tcp"
   val conf = ConfigFactory.parseString(s"""
     pekko {
       actor.deployment {
@@ -89,7 +89,7 @@ class RemoteRouterSpec extends PekkoSpec(s"""
           nr-of-instances = 2
         }
         /local-blub {
-          remote = "akka://$masterSystemName"
+          remote = "pekko://$masterSystemName"
           router = round-robin-pool
           nr-of-instances = 2
           target.nodes = ["$protocol://${sysName}@localhost:${port}"]
@@ -193,7 +193,7 @@ class RemoteRouterSpec extends PekkoSpec(s"""
           .props(echoActorProps)
           .withDeploy(Deploy(scope = RemoteScope(AddressFromURIString(s"$protocol://${sysName}@localhost:${port}")))),
         "local-blub")
-      router.path.address.toString should ===(s"akka://$masterSystemName")
+      router.path.address.toString should ===(s"pekko://$masterSystemName")
       val replies = collectRouteePaths(probe, router, 5)
       val children = replies.toSet
       children should have size 2
diff --git a/remote/src/test/scala/org/apache/pekko/remote/TransientSerializationErrorSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/TransientSerializationErrorSpec.scala
index 6540ca75b8..151329b90b 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/TransientSerializationErrorSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/TransientSerializationErrorSpec.scala
@@ -86,8 +86,8 @@ abstract class AbstractTransientSerializationErrorSpec(config: Config)
   val port = system.asInstanceOf[ExtendedActorSystem].provider.getDefaultAddress.port.get
   val sysName = system.name
   val protocol =
-    if (RARP(system).provider.remoteSettings.Artery.Enabled) "akka"
-    else "akka.tcp"
+    if (RARP(system).provider.remoteSettings.Artery.Enabled) "pekko"
+    else "pekko.tcp"
 
   val system2 = ActorSystem(system.name, system.settings.config)
   val system2Address = RARP(system2).provider.getDefaultAddress
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/BindCanonicalAddressSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/BindCanonicalAddressSpec.scala
index 5e48da5879..96d51e8beb 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/BindCanonicalAddressSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/BindCanonicalAddressSpec.scala
@@ -54,7 +54,7 @@ trait BindCanonicalAddressBehaviors {
 
       implicit val sys = ActorSystem("sys", config.withFallback(commonConfig))
 
-      getExternal() should ===(address.toAkkaAddress("akka"))
+      getExternal() should ===(address.toAkkaAddress("pekko"))
       // May have selected the same random port - bind another in that case while the other still has the canonical port
       val internals =
         if (getInternal().collect { case Address(_, _, _, Some(port)) => port }.toSeq.contains(address.getPort)) {
@@ -65,7 +65,7 @@ trait BindCanonicalAddressBehaviors {
         } else {
           getInternal()
         }
-      internals should not contain address.toAkkaAddress("akka")
+      internals should not contain address.toAkkaAddress("pekko")
       Await.result(sys.terminate(), Duration.Inf)
     }
 
@@ -92,8 +92,8 @@ trait BindCanonicalAddressBehaviors {
 
       implicit val sys = ActorSystem("sys", config.withFallback(commonConfig))
 
-      getExternal() should ===(address.toAkkaAddress("akka"))
-      getInternal() should contain(address.toAkkaAddress("akka"))
+      getExternal() should ===(address.toAkkaAddress("pekko"))
+      getInternal() should contain(address.toAkkaAddress("pekko"))
     }
 
     "bind to all interfaces" in {
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/DuplicateFlushSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/DuplicateFlushSpec.scala
index 0475f6863d..648b9bcbe2 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/DuplicateFlushSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/DuplicateFlushSpec.scala
@@ -35,8 +35,8 @@ class DuplicateFlushSpec extends PekkoSpec("""
   private val pool = new EnvelopeBufferPool(1034 * 1024, 128)
   private val serialization = SerializationExtension(system)
 
-  private val addressA = UniqueAddress(Address("akka", "sysA", "hostA", 1001), 1)
-  private val addressB = UniqueAddress(Address("akka", "sysB", "hostB", 1002), 2)
+  private val addressA = UniqueAddress(Address("pekko", "sysA", "hostA", 1001), 1)
+  private val addressB = UniqueAddress(Address("pekko", "sysB", "hostB", 1002), 2)
 
   private def setupStream(inboundContext: InboundContext): (TestPublisher.Probe[AnyRef], TestSubscriber.Probe[Any]) = {
     TestSource
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/DuplicateHandshakeSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/DuplicateHandshakeSpec.scala
index 2bf2a05986..4762322481 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/DuplicateHandshakeSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/DuplicateHandshakeSpec.scala
@@ -36,8 +36,8 @@ class DuplicateHandshakeSpec extends PekkoSpec("""
   val pool = new EnvelopeBufferPool(1034 * 1024, 128)
   val serialization = SerializationExtension(system)
 
-  val addressA = UniqueAddress(Address("akka", "sysA", "hostA", 1001), 1)
-  val addressB = UniqueAddress(Address("akka", "sysB", "hostB", 1002), 2)
+  val addressA = UniqueAddress(Address("pekko", "sysA", "hostA", 1001), 1)
+  val addressB = UniqueAddress(Address("pekko", "sysB", "hostB", 1002), 2)
 
   private def setupStream(inboundContext: InboundContext): (TestPublisher.Probe[AnyRef], TestSubscriber.Probe[Any]) = {
     TestSource
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/EnvelopeBufferSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/EnvelopeBufferSpec.scala
index 39eedeae43..d977b00f72 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/EnvelopeBufferSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/EnvelopeBufferSpec.scala
@@ -95,10 +95,10 @@ class EnvelopeBufferSpec extends PekkoSpec {
       headerOut.inboundClassManifestCompressionTableVersion should ===(35.toByte)
       headerOut.serializer should ===(4)
       headerOut.senderActorRef(originUid).get.path.toSerializationFormat should ===(
-        "akka://EnvelopeBufferSpec/compressable0")
+        "pekko://EnvelopeBufferSpec/compressable0")
       headerOut.senderActorRefPath should ===(OptionVal.None)
       headerOut.recipientActorRef(originUid).get.path.toSerializationFormat should ===(
-        "akka://EnvelopeBufferSpec/compressable1")
+        "pekko://EnvelopeBufferSpec/compressable1")
       headerOut.recipientActorRefPath should ===(OptionVal.None)
       headerOut.manifest(originUid).get should ===("manifest1")
     }
@@ -129,9 +129,9 @@ class EnvelopeBufferSpec extends PekkoSpec {
       headerOut.version should ===(version)
       headerOut.uid should ===(42L)
       headerOut.serializer should ===(4)
-      headerOut.senderActorRefPath should ===(OptionVal.Some("akka://EnvelopeBufferSpec/uncompressable0"))
+      headerOut.senderActorRefPath should ===(OptionVal.Some("pekko://EnvelopeBufferSpec/uncompressable0"))
       headerOut.senderActorRef(originUid) should ===(OptionVal.None)
-      headerOut.recipientActorRefPath should ===(OptionVal.Some("akka://EnvelopeBufferSpec/uncompressable11"))
+      headerOut.recipientActorRefPath should ===(OptionVal.Some("pekko://EnvelopeBufferSpec/uncompressable11"))
       headerOut.recipientActorRef(originUid) should ===(OptionVal.None)
       headerOut.manifest(originUid).get should ===("uncompressable3333")
     }
@@ -158,9 +158,9 @@ class EnvelopeBufferSpec extends PekkoSpec {
       headerOut.uid should ===(42L)
       headerOut.serializer should ===(4)
       headerOut.senderActorRef(originUid).get.path.toSerializationFormat should ===(
-        "akka://EnvelopeBufferSpec/reallylongcompressablestring")
+        "pekko://EnvelopeBufferSpec/reallylongcompressablestring")
       headerOut.senderActorRefPath should ===(OptionVal.None)
-      headerOut.recipientActorRefPath should ===(OptionVal.Some("akka://EnvelopeBufferSpec/uncompressable1"))
+      headerOut.recipientActorRefPath should ===(OptionVal.Some("pekko://EnvelopeBufferSpec/uncompressable1"))
       headerOut.recipientActorRef(originUid) should ===(OptionVal.None)
       headerOut.manifest(originUid).get should ===("manifest1")
 
@@ -185,10 +185,10 @@ class EnvelopeBufferSpec extends PekkoSpec {
       headerOut.version should ===(version)
       headerOut.uid should ===(Long.MinValue)
       headerOut.serializer should ===(-1)
-      headerOut.senderActorRefPath should ===(OptionVal.Some("akka://EnvelopeBufferSpec/uncompressable0"))
+      headerOut.senderActorRefPath should ===(OptionVal.Some("pekko://EnvelopeBufferSpec/uncompressable0"))
       headerOut.senderActorRef(originUid) should ===(OptionVal.None)
       headerOut.recipientActorRef(originUid).get.path.toSerializationFormat should ===(
-        "akka://EnvelopeBufferSpec/reallylongcompressablestring")
+        "pekko://EnvelopeBufferSpec/reallylongcompressablestring")
       headerOut.recipientActorRefPath should ===(OptionVal.None)
       headerOut.manifest(originUid).get should ===("longlonglongliteralmanifest")
     }
@@ -213,9 +213,9 @@ class EnvelopeBufferSpec extends PekkoSpec {
       headerOut.uid should ===(42L)
       headerOut.serializer should ===(4)
       headerOut.senderActorRef(originUid).get.path.toSerializationFormat should ===(
-        "akka://EnvelopeBufferSpec/reallylongcompressablestring")
+        "pekko://EnvelopeBufferSpec/reallylongcompressablestring")
       headerOut.senderActorRefPath should ===(OptionVal.None)
-      headerOut.recipientActorRefPath should ===(OptionVal.Some("akka://EnvelopeBufferSpec/uncompressable1"))
+      headerOut.recipientActorRefPath should ===(OptionVal.Some("pekko://EnvelopeBufferSpec/uncompressable1"))
       headerOut.recipientActorRef(originUid) should ===(OptionVal.None)
       headerOut.manifest(originUid).get should ===("manifest1")
 
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/HandshakeFailureSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/HandshakeFailureSpec.scala
index e036adfa94..0b59a9b033 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/HandshakeFailureSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/HandshakeFailureSpec.scala
@@ -39,7 +39,7 @@ class HandshakeFailureSpec extends ArteryMultiNodeSpec(HandshakeFailureSpec.comm
   "Artery handshake" must {
 
     "allow for timeout and later connect" in {
-      def sel = system.actorSelection(s"akka://systemB@localhost:$portB/user/echo")
+      def sel = system.actorSelection(s"pekko://systemB@localhost:$portB/user/echo")
       sel ! "hello"
       expectNoMessage(3.seconds) // longer than handshake-timeout
 
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/HandshakeRetrySpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/HandshakeRetrySpec.scala
index e73b3b578f..d4bbc2edb7 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/HandshakeRetrySpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/HandshakeRetrySpec.scala
@@ -37,7 +37,7 @@ class HandshakeRetrySpec extends ArteryMultiNodeSpec(HandshakeRetrySpec.commonCo
   "Artery handshake" must {
 
     "be retried during handshake-timeout (no message loss)" in {
-      def sel = system.actorSelection(s"akka://systemB@localhost:$portB/user/echo")
+      def sel = system.actorSelection(s"pekko://systemB@localhost:$portB/user/echo")
       sel ! "hello"
       expectNoMessage(1.second)
 
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/InboundControlJunctionSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/InboundControlJunctionSpec.scala
index fa21cc53e3..0105257862 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/InboundControlJunctionSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/InboundControlJunctionSpec.scala
@@ -46,8 +46,8 @@ class InboundControlJunctionSpec
     with ImplicitSender {
   import InboundControlJunctionSpec._
 
-  val addressA = UniqueAddress(Address("akka", "sysA", "hostA", 1001), 1)
-  val addressB = UniqueAddress(Address("akka", "sysB", "hostB", 1002), 2)
+  val addressA = UniqueAddress(Address("pekko", "sysA", "hostA", 1001), 1)
+  val addressB = UniqueAddress(Address("pekko", "sysB", "hostB", 1002), 2)
 
   "Control messages" must {
 
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/InboundHandshakeSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/InboundHandshakeSpec.scala
index eec00d506a..a1222710b3 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/InboundHandshakeSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/InboundHandshakeSpec.scala
@@ -43,8 +43,8 @@ class InboundHandshakeSpec extends PekkoSpec("""
     pekko.stream.materializer.debug.fuzzing-mode = on
   """) with ImplicitSender {
 
-  val addressA = UniqueAddress(Address("akka", "sysA", "hostA", 1001), 1)
-  val addressB = UniqueAddress(Address("akka", "sysB", "hostB", 1002), 2)
+  val addressA = UniqueAddress(Address("pekko", "sysA", "hostA", 1001), 1)
+  val addressB = UniqueAddress(Address("pekko", "sysB", "hostB", 1002), 2)
 
   private def setupStream(inboundContext: InboundContext): (TestPublisher.Probe[AnyRef], TestSubscriber.Probe[Any]) = {
     val recipient = OptionVal.None // not used
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/LateConnectSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/LateConnectSpec.scala
index b6a32071e4..2c5d6e849a 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/LateConnectSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/LateConnectSpec.scala
@@ -44,7 +44,7 @@ class LateConnectSpec extends ArteryMultiNodeSpec(LateConnectSpec.config) with I
     "be established after initial lazy restart" in {
       system.actorOf(TestActors.echoActorProps, "echoA")
 
-      val echoB = system.actorSelection(s"akka://systemB@localhost:$portB/user/echoB")
+      val echoB = system.actorSelection(s"pekko://systemB@localhost:$portB/user/echoB")
       echoB ! "ping1"
 
       // let the outbound streams be restarted (lazy), systemB is not started yet
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/OutboundControlJunctionSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/OutboundControlJunctionSpec.scala
index d6edfe13f9..9e18c37feb 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/OutboundControlJunctionSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/OutboundControlJunctionSpec.scala
@@ -34,8 +34,8 @@ class OutboundControlJunctionSpec extends PekkoSpec("""
   """) with ImplicitSender {
   import OutboundControlJunctionSpec._
 
-  val addressA = UniqueAddress(Address("akka", "sysA", "hostA", 1001), 1)
-  val addressB = UniqueAddress(Address("akka", "sysB", "hostB", 1002), 2)
+  val addressA = UniqueAddress(Address("pekko", "sysA", "hostA", 1001), 1)
+  val addressB = UniqueAddress(Address("pekko", "sysB", "hostB", 1002), 2)
 
   private val outboundEnvelopePool = ReusableOutboundEnvelope.createObjectPool(capacity = 16)
 
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/OutboundHandshakeSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/OutboundHandshakeSpec.scala
index 84140b8690..a3943e722b 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/OutboundHandshakeSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/OutboundHandshakeSpec.scala
@@ -33,8 +33,8 @@ class OutboundHandshakeSpec extends PekkoSpec("""
     pekko.stream.materializer.debug.fuzzing-mode = on
   """) with ImplicitSender {
 
-  val addressA = UniqueAddress(Address("akka", "sysA", "hostA", 1001), 1)
-  val addressB = UniqueAddress(Address("akka", "sysB", "hostB", 1002), 2)
+  val addressA = UniqueAddress(Address("pekko", "sysA", "hostA", 1001), 1)
+  val addressB = UniqueAddress(Address("pekko", "sysB", "hostB", 1002), 2)
 
   private val outboundEnvelopePool = ReusableOutboundEnvelope.createObjectPool(capacity = 16)
 
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteActorRefProviderSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteActorRefProviderSpec.scala
index bdcd6f2bdb..fbb7f216f8 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteActorRefProviderSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteActorRefProviderSpec.scala
@@ -32,19 +32,19 @@ class RemoteActorRefProviderSpec extends ArteryMultiNodeSpec {
   "RemoteActorRefProvider" must {
 
     "resolve local actor selection" in {
-      val sel = system.actorSelection(s"akka://${system.name}@${addressA.host.get}:${addressA.port.get}/user/echo")
+      val sel = system.actorSelection(s"pekko://${system.name}@${addressA.host.get}:${addressA.port.get}/user/echo")
       sel.anchor.asInstanceOf[InternalActorRef].isLocal should be(true)
     }
 
     "resolve remote actor selection" in {
-      val sel = system.actorSelection(s"akka://${systemB.name}@${addressB.host.get}:${addressB.port.get}/user/echo")
+      val sel = system.actorSelection(s"pekko://${systemB.name}@${addressB.host.get}:${addressB.port.get}/user/echo")
       sel.anchor.getClass should ===(classOf[RemoteActorRef])
       sel.anchor.asInstanceOf[InternalActorRef].isLocal should be(false)
     }
 
     "cache resolveActorRef for local ref" in {
       val provider = localSystem.asInstanceOf[ExtendedActorSystem].provider
-      val path = s"akka://${system.name}@${addressA.host.get}:${addressA.port.get}/user/echo"
+      val path = s"pekko://${system.name}@${addressA.host.get}:${addressA.port.get}/user/echo"
       val ref1 = provider.resolveActorRef(path)
       ref1.getClass should !==(classOf[EmptyLocalActorRef])
       ref1.asInstanceOf[ActorRefScope].isLocal should ===(true)
@@ -55,7 +55,7 @@ class RemoteActorRefProviderSpec extends ArteryMultiNodeSpec {
 
     "not cache resolveActorRef for unresolved ref" in {
       val provider = localSystem.asInstanceOf[ExtendedActorSystem].provider
-      val path = s"akka://${system.name}@${addressA.host.get}:${addressA.port.get}/user/doesNotExist"
+      val path = s"pekko://${system.name}@${addressA.host.get}:${addressA.port.get}/user/doesNotExist"
       val ref1 = provider.resolveActorRef(path)
       ref1.getClass should ===(classOf[EmptyLocalActorRef])
 
@@ -65,7 +65,7 @@ class RemoteActorRefProviderSpec extends ArteryMultiNodeSpec {
 
     "cache resolveActorRef for remote ref" in {
       val provider = localSystem.asInstanceOf[ExtendedActorSystem].provider
-      val path = s"akka://${systemB.name}@${addressB.host.get}:${addressB.port.get}/user/echo"
+      val path = s"pekko://${systemB.name}@${addressB.host.get}:${addressB.port.get}/user/echo"
       val ref1 = provider.resolveActorRef(path)
       ref1.getClass should ===(classOf[RemoteActorRef])
 
@@ -76,7 +76,7 @@ class RemoteActorRefProviderSpec extends ArteryMultiNodeSpec {
     "detect wrong protocol" in {
       EventFilter[IllegalArgumentException](start = "No root guardian at", occurrences = 1).intercept {
         val sel =
-          system.actorSelection(s"akka.tcp://${systemB.name}@${addressB.host.get}:${addressB.port.get}/user/echo")
+          system.actorSelection(s"pekko.tcp://${systemB.name}@${addressB.host.get}:${addressB.port.get}/user/echo")
         sel.anchor.getClass should ===(classOf[EmptyLocalActorRef])
       }
     }
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteActorSelectionSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteActorSelectionSpec.scala
index bc617aeb6e..12754f503d 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteActorSelectionSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteActorSelectionSpec.scala
@@ -69,8 +69,8 @@ class RemoteActorSelectionSpec extends ArteryMultiNodeSpec with ImplicitSender {
           pekko {
             remote.artery.port = $port
             actor.deployment {
-              /looker2/child.remote = "akka://$remoteSysName@localhost:$remotePort"
-              /looker2/child/grandchild.remote = "akka://$localSysName@localhost:$localPort"
+              /looker2/child.remote = "pekko://$remoteSysName@localhost:$remotePort"
+              /looker2/child/grandchild.remote = "pekko://$localSysName@localhost:$localPort"
             }
           }
         """
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteConnectionSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteConnectionSpec.scala
index 0bebda8863..cabf8a055e 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteConnectionSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteConnectionSpec.scala
@@ -38,7 +38,7 @@ class RemoteConnectionSpec extends ArteryMultiNodeSpec("pekko.remote.retry-gate-
       val remotePort = freePort()
 
       // try to talk to it before it is up
-      val selection = localSystem.actorSelection(s"akka://$nextGeneratedSystemName@localhost:$remotePort/user/echo")
+      val selection = localSystem.actorSelection(s"pekko://$nextGeneratedSystemName@localhost:$remotePort/user/echo")
       selection.tell("ping", localProbe.ref)
       localProbe.expectNoMessage(1.seconds)
 
@@ -69,7 +69,7 @@ class RemoteConnectionSpec extends ArteryMultiNodeSpec("pekko.remote.retry-gate-
       val remotePort = freePort()
 
       // try to talk to remote before it is up
-      val selection = localSystem.actorSelection(s"akka://$nextGeneratedSystemName@localhost:$remotePort/user/echo")
+      val selection = localSystem.actorSelection(s"pekko://$nextGeneratedSystemName@localhost:$remotePort/user/echo")
       selection.tell("ping", localProbe.ref)
       localProbe.expectNoMessage(1.seconds)
 
@@ -80,7 +80,7 @@ class RemoteConnectionSpec extends ArteryMultiNodeSpec("pekko.remote.retry-gate-
       localProbe.expectNoMessage(2.seconds)
       val otherProbe = new TestProbe(remoteSystem)
       val otherSender = otherProbe.ref
-      val thisSelection = remoteSystem.actorSelection(s"akka://${localSystem.name}@localhost:$localPort/user/echo")
+      val thisSelection = remoteSystem.actorSelection(s"pekko://${localSystem.name}@localhost:$localPort/user/echo")
       within(5.seconds) {
         awaitAssert {
           thisSelection.tell("ping", otherSender)
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeathWatchSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeathWatchSpec.scala
index bc806e9022..ada682253a 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeathWatchSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeathWatchSpec.scala
@@ -33,7 +33,7 @@ object RemoteDeathWatchSpec {
         actor {
             provider = remote
             deployment {
-                /watchers.remote = "akka://other@localhost:$otherPort"
+                /watchers.remote = "pekko://other@localhost:$otherPort"
             }
         }
         test.filter-leeway = 10s
@@ -74,7 +74,7 @@ class RemoteDeathWatchSpec
     // pick an unused port
     val port = SocketUtil.temporaryLocalPort(udp = true)
     // simulate de-serialized ActorRef
-    val ref = rarp.resolveActorRef(s"akka://OtherSystem@localhost:$port/user/foo/bar#1752527294")
+    val ref = rarp.resolveActorRef(s"pekko://OtherSystem@localhost:$port/user/foo/bar#1752527294")
 
     // we don't expect real quarantine when the UID is unknown, i.e. QuarantinedEvent is not published
     EventFilter.warning(pattern = "Quarantine of .* ignored because unknown UID", occurrences = 1).intercept {
@@ -94,7 +94,7 @@ class RemoteDeathWatchSpec
   }
 
   "receive Terminated when watched node is unknown host" in {
-    val path = RootActorPath(Address("akka", system.name, "unknownhost", 2552)) / "user" / "subject"
+    val path = RootActorPath(Address("pekko", system.name, "unknownhost", 2552)) / "user" / "subject"
 
     system.actorOf(Props(new Actor {
         @nowarn
@@ -114,7 +114,7 @@ class RemoteDeathWatchSpec
     // immediately in constructor from aeron.addPublication when UnknownHostException. That will trigger
     // this immediately. With TCP it will trigger after handshake timeout. Can we see the UnknownHostException
     // reason somehow and fail the stream immediately for that case?
-    val path = RootActorPath(Address("akka", system.name, "unknownhost2", 2552)) / "user" / "subject"
+    val path = RootActorPath(Address("pekko", system.name, "unknownhost2", 2552)) / "user" / "subject"
     system.actorSelection(path) ! Identify(path.toString)
     expectMsg(60.seconds, ActorIdentity(path.toString, None))
   }
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeployerSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeployerSpec.scala
index eecf649e26..406df034c9 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeployerSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeployerSpec.scala
@@ -28,7 +28,7 @@ object RemoteDeployerSpec {
         /service2 {
           router = round-robin-pool
           nr-of-instances = 3
-          remote = "akka://sys@wallace:2552"
+          remote = "pekko://sys@wallace:2552"
           dispatcher = mydispatcher
         }
       }
@@ -54,7 +54,7 @@ class RemoteDeployerSpec extends PekkoSpec(RemoteDeployerSpec.deployerConf) {
             service,
             deployment.get.config,
             RoundRobinPool(3),
-            RemoteScope(Address("akka", "sys", "wallace", 2552)),
+            RemoteScope(Address("pekko", "sys", "wallace", 2552)),
             "mydispatcher")))
     }
 
@@ -62,7 +62,7 @@ class RemoteDeployerSpec extends PekkoSpec(RemoteDeployerSpec.deployerConf) {
       intercept[ConfigurationException] {
         system.actorOf(Props.empty.withDeploy(Deploy.local), "service2")
       }.getMessage should ===(
-        "configuration requested remote deployment for local-only Props at [akka://RemoteDeployerSpec/user/service2]")
+        "configuration requested remote deployment for local-only Props at [pekko://RemoteDeployerSpec/user/service2]")
     }
 
   }
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeploymentSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeploymentSpec.scala
index 1a2c5b922c..ce6d88a30a 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeploymentSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteDeploymentSpec.scala
@@ -91,9 +91,9 @@ class RemoteDeploymentSpec
   val conf =
     s"""
     pekko.actor.deployment {
-      /blub.remote = "akka://${system.name}@localhost:$port"
-      /blub2.remote = "akka://${system.name}@localhost:$port"
-      "/parent*/*".remote = "akka://${system.name}@localhost:$port"
+      /blub.remote = "pekko://${system.name}@localhost:$port"
+      /blub2.remote = "pekko://${system.name}@localhost:$port"
+      "/parent*/*".remote = "pekko://${system.name}@localhost:$port"
     }
     pekko.remote.artery.advanced.inbound-lanes = 10
     pekko.remote.artery.advanced.outbound-lanes = 3
@@ -108,7 +108,7 @@ class RemoteDeploymentSpec
       val senderProbe = TestProbe()(masterSystem)
       val r = masterSystem.actorOf(Props[Echo1](), "blub")
       r.path.toString should ===(
-        s"akka://${system.name}@localhost:${port}/remote/akka/${masterSystem.name}@localhost:${masterPort}/user/blub")
+        s"pekko://${system.name}@localhost:${port}/remote/pekko/${masterSystem.name}@localhost:${masterPort}/user/blub")
 
       r.tell(42, senderProbe.ref)
       senderProbe.expectMsg(42)
@@ -126,7 +126,7 @@ class RemoteDeploymentSpec
       val senderProbe = TestProbe()(masterSystem)
       val r = masterSystem.actorOf(Props[Echo1](), "blub2")
       r.path.toString should ===(
-        s"akka://${system.name}@localhost:${port}/remote/akka/${masterSystem.name}@localhost:${masterPort}/user/blub2")
+        s"pekko://${system.name}@localhost:${port}/remote/pekko/${masterSystem.name}@localhost:${masterPort}/user/blub2")
 
       r.tell(42, senderProbe.ref)
       senderProbe.expectMsg(42)
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteMessageSerializationSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteMessageSerializationSpec.scala
index 774e26459c..134da3f2a0 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteMessageSerializationSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteMessageSerializationSpec.scala
@@ -105,7 +105,7 @@ class RemoteMessageSerializationSpec extends ArteryMultiNodeSpec with ImplicitSe
       }), bigBounceId)
     @nowarn
     val bigBounceHere =
-      RARP(system).provider.resolveActorRef(s"akka://${remoteSystem.name}@localhost:$remotePort/user/$bigBounceId")
+      RARP(system).provider.resolveActorRef(s"pekko://${remoteSystem.name}@localhost:$remotePort/user/$bigBounceId")
 
     val eventForwarder = localSystem.actorOf(Props(new Actor {
       def receive = {
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteRouterSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteRouterSpec.scala
index 9479d5c064..780fbafcd8 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteRouterSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/RemoteRouterSpec.scala
@@ -62,7 +62,7 @@ class RemoteRouterSpec
         /blub {
           router = round-robin-pool
           nr-of-instances = 2
-          target.nodes = ["akka://${sysName}@localhost:${port}"]
+          target.nodes = ["pekko://${sysName}@localhost:${port}"]
         }
         /elastic-blub {
           router = round-robin-pool
@@ -70,23 +70,23 @@ class RemoteRouterSpec
             lower-bound = 2
             upper-bound = 3
           }
-          target.nodes = ["akka://${sysName}@localhost:${port}"]
+          target.nodes = ["pekko://${sysName}@localhost:${port}"]
         }
         /remote-blub {
-          remote = "akka://${sysName}@localhost:${port}"
+          remote = "pekko://${sysName}@localhost:${port}"
           router = round-robin-pool
           nr-of-instances = 2
         }
         /local-blub {
-          remote = "akka://MasterRemoteRouterSpec"
+          remote = "pekko://MasterRemoteRouterSpec"
           router = round-robin-pool
           nr-of-instances = 2
-          target.nodes = ["akka://${sysName}@localhost:${port}"]
+          target.nodes = ["pekko://${sysName}@localhost:${port}"]
         }
         /local-blub2 {
           router = round-robin-pool
           nr-of-instances = 4
-          target.nodes = ["akka://${sysName}@localhost:${port}"]
+          target.nodes = ["pekko://${sysName}@localhost:${port}"]
         }
       }
     }""").withFallback(system.settings.config)
@@ -115,7 +115,7 @@ class RemoteRouterSpec
       val children = replies.toSet
       children should have size 2
       children.map(_.parent) should have size 1
-      children.foreach(_.address.toString should ===(s"akka://${sysName}@localhost:${port}"))
+      children.foreach(_.address.toString should ===(s"pekko://${sysName}@localhost:${port}"))
       masterSystem.stop(router)
     }
 
@@ -123,14 +123,14 @@ class RemoteRouterSpec
       val probe = TestProbe()(masterSystem)
       val router =
         masterSystem.actorOf(
-          new RemoteRouterConfig(RoundRobinPool(2), Seq(Address("akka", sysName, "localhost", port)))
+          new RemoteRouterConfig(RoundRobinPool(2), Seq(Address("pekko", sysName, "localhost", port)))
             .props(echoActorProps),
           "blub2")
       val replies = collectRouteePaths(probe, router, 5)
       val children = replies.toSet
       children should have size 2
       children.map(_.parent) should have size 1
-      children.foreach(_.address.toString should ===(s"akka://${sysName}@localhost:${port}"))
+      children.foreach(_.address.toString should ===(s"pekko://${sysName}@localhost:${port}"))
       masterSystem.stop(router)
     }
 
@@ -141,21 +141,21 @@ class RemoteRouterSpec
       val children = replies.toSet
       children.size should be >= 2
       children.map(_.parent) should have size 1
-      children.foreach(_.address.toString should ===(s"akka://${sysName}@localhost:${port}"))
+      children.foreach(_.address.toString should ===(s"pekko://${sysName}@localhost:${port}"))
       masterSystem.stop(router)
     }
 
     "deploy remote routers based on configuration" in {
       val probe = TestProbe()(masterSystem)
       val router = masterSystem.actorOf(FromConfig.props(echoActorProps), "remote-blub")
-      router.path.address.toString should ===(s"akka://${sysName}@localhost:${port}")
+      router.path.address.toString should ===(s"pekko://${sysName}@localhost:${port}")
       val replies = collectRouteePaths(probe, router, 5)
       val children = replies.toSet
       children should have size 2
       val parents = children.map(_.parent)
       parents should have size 1
       parents.head should ===(router.path)
-      children.foreach(_.address.toString should ===(s"akka://${sysName}@localhost:${port}"))
+      children.foreach(_.address.toString should ===(s"pekko://${sysName}@localhost:${port}"))
       masterSystem.stop(router)
     }
 
@@ -164,16 +164,16 @@ class RemoteRouterSpec
       val router = masterSystem.actorOf(
         RoundRobinPool(2)
           .props(echoActorProps)
-          .withDeploy(Deploy(scope = RemoteScope(AddressFromURIString(s"akka://${sysName}@localhost:${port}")))),
+          .withDeploy(Deploy(scope = RemoteScope(AddressFromURIString(s"pekko://${sysName}@localhost:${port}")))),
         "remote-blub2")
-      router.path.address.toString should ===(s"akka://${sysName}@localhost:${port}")
+      router.path.address.toString should ===(s"pekko://${sysName}@localhost:${port}")
       val replies = collectRouteePaths(probe, router, 5)
       val children = replies.toSet
       children should have size 2
       val parents = children.map(_.parent)
       parents should have size 1
       parents.head should ===(router.path)
-      children.foreach(_.address.toString should ===(s"akka://${sysName}@localhost:${port}"))
+      children.foreach(_.address.toString should ===(s"pekko://${sysName}@localhost:${port}"))
       masterSystem.stop(router)
     }
 
@@ -182,16 +182,16 @@ class RemoteRouterSpec
       val router = masterSystem.actorOf(
         RoundRobinPool(2)
           .props(echoActorProps)
-          .withDeploy(Deploy(scope = RemoteScope(AddressFromURIString(s"akka://${sysName}@localhost:${port}")))),
+          .withDeploy(Deploy(scope = RemoteScope(AddressFromURIString(s"pekko://${sysName}@localhost:${port}")))),
         "local-blub")
-      router.path.address.toString should ===("akka://MasterRemoteRouterSpec")
+      router.path.address.toString should ===("pekko://MasterRemoteRouterSpec")
       val replies = collectRouteePaths(probe, router, 5)
       val children = replies.toSet
       children should have size 2
       val parents = children.map(_.parent)
       parents should have size 1
-      parents.head.address should ===(Address("akka", sysName, "localhost", port))
-      children.foreach(_.address.toString should ===(s"akka://${sysName}@localhost:${port}"))
+      parents.head.address should ===(Address("pekko", sysName, "localhost", port))
+      children.foreach(_.address.toString should ===(s"pekko://${sysName}@localhost:${port}"))
       masterSystem.stop(router)
     }
 
@@ -200,16 +200,16 @@ class RemoteRouterSpec
       val router = masterSystem.actorOf(
         RoundRobinPool(2)
           .props(echoActorProps)
-          .withDeploy(Deploy(scope = RemoteScope(AddressFromURIString(s"akka://${sysName}@localhost:${port}")))),
+          .withDeploy(Deploy(scope = RemoteScope(AddressFromURIString(s"pekko://${sysName}@localhost:${port}")))),
         "local-blub2")
-      router.path.address.toString should ===(s"akka://${sysName}@localhost:${port}")
+      router.path.address.toString should ===(s"pekko://${sysName}@localhost:${port}")
       val replies = collectRouteePaths(probe, router, 5)
       val children = replies.toSet
       children should have size 4
       val parents = children.map(_.parent)
       parents should have size 1
       parents.head should ===(router.path)
-      children.foreach(_.address.toString should ===(s"akka://${sysName}@localhost:${port}"))
+      children.foreach(_.address.toString should ===(s"pekko://${sysName}@localhost:${port}"))
       masterSystem.stop(router)
     }
 
@@ -218,16 +218,16 @@ class RemoteRouterSpec
       val router = masterSystem.actorOf(
         RoundRobinPool(2)
           .props(echoActorProps)
-          .withDeploy(Deploy(scope = RemoteScope(AddressFromURIString(s"akka://${sysName}@localhost:${port}")))),
+          .withDeploy(Deploy(scope = RemoteScope(AddressFromURIString(s"pekko://${sysName}@localhost:${port}")))),
         "remote-override")
-      router.path.address.toString should ===(s"akka://${sysName}@localhost:${port}")
+      router.path.address.toString should ===(s"pekko://${sysName}@localhost:${port}")
       val replies = collectRouteePaths(probe, router, 5)
       val children = replies.toSet
       children should have size 4
       val parents = children.map(_.parent)
       parents should have size 1
       parents.head should ===(router.path)
-      children.foreach(_.address.toString should ===(s"akka://${sysName}@localhost:${port}"))
+      children.foreach(_.address.toString should ===(s"pekko://${sysName}@localhost:${port}"))
       masterSystem.stop(router)
     }
 
@@ -239,7 +239,7 @@ class RemoteRouterSpec
       val router = masterSystem.actorOf(
         new RemoteRouterConfig(
           RoundRobinPool(1, supervisorStrategy = escalator),
-          Seq(Address("akka", sysName, "localhost", port))).props(Props.empty),
+          Seq(Address("pekko", sysName, "localhost", port))).props(Props.empty),
         "blub3")
 
       router.tell(GetRoutees, probe.ref)
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/SystemMessageAckerSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/SystemMessageAckerSpec.scala
index 0393bbc982..fdb9c43e9c 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/SystemMessageAckerSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/SystemMessageAckerSpec.scala
@@ -31,9 +31,9 @@ class SystemMessageAckerSpec extends PekkoSpec("""
     pekko.stream.materializer.debug.fuzzing-mode = on
   """) with ImplicitSender {
 
-  val addressA = UniqueAddress(Address("akka", "sysA", "hostA", 1001), 1)
-  val addressB = UniqueAddress(Address("akka", "sysB", "hostB", 1002), 2)
-  val addressC = UniqueAddress(Address("akka", "sysC", "hostB", 1003), 3)
+  val addressA = UniqueAddress(Address("pekko", "sysA", "hostA", 1001), 1)
+  val addressB = UniqueAddress(Address("pekko", "sysB", "hostB", 1002), 2)
+  val addressC = UniqueAddress(Address("pekko", "sysC", "hostB", 1003), 3)
 
   private def setupStream(inboundContext: InboundContext): (TestPublisher.Probe[AnyRef], TestSubscriber.Probe[Any]) = {
     val recipient = OptionVal.None // not used
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/compress/HandshakeShouldDropCompressionTableSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/compress/HandshakeShouldDropCompressionTableSpec.scala
index 28dc7fd26e..60f029a822 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/compress/HandshakeShouldDropCompressionTableSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/compress/HandshakeShouldDropCompressionTableSpec.scala
@@ -75,7 +75,7 @@ class HandshakeShouldDropCompressionTableSpec
       system.eventStream.subscribe(aProbe.ref, classOf[Event])
       systemB.eventStream.subscribe(b1Probe.ref, classOf[Event])
 
-      def echoSel = system.actorSelection(s"akka://systemB@localhost:$portB/user/echo")
+      def echoSel = system.actorSelection(s"pekko://systemB@localhost:$portB/user/echo")
       systemB.actorOf(TestActors.echoActorProps, "echo")
 
       // cause testActor-1 to become a heavy hitter
@@ -146,7 +146,7 @@ class HandshakeShouldDropCompressionTableSpec
 
   def identify(_system: String, port: Int, name: String) = {
     val selection =
-      system.actorSelection(s"akka://${_system}@localhost:$port/user/$name")
+      system.actorSelection(s"pekko://${_system}@localhost:$port/user/$name")
     val identity = Await.result((selection ? Identify(1)).mapTo[ActorIdentity], 3.seconds)
     if (identity.correlationId != 1) throw new RuntimeException("Got the wrong identity back")
     identity.ref.get
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/tcp/TlsTcpSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/tcp/TlsTcpSpec.scala
index 7fdfc633b6..abd1019fe8 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/tcp/TlsTcpSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/tcp/TlsTcpSpec.scala
@@ -188,7 +188,7 @@ class TlsTcpWithHostnameVerificationSpec
       EventFilter
         .warning(
           pattern =
-            "outbound connection to \\[akka://systemB@127.0.0.1:.*" +
+            "outbound connection to \\[pekko://systemB@127.0.0.1:.*" +
             "Upstream failed, cause: SSLHandshakeException: .*",
           occurrences = 3)
         .intercept {
diff --git a/remote/src/test/scala/org/apache/pekko/remote/classic/RemoteDeathWatchSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/classic/RemoteDeathWatchSpec.scala
index e425839e08..192db6b9d3 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/classic/RemoteDeathWatchSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/classic/RemoteDeathWatchSpec.scala
@@ -31,7 +31,7 @@ pekko {
     actor {
         provider = remote
         deployment {
-            /watchers.remote = "akka.tcp://other@localhost:2666"
+            /watchers.remote = "pekko.tcp://other@localhost:2666"
         }
 
     }
@@ -55,8 +55,8 @@ pekko.actor.warn-about-java-serializer-usage = off
     with DeathWatchSpec {
 
   val protocol =
-    if (RARP(system).provider.remoteSettings.Artery.Enabled) "akka"
-    else "akka.tcp"
+    if (RARP(system).provider.remoteSettings.Artery.Enabled) "pekko"
+    else "pekko.tcp"
 
   val other = ActorSystem(
     "other",
diff --git a/remote/src/test/scala/org/apache/pekko/remote/classic/RemoteDeploymentAllowListSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/classic/RemoteDeploymentAllowListSpec.scala
index 9cef801813..d792f5792e 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/classic/RemoteDeploymentAllowListSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/classic/RemoteDeploymentAllowListSpec.scala
@@ -96,8 +96,8 @@ object RemoteDeploymentAllowListSpec {
       }
 
       actor.deployment {
-        /blub.remote = "akka.test://remote-sys@localhost:12346"
-        /danger-mouse.remote = "akka.test://remote-sys@localhost:12346"
+        /blub.remote = "pekko.test://remote-sys@localhost:12346"
+        /danger-mouse.remote = "pekko.test://remote-sys@localhost:12346"
       }
     }
     # test is using Java serialization and not priority to rewrite
@@ -161,7 +161,7 @@ class RemoteDeploymentAllowListSpec
     "allow deploying Echo actor (included in allow list)" in {
       val r = system.actorOf(Props[EchoAllowed](), "blub")
       r.path.toString should ===(
-        s"akka.test://remote-sys@localhost:12346/remote/akka.test/${getClass.getSimpleName}@localhost:12345/user/blub")
+        s"pekko.test://remote-sys@localhost:12346/remote/pekko.test/${getClass.getSimpleName}@localhost:12345/user/blub")
       r ! 42
       expectMsg(42)
       EventFilter[Exception]("crash", occurrences = 1).intercept {
@@ -181,7 +181,7 @@ class RemoteDeploymentAllowListSpec
           EventFilter[NotAllowedClassRemoteDeploymentAttemptException](occurrences = 1).intercept {
             val r = system.actorOf(Props[EchoNotAllowed](), "danger-mouse")
             r.path.toString should ===(
-              s"akka.test://remote-sys@localhost:12346/remote/akka.test/${getClass.getSimpleName}@localhost:12345/user/danger-mouse")
+              s"pekko.test://remote-sys@localhost:12346/remote/pekko.test/${getClass.getSimpleName}@localhost:12345/user/danger-mouse")
             r ! 42
             expectNoMessage(1.second)
             system.stop(r)
diff --git a/remote/src/test/scala/org/apache/pekko/remote/classic/RemotingSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/classic/RemotingSpec.scala
index a4799a251c..26b794fff7 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/classic/RemotingSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/classic/RemotingSpec.scala
@@ -126,11 +126,11 @@ object RemotingSpec {
       }
 
       actor.deployment {
-        /blub.remote = "akka.test://remote-sys@localhost:12346"
-        /looker1/child.remote = "akka.test://remote-sys@localhost:12346"
-        /looker1/child/grandchild.remote = "akka.test://RemotingSpec@localhost:12345"
-        /looker2/child.remote = "akka.test://remote-sys@localhost:12346"
-        /looker2/child/grandchild.remote = "akka.test://RemotingSpec@localhost:12345"
+        /blub.remote = "pekko.test://remote-sys@localhost:12346"
+        /looker1/child.remote = "pekko.test://remote-sys@localhost:12346"
+        /looker1/child/grandchild.remote = "pekko.test://RemotingSpec@localhost:12345"
+        /looker2/child.remote = "pekko.test://remote-sys@localhost:12346"
+        /looker2/child/grandchild.remote = "pekko.test://RemotingSpec@localhost:12345"
       }
     }
   """)
@@ -162,7 +162,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
     deploy(system, Deploy(name, scope = RemoteScope(getOtherAddress(remoteSystem, proto))))
 
   def getOtherAddress(sys: ActorSystem, proto: String) =
-    sys.asInstanceOf[ExtendedActorSystem].provider.getExternalAddressFor(Address(s"akka.$proto", "", "", 0)).get
+    sys.asInstanceOf[ExtendedActorSystem].provider.getExternalAddressFor(Address(s"pekko.$proto", "", "", 0)).get
   def port(sys: ActorSystem, proto: String) = getOtherAddress(sys, proto).port.get
   def deploy(sys: ActorSystem, d: Deploy): Unit = {
     sys.asInstanceOf[ExtendedActorSystem].provider.asInstanceOf[RemoteActorRefProvider].deployer.deploy(d)
@@ -170,7 +170,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
 
   val remote = remoteSystem.actorOf(Props[Echo2](), "echo")
 
-  val here = RARP(system).provider.resolveActorRef("akka.test://remote-sys@localhost:12346/user/echo")
+  val here = RARP(system).provider.resolveActorRef("pekko.test://remote-sys@localhost:12346/user/echo")
 
   private def verifySend(msg: Any)(afterSend: => Unit): Unit = {
     val bigBounceId = s"bigBounce-${ThreadLocalRandom.current.nextInt()}"
@@ -181,7 +181,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
         }
       }).withDeploy(Deploy.local), bigBounceId)
     val bigBounceHere =
-      RARP(system).provider.resolveActorRef(s"akka.test://remote-sys@localhost:12346/user/$bigBounceId")
+      RARP(system).provider.resolveActorRef(s"pekko.test://remote-sys@localhost:12346/user/$bigBounceId")
 
     val eventForwarder = system.actorOf(Props(new Actor {
       def receive = {
@@ -229,7 +229,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
 
     "send warning message for wrong address" in {
       filterEvents(EventFilter.warning(pattern = "Address is now gated for ", occurrences = 1)) {
-        RARP(system).provider.resolveActorRef("akka.test://nonexistingsystem@localhost:12346/user/echo") ! "ping"
+        RARP(system).provider.resolveActorRef("pekko.test://nonexistingsystem@localhost:12346/user/echo") ! "ping"
       }
     }
 
@@ -244,7 +244,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
       EventFilter
         .warning(pattern = "dead.*buh", occurrences = 1)
         .intercept {
-          RARP(system).provider.resolveActorRef("akka.test://remote-sys@localhost:12346/does/not/exist") ! "buh"
+          RARP(system).provider.resolveActorRef("pekko.test://remote-sys@localhost:12346/does/not/exist") ! "buh"
         }(remoteSystem)
     }
 
@@ -296,7 +296,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
     "create and supervise children on remote node" in {
       val r = system.actorOf(Props[Echo1](), "blub")
       r.path.toString should ===(
-        "akka.test://remote-sys@localhost:12346/remote/akka.test/RemotingSpec@localhost:12345/user/blub")
+        "pekko.test://remote-sys@localhost:12346/remote/pekko.test/RemotingSpec@localhost:12345/user/blub")
       r ! 42
       expectMsg(42)
       EventFilter[Exception]("crash", occurrences = 1).intercept {
@@ -329,13 +329,13 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
       remoteSystem.actorSelection("/user/otherEcho1") ! 75
       expectMsg(75)
 
-      system.actorSelection("akka.test://remote-sys@localhost:12346/user/otherEcho1") ! 76
+      system.actorSelection("pekko.test://remote-sys@localhost:12346/user/otherEcho1") ! 76
       expectMsg(76)
 
       remoteSystem.actorSelection("/user/otherEcho1") ! 77
       expectMsg(77)
 
-      system.actorSelection("akka.test://remote-sys@localhost:12346/user/otherEcho1") ! 78
+      system.actorSelection("pekko.test://remote-sys@localhost:12346/user/otherEcho1") ! 78
       expectMsg(78)
     }
 
@@ -442,7 +442,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
     "be able to use multiple transports and use the appropriate one (TCP)" in {
       val r = system.actorOf(Props[Echo1](), "gonk")
       r.path.toString should ===(
-        s"akka.tcp://remote-sys@localhost:${port(remoteSystem, "tcp")}/remote/akka.tcp/RemotingSpec@localhost:${port(
+        s"pekko.tcp://remote-sys@localhost:${port(remoteSystem, "tcp")}/remote/pekko.tcp/RemotingSpec@localhost:${port(
             system, "tcp")}/user/gonk")
       r ! 42
       expectMsg(42)
@@ -459,8 +459,8 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
     "be able to use multiple transports and use the appropriate one (SSL)" in {
       val r = system.actorOf(Props[Echo1](), "roghtaar")
       r.path.toString should ===(
-        s"akka.ssl.tcp://remote-sys@localhost:${port(remoteSystem,
-            "ssl.tcp")}/remote/akka.ssl.tcp/RemotingSpec@localhost:${port(system, "ssl.tcp")}/user/roghtaar")
+        s"pekko.ssl.tcp://remote-sys@localhost:${port(remoteSystem,
+            "ssl.tcp")}/remote/pekko.ssl.tcp/RemotingSpec@localhost:${port(system, "ssl.tcp")}/user/roghtaar")
       r ! 42
       expectMsg(10.seconds, 42)
       EventFilter[Exception]("crash", occurrences = 1).intercept {
@@ -528,7 +528,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
         val otherGuyRemoteTcp = otherGuy.path.toSerializationFormatWithAddress(getOtherAddress(otherSystem, "tcp"))
         val remoteEchoHereTcp =
           RARP(system).provider
-            .resolveActorRef(s"akka.tcp://remote-sys@localhost:${port(remoteSystem, "tcp")}/user/echo")
+            .resolveActorRef(s"pekko.tcp://remote-sys@localhost:${port(remoteSystem, "tcp")}/user/echo")
         val proxyTcp = system.actorOf(Props(classOf[Proxy], remoteEchoHereTcp, testActor), "proxy-tcp")
         proxyTcp ! otherGuy
         expectMsg(3.seconds, ("pong", otherGuyRemoteTcp))
@@ -536,7 +536,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
         val otherGuyRemoteTest = otherGuy.path.toSerializationFormatWithAddress(getOtherAddress(otherSystem, "test"))
         val remoteEchoHereSsl =
           RARP(system).provider
-            .resolveActorRef(s"akka.ssl.tcp://remote-sys@localhost:${port(remoteSystem, "ssl.tcp")}/user/echo")
+            .resolveActorRef(s"pekko.ssl.tcp://remote-sys@localhost:${port(remoteSystem, "ssl.tcp")}/user/echo")
         val proxySsl = system.actorOf(Props(classOf[Proxy], remoteEchoHereSsl, testActor), "proxy-ssl")
         EventFilter
           .warning(start = "Error while resolving ActorRef", occurrences = 1)
@@ -550,9 +550,9 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
     }
 
     "should not publish AddressTerminated even on InvalidAssociationExceptions" in {
-      val localAddress = Address("akka.test", "system1", "localhost", 1)
+      val localAddress = Address("pekko.test", "system1", "localhost", 1)
       val rawLocalAddress = localAddress.copy(protocol = "test")
-      val remoteAddress = Address("akka.test", "system2", "localhost", 2)
+      val remoteAddress = Address("pekko.test", "system2", "localhost", 2)
 
       val config = ConfigFactory.parseString(s"""
             pekko.remote.enabled-transports = ["pekko.remote.classic.test"]
@@ -607,9 +607,9 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
     }
 
     "should stash inbound connections until UID is known for pending outbound" in {
-      val localAddress = Address("akka.test", "system1", "localhost", 1)
+      val localAddress = Address("pekko.test", "system1", "localhost", 1)
       val rawLocalAddress = localAddress.copy(protocol = "test")
-      val remoteAddress = Address("akka.test", "system2", "localhost", 2)
+      val remoteAddress = Address("pekko.test", "system2", "localhost", 2)
       val rawRemoteAddress = remoteAddress.copy(protocol = "test")
 
       val config = ConfigFactory.parseString(s"""
@@ -688,9 +688,9 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
     }
 
     "should properly quarantine stashed inbound connections" in {
-      val localAddress = Address("akka.test", "system1", "localhost", 1)
+      val localAddress = Address("pekko.test", "system1", "localhost", 1)
       val rawLocalAddress = localAddress.copy(protocol = "test")
-      val remoteAddress = Address("akka.test", "system2", "localhost", 2)
+      val remoteAddress = Address("pekko.test", "system2", "localhost", 2)
       val rawRemoteAddress = remoteAddress.copy(protocol = "test")
       val remoteUID = 16
 
@@ -783,7 +783,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
               pekko.remote.classic.netty.tcp.port = ${otherAddress.getPort}
               """).withFallback(config)
       val otherSelection =
-        thisSystem.actorSelection(s"akka.tcp://other-system@localhost:${otherAddress.getPort}/user/echo")
+        thisSystem.actorSelection(s"pekko.tcp://other-system@localhost:${otherAddress.getPort}/user/echo")
       otherSelection.tell("ping", probe.ref)
       probe.expectNoMessage(200.millis)
       try {
@@ -842,7 +842,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
               pekko.remote.classic.netty.tcp.port = ${otherAddress.getPort}
               """).withFallback(config)
         val otherSelection =
-          thisSystem.actorSelection(s"akka.tcp://other-system@localhost:${otherAddress.getPort}/user/echo")
+          thisSystem.actorSelection(s"pekko.tcp://other-system@localhost:${otherAddress.getPort}/user/echo")
         otherSelection.tell("ping", thisSender)
         thisProbe.expectNoMessage(1.seconds)
         val otherSystem = ActorSystem("other-system", otherConfig)
@@ -852,7 +852,7 @@ class RemotingSpec extends PekkoSpec(RemotingSpec.cfg) with ImplicitSender with
           val otherProbe = new TestProbe(otherSystem)
           val otherSender = otherProbe.ref
           val thisSelection =
-            otherSystem.actorSelection(s"akka.tcp://this-system@localhost:${port(thisSystem, "tcp")}/user/echo")
+            otherSystem.actorSelection(s"pekko.tcp://this-system@localhost:${port(thisSystem, "tcp")}/user/echo")
           within(5.seconds) {
             awaitAssert {
               thisSelection.tell("ping", otherSender)
diff --git a/remote/src/test/scala/org/apache/pekko/remote/classic/transport/PekkoProtocolSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/classic/transport/PekkoProtocolSpec.scala
index 279147c6a7..8316489a94 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/classic/transport/PekkoProtocolSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/classic/transport/PekkoProtocolSpec.scala
@@ -83,10 +83,10 @@ class PekkoProtocolSpec extends PekkoSpec("""pekko.actor.provider = remote """)
   """).withFallback(system.settings.config)
 
   val localAddress = Address("test", "testsystem", "testhost", 1234)
-  val localAkkaAddress = Address("akka.test", "testsystem", "testhost", 1234)
+  val localAkkaAddress = Address("pekko.test", "testsystem", "testhost", 1234)
 
   val remoteAddress = Address("test", "testsystem2", "testhost2", 1234)
-  val remoteAkkaAddress = Address("akka.test", "testsystem2", "testhost2", 1234)
+  val remoteAkkaAddress = Address("pekko.test", "testsystem2", "testhost2", 1234)
 
   val codec = PekkoPduProtobufCodec$
 
diff --git a/remote/src/test/scala/org/apache/pekko/remote/classic/transport/PekkoProtocolStressTest.scala b/remote/src/test/scala/org/apache/pekko/remote/classic/transport/PekkoProtocolStressTest.scala
index ee22a479af..4246629b15 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/classic/transport/PekkoProtocolStressTest.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/classic/transport/PekkoProtocolStressTest.scala
@@ -136,7 +136,7 @@ class PekkoProtocolStressTest extends PekkoSpec(configA) with ImplicitSender wit
   override def beforeTermination(): Unit = {
     system.eventStream.publish(
       TestEvent.Mute(
-        EventFilter.warning(source = s"akka://AkkaProtocolStressTest/user/$$a", start = "received dead letter"),
+        EventFilter.warning(source = s"pekko://AkkaProtocolStressTest/user/$$a", start = "received dead letter"),
         EventFilter.warning(pattern = "received dead letter.*(InboundPayload|Disassociate)")))
     systemB.eventStream.publish(
       TestEvent.Mute(
diff --git a/remote/src/test/scala/org/apache/pekko/remote/classic/transport/SystemMessageDeliveryStressTest.scala b/remote/src/test/scala/org/apache/pekko/remote/classic/transport/SystemMessageDeliveryStressTest.scala
index 2d65b5061d..f5fc4fed07 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/classic/transport/SystemMessageDeliveryStressTest.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/classic/transport/SystemMessageDeliveryStressTest.scala
@@ -189,7 +189,7 @@ abstract class SystemMessageDeliveryStressTest(msg: String, cfg: String)
   override def beforeTermination(): Unit = {
     system.eventStream.publish(
       TestEvent.Mute(
-        EventFilter.warning(source = s"akka://AkkaProtocolStressTest/user/$$a", start = "received dead letter"),
+        EventFilter.warning(source = s"pekko://AkkaProtocolStressTest/user/$$a", start = "received dead letter"),
         EventFilter.warning(pattern = "received dead letter.*(InboundPayload|Disassociate)")))
     systemB.eventStream.publish(
       TestEvent.Mute(
diff --git a/remote/src/test/scala/org/apache/pekko/remote/classic/transport/ThrottlerTransportAdapterSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/classic/transport/ThrottlerTransportAdapterSpec.scala
index da0ee054e0..00014096c8 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/classic/transport/ThrottlerTransportAdapterSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/classic/transport/ThrottlerTransportAdapterSpec.scala
@@ -97,13 +97,13 @@ class ThrottlerTransportAdapterSpec extends PekkoSpec(configA) with ImplicitSend
   }
 
   def throttle(direction: Direction, mode: ThrottleMode): Boolean = {
-    val rootBAddress = Address("akka", "systemB", "localhost", rootB.address.port.get)
+    val rootBAddress = Address("pekko", "systemB", "localhost", rootB.address.port.get)
     val transport = system.asInstanceOf[ExtendedActorSystem].provider.asInstanceOf[RemoteActorRefProvider].transport
     Await.result(transport.managementCommand(SetThrottle(rootBAddress, direction, mode)), 3.seconds)
   }
 
   def disassociate(): Boolean = {
-    val rootBAddress = Address("akka", "systemB", "localhost", rootB.address.port.get)
+    val rootBAddress = Address("pekko", "systemB", "localhost", rootB.address.port.get)
     val transport = system.asInstanceOf[ExtendedActorSystem].provider.asInstanceOf[RemoteActorRefProvider].transport
     Await.result(transport.managementCommand(ForceDisassociate(rootBAddress)), 3.seconds)
   }
@@ -159,7 +159,7 @@ class ThrottlerTransportAdapterSpec extends PekkoSpec(configA) with ImplicitSend
   override def beforeTermination(): Unit = {
     system.eventStream.publish(
       TestEvent.Mute(
-        EventFilter.warning(source = s"akka://AkkaProtocolStressTest/user/$$a", start = "received dead letter"),
+        EventFilter.warning(source = s"pekko://AkkaProtocolStressTest/user/$$a", start = "received dead letter"),
         EventFilter.warning(pattern = "received dead letter.*(InboundPayload|Disassociate)")))
     systemB.eventStream.publish(
       TestEvent.Mute(
@@ -175,7 +175,7 @@ class ThrottlerTransportAdapterSpec extends PekkoSpec(configA) with ImplicitSend
 class ThrottlerTransportAdapterGenericSpec extends GenericTransportSpec(withAkkaProtocol = true) {
 
   def transportName = "ThrottlerTransportAdapter"
-  def schemeIdentifier = "akka.trttl"
+  def schemeIdentifier = "pekko.trttl"
   def freshTransport(testTransport: TestTransport) =
     new ThrottlerTransportAdapter(testTransport, system.asInstanceOf[ExtendedActorSystem])
 
diff --git a/remote/src/test/scala/org/apache/pekko/remote/classic/transport/netty/NettyTransportSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/classic/transport/netty/NettyTransportSpec.scala
index f9ef3ab9c8..d0f055838d 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/classic/transport/netty/NettyTransportSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/classic/transport/netty/NettyTransportSpec.scala
@@ -84,7 +84,7 @@ class NettyTransportSpec extends AnyWordSpec with Matchers with BindBehavior {
         """)
         implicit val sys = ActorSystem("sys", bindConfig.withFallback(commonConfig))
 
-        getExternal() should ===(address.toAkkaAddress("akka.tcp"))
+        getExternal() should ===(address.toAkkaAddress("pekko.tcp"))
         getInternal() should not contain address.toAkkaAddress("tcp")
 
         Await.result(sys.terminate(), Duration.Inf)
@@ -112,7 +112,7 @@ class NettyTransportSpec extends AnyWordSpec with Matchers with BindBehavior {
         """)
       implicit val sys = ActorSystem("sys", bindConfig.withFallback(commonConfig))
 
-      getExternal() should ===(address.toAkkaAddress("akka.tcp"))
+      getExternal() should ===(address.toAkkaAddress("pekko.tcp"))
       getInternal() should contain(address.toAkkaAddress("tcp"))
 
       Await.result(sys.terminate(), Duration.Inf)
@@ -157,7 +157,7 @@ trait BindBehavior {
         """)
       implicit val sys = ActorSystem("sys", bindConfig.withFallback(commonConfig))
 
-      getExternal() should ===(address.toAkkaAddress(s"akka.tcp"))
+      getExternal() should ===(address.toAkkaAddress(s"pekko.tcp"))
       getInternal() should contain(address.toAkkaAddress("tcp"))
 
       Await.result(sys.terminate(), Duration.Inf)
@@ -189,7 +189,7 @@ trait BindBehavior {
         """)
       implicit val sys = ActorSystem("sys", bindConfig.withFallback(commonConfig))
 
-      getExternal() should ===(address.toAkkaAddress(s"akka.tcp"))
+      getExternal() should ===(address.toAkkaAddress(s"pekko.tcp"))
       getInternal() should contain(bindAddress.toAkkaAddress("tcp"))
 
       Await.result(sys.terminate(), Duration.Inf)
diff --git a/remote/src/test/scala/org/apache/pekko/remote/serialization/DaemonMsgCreateSerializerAllowJavaSerializationSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/serialization/DaemonMsgCreateSerializerAllowJavaSerializationSpec.scala
index 9274b7d3f0..140e8515f9 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/serialization/DaemonMsgCreateSerializerAllowJavaSerializationSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/serialization/DaemonMsgCreateSerializerAllowJavaSerializationSpec.scala
@@ -118,13 +118,13 @@ class DaemonMsgCreateSerializerAllowJavaSerializationSpec
           path = "path1",
           config = ConfigFactory.parseString("a=1"),
           routerConfig = RoundRobinPool(nrOfInstances = 5, supervisorStrategy = supervisorStrategy),
-          scope = RemoteScope(Address("akka", "Test", "host1", 1921)),
+          scope = RemoteScope(Address("pekko", "Test", "host1", 1921)),
           dispatcher = "mydispatcher")
         val deploy2 = Deploy(
           path = "path2",
           config = ConfigFactory.parseString("a=2"),
           routerConfig = FromConfig,
-          scope = RemoteScope(Address("akka", "Test", "host2", 1922)),
+          scope = RemoteScope(Address("pekko", "Test", "host2", 1922)),
           dispatcher = Deploy.NoDispatcherGiven)
         DaemonMsgCreate(
           props = Props[MyActor]().withDispatcher("my-disp").withDeploy(deploy1),
@@ -168,13 +168,13 @@ class DaemonMsgCreateSerializerNoJavaSerializationSpec extends PekkoSpec("""
         path = "path1",
         config = ConfigFactory.parseString("a=1"),
         // a whole can of worms: routerConfig = RoundRobinPool(nrOfInstances = 5, supervisorStrategy = supervisorStrategy),
-        scope = RemoteScope(Address("akka", "Test", "host1", 1921)),
+        scope = RemoteScope(Address("pekko", "Test", "host1", 1921)),
         dispatcher = "mydispatcher")
       val deploy2 = Deploy(
         path = "path2",
         config = ConfigFactory.parseString("a=2"),
         routerConfig = FromConfig,
-        scope = RemoteScope(Address("akka", "Test", "host2", 1922)),
+        scope = RemoteScope(Address("pekko", "Test", "host2", 1922)),
         dispatcher = Deploy.NoDispatcherGiven)
       DaemonMsgCreate(
         props = Props[MyActor]().withDispatcher("my-disp").withDeploy(deploy1),
diff --git a/remote/src/test/scala/org/apache/pekko/remote/serialization/MiscMessageSerializerSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/serialization/MiscMessageSerializerSpec.scala
index 3703459994..a569906178 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/serialization/MiscMessageSerializerSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/serialization/MiscMessageSerializerSpec.scala
@@ -117,10 +117,10 @@ class MiscMessageSerializerSpec extends PekkoSpec(MiscMessageSerializerSpec.test
       "RemoteWatcher.HertbeatRsp" -> RemoteWatcher.HeartbeatRsp(65537),
       "Done" -> Done,
       "NotUsed" -> NotUsed,
-      "Address" -> Address("akka", "system", "host", 1337),
-      "UniqueAddress" -> pekko.remote.UniqueAddress(Address("akka", "system", "host", 1337), 82751),
+      "Address" -> Address("pekko", "system", "host", 1337),
+      "UniqueAddress" -> pekko.remote.UniqueAddress(Address("pekko", "system", "host", 1337), 82751),
       "LocalScope" -> LocalScope,
-      "RemoteScope" -> RemoteScope(Address("akka", "system", "localhost", 2525)),
+      "RemoteScope" -> RemoteScope(Address("pekko", "system", "localhost", 2525)),
       "Config" -> system.settings.config,
       "Empty Config" -> ConfigFactory.empty(),
       "FromConfig" -> FromConfig,
@@ -141,7 +141,7 @@ class MiscMessageSerializerSpec extends PekkoSpec(MiscMessageSerializerSpec.test
       "TailChoppingPool" -> TailChoppingPool(25, within = 3.seconds, interval = 1.second),
       "RemoteRouterConfig" -> RemoteRouterConfig(
         local = RandomPool(25),
-        nodes = List(Address("akka", "system", "localhost", 2525))),
+        nodes = List(Address("pekko", "system", "localhost", 2525))),
       "StatusReply.success" -> StatusReply.success("woho!"),
       "StatusReply.Ack" -> StatusReply.Ack,
       "StatusReply.error(errorMessage)" -> StatusReply.error("boho!"),
diff --git a/remote/src/test/scala/org/apache/pekko/remote/serialization/SerializationTransportInformationSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/serialization/SerializationTransportInformationSpec.scala
index 032f15aadb..d565d1aca3 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/serialization/SerializationTransportInformationSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/serialization/SerializationTransportInformationSpec.scala
@@ -105,8 +105,8 @@ abstract class AbstractSerializationTransportInformationSpec(config: Config)
   val port = system.asInstanceOf[ExtendedActorSystem].provider.getDefaultAddress.port.get
   val sysName = system.name
   val protocol =
-    if (RARP(system).provider.remoteSettings.Artery.Enabled) "akka"
-    else "akka.tcp"
+    if (RARP(system).provider.remoteSettings.Artery.Enabled) "pekko"
+    else "pekko.tcp"
 
   val system2 = ActorSystem(system.name, system.settings.config)
   val system2Address = RARP(system2).provider.getDefaultAddress
diff --git a/scripts/release-train-issue-template.md b/scripts/release-train-issue-template.md
index 5cd574c96c..a42cc00a74 100644
--- a/scripts/release-train-issue-template.md
+++ b/scripts/release-train-issue-template.md
@@ -19,7 +19,7 @@ Release Akka $VERSION$
 ### Check availability
 
 - [ ] Check [reference](https://pekko.apache.org/docs/pekko/$VERSION$/) documentation
-- [ ] Check the release on [Maven central](https://repo1.maven.org/maven2/com/typesafe/akka/akka-actor_2.13/$VERSION$/)
+- [ ] Check the release on [Maven central](https://repo1.maven.org/maven2/org/apache/pekko/pekko-actor_2.13/$VERSION$/)
 
 ### When everything is on maven central
 
diff --git a/serialization-jackson/src/test/scala/org/apache/pekko/serialization/jackson/JacksonSerializerSpec.scala b/serialization-jackson/src/test/scala/org/apache/pekko/serialization/jackson/JacksonSerializerSpec.scala
index eab692c2a2..5f97c97c1f 100644
--- a/serialization-jackson/src/test/scala/org/apache/pekko/serialization/jackson/JacksonSerializerSpec.scala
+++ b/serialization-jackson/src/test/scala/org/apache/pekko/serialization/jackson/JacksonSerializerSpec.scala
@@ -856,7 +856,7 @@ abstract class JacksonSerializerSpec(serializerName: String)
     }
 
     "serialize with Address" in {
-      val address = Address("akka", "sys", "localhost", 2552)
+      val address = Address("pekko", "sys", "localhost", 2552)
       checkSerialization(new CommandWithAddress("echo", address))
     }
 
@@ -1082,7 +1082,7 @@ abstract class JacksonSerializerSpec(serializerName: String)
     }
 
     "serialize with Address" in {
-      val address = Address("akka", "sys", "localhost", 2552)
+      val address = Address("pekko", "sys", "localhost", 2552)
       checkSerialization(CommandWithAddress("echo", address))
     }
 
diff --git a/slf4j/src/test/scala/org/apache/pekko/event/slf4j/Slf4jLoggerSpec.scala b/slf4j/src/test/scala/org/apache/pekko/event/slf4j/Slf4jLoggerSpec.scala
index 737e0d2351..61c8530368 100644
--- a/slf4j/src/test/scala/org/apache/pekko/event/slf4j/Slf4jLoggerSpec.scala
+++ b/slf4j/src/test/scala/org/apache/pekko/event/slf4j/Slf4jLoggerSpec.scala
@@ -101,8 +101,8 @@ class Slf4jLoggerSpec extends PekkoSpec(Slf4jLoggerSpec.config) with BeforeAndAf
 
       awaitCond(outputString.contains("----"), 5 seconds)
       val s = outputString
-      s should include("pekkoSource=akka://Slf4jLoggerSpec/user/logProducer")
-      s should include("pekkoAddress=akka://Slf4jLoggerSpec")
+      s should include("pekkoSource=pekko://Slf4jLoggerSpec/user/logProducer")
+      s should include("pekkoAddress=pekko://Slf4jLoggerSpec")
       s should include("pekkoUid=")
       s should include("level=[ERROR]")
       s should include("logger=[org.apache.pekko.event.slf4j.Slf4jLoggerSpec$LogProducer]")
@@ -117,8 +117,8 @@ class Slf4jLoggerSpec extends PekkoSpec(Slf4jLoggerSpec.config) with BeforeAndAf
 
       awaitCond(outputString.contains("----"), 5 seconds)
       val s = outputString
-      s should include("pekkoSource=akka://Slf4jLoggerSpec/user/logProducer")
-      s should include("pekkoAddress=akka://Slf4jLoggerSpec")
+      s should include("pekkoSource=pekko://Slf4jLoggerSpec/user/logProducer")
+      s should include("pekkoAddress=pekko://Slf4jLoggerSpec")
       s should include("level=[INFO]")
       s should include("logger=[org.apache.pekko.event.slf4j.Slf4jLoggerSpec$LogProducer]")
       (s should include).regex(sourceThreadRegex)
@@ -177,7 +177,7 @@ class Slf4jLoggerSpec extends PekkoSpec(Slf4jLoggerSpec.config) with BeforeAndAf
 
       awaitCond(outputString.contains("----"), 5 seconds)
       val s = outputString
-      s should include("pekkoSource=akka://Slf4jLoggerSpec/user/logProducer")
+      s should include("pekkoSource=pekko://Slf4jLoggerSpec/user/logProducer")
       s should include("level=[INFO]")
       s should include("logger=[org.apache.pekko.event.slf4j.Slf4jLoggerSpec$LogProducer]")
       (s should include).regex(sourceThreadRegex)
@@ -198,7 +198,7 @@ class Slf4jLoggerSpec extends PekkoSpec(Slf4jLoggerSpec.config) with BeforeAndAf
 
       awaitCond(outputString.contains("----"), 5 seconds)
       val s = outputString
-      s should include("pekkoSource=akka://Slf4jLoggerSpec/user/logProducer")
+      s should include("pekkoSource=pekko://Slf4jLoggerSpec/user/logProducer")
       s should include("level=[INFO]")
       s should include("logger=[org.apache.pekko.event.slf4j.Slf4jLoggerSpec$LogProducer]")
       println(s)
@@ -212,8 +212,8 @@ class Slf4jLoggerSpec extends PekkoSpec(Slf4jLoggerSpec.config) with BeforeAndAf
       log.info("test")
       awaitCond(outputString.contains("----"), 5 seconds)
       val s = outputString
-      s should include("pekkoSource=org.apache.pekko.event.slf4j.Slf4jLoggerSpec.MyLogSource(akka://Slf4jLoggerSpec)")
-      s should include("logger=[org.apache.pekko.event.slf4j.Slf4jLoggerSpec.MyLogSource(akka://Slf4jLoggerSpec)]")
+      s should include("pekkoSource=org.apache.pekko.event.slf4j.Slf4jLoggerSpec.MyLogSource(pekko://Slf4jLoggerSpec)")
+      s should include("logger=[org.apache.pekko.event.slf4j.Slf4jLoggerSpec.MyLogSource(pekko://Slf4jLoggerSpec)]")
     }
 
     "not include system info in pekkoSource when creating Logging with system.eventStream" in {
@@ -230,7 +230,7 @@ class Slf4jLoggerSpec extends PekkoSpec(Slf4jLoggerSpec.config) with BeforeAndAf
       log.info("test")
       awaitCond(outputString.contains("----"), 5 seconds)
       val s = outputString
-      s should include("pekkoSource=Slf4jLoggerSpec$MyLogSource(akka://Slf4jLoggerSpec)")
+      s should include("pekkoSource=Slf4jLoggerSpec$MyLogSource(pekko://Slf4jLoggerSpec)")
       s should include("logger=[org.apache.pekko.event.slf4j.Slf4jLoggerSpec$MyLogSource]")
     }
 
diff --git a/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowAskSpec.scala b/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowAskSpec.scala
index 649e71d513..d4d204fe13 100644
--- a/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowAskSpec.scala
+++ b/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowAskSpec.scala
@@ -170,7 +170,7 @@ class FlowAskSpec extends StreamSpec {
         .to(Sink.fromSubscriber(c))
         .run()
       c.expectSubscription().request(10)
-      c.expectError().getMessage should startWith("Ask timed out on [Actor[akka://FlowAskSpec/user/dontReply#")
+      c.expectError().getMessage should startWith("Ask timed out on [Actor[pekko://FlowAskSpec/user/dontReply#")
     }
 
     "signal ask failure" in {
@@ -190,7 +190,7 @@ class FlowAskSpec extends StreamSpec {
         r ! PoisonPill
         Await.result(done, remainingOrDefault)
       }.getMessage should startWith(
-        "Actor watched by [ask()] has terminated! Was: Actor[akka://FlowAskSpec/user/wanna-fail#")
+        "Actor watched by [ask()] has terminated! Was: Actor[pekko://FlowAskSpec/user/wanna-fail#")
     }
 
     "a failure mid-stream must skip element with resume strategy" in {
diff --git a/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowLogSpec.scala b/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowLogSpec.scala
index a42536dad5..e2d38d4077 100644
--- a/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowLogSpec.scala
+++ b/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowLogSpec.scala
@@ -122,7 +122,7 @@ class FlowLogSpec extends StreamSpec("""
 
         Source.single(42).log("flow-5")(log).runWith(Sink.ignore)
 
-        val src = "com.example.ImportantLogger(akka://FlowLogSpec)"
+        val src = "com.example.ImportantLogger(pekko://FlowLogSpec)"
         val clazz = classOf[DummyClassForStringSources]
         logProbe.expectMsg(Logging.Debug(src, clazz, "[flow-5] Element: 42"))
         logProbe.expectMsg(Logging.Debug(src, clazz, "[flow-5] Upstream finished."))
diff --git a/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowLogWithMarkerSpec.scala b/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowLogWithMarkerSpec.scala
index e51f61fb2b..0c885a20ce 100644
--- a/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowLogWithMarkerSpec.scala
+++ b/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowLogWithMarkerSpec.scala
@@ -130,7 +130,7 @@ class FlowLogWithMarkerSpec extends StreamSpec("""
 
         Source.single(42).logWithMarker("flow-5", _ => marker)(log).runWith(Sink.ignore)
 
-        val src = "com.example.ImportantLogger(akka://FlowLogWithMarkerSpec)"
+        val src = "com.example.ImportantLogger(pekko://FlowLogWithMarkerSpec)"
         val clazz = classOf[DummyClassForStringSources]
         logProbe.expectMsg(Logging.Debug(src, clazz, "[flow-5] Element: 42", mdc, marker))
         logProbe.expectMsg(Logging.Debug(src, clazz, "[flow-5] Upstream finished."))
diff --git a/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowWatchSpec.scala b/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowWatchSpec.scala
index da0f12b2d4..06cdc773c5 100644
--- a/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowWatchSpec.scala
+++ b/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/FlowWatchSpec.scala
@@ -66,7 +66,7 @@ class FlowWatchSpec extends StreamSpec {
         r ! PoisonPill
         Await.result(done, remainingOrDefault)
       }.getMessage should startWith(
-        "Actor watched by [Watch] has terminated! Was: Actor[akka://FlowWatchSpec/user/wanna-fail#")
+        "Actor watched by [Watch] has terminated! Was: Actor[pekko://FlowWatchSpec/user/wanna-fail#")
     }
 
     "should handle cancel properly" in {
diff --git a/stream-typed/src/test/scala/docs/scaladsl/ActorFlowSpec.scala b/stream-typed/src/test/scala/docs/scaladsl/ActorFlowSpec.scala
index 5395ac2af3..99fbf141ce 100644
--- a/stream-typed/src/test/scala/docs/scaladsl/ActorFlowSpec.scala
+++ b/stream-typed/src/test/scala/docs/scaladsl/ActorFlowSpec.scala
@@ -206,7 +206,7 @@ class ActorFlowSpec extends ScalaTestWithActorTestKit with AnyWordSpecLike {
       intercept[RuntimeException] {
         replier ! Asking("TERMINATE", system.deadLetters)
         Await.result(done, 3.seconds)
-      }.getMessage should startWith("Actor watched by [ask()] has terminated! Was: Actor[akka://ActorFlowSpec")
+      }.getMessage should startWith("Actor watched by [ask()] has terminated! Was: Actor[pekko://ActorFlowSpec")
     }
 
   }


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