You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pekko.apache.org by he...@apache.org on 2023/03/08 21:00:10 UTC

[incubator-pekko] 02/05: change 2552+ port numbers

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

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

commit 1969f7580dcb30f1db7d5019f3eee2a54e596a88
Author: PJ Fanning <pj...@users.noreply.github.com>
AuthorDate: Mon Mar 6 12:29:03 2023 +0100

    change 2552+ port numbers
---
 .../apache/pekko/cluster/metrics/MetricSpec.scala  | 32 +++++++++++-----------
 .../org/apache/pekko/cluster/ClusterSpec.scala     |  4 +--
 .../pekko/cluster/ddata/DataEnvelopeSpec.scala     |  4 +--
 .../apache/pekko/cluster/ddata/GCounterSpec.scala  |  2 +-
 .../org/apache/pekko/cluster/ddata/ORSetSpec.scala |  2 +-
 .../pekko/cluster/ddata/PruningStateSpec.scala     |  4 +--
 .../pekko/cluster/ddata/VersionVectorSpec.scala    |  4 +--
 docs/src/main/paradox/remoting.md                  |  4 +--
 .../src/test/scala/docs/config/ConfigDocSpec.scala |  2 +-
 remote/src/main/resources/reference.conf           |  8 +++---
 .../pekko/remote/classic/ActorsLeakSpec.scala      |  2 +-
 11 files changed, 34 insertions(+), 34 deletions(-)

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 eecb2274a4..d6a03c2cec 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("pekko", "sys", "a", 2554)
-  val node2 = Address("pekko", "sys", "a", 2555)
+  val node1 = Address("pekko", "sys", "a", 7357)
+  val node2 = Address("pekko", "sys", "a", 7358)
 
   "NodeMetrics must" must {
 
@@ -162,8 +162,8 @@ class MetricsGossipSpec
 
   "A MetricsGossip" must {
     "add new NodeMetrics" in {
-      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 m1 = NodeMetrics(Address("pekko", "sys", "a", 7357), newTimestamp, collector.sample().metrics)
+      val m2 = NodeMetrics(Address("pekko", "sys", "a", 7358), 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("pekko", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
-      val m2 = NodeMetrics(Address("pekko", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
+      val m1 = NodeMetrics(Address("pekko", "sys", "a", 7357), newTimestamp, collector.sample().metrics)
+      val m2 = NodeMetrics(Address("pekko", "sys", "a", 7358), 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("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 m1 = NodeMetrics(Address("pekko", "sys", "a", 7357), newTimestamp, collector.sample().metrics)
+      val m2 = NodeMetrics(Address("pekko", "sys", "a", 7358), newTimestamp, collector.sample().metrics)
+      val m3 = NodeMetrics(Address("pekko", "sys", "a", 7359), 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("pekko", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
+      val m1 = NodeMetrics(Address("pekko", "sys", "a", 7357), 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("pekko", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
-      val m2 = NodeMetrics(Address("pekko", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
+      val m1 = NodeMetrics(Address("pekko", "sys", "a", 7357), newTimestamp, collector.sample().metrics)
+      val m2 = NodeMetrics(Address("pekko", "sys", "a", 7358), 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("pekko", "sys", "a", 2554), newTimestamp, collector.sample().metrics)
-      val m2 = NodeMetrics(Address("pekko", "sys", "a", 2555), newTimestamp, collector.sample().metrics)
+      val m1 = NodeMetrics(Address("pekko", "sys", "a", 7357), newTimestamp, collector.sample().metrics)
+      val m2 = NodeMetrics(Address("pekko", "sys", "a", 7358), 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("pekko", "sys", "a", 2554), 1, collector.sample().metrics)
-  val node2 = NodeMetrics(Address("pekko", "sys", "a", 2555), 1, collector.sample().metrics)
+  val node1 = NodeMetrics(Address("pekko", "sys", "a", 7357), 1, collector.sample().metrics)
+  val node2 = NodeMetrics(Address("pekko", "sys", "a", 7358), 1, collector.sample().metrics)
 
   val nodes: Seq[NodeMetrics] = {
     (1 to 100).foldLeft(List(node1, node2)) { (nodes, _) =>
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 7de9e559a9..4a2c87e246 100644
--- a/cluster/src/test/scala/org/apache/pekko/cluster/ClusterSpec.scala
+++ b/cluster/src/test/scala/org/apache/pekko/cluster/ClusterSpec.scala
@@ -358,7 +358,7 @@ class ClusterSpec extends PekkoSpec(ClusterSpec.config) with ImplicitSender {
           """).withFallback(ConfigFactory.parseString(ClusterSpec.config))
 
       val sys1 = ActorSystem("ClusterSpec4", getConfig(7355))
-      val sys2 = ActorSystem("ClusterSpec4", getConfig(2553))
+      val sys2 = ActorSystem("ClusterSpec4", getConfig(7356))
 
       try {
         Cluster(sys1)
@@ -369,7 +369,7 @@ class ClusterSpec extends PekkoSpec(ClusterSpec.config) with ImplicitSender {
         info1.getAttributes.length should be > 0
         info1.getOperations.length should be > 0
 
-        val name2 = new ObjectName(s"pekko:type=Cluster,port=2553")
+        val name2 = new ObjectName(s"pekko:type=Cluster,port=7356")
         val info2 = ManagementFactory.getPlatformMBeanServer.getMBeanInfo(name2)
         info2.getAttributes.length should be > 0
         info2.getOperations.length should be > 0
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 d25f8adbde..c48c080db8 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
@@ -26,8 +26,8 @@ class DataEnvelopeSpec extends AnyWordSpec with Matchers {
 
   val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(7355)), 2L)
-  val node3 = UniqueAddress(node1.address.copy(port = Some(2553)), 3L)
-  val node4 = UniqueAddress(node1.address.copy(port = Some(2554)), 4L)
+  val node3 = UniqueAddress(node1.address.copy(port = Some(7356)), 3L)
+  val node4 = UniqueAddress(node1.address.copy(port = Some(7357)), 4L)
   val obsoleteTimeInFuture = System.currentTimeMillis() + 3600 * 1000
   val oldObsoleteTime = System.currentTimeMillis() - 3600 * 1000
 
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 2d7c90cfed..d04649f707 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
@@ -24,7 +24,7 @@ import pekko.cluster.ddata.Replicator.Changed
 class GCounterSpec extends AnyWordSpec with Matchers {
   val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(7355)), 2L)
-  val node3 = UniqueAddress(node1.address.copy(port = Some(2553)), 3L)
+  val node3 = UniqueAddress(node1.address.copy(port = Some(7356)), 3L)
 
   "A GCounter" 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 4d92b37107..f8a1cee29d 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
@@ -27,7 +27,7 @@ class ORSetSpec extends AnyWordSpec with Matchers {
 
   val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(7355)), 2L)
-  val node3 = UniqueAddress(node1.address.copy(port = Some(2553)), 3L)
+  val node3 = UniqueAddress(node1.address.copy(port = Some(7356)), 3L)
 
   val nodeA = UniqueAddress(Address("pekko", "Sys", "a", 7355), 1L)
   val nodeB = UniqueAddress(nodeA.address.copy(host = Some("b")), 2L)
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 ef681c8dc0..24ab7c978b 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
@@ -25,8 +25,8 @@ class PruningStateSpec extends AnyWordSpec with Matchers {
 
   val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(7355)), 2L)
-  val node3 = UniqueAddress(node1.address.copy(port = Some(2553)), 3L)
-  val node4 = UniqueAddress(node1.address.copy(port = Some(2554)), 4L)
+  val node3 = UniqueAddress(node1.address.copy(port = Some(7356)), 3L)
+  val node4 = UniqueAddress(node1.address.copy(port = Some(7357)), 4L)
 
   "Pruning state" must {
 
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 6be8df509f..ff65f934b4 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
@@ -31,8 +31,8 @@ class VersionVectorSpec
 
   val node1 = UniqueAddress(Address("pekko", "Sys", "localhost", 2551), 1L)
   val node2 = UniqueAddress(node1.address.copy(port = Some(7355)), 2L)
-  val node3 = UniqueAddress(node1.address.copy(port = Some(2553)), 3L)
-  val node4 = UniqueAddress(node1.address.copy(port = Some(2554)), 4L)
+  val node3 = UniqueAddress(node1.address.copy(port = Some(7356)), 3L)
+  val node4 = UniqueAddress(node1.address.copy(port = Some(7357)), 4L)
 
   override def afterAll(): Unit = {
     shutdown()
diff --git a/docs/src/main/paradox/remoting.md b/docs/src/main/paradox/remoting.md
index edee72d236..2d02e8cb40 100644
--- a/docs/src/main/paradox/remoting.md
+++ b/docs/src/main/paradox/remoting.md
@@ -190,7 +190,7 @@ pekko {
   actor {
     deployment {
       /sampleActor {
-        remote = "pekko.tcp://sampleActorSystem@127.0.0.1:2553"
+        remote = "pekko.tcp://sampleActorSystem@127.0.0.1:7356"
       }
     }
   }
@@ -200,7 +200,7 @@ pekko {
 The configuration above instructs Pekko to react when an actor with path `/sampleActor` is created, i.e.
 using @scala[`system.actorOf(Props(...), "sampleActor")`]@java[`system.actorOf(new Props(...), "sampleActor")`]. This specific actor will not be directly instantiated,
 but instead the remote daemon of the remote system will be asked to create the actor,
-which in this sample corresponds to `sampleActorSystem@127.0.0.1:2553`.
+which in this sample corresponds to `sampleActorSystem@127.0.0.1:7356`.
 
 Once you have configured the properties above you would do the following in code:
 
diff --git a/docs/src/test/scala/docs/config/ConfigDocSpec.scala b/docs/src/test/scala/docs/config/ConfigDocSpec.scala
index 63edabdc4a..dacdaf9f87 100644
--- a/docs/src/test/scala/docs/config/ConfigDocSpec.scala
+++ b/docs/src/test/scala/docs/config/ConfigDocSpec.scala
@@ -78,7 +78,7 @@ class ConfigDocSpec extends AnyWordSpec with Matchers {
   
     # '/user/actorA/actorB' is a remote deployed actor
     /actorA/actorB {
-      remote = "pekko://sampleActorSystem@127.0.0.1:2553"
+      remote = "pekko://sampleActorSystem@127.0.0.1:7356"
     }
     
     # all direct children of '/user/actorC' have a dedicated dispatcher 
diff --git a/remote/src/main/resources/reference.conf b/remote/src/main/resources/reference.conf
index 8e761ffa13..4f03796b62 100644
--- a/remote/src/main/resources/reference.conf
+++ b/remote/src/main/resources/reference.conf
@@ -513,8 +513,8 @@ pekko {
         # Use 0 if you want a random available port. Examples:
         #
         # pekko.remote.classic.netty.tcp.port = 7355
-        # pekko.remote.classic.netty.tcp.bind-port = 2553
-        # Network interface will be bound to the 2553 port, but remoting protocol will
+        # pekko.remote.classic.netty.tcp.bind-port = 7356
+        # Network interface will be bound to the 7356 port, but remoting protocol will
         # expect messages sent to port 7355.
         #
         # pekko.remote.classic.netty.tcp.port = 0
@@ -528,8 +528,8 @@ pekko {
         # expect messages sent to port 7355.
         #
         # pekko.remote.classic.netty.tcp.port = 0
-        # pekko.remote.classic.netty.tcp.bind-port = 2553
-        # Network interface will be bound to the 2553 port, and remoting protocol will
+        # pekko.remote.classic.netty.tcp.bind-port = 7356
+        # Network interface will be bound to the 7356 port, and remoting protocol will
         # expect messages sent to the bound port.
         #
         # pekko.remote.classic.netty.tcp.port = 7355
diff --git a/remote/src/test/scala/org/apache/pekko/remote/classic/ActorsLeakSpec.scala b/remote/src/test/scala/org/apache/pekko/remote/classic/ActorsLeakSpec.scala
index d5db97ce2c..9d3c2d67b6 100644
--- a/remote/src/test/scala/org/apache/pekko/remote/classic/ActorsLeakSpec.scala
+++ b/remote/src/test/scala/org/apache/pekko/remote/classic/ActorsLeakSpec.scala
@@ -124,7 +124,7 @@ class ActorsLeakSpec extends PekkoSpec(ActorsLeakSpec.config) with ImplicitSende
             "remote",
             ConfigFactory.parseString("""
                 pekko.remote.artery.enabled = false
-                pekko.remote.classic.netty.tcp.port = 2553
+                pekko.remote.classic.netty.tcp.port = 7356
               """.stripMargin).withFallback(config))
 
         try {


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