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/01/23 11:09:09 UTC

[incubator-pekko] branch main updated: use Apache Pekko name for version check (#119)

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 474ed8b4d0 use Apache Pekko name for version check (#119)
474ed8b4d0 is described below

commit 474ed8b4d0313191fdf713375fe319cfc6ee0f9b
Author: PJ Fanning <pj...@users.noreply.github.com>
AuthorDate: Mon Jan 23 11:09:03 2023 +0000

    use Apache Pekko name for version check (#119)
---
 .../scala/org/apache/pekko/util/ByteStringSpec.scala     |  2 +-
 .../scala/org/apache/pekko/actor/ActorSelection.scala    |  2 +-
 .../main/scala/org/apache/pekko/actor/ActorSystem.scala  |  2 +-
 .../main/scala/org/apache/pekko/util/ManifestInfo.scala  |  9 +--------
 build.sbt                                                | 15 +++++++--------
 project/JdkOptions.scala                                 |  2 +-
 project/Publish.scala                                    | 16 ++++++++--------
 remote/src/test/resources/aeron.properties               |  2 +-
 .../remote/artery/tcp/ssl/PemManagersProviderSpec.scala  |  2 +-
 .../pekko/stream/scaladsl/BoundedSourceQueueSpec.scala   |  2 +-
 10 files changed, 23 insertions(+), 31 deletions(-)

diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringSpec.scala
index ed654343c1..78797f5239 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringSpec.scala
@@ -992,7 +992,7 @@ class ByteStringSpec extends AnyWordSpec with Matchers with Checkers {
 
     "serialize correctly" when {
       // note that this is serialization with Java serialization
-      // real serialization is in akka-remote
+      // real serialization is in pekko-remote
       if (util.Properties.versionNumberString.startsWith("2.12")) {
         "parsing regular ByteString1C as compat" in {
           val oldSerd =
diff --git a/actor/src/main/scala/org/apache/pekko/actor/ActorSelection.scala b/actor/src/main/scala/org/apache/pekko/actor/ActorSelection.scala
index 2d81faabe8..0f9df0694e 100644
--- a/actor/src/main/scala/org/apache/pekko/actor/ActorSelection.scala
+++ b/actor/src/main/scala/org/apache/pekko/actor/ActorSelection.scala
@@ -315,7 +315,7 @@ trait ScalaActorSelection {
  * nested path descriptions whenever using ! on them, the idea being that the
  * message is delivered by traversing the various actor paths involved.
  */
-@SerialVersionUID(2L) // it has protobuf serialization in akka-remote
+@SerialVersionUID(2L) // it has protobuf serialization in pekko-remote
 private[pekko] final case class ActorSelectionMessage(
     msg: Any,
     elements: immutable.Iterable[SelectionPathElement],
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 46f4feb6b4..c660605924 100644
--- a/actor/src/main/scala/org/apache/pekko/actor/ActorSystem.scala
+++ b/actor/src/main/scala/org/apache/pekko/actor/ActorSystem.scala
@@ -1049,7 +1049,7 @@ private[pekko] class ActorSystemImpl(
       if (settings.LogDeadLetters > 0)
         logDeadLetterListener = Some(systemActorOf(Props[DeadLetterListener](), "deadLetterListener"))
       eventStream.startUnsubscriber()
-      ManifestInfo(this).checkSameVersion("Akka", allModules, logWarning = true)
+      ManifestInfo(this).checkSameVersion("Apache Pekko", allModules, logWarning = true)
       if (!terminating)
         loadExtensions()
       if (LogConfigOnStart) logConfiguration()
diff --git a/actor/src/main/scala/org/apache/pekko/util/ManifestInfo.scala b/actor/src/main/scala/org/apache/pekko/util/ManifestInfo.scala
index 8424018b91..986a1ed5b7 100644
--- a/actor/src/main/scala/org/apache/pekko/util/ManifestInfo.scala
+++ b/actor/src/main/scala/org/apache/pekko/util/ManifestInfo.scala
@@ -43,14 +43,7 @@ object ManifestInfo extends ExtensionId[ManifestInfo] with ExtensionIdProvider {
   private val BundleVersion = "Bundle-Version"
   private val BundleVendor = "Bundle-Vendor"
 
-  private val knownVendors = Set(
-    "org.apache.pekko",
-    "com.typesafe.akka",
-    "com.lightbend.akka",
-    "Lightbend Inc.",
-    "Lightbend",
-    "com.lightbend.lagom",
-    "com.typesafe.play")
+  private val knownVendors = Set("org.apache.pekko")
 
   override def get(system: ActorSystem): ManifestInfo = super.get(system)
   override def get(system: ClassicActorSystemProvider): ManifestInfo = super.get(system)
diff --git a/build.sbt b/build.sbt
index 161c3bfe47..93f7a523d5 100644
--- a/build.sbt
+++ b/build.sbt
@@ -170,7 +170,7 @@ lazy val clusterMetrics = pekkoModule("cluster-metrics")
   .enablePlugins(MultiNodeScalaTest)
 
 lazy val clusterSharding = pekkoModule("cluster-sharding")
-// TODO akka-persistence dependency should be provided in pom.xml artifact.
+// TODO pekko-persistence dependency should be provided in pom.xml artifact.
 //      If I only use "provided" here it works, but then we can't run tests.
 //      Scope "test" is alright in the pom.xml, but would have been nicer with
 //      provided.
@@ -308,7 +308,7 @@ lazy val persistenceQuery = pekkoModule("persistence-query")
   .settings(OSGi.persistenceQuery)
   .settings(Protobuf.settings)
   // To be able to import ContainerFormats.proto
-  .settings(Protobuf.importPath := Some(baseDirectory.value / ".." / "akka-remote" / "src" / "main" / "protobuf"))
+  .settings(Protobuf.importPath := Some(baseDirectory.value / ".." / "remote" / "src" / "main" / "protobuf"))
   .settings(Test / fork := true)
   .enablePlugins(ScaladocNoVerificationOfDiagrams)
 
@@ -389,7 +389,7 @@ lazy val protobufV3 = pekkoModule("protobuf-v3")
     // Prevent cyclic task dependencies, see https://github.com/sbt/sbt-assembly/issues/365
     assembly / fullClasspath := (Runtime / managedClasspath).value, // otherwise, there's a cyclic dependency between packageBin and assembly
     assembly / test := {}, // assembly runs tests for unknown reason which introduces another cyclic dependency to packageBin via exportedJars
-    description := "Akka Protobuf V3 is a shaded version of the protobuf runtime. Original POM: https://github.com/protocolbuffers/protobuf/blob/v3.9.0/java/pom.xml")
+    description := "Apache Pekko Protobuf V3 is a shaded version of the protobuf runtime. Original POM: https://github.com/protocolbuffers/protobuf/blob/v3.9.0/java/pom.xml")
 
 lazy val pki =
   pekkoModule("pki")
@@ -397,7 +397,6 @@ lazy val pki =
     .settings(Dependencies.pki)
     .settings(AutomaticModuleName.settings("pekko.pki"))
     .settings(MetaInfLicenseNoticeCopy.settings)
-    // The akka-pki artifact was added in Akka 2.6.2, no MiMa checks yet.
     .disablePlugins(MimaPlugin)
 
 lazy val remote =
@@ -523,7 +522,7 @@ lazy val persistenceTyped = pekkoModule("persistence-typed")
   .settings(MetaInfLicenseNoticeCopy.settings)
   .settings(Protobuf.settings)
   // To be able to import ContainerFormats.proto
-  .settings(Protobuf.importPath := Some(baseDirectory.value / ".." / "akka-remote" / "src" / "main" / "protobuf"))
+  .settings(Protobuf.importPath := Some(baseDirectory.value / ".." / "remote" / "src" / "main" / "protobuf"))
   .settings(OSGi.persistenceTyped)
 
 lazy val clusterTyped = pekkoModule("cluster-typed")
@@ -538,12 +537,12 @@ lazy val clusterTyped = pekkoModule("cluster-typed")
     jackson % "test->test")
   .settings(Protobuf.settings)
   // To be able to import ContainerFormats.proto
-  .settings(Protobuf.importPath := Some(baseDirectory.value / ".." / "akka-remote" / "src" / "main" / "protobuf"))
+  .settings(Protobuf.importPath := Some(baseDirectory.value / ".." / "remote" / "src" / "main" / "protobuf"))
   .settings(AutomaticModuleName.settings("pekko.cluster.typed"))
   .settings(MetaInfLicenseNoticeCopy.settings)
   .settings(Protobuf.settings)
   // To be able to import ContainerFormats.proto
-  .settings(Protobuf.importPath := Some(baseDirectory.value / ".." / "akka-remote" / "src" / "main" / "protobuf"))
+  .settings(Protobuf.importPath := Some(baseDirectory.value / ".." / "remote" / "src" / "main" / "protobuf"))
   .configs(MultiJvm)
   .enablePlugins(MultiNodeScalaTest)
 
@@ -565,7 +564,7 @@ lazy val clusterShardingTyped = pekkoModule("cluster-sharding-typed")
   .settings(MetaInfLicenseNoticeCopy.settings)
   // To be able to import ContainerFormats.proto
   .settings(Protobuf.settings)
-  .settings(Protobuf.importPath := Some(baseDirectory.value / ".." / "akka-remote" / "src" / "main" / "protobuf"))
+  .settings(Protobuf.importPath := Some(baseDirectory.value / ".." / "remote" / "src" / "main" / "protobuf"))
   .configs(MultiJvm)
   .enablePlugins(MultiNodeScalaTest)
 
diff --git a/project/JdkOptions.scala b/project/JdkOptions.scala
index 8975459472..691fec3bbd 100644
--- a/project/JdkOptions.scala
+++ b/project/JdkOptions.scala
@@ -60,7 +60,7 @@ object JdkOptions extends AutoPlugin {
       Seq(if (scalaVersion.startsWith("3.")) "-Xtarget:8" else "-target:jvm-1.8"),
       // '-release 8' is not enough, for some reason we need the 8 rt.jar
       // explicitly. To test whether this has the desired effect, compile
-      // akka-remote and check the invocation of 'ByteBuffer.clear()' in
+      // pekko-remote and check the invocation of 'ByteBuffer.clear()' in
       // EnvelopeBuffer.class with 'javap -c': it should refer to
       // ""java/nio/ByteBuffer.clear:()Ljava/nio/Buffer" and not
       // "java/nio/ByteBuffer.clear:()Ljava/nio/ByteBuffer". Issue #27079
diff --git a/project/Publish.scala b/project/Publish.scala
index c452861154..f9e05a13f8 100644
--- a/project/Publish.scala
+++ b/project/Publish.scala
@@ -29,16 +29,16 @@ object Publish extends AutoPlugin {
     publishTo := Some(akkaPublishTo.value),
     publishRsyncHost := "akkarepo@gustav.akka.io",
     credentials ++= akkaCredentials,
-    organizationName := "Lightbend Inc.",
-    organizationHomepage := Some(url("https://www.lightbend.com")),
-    sonatypeProfileName := "com.typesafe",
-    startYear := Some(2009),
+    organizationName := "Apache Software Foundation",
+    organizationHomepage := Some(url("https://www.apache.org")),
+    sonatypeProfileName := "org.apache.pekko",
+    startYear := Some(2022),
     developers := List(
       Developer(
-        "akka-contributors",
-        "Akka Contributors",
-        "akka.official@gmail.com",
-        url("https://github.com/akka/akka/graphs/contributors"))),
+        "pekko-contributors",
+        "Apache Pekko Contributors",
+        "dev@pekko.apache.org",
+        url("https://github.com/apache/incubator-pekko/graphs/contributors"))),
     publishMavenStyle := true,
     pomIncludeRepository := { x =>
       false
diff --git a/remote/src/test/resources/aeron.properties b/remote/src/test/resources/aeron.properties
index a80556583b..83cd17af9f 100644
--- a/remote/src/test/resources/aeron.properties
+++ b/remote/src/test/resources/aeron.properties
@@ -1,6 +1,6 @@
 # External Aeron Media Driver using this properties file (loaded as classpath resource)
 # can be run with:  
-# sbt "akka-remote/test:runMain io.aeron.driver.MediaDriver aeron.properties"
+# sbt "remote/test:runMain io.aeron.driver.MediaDriver aeron.properties"
 
 aeron.mtu.length=16384
 aeron.socket.so_sndbuf=2097152
diff --git a/remote/src/test/scala/org/apache/pekko/remote/artery/tcp/ssl/PemManagersProviderSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/artery/tcp/ssl/PemManagersProviderSpec.scala
index d33266fea1..7770dc46f4 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/artery/tcp/ssl/PemManagersProviderSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/artery/tcp/ssl/PemManagersProviderSpec.scala
@@ -27,7 +27,7 @@ class PemManagersProviderSpec extends AnyWordSpec with Matchers {
   "A PemManagersProvider" must {
 
     "load stores reading files setup in config (akka-pki samples)" in {
-      // These set of certificates are valid PEMs but are invalid for akka-remote
+      // These set of certificates are valid PEMs but are invalid for pekko-remote
       // use. Either the key length, certificate usage limitations (via the UsageKeyExtensions),
       // or the fact that the key's certificate is self-signed cause one of the following
       // errors: `certificate_unknown`, `certificate verify message signature error`/`bad_certificate`
diff --git a/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/BoundedSourceQueueSpec.scala b/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/BoundedSourceQueueSpec.scala
index b9674d1164..d3480ea566 100644
--- a/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/BoundedSourceQueueSpec.scala
+++ b/stream-tests/src/test/scala/org/apache/pekko/stream/scaladsl/BoundedSourceQueueSpec.scala
@@ -184,7 +184,7 @@ class BoundedSourceQueueSpec extends StreamSpec("""pekko.loglevel = debug
       result.futureValue should be(counter.get())
     }
 
-    // copied from akka-remote SendQueueSpec
+    // copied from pekko-remote SendQueueSpec
     "deliver bursts of messages" in {
       // this test verifies that the wakeup signal is triggered correctly
       val burstSize = 100


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