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/19 18:49:47 UTC

[incubator-pekko-site] branch asf-staging updated: fix links to pekko source

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

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


The following commit(s) were added to refs/heads/asf-staging by this push:
     new 571301a  fix links to pekko source
571301a is described below

commit 571301a052f2e200d4fba5f713b7d63c5a824369
Author: PJ Fanning <pj...@users.noreply.github.com>
AuthorDate: Thu Jan 19 18:49:21 2023 +0000

    fix links to pekko source
---
 content/actors.html                                | 288 ++++++++--------
 content/additional/books.html                      |   8 +-
 content/additional/deploy.html                     |   8 +-
 content/additional/deploying.html                  |   8 +-
 content/additional/faq.html                        |   8 +-
 content/additional/ide.html                        |   8 +-
 content/additional/operations.html                 |   8 +-
 content/additional/osgi.html                       |  20 +-
 content/additional/packaging.html                  |   8 +-
 content/additional/rolling-updates.html            |  10 +-
 content/cluster-client.html                        |  78 ++---
 content/cluster-dc.html                            |  20 +-
 content/cluster-metrics.html                       |  40 +--
 content/cluster-routing.html                       |  40 +--
 content/cluster-sharding.html                      |  50 +--
 content/cluster-singleton.html                     |  48 +--
 content/cluster-usage.html                         | 102 +++---
 content/common/binary-compatibility-rules.html     |   8 +-
 content/common/circuitbreaker.html                 |  40 +--
 content/common/io-layer.html                       |  12 +-
 content/common/may-change.html                     |   8 +-
 content/common/other-modules.html                  |   8 +-
 content/coordinated-shutdown.html                  |  36 +-
 content/coordination.html                          |  40 +--
 content/discovery/index.html                       |  40 +--
 content/dispatchers.html                           |  36 +-
 content/distributed-data.html                      | 110 +++----
 content/distributed-pub-sub.html                   |  82 ++---
 content/durable-state/persistence-query.html       |  20 +-
 content/event-bus.html                             |  80 ++---
 content/extending-pekko.html                       |  50 +--
 content/fault-tolerance-sample.html                |  12 +-
 content/fault-tolerance.html                       |  76 ++---
 content/fsm.html                                   |  90 ++---
 content/futures.html                               |  22 +-
 content/general/actor-systems.html                 |  12 +-
 content/general/actors.html                        |   8 +-
 content/general/addressing.html                    |  18 +-
 content/general/configuration-reference.html       |  50 +--
 content/general/configuration.html                 |  32 +-
 content/general/index.html                         |   8 +-
 content/general/jmm.html                           |  12 +-
 content/general/message-delivery-reliability.html  |  16 +-
 content/general/remoting.html                      |   8 +-
 content/general/stream/stream-configuration.html   |  10 +-
 content/general/stream/stream-design.html          |  26 +-
 content/general/supervision.html                   |  12 +-
 content/general/terminology.html                   |   8 +-
 content/index-actors.html                          |  14 +-
 content/index-classic.html                         |   8 +-
 content/index-cluster.html                         |   8 +-
 content/index-network.html                         |   8 +-
 content/index-utilities-classic.html               |  14 +-
 content/index-utilities.html                       |   8 +-
 content/index.html                                 |   8 +-
 content/io-dns.html                                |  24 +-
 content/io-tcp.html                                |  80 ++---
 content/io-udp.html                                |  38 +--
 content/io.html                                    |  34 +-
 content/logging.html                               |  92 +++---
 content/mailboxes.html                             |  66 ++--
 content/multi-jvm-testing.html                     |   8 +-
 content/multi-node-testing.html                    |  38 +--
 content/paradox.json                               |   2 +-
 content/persistence-fsm.html                       |  88 ++---
 content/persistence-journals.html                  |  50 +--
 content/persistence-plugins.html                   |  30 +-
 content/persistence-query-leveldb.html             |  36 +-
 content/persistence-query.html                     | 104 +++---
 content/persistence-schema-evolution.html          |  78 ++---
 content/persistence.html                           | 204 ++++++------
 content/project/downstream-upgrade-strategy.html   |   8 +-
 content/project/examples.html                      |   8 +-
 content/project/immutable.html                     |   8 +-
 content/project/index.html                         |   8 +-
 content/project/issue-tracking.html                |   8 +-
 content/project/licenses.html                      |   8 +-
 content/project/links.html                         |   8 +-
 content/project/migration-guides.html              |   8 +-
 content/project/rolling-update.html                |   8 +-
 content/project/scala3.html                        |   8 +-
 content/remoting-artery.html                       |  68 ++--
 content/remoting.html                              |  46 +--
 content/routing.html                               | 362 ++++++++++-----------
 content/scheduler.html                             |  44 +--
 content/security/index.html                        |   8 +-
 content/serialization-classic.html                 |  30 +-
 content/serialization-jackson.html                 | 136 ++++----
 content/serialization.html                         |  74 ++---
 content/split-brain-resolver.html                  |  32 +-
 content/stream/actor-interop.html                  |  42 +--
 content/stream/futures-interop.html                |  64 ++--
 content/stream/index.html                          |  22 +-
 content/stream/operators/ActorFlow/ask.html        |  22 +-
 .../stream/operators/ActorFlow/askWithContext.html |  18 +-
 .../stream/operators/ActorFlow/askWithStatus.html  |  22 +-
 .../ActorFlow/askWithStatusAndContext.html         |  18 +-
 content/stream/operators/ActorSink/actorRef.html   |  16 +-
 .../ActorSink/actorRefWithBackpressure.html        |  20 +-
 content/stream/operators/ActorSource/actorRef.html |  20 +-
 .../ActorSource/actorRefWithBackpressure.html      |  20 +-
 content/stream/operators/Balance.html              |   8 +-
 content/stream/operators/Broadcast.html            |  18 +-
 content/stream/operators/Compression/deflate.html  |  12 +-
 content/stream/operators/Compression/gunzip.html   |  10 +-
 content/stream/operators/Compression/gzip.html     |  12 +-
 content/stream/operators/Compression/inflate.html  |  10 +-
 content/stream/operators/FileIO/fromFile.html      |  10 +-
 content/stream/operators/FileIO/fromPath.html      |  14 +-
 content/stream/operators/FileIO/toFile.html        |  10 +-
 content/stream/operators/FileIO/toPath.html        |  14 +-
 .../stream/operators/Flow/asFlowWithContext.html   |  16 +-
 .../stream/operators/Flow/completionStageFlow.html |  12 +-
 content/stream/operators/Flow/flattenOptional.html |  10 +-
 .../stream/operators/Flow/fromSinkAndSource.html   |  24 +-
 .../operators/Flow/fromSinkAndSourceCoupled.html   |  10 +-
 content/stream/operators/Flow/futureFlow.html      |  12 +-
 .../operators/Flow/lazyCompletionStageFlow.html    |   8 +-
 content/stream/operators/Flow/lazyFlow.html        |  18 +-
 content/stream/operators/Flow/lazyFutureFlow.html  |  10 +-
 content/stream/operators/Flow/lazyInitAsync.html   |  10 +-
 content/stream/operators/MergeSequence.html        |  14 +-
 content/stream/operators/Partition.html            |  14 +-
 content/stream/operators/PubSub/sink.html          |  18 +-
 content/stream/operators/PubSub/source.html        |  18 +-
 .../RestartFlow/onFailuresWithBackoff.html         |  20 +-
 .../stream/operators/RestartFlow/withBackoff.html  |  20 +-
 .../stream/operators/RestartSink/withBackoff.html  |  20 +-
 .../RestartSource/onFailuresWithBackoff.html       |  30 +-
 .../operators/RestartSource/withBackoff.html       |  18 +-
 .../stream/operators/RetryFlow/withBackoff.html    |  16 +-
 .../operators/RetryFlow/withBackoffAndContext.html |  16 +-
 content/stream/operators/Sink/actorRef.html        |  10 +-
 .../operators/Sink/actorRefWithBackpressure.html   |  18 +-
 content/stream/operators/Sink/asPublisher.html     |  14 +-
 content/stream/operators/Sink/cancelled.html       |  14 +-
 content/stream/operators/Sink/collect.html         |  12 +-
 content/stream/operators/Sink/collection.html      |  12 +-
 content/stream/operators/Sink/combine.html         |  14 +-
 .../stream/operators/Sink/completionStageSink.html |   8 +-
 content/stream/operators/Sink/fold.html            |  14 +-
 content/stream/operators/Sink/foreach.html         |  14 +-
 content/stream/operators/Sink/foreachAsync.html    |  14 +-
 content/stream/operators/Sink/foreachParallel.html |   8 +-
 .../stream/operators/Sink/fromMaterializer.html    |  10 +-
 content/stream/operators/Sink/fromSubscriber.html  |  10 +-
 content/stream/operators/Sink/futureSink.html      |  10 +-
 content/stream/operators/Sink/head.html            |  14 +-
 content/stream/operators/Sink/headOption.html      |  14 +-
 content/stream/operators/Sink/ignore.html          |  14 +-
 content/stream/operators/Sink/last.html            |  14 +-
 content/stream/operators/Sink/lastOption.html      |  14 +-
 .../operators/Sink/lazyCompletionStageSink.html    |   8 +-
 content/stream/operators/Sink/lazyFutureSink.html  |  10 +-
 content/stream/operators/Sink/lazyInitAsync.html   |  10 +-
 content/stream/operators/Sink/lazySink.html        |  14 +-
 content/stream/operators/Sink/never.html           |  10 +-
 content/stream/operators/Sink/onComplete.html      |  10 +-
 content/stream/operators/Sink/preMaterialize.html  |  10 +-
 content/stream/operators/Sink/queue.html           |  10 +-
 content/stream/operators/Sink/reduce.html          |  14 +-
 content/stream/operators/Sink/seq.html             |  14 +-
 content/stream/operators/Sink/setup.html           |  10 +-
 content/stream/operators/Sink/takeLast.html        |  14 +-
 .../Source-or-Flow/aggregateWithBoundary.html      |  10 +-
 .../stream/operators/Source-or-Flow/alsoTo.html    |  10 +-
 .../stream/operators/Source-or-Flow/alsoToAll.html |  20 +-
 content/stream/operators/Source-or-Flow/ask.html   |  16 +-
 .../Source-or-Flow/backpressureTimeout.html        |  10 +-
 content/stream/operators/Source-or-Flow/batch.html |  10 +-
 .../operators/Source-or-Flow/batchWeighted.html    |  10 +-
 .../stream/operators/Source-or-Flow/buffer.html    |  10 +-
 .../stream/operators/Source-or-Flow/collect.html   |  22 +-
 .../operators/Source-or-Flow/collectType.html      |  18 +-
 .../Source-or-Flow/completionTimeout.html          |  14 +-
 .../stream/operators/Source-or-Flow/concat.html    |  14 +-
 .../operators/Source-or-Flow/concatAllLazy.html    |  14 +-
 .../operators/Source-or-Flow/concatLazy.html       |  14 +-
 .../stream/operators/Source-or-Flow/conflate.html  |  14 +-
 .../operators/Source-or-Flow/conflateWithSeed.html |  14 +-
 content/stream/operators/Source-or-Flow/delay.html |  10 +-
 .../stream/operators/Source-or-Flow/delayWith.html |  10 +-
 .../stream/operators/Source-or-Flow/detach.html    |  10 +-
 .../stream/operators/Source-or-Flow/divertTo.html  |  10 +-
 content/stream/operators/Source-or-Flow/drop.html  |  14 +-
 .../stream/operators/Source-or-Flow/dropWhile.html |  14 +-
 .../operators/Source-or-Flow/dropWithin.html       |  10 +-
 .../stream/operators/Source-or-Flow/expand.html    |  14 +-
 .../operators/Source-or-Flow/extrapolate.html      |  14 +-
 .../stream/operators/Source-or-Flow/filter.html    |  16 +-
 .../stream/operators/Source-or-Flow/filterNot.html |  16 +-
 .../operators/Source-or-Flow/flatMapConcat.html    |  14 +-
 .../operators/Source-or-Flow/flatMapMerge.html     |  14 +-
 .../operators/Source-or-Flow/flatMapPrefix.html    |  10 +-
 content/stream/operators/Source-or-Flow/fold.html  |  14 +-
 .../stream/operators/Source-or-Flow/foldAsync.html |  14 +-
 .../operators/Source-or-Flow/fromMaterializer.html |  10 +-
 .../stream/operators/Source-or-Flow/groupBy.html   |  14 +-
 .../stream/operators/Source-or-Flow/grouped.html   |  14 +-
 .../operators/Source-or-Flow/groupedWeighted.html  |  14 +-
 .../Source-or-Flow/groupedWeightedWithin.html      |  10 +-
 .../operators/Source-or-Flow/groupedWithin.html    |  10 +-
 .../operators/Source-or-Flow/idleTimeout.html      |  10 +-
 .../operators/Source-or-Flow/initialDelay.html     |  10 +-
 .../operators/Source-or-Flow/initialTimeout.html   |  10 +-
 .../operators/Source-or-Flow/interleave.html       |  14 +-
 .../operators/Source-or-Flow/interleaveAll.html    |  14 +-
 .../operators/Source-or-Flow/intersperse.html      |  14 +-
 .../stream/operators/Source-or-Flow/keepAlive.html |  10 +-
 content/stream/operators/Source-or-Flow/limit.html |  16 +-
 .../operators/Source-or-Flow/limitWeighted.html    |  16 +-
 content/stream/operators/Source-or-Flow/log.html   |  14 +-
 .../operators/Source-or-Flow/logWithMarker.html    |  14 +-
 content/stream/operators/Source-or-Flow/map.html   |  12 +-
 .../stream/operators/Source-or-Flow/mapAsync.html  |  18 +-
 .../Source-or-Flow/mapAsyncUnordered.html          |  14 +-
 .../stream/operators/Source-or-Flow/mapConcat.html |  14 +-
 .../stream/operators/Source-or-Flow/mapError.html  |  14 +-
 content/stream/operators/Source-or-Flow/merge.html |  14 +-
 .../stream/operators/Source-or-Flow/mergeAll.html  |  14 +-
 .../operators/Source-or-Flow/mergeLatest.html      |  14 +-
 .../operators/Source-or-Flow/mergePreferred.html   |  14 +-
 .../operators/Source-or-Flow/mergePrioritized.html |  14 +-
 .../operators/Source-or-Flow/mergeSorted.html      |  14 +-
 .../stream/operators/Source-or-Flow/monitor.html   |  14 +-
 .../stream/operators/Source-or-Flow/orElse.html    |  14 +-
 .../operators/Source-or-Flow/preMaterialize.html   |  10 +-
 .../operators/Source-or-Flow/prefixAndTail.html    |  10 +-
 .../stream/operators/Source-or-Flow/prepend.html   |  14 +-
 .../operators/Source-or-Flow/prependLazy.html      |  14 +-
 .../stream/operators/Source-or-Flow/recover.html   |  18 +-
 .../operators/Source-or-Flow/recoverWith.html      |  10 +-
 .../Source-or-Flow/recoverWithRetries.html         |  10 +-
 .../stream/operators/Source-or-Flow/reduce.html    |  14 +-
 content/stream/operators/Source-or-Flow/scan.html  |  14 +-
 .../stream/operators/Source-or-Flow/scanAsync.html |  14 +-
 content/stream/operators/Source-or-Flow/setup.html |  10 +-
 .../stream/operators/Source-or-Flow/sliding.html   |  22 +-
 .../operators/Source-or-Flow/splitAfter.html       |  14 +-
 .../stream/operators/Source-or-Flow/splitWhen.html |  14 +-
 .../operators/Source-or-Flow/statefulMap.html      |  26 +-
 .../Source-or-Flow/statefulMapConcat.html          |  22 +-
 content/stream/operators/Source-or-Flow/take.html  |  14 +-
 .../stream/operators/Source-or-Flow/takeWhile.html |  14 +-
 .../operators/Source-or-Flow/takeWithin.html       |  10 +-
 .../stream/operators/Source-or-Flow/throttle.html  |  20 +-
 content/stream/operators/Source-or-Flow/watch.html |  14 +-
 .../operators/Source-or-Flow/watchTermination.html |  14 +-
 .../stream/operators/Source-or-Flow/wireTap.html   |  10 +-
 content/stream/operators/Source-or-Flow/zip.html   |  14 +-
 .../stream/operators/Source-or-Flow/zipAll.html    |  14 +-
 .../stream/operators/Source-or-Flow/zipLatest.html |  10 +-
 .../operators/Source-or-Flow/zipLatestWith.html    |  10 +-
 .../stream/operators/Source-or-Flow/zipWith.html   |  14 +-
 .../operators/Source-or-Flow/zipWithIndex.html     |  14 +-
 content/stream/operators/Source/actorRef.html      |  14 +-
 .../operators/Source/actorRefWithBackpressure.html |  14 +-
 .../operators/Source/asSourceWithContext.html      |  16 +-
 content/stream/operators/Source/asSubscriber.html  |  22 +-
 content/stream/operators/Source/combine.html       |  30 +-
 .../stream/operators/Source/completionStage.html   |  12 +-
 .../operators/Source/completionStageSource.html    |  14 +-
 content/stream/operators/Source/cycle.html         |  18 +-
 content/stream/operators/Source/empty.html         |  10 +-
 content/stream/operators/Source/failed.html        |  10 +-
 content/stream/operators/Source/from.html          |  14 +-
 .../operators/Source/fromCompletionStage.html      |  10 +-
 content/stream/operators/Source/fromFuture.html    |  10 +-
 .../stream/operators/Source/fromFutureSource.html  |  10 +-
 content/stream/operators/Source/fromIterator.html  |  14 +-
 .../stream/operators/Source/fromJavaStream.html    |  14 +-
 content/stream/operators/Source/fromPublisher.html |  22 +-
 .../Source/fromSourceCompletionStage.html          |   8 +-
 content/stream/operators/Source/future.html        |  12 +-
 content/stream/operators/Source/futureSource.html  |  14 +-
 content/stream/operators/Source/lazily.html        |  10 +-
 content/stream/operators/Source/lazilyAsync.html   |   8 +-
 .../operators/Source/lazyCompletionStage.html      |   8 +-
 .../Source/lazyCompletionStageSource.html          |   8 +-
 content/stream/operators/Source/lazyFuture.html    |  10 +-
 .../stream/operators/Source/lazyFutureSource.html  |  10 +-
 content/stream/operators/Source/lazySingle.html    |  10 +-
 content/stream/operators/Source/lazySource.html    |  18 +-
 content/stream/operators/Source/maybe.html         |  14 +-
 .../stream/operators/Source/mergePrioritizedN.html |  12 +-
 content/stream/operators/Source/never.html         |  10 +-
 content/stream/operators/Source/queue.html         |  20 +-
 content/stream/operators/Source/range.html         |  18 +-
 content/stream/operators/Source/repeat.html        |  14 +-
 content/stream/operators/Source/single.html        |  14 +-
 content/stream/operators/Source/tick.html          |  24 +-
 content/stream/operators/Source/unfold.html        |  18 +-
 content/stream/operators/Source/unfoldAsync.html   |  18 +-
 .../stream/operators/Source/unfoldResource.html    |  18 +-
 .../operators/Source/unfoldResourceAsync.html      |  18 +-
 content/stream/operators/Source/zipN.html          |  14 +-
 content/stream/operators/Source/zipWithN.html      |  14 +-
 .../operators/StreamConverters/asInputStream.html  |  16 +-
 .../operators/StreamConverters/asJavaStream.html   |  16 +-
 .../operators/StreamConverters/asOutputStream.html |  16 +-
 .../StreamConverters/fromInputStream.html          |  16 +-
 .../operators/StreamConverters/fromJavaStream.html |  16 +-
 .../StreamConverters/fromOutputStream.html         |  16 +-
 .../operators/StreamConverters/javaCollector.html  |  10 +-
 .../javaCollectorParallelUnordered.html            |  10 +-
 content/stream/operators/Unzip.html                |   8 +-
 content/stream/operators/UnzipWith.html            |   8 +-
 content/stream/operators/index.html                |  28 +-
 content/stream/reactive-streams-interop.html       |  54 +--
 content/stream/stream-composition.html             |  74 ++---
 content/stream/stream-context.html                 |  26 +-
 content/stream/stream-cookbook.html                | 142 ++++----
 content/stream/stream-customize.html               | 126 +++----
 content/stream/stream-dynamic.html                 | 106 +++---
 content/stream/stream-error.html                   |  98 +++---
 content/stream/stream-flows-and-basics.html        |  94 +++---
 content/stream/stream-graphs.html                  | 100 +++---
 content/stream/stream-introduction.html            |   8 +-
 content/stream/stream-io.html                      |  62 ++--
 content/stream/stream-parallelism.html             |  32 +-
 content/stream/stream-quickstart.html              | 152 ++++-----
 content/stream/stream-rate.html                    |  74 ++---
 content/stream/stream-refs.html                    |  38 +--
 content/stream/stream-substream.html               |  68 ++--
 content/stream/stream-testkit.html                 |  72 ++--
 content/supervision-classic.html                   |   8 +-
 content/testing.html                               | 146 ++++-----
 content/typed/actor-discovery.html                 |  46 +--
 content/typed/actor-lifecycle.html                 |  92 +++---
 content/typed/actors.html                          | 108 +++---
 content/typed/choosing-cluster.html                |   8 +-
 content/typed/cluster-concepts.html                |  10 +-
 content/typed/cluster-dc.html                      |  30 +-
 content/typed/cluster-membership.html              |  10 +-
 content/typed/cluster-sharded-daemon-process.html  |  26 +-
 content/typed/cluster-sharding-concepts.html       |   8 +-
 content/typed/cluster-sharding.html                | 170 +++++-----
 content/typed/cluster-singleton.html               |  62 ++--
 content/typed/cluster.html                         |  82 ++---
 content/typed/coexisting.html                      |  56 ++--
 content/typed/cqrs.html                            |   8 +-
 content/typed/dispatchers.html                     |  54 +--
 content/typed/distributed-data.html                |  96 +++---
 content/typed/distributed-pub-sub.html             |  16 +-
 content/typed/durable-state/cqrs.html              |   8 +-
 content/typed/durable-state/persistence-style.html |  14 +-
 content/typed/durable-state/persistence.html       | 104 +++---
 content/typed/extending.html                       |  30 +-
 content/typed/failure-detector.html                |   8 +-
 content/typed/fault-tolerance.html                 |  72 ++--
 content/typed/from-classic.html                    |  26 +-
 content/typed/fsm.html                             |  20 +-
 content/typed/guide/actors-intro.html              |   8 +-
 content/typed/guide/actors-motivation.html         |   8 +-
 content/typed/guide/index.html                     |   8 +-
 content/typed/guide/introduction.html              |   8 +-
 content/typed/guide/modules.html                   |  62 ++--
 content/typed/guide/tutorial.html                  |   8 +-
 content/typed/guide/tutorial_1.html                |  48 +--
 content/typed/guide/tutorial_2.html                |  16 +-
 content/typed/guide/tutorial_3.html                |  40 +--
 content/typed/guide/tutorial_4.html                |  62 ++--
 content/typed/guide/tutorial_5.html                |  70 ++--
 content/typed/index-cluster.html                   |   8 +-
 content/typed/index-persistence-durable-state.html |   8 +-
 content/typed/index-persistence.html               |   8 +-
 content/typed/index.html                           |   8 +-
 content/typed/interaction-patterns.html            | 138 ++++----
 content/typed/logging.html                         |  74 ++---
 content/typed/mailboxes.html                       |  68 ++--
 content/typed/persistence-fsm.html                 |  26 +-
 content/typed/persistence-snapshot.html            |  32 +-
 content/typed/persistence-style.html               |  20 +-
 content/typed/persistence-testing.html             | 110 +++----
 content/typed/persistence.html                     | 198 +++++------
 content/typed/reliable-delivery.html               |  74 ++---
 .../typed/replicated-eventsourcing-auction.html    |  34 +-
 content/typed/replicated-eventsourcing-cart.html   |  14 +-
 .../typed/replicated-eventsourcing-examples.html   |   8 +-
 content/typed/replicated-eventsourcing.html        |  78 ++---
 content/typed/routers.html                         |  42 +--
 content/typed/stash.html                           |  26 +-
 content/typed/style-guide.html                     |  96 +++---
 content/typed/testing-async.html                   |  90 ++---
 content/typed/testing-sync.html                    |  58 ++--
 content/typed/testing.html                         |  26 +-
 386 files changed, 5498 insertions(+), 5498 deletions(-)

diff --git a/content/actors.html b/content/actors.html
index 216c920..f767fc6 100644
--- a/content/actors.html
+++ b/content/actors.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -420,7 +420,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h1><a href="#classic-actors" name="classic-actors" class="anchor"><span class="anchor-link"></span></a>Classic Actors</h1><div class="callout note "><div class="callout-title">Note</div>
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2>
-<p>To use Classic Actors, add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Classic Actors, add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies ++= Seq(
   "org.apache.pekko" %% "pekko-actor" % PekkoVersion,
   "org.apache.pekko" %% "pekko-testkit" % PekkoVersion % Test
@@ -432,7 +432,7 @@ libraryDependencies ++= Seq(
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -452,7 +452,7 @@ libraryDependencies ++= Seq(
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
   testImplementation "org.apache.pekko:pekko-testkit_${versions.ScalaBinary}"
@@ -461,7 +461,7 @@ dependencies {
 <tr><th colspan="2">Project Info: Pekko Actors (classic)</th></tr>
   <tr><th>Artifact</th><td><div>org.apache.pekko</div>
   <div>pekko-actor</div>
-  <div>0.0.0+26533-ec68a528-SNAPSHOT</div>
+  <div>0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT</div>
   <div><a href="project/links.html#snapshots-repository">Snapshots are available</a></div>
   </td></tr>
   <tr><th>JDK versions</th><td><div>Adopt OpenJDK 8</div><div>Adopt OpenJDK 11</div></td></tr>
@@ -476,11 +476,11 @@ dependencies {
   <div><a href="https://doc.akka.io/japi/akka/snapshot/akka/actor/package-summary.html" target="_blank" rel="noopener noreferrer">API (Javadoc)</a></div>
   </td></tr>
   <tr><th>Forums</th><td>
-  <div><a href="https://discuss.akka.io" target="_blank" rel="noopener noreferrer">Lightbend Discuss</a></div>
-  <div><a href="https://gitter.im/akka/akka" target="_blank" rel="noopener noreferrer">akka/akka Gitter channel</a></div>
+  <div><a href="https://lists.apache.org/list.html?dev@pekko.apache.org" target="_blank" rel="noopener noreferrer">Apache Pekko Dev mailing list</a></div>
+  <div><a href="https://github.com/apache/incubator-pekko/discussions" target="_blank" rel="noopener noreferrer">apache/incubator-pekko discussion</a></div>
   </td></tr>
   <tr><th>Release notes</th><td><a href="https://akka.io/blog/news-archive.html">akka.io blog</a></td></tr>
-  <tr><th>Issues</th><td><a href="https://github.com/akka/akka/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
+  <tr><th>Issues</th><td><a href="https://github.com/apache/incubator-pekko/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
   <tr><th>Sources</th><td><a href="https://github.com/apache/incubator-pekko" target="_blank" rel="noopener noreferrer">https://github.com/apache/incubator-pekko</a></td></tr>
 </table>
 
@@ -501,7 +501,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L22-L26" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L22-L26" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.Actor
 import pekko.actor.Props
 import pekko.event.Logging
@@ -516,7 +516,7 @@ class MyActor extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/MyActor.java#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractActor;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/MyActor.java#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractActor;
 import org.apache.pekko.event.Logging;
 import org.apache.pekko.event.LoggingAdapter;
 
@@ -536,7 +536,7 @@ public class MyActor extends AbstractActor {
   }
 }</code></pre></dd>
 </dl>
-<p>Please note that the Pekko Actor <span class="group-scala"><code>receive</code></span> message loop is exhaustive, which is different compared to Erlang and the late Scala Actors. This means that you need to provide a pattern match for all messages that it can accept and if you want to be able to handle unknown messages then you need to have a default case as in the example above. Otherwise an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHO [...]
+<p>Please note that the Pekko Actor <span class="group-scala"><code>receive</code></span> message loop is exhaustive, which is different compared to Erlang and the late Scala Actors. This means that you need to provide a pattern match for all messages that it can accept and if you want to be able to handle unknown messages then you need to have a default case as in the example above. Otherwise an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+2023011 [...]
 <p>Note further that the return type of the behavior defined above is <a href="http://www.scala-lang.org/api/2.13.8/scala/Unit.html" title="scala.Unit"><code>Unit</code></a>; if the actor shall reply to the received message then this must be done explicitly as explained below.</p>
 <p>The result of the <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#receive:org.apache.pekko.actor.Actor.Receive" title="pekko.actor.Actor"><code>receive</code></a> method is a partial function object, which is</span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#createReceive()" title="pekko.actor.AbstractActor"><code>createReceive</code></a> method is <a href="https:// [...]
 <h4><a href="#here-is-another-example-that-you-can-edit-and-run-in-the-browser-" name="here-is-another-example-that-you-can-edit-and-run-in-the-browser-" class="anchor"><span class="anchor-link"></span></a>Here is another example that you can edit and run in the browser:</h4>
@@ -589,36 +589,36 @@ class Ponger(pinger: ActorRef) extends Actor {
         <script defer="true" src="https://embed.scalafiddle.io/integration.js"></script>
         </div>
 <h3><a href="#props" name="props" class="anchor"><span class="anchor-link"></span></a>Props</h3>
-<p><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span> is a configuration class to specify options for the creation of actors, think of it as an immutable [...]
+<p><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span> is a configuration class to specify options for the creation of actors, [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L420-L424" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Props
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L420-L424" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Props
 
 val props1 = Props[MyActor]()
 val props2 = Props(new ActorWithArgs(&quot;arg&quot;)) // careful, see below
 val props3 = Props(classOf[ActorWithArgs], &quot;arg&quot;) // no support for value class arguments</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L36" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.Props;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L36" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.Props;
 Props props1 = Props.create(MyActor.class);
 Props props2 =
     Props.create(ActorWithArgs.class, () -&gt; new ActorWithArgs(&quot;arg&quot;)); // careful, see below
 Props props3 = Props.create(ActorWithArgs.class, &quot;arg&quot;);</code></pre></dd>
 </dl>
-<p>The second variant shows how to pass constructor arguments to the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span> being created, but it should only [...]
+<p>The second variant shows how to pass constructor arguments to the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span> being [...]
 <p>The last line shows a possibility to pass constructor arguments regardless of the context it is being used in. The presence of a matching constructor is verified during construction of the <code>Props</code> object, resulting in an <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/IllegalArgumentException.html" title="java.lang.IllegalArgumentException"><code>IllegalArgumentException</code></a> if no or multiple matching constructors are found.</p><div cl [...]
-<p>The recommended approach to create the actor <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span> is not supported for cases when the actor constructor  [...]
+<p>The recommended approach to create the actor <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span> is not supported for cases [...]
 <h4><a href="#dangerous-variants" name="dangerous-variants" class="anchor"><span class="anchor-link"></span></a>Dangerous Variants</h4>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L428-L430" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// NOT RECOMMENDED within another actor:
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L428-L430" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// NOT RECOMMENDED within another actor:
 // encourages to close over enclosing class
 val props7 = Props(new MyActor)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L528-L530" target="_blank" title="Go to snippet source">source</a><code class="language-java">// NOT RECOMMENDED within another actor:
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L528-L530" target="_blank" title="Go to snippet source">source</a><code class="language-java">// NOT RECOMMENDED within another actor:
 // encourages to close over enclosing class
 Props props7 = Props.create(ActorWithArgs.class, () -&gt; new ActorWithArgs(&quot;arg&quot;));</code></pre></dd>
 </dl>
@@ -630,9 +630,9 @@ Props props7 = Props.create(ActorWithArgs.class, () -&gt; new ActorWithArgs(&quo
 <ul>
   <li>An actor with <a href="http://www.scala-lang.org/api/2.13.8/scala/AnyVal.html" title="scala.AnyVal"><code>AnyVal</code></a> arguments.</li>
 </ul>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/PropsEdgeCaseSpec.scala#L21-L22" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case class MyValueClass(v: Int) extends AnyVal
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/PropsEdgeCaseSpec.scala#L21-L22" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case class MyValueClass(v: Int) extends AnyVal
 </code></pre>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/PropsEdgeCaseSpec.scala#L28-L33" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class ValueActor(value: MyValueClass) extends Actor {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/PropsEdgeCaseSpec.scala#L28-L33" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class ValueActor(value: MyValueClass) extends Actor {
   def receive = {
     case multiplier: Long =&gt; sender() ! (value.v * multiplier)
   }
@@ -641,7 +641,7 @@ val valueClassProp = Props(classOf[ValueActor], MyValueClass(5)) // Unsupported<
 <ul>
   <li>An actor with default constructor values.</li>
 </ul>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/PropsEdgeCaseSpec.scala#L37-L51" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class DefaultValueActor(a: Int, b: Int = 5) extends Actor {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/PropsEdgeCaseSpec.scala#L37-L51" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class DefaultValueActor(a: Int, b: Int = 5) extends Actor {
   def receive = {
     case x: Int =&gt; sender() ! ((a + x) * b)
   }
@@ -659,11 +659,11 @@ val defaultValueProp3 = Props(classOf[DefaultValueActor2]) // Unsupported</code>
 <p>In both cases, an <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/IllegalArgumentException.html" title="java.lang.IllegalArgumentException"><code>IllegalArgumentException</code></a> will be thrown stating no matching constructor could be found.</p>
 <p>The next section explains the recommended ways to create <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html" title="pekko.actor.Actor"><code>Actor</code></a> props in a way, which simultaneously safe-guards against these edge cases.</p></div>
 <h4><a href="#recommended-practices" name="recommended-practices" class="anchor"><span class="anchor-link"></span></a>Recommended Practices</h4>
-<p>It is a good idea to provide <span class="group-scala">factory methods on the companion object of each <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></sp [...]
+<p>It is a good idea to provide <span class="group-scala">factory methods on the companion object of each <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L82-L109" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object DemoActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L82-L109" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object DemoActor {
 
   /**
    * Create Props for an actor of this type.
@@ -688,7 +688,7 @@ class SomeOtherActor extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L188-L233" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class DemoActor extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L188-L233" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class DemoActor extends AbstractActor {
   /**
    * Create Props for an actor of this type.
    *
@@ -730,7 +730,7 @@ static class SomeOtherActor extends AbstractActor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L117-L127" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object MyActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L117-L127" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object MyActor {
   case class Greeting(from: String)
   case object Goodbye
 }
@@ -743,7 +743,7 @@ class MyActor extends Actor with ActorLogging {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L238-L262" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class DemoMessagesActor extends AbstractLoggingActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L238-L262" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class DemoMessagesActor extends AbstractLoggingActor {
 
   public static class Greeting {
     private final String from;
@@ -770,25 +770,25 @@ class MyActor extends Actor with ActorLogging {
 }</code></pre></dd>
 </dl>
 <h3><a href="#creating-actors-with-props" name="creating-actors-with-props" class="anchor"><span class="anchor-link"></span></a>Creating Actors with Props</h3>
-<p>Actors are created by passing a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span> instance into the <code>actorOf</code> factory method which is avai [...]
+<p>Actors are created by passing a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span> instance into the <code>actorOf</code>  [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L436-L440" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.ActorSystem
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L436-L440" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.ActorSystem
 
 // ActorSystem is a heavy object: create only one per application
 val system = ActorSystem(&quot;mySystem&quot;)
 val myActor = system.actorOf(Props[MyActor](), &quot;myactor2&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L39-L40" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.ActorRef;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L39-L40" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.ActorRef;
 import org.apache.pekko.actor.ActorSystem;</code></pre></dd>
 </dl>
 <p>Using the <code>ActorSystem</code> will create top-level actors, supervised by the actor system’s provided guardian actor while using an actor’s context will create a child actor.</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L53-L60" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class FirstActor extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L53-L60" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class FirstActor extends Actor {
   val child = context.actorOf(Props[MyActor](), name = &quot;myChild&quot;)
   def receive = {
     case x =&gt; sender() ! x
@@ -796,7 +796,7 @@ import org.apache.pekko.actor.ActorSystem;</code></pre></dd>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L87-L96" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class FirstActor extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L87-L96" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class FirstActor extends AbstractActor {
   final ActorRef child = getContext().actorOf(Props.create(MyActor.class), &quot;myChild&quot;);
 
   @Override
@@ -806,12 +806,12 @@ import org.apache.pekko.actor.ActorSystem;</code></pre></dd>
 }</code></pre></dd>
 </dl>
 <p>It is recommended to create a hierarchy of children, grand-children and so on such that it fits the logical failure-handling structure of the application, see <a href="general/actor-systems.html">Actor Systems</a>.</p>
-<p>The call to <code>actorOf</code> returns an instance of <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span>. This is a handle to the  [...]
-<p>The name parameter is optional, but you should preferably name your actors, since that is used in log messages and for identifying actors. The name must not be empty or start with <code>$</code>, but it may contain URL encoded characters (eg., <code>%20</code> for a blank space). If the given name is already in use by another child to the same parent an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/InvalidActorName [...]
+<p>The call to <code>actorOf</code> returns an instance of <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></spa [...]
+<p>The name parameter is optional, but you should preferably name your actors, since that is used in log messages and for identifying actors. The name must not be empty or start with <code>$</code>, but it may contain URL encoded characters (eg., <code>%20</code> for a blank space). If the given name is already in use by another child to the same parent an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/In [...]
 <p>Actors are automatically started asynchronously when created.</p><div class="group-scala">
 <h4><a href="#value-classes-as-constructor-arguments" name="value-classes-as-constructor-arguments" class="anchor"><span class="anchor-link"></span></a>Value classes as constructor arguments</h4>
 <p>The recommended way to instantiate actor props uses reflection at runtime to determine the correct actor constructor to be invoked and due to technical limitations it is not supported when said constructor takes arguments that are value classes. In these cases you should either unpack the arguments or create the props by calling the constructor manually:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L68-L77" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Argument(val value: String) extends AnyVal
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L68-L77" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Argument(val value: String) extends AnyVal
 class ValueClassActor(arg: Argument) extends Actor {
   def receive = { case _ =&gt; () }
 }
@@ -822,11 +822,11 @@ object ValueClassActor {
   def props3(arg: Argument) = Props(new ValueClassActor(arg)) // ok
 }</code></pre></div>
 <h3><a href="#dependency-injection" name="dependency-injection" class="anchor"><span class="anchor-link"></span></a>Dependency Injection</h3>
-<p>If your <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span> has a constructor that takes parameters then those need to be part of the <span class="grou [...]
+<p>If your <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span> has a constructor that takes parameters then those need to be p [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L461-L474" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.IndirectActorProducer
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L461-L474" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.IndirectActorProducer
 
 class DependencyInjector(applicationContext: AnyRef, beanName: String) extends IndirectActorProducer {
 
@@ -840,7 +840,7 @@ class DependencyInjector(applicationContext: AnyRef, beanName: String) extends I
 val actorRef = system.actorOf(Props(classOf[DependencyInjector], applicationContext, &quot;hello&quot;), &quot;helloBean&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/DependencyInjectionDocTest.java#L28-L29" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.Actor;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/DependencyInjectionDocTest.java#L28-L29" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.Actor;
 import org.apache.pekko.actor.IndirectActorProducer;
 class DependencyInjector implements IndirectActorProducer {
   final Object applicationContext;
@@ -869,14 +869,14 @@ class DependencyInjector implements IndirectActorProducer {
           .actorOf(
               Props.create(DependencyInjector.class, applicationContext, &quot;TheActor&quot;), &quot;TheActor&quot;);</code></pre></dd>
 </dl><div class="callout warning "><div class="callout-title">Warning</div>
-<p>You might be tempted at times to offer an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/IndirectActorProducer.html" title="org.apache.pekko.actor.IndirectActorProducer"><code>IndirectActorProducer</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/IndirectActorProducer.html" title="org.apache.pekko.actor.IndirectActorProducer"><code>I [...]
+<p>You might be tempted at times to offer an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/IndirectActorProducer.html" title="org.apache.pekko.actor.IndirectActorProducer"><code>IndirectActorProducer</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/IndirectActorProducer.html" title="org.apache.pekko.actor.In [...]
 <p>When using a dependency injection framework, actor beans <em>MUST NOT</em> have singleton scope.</p>
 <h2><a href="#actor-api" name="actor-api" class="anchor"><span class="anchor-link"></span></a>Actor API</h2>
-<p><span class="group-scala">The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span> trait defines only one abstract method, the above mentioned <code>rec [...]
-<p>If the current actor behavior does not match a received message, <code>unhandled</code> is called, which by default publishes an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/UnhandledMessage.html" title="org.apache.pekko.actor.UnhandledMessage"><code>actor.UnhandledMessage(message, sender, recipient)</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/a [...]
+<p><span class="group-scala">The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span> trait defines only one abstract method, t [...]
+<p>If the current actor behavior does not match a received message, <code>unhandled</code> is called, which by default publishes an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/UnhandledMessage.html" title="org.apache.pekko.actor.UnhandledMessage"><code>actor.UnhandledMessage(message, sender, recipient)</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+ [...]
 <p>In addition, it offers:</p>
 <ul>
-  <li><span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#self:org.apache.pekko.actor.ActorRef" title="pekko.actor.Actor"><code>self</code></a></span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#getSelf()" title="pekko.actor.AbstractActor"><code>getSelf()</code></a></span> reference to the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528- [...]
+  <li><span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#self:org.apache.pekko.actor.ActorRef" title="pekko.actor.Actor"><code>self</code></a></span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#getSelf()" title="pekko.actor.AbstractActor"><code>getSelf()</code></a></span> reference to the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+ [...]
   <li><span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#sender():org.apache.pekko.actor.ActorRef" title="pekko.actor.Actor"><code>sender</code></a></span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#getSender()" title="pekko.actor.AbstractActor"><code>getSender()</code></a></span> reference sender Actor of the last received message, typically used as described in  <span c [...]
   <li><span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#supervisorStrategy:org.apache.pekko.actor.SupervisorStrategy" title="pekko.actor.Actor"><code>supervisorStrategy</code></a></span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#supervisorStrategy()" title="pekko.actor.AbstractActor"><code>supervisorStrategy()</code></a></span> user overridable definition the strategy t [...]
 </ul>
@@ -895,7 +895,7 @@ class DependencyInjector implements IndirectActorProducer {
 </ul>
 <p>@@@ div { .group-scala }</p>
 <p>You can import the members in the <code>context</code> to avoid prefixing access with <code>context.</code></p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L339-L345" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class FirstActor extends Actor {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L339-L345" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class FirstActor extends Actor {
   import context._
   val myActor = actorOf(Props[MyActor](), name = &quot;myactor&quot;)
   def receive = {
@@ -906,7 +906,7 @@ class DependencyInjector implements IndirectActorProducer {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/actor/src/main/scala/org/apache/pekko/actor/Actor.scala#L599-L645" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def preStart(): Unit = ()
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/actor/src/main/scala/org/apache/pekko/actor/Actor.scala#L599-L645" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def preStart(): Unit = ()
 
 def postStop(): Unit = ()
 
@@ -923,7 +923,7 @@ def postRestart(@unused reason: Throwable): Unit = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L278-L292" target="_blank" title="Go to snippet source">source</a><code class="language-java">public void preStart() {}
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L278-L292" target="_blank" title="Go to snippet source">source</a><code class="language-java">public void preStart() {}
 
 public void preRestart(Throwable reason, Optional&lt;Object&gt; message) {
   for (ActorRef each : getContext().getChildren()) {
@@ -942,26 +942,26 @@ public void postStop() {}</code></pre></dd>
 <p>The implementations shown above are the defaults provided by the <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html" title="pekko.actor.Actor"><code>Actor</code></a> trait.</span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html" title="pekko.actor.AbstractActor"><code>AbstractActor</code></a> class.</span></p>
 <h3><a href="#actor-lifecycle" name="actor-lifecycle" class="anchor"><span class="anchor-link"></span></a>Actor Lifecycle</h3>
 <p><img src="./images/actor_lifecycle.png" alt="actor_lifecycle.png" /></p>
-<p>A path in an actor system represents a &ldquo;place&rdquo; that might be occupied by a living actor. Initially (apart from system initialized actors) a path is empty. When <code>actorOf()</code> is called it assigns an <em>incarnation</em> of the actor described by the passed <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span><span class="grou [...]
+<p>A path in an actor system represents a &ldquo;place&rdquo; that might be occupied by a living actor. Initially (apart from system initialized actors) a path is empty. When <code>actorOf()</code> is called it assigns an <em>incarnation</em> of the actor described by the passed <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span><sp [...]
 <p>It is worth noting about the difference between:</p>
 <ul>
   <li>restart</li>
   <li>stop, followed by a re-creation of the actor</li>
 </ul>
 <p>as explained below.</p>
-<p>A restart only swaps the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span> instance defined by the <span class="group-scala"><a href="https://doc.akk [...]
-<p>The lifecycle of an incarnation ends when the actor is stopped. At that point, the appropriate lifecycle events are called and watching actors are notified of the termination. After the incarnation is stopped, the path can be reused again by creating an actor with <code>actorOf()</code>. In this case, the name of the new incarnation will be the same as the previous one, but the UIDs will differ. An actor can be stopped by the actor itself, another actor or the <span class="group-scala [...]
+<p>A restart only swaps the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span> instance defined by the <span class="group-sca [...]
+<p>The lifecycle of an incarnation ends when the actor is stopped. At that point, the appropriate lifecycle events are called and watching actors are notified of the termination. After the incarnation is stopped, the path can be reused again by creating an actor with <code>actorOf()</code>. In this case, the name of the new incarnation will be the same as the previous one, but the UIDs will differ. An actor can be stopped by the actor itself, another actor or the <span class="group-scala [...]
 <p>It is important to note that Actors do not stop automatically when no longer referenced, every Actor that is created must also explicitly be destroyed. The only simplification is that stopping a parent Actor will also recursively stop all the child Actors that this parent has created.</p></div>
-<p>An <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span> always represents an incarnation (path and UID) not just a given path. Therefo [...]
-<p><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSelection.html" title="org.apache.pekko.actor.ActorSelection"><code>ActorSelection</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSelection.html" title="org.apache.pekko.actor.ActorSelection"><code>ActorSelection</code></a></span> on the other hand points to the path (or mult [...]
+<p>An <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span> always represents an incarnation (path and UID) no [...]
+<p><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSelection.html" title="org.apache.pekko.actor.ActorSelection"><code>ActorSelection</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSelection.html" title="org.apache.pekko.actor.ActorSelection"><code>ActorSelection</code></a></span> on the other hand [...]
 <a id="deathwatch"></a>
 <h3><a href="#lifecycle-monitoring-aka-deathwatch" name="lifecycle-monitoring-aka-deathwatch" class="anchor"><span class="anchor-link"></span></a>Lifecycle Monitoring aka DeathWatch</h3>
-<p>To be notified when another actor terminates (i.e., stops permanently, not a temporary failure and restart), an actor may register itself for reception of the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Terminated.html" title="org.apache.pekko.actor.Terminated"><code>Terminated</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Term [...]
+<p>To be notified when another actor terminates (i.e., stops permanently, not a temporary failure and restart), an actor may register itself for reception of the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Terminated.html" title="org.apache.pekko.actor.Terminated"><code>Terminated</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT [...]
 <p>Registering a monitor is easy:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L583-L597" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.{ Actor, Props, Terminated }
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L583-L597" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.{ Actor, Props, Terminated }
 
 class WatchActor extends Actor {
   val child = context.actorOf(Props.empty, &quot;child&quot;)
@@ -978,7 +978,7 @@ class WatchActor extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L60" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.Terminated;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L60" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.Terminated;
 static class WatchActor extends AbstractActor {
   private final ActorRef child = getContext().actorOf(Props.empty(), &quot;target&quot;);
   private ActorRef lastSender = system.deadLetters();
@@ -1006,20 +1006,20 @@ static class WatchActor extends AbstractActor {
   }
 }</code></pre></dd>
 </dl>
-<p>It should be noted that the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Terminated.html" title="org.apache.pekko.actor.Terminated"><code>Terminated</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Terminated.html" title="org.apache.pekko.actor.Terminated"><code>Terminated</code></a></span> message is generated independently of the [...]
+<p>It should be noted that the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Terminated.html" title="org.apache.pekko.actor.Terminated"><code>Terminated</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Terminated.html" title="org.apache.pekko.actor.Terminated"><code>Terminated</code></a></span> message is ge [...]
 <p>Registering multiple times does not necessarily lead to multiple messages being generated, but there is no guarantee that only exactly one such message is received: if termination of the watched actor has generated and queued the message, and another registration is done before this message has been processed, then a second message will be queued because registering for monitoring of an already terminated actor leads to the immediate generation of the <code>Terminated</code> message.</p>
-<p>It is also possible to deregister from watching another actor’s liveliness using <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorContext.html#unwatch(subject:org.apache.pekko.actor.ActorRef):org.apache.pekko.actor.ActorRef" title="org.apache.pekko.actor.ActorContext"><code>context.unwatch(target)</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apa [...]
+<p>It is also possible to deregister from watching another actor’s liveliness using <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorContext.html#unwatch(subject:org.apache.pekko.actor.ActorRef):org.apache.pekko.actor.ActorRef" title="org.apache.pekko.actor.ActorContext"><code>context.unwatch(target)</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20 [...]
 <h3><a href="#start-hook" name="start-hook" class="anchor"><span class="anchor-link"></span></a>Start Hook</h3>
 <p>Right after starting the actor, its <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#preStart():Unit" title="pekko.actor.Actor"><code>preStart</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#preStart()" title="pekko.actor.AbstractActor"><code>preStart</code></a></span> method is invoked.</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L136-L138" target="_blank" title="Go to snippet source">source</a><code class="language-scala">override def preStart(): Unit = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L136-L138" target="_blank" title="Go to snippet source">source</a><code class="language-scala">override def preStart(): Unit = {
   child = context.actorOf(Props[MyActor](), &quot;child&quot;)
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L306-L309" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L306-L309" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public void preStart() {
   target = getContext().actorOf(Props.create(MyActor.class, &quot;target&quot;));
 }</code></pre></dd>
@@ -1036,20 +1036,20 @@ public void preStart() {
 <p>An actor restart replaces only the actual actor object; the contents of the mailbox are unaffected by the restart, so the processing of messages will resume after the <code>postRestart</code> hook returns. The message that triggered the exception will not be received again. Any message sent to an actor while it is being restarted will be queued to its mailbox as usual.</p><div class="callout warning "><div class="callout-title">Warning</div>
 <p>Be aware that the ordering of failure notifications relative to user messages is not deterministic. In particular, a parent might restart its child before it has processed the last messages sent by the child before the failure. See <a href="general/message-delivery-reliability.html#message-ordering">Discussion: Message Ordering</a> for details.</p></div>
 <h3><a href="#stop-hook" name="stop-hook" class="anchor"><span class="anchor-link"></span></a>Stop Hook</h3>
-<p>After stopping an actor, its <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#postStop():Unit" title="pekko.actor.Actor"><code>postStop</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#postStop()" title="pekko.actor.AbstractActor"><code>postStop</code></a></span> hook is called, which may be used e.g. for deregistering this actor from other services. This  [...]
+<p>After stopping an actor, its <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#postStop():Unit" title="pekko.actor.Actor"><code>postStop</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#postStop()" title="pekko.actor.AbstractActor"><code>postStop</code></a></span> hook is called, which may be used e.g. for deregistering this actor from other services. This  [...]
 <a id="actorselection"></a>
 <h2><a href="#identifying-actors-via-actor-selection" name="identifying-actors-via-actor-selection" class="anchor"><span class="anchor-link"></span></a>Identifying Actors via Actor Selection</h2>
-<p>As described in <a href="general/addressing.html">Actor References, Paths and Addresses</a>, each actor has a unique logical path, which is obtained by following the chain of actors from child to parent until reaching the root of the actor system, and it has a physical path, which may differ if the supervision chain includes any remote supervisors. These paths are used by the system to look up actors, e.g. when a remote message is received and the recipient is searched, but they are a [...]
+<p>As described in <a href="general/addressing.html">Actor References, Paths and Addresses</a>, each actor has a unique logical path, which is obtained by following the chain of actors from child to parent until reaching the root of the actor system, and it has a physical path, which may differ if the supervision chain includes any remote supervisors. These paths are used by the system to look up actors, e.g. when a remote message is received and the recipient is searched, but they are a [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L625-L628" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// will look up this absolute path
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L625-L628" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// will look up this absolute path
 context.actorSelection(&quot;/user/serviceA/aggregator&quot;)
 // will look up sibling beneath same supervisor
 context.actorSelection(&quot;../joe&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L332-L335" target="_blank" title="Go to snippet source">source</a><code class="language-java">// will look up this absolute path
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L332-L335" target="_blank" title="Go to snippet source">source</a><code class="language-java">// will look up this absolute path
 getContext().actorSelection(&quot;/user/serviceA/actor&quot;);
 // will look up sibling beneath same supervisor
 getContext().actorSelection(&quot;../joe&quot;);</code></pre></dd>
@@ -1065,23 +1065,23 @@ getContext().actorSelection(&quot;../joe&quot;);</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L631-L634" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// will look all children to serviceB with names starting with worker
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L631-L634" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// will look all children to serviceB with names starting with worker
 context.actorSelection(&quot;/user/serviceB/worker*&quot;)
 // will look up all siblings beneath same supervisor
 context.actorSelection(&quot;../*&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L339-L342" target="_blank" title="Go to snippet source">source</a><code class="language-java">// will look all children to serviceB with names starting with worker
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L339-L342" target="_blank" title="Go to snippet source">source</a><code class="language-java">// will look all children to serviceB with names starting with worker
 getContext().actorSelection(&quot;/user/serviceB/worker*&quot;);
 // will look up all siblings beneath same supervisor
 getContext().actorSelection(&quot;../*&quot;);</code></pre></dd>
 </dl>
-<p>Messages can be sent via the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSelection.html" title="org.apache.pekko.actor.ActorSelection"><code>ActorSelection</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSelection.html" title="org.apache.pekko.actor.ActorSelection"><code>ActorSelection</code></a></span> and the path of  [...]
-<p>To acquire an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span> for an <code>ActorSelection</code> you need to send a message to th [...]
+<p>Messages can be sent via the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSelection.html" title="org.apache.pekko.actor.ActorSelection"><code>ActorSelection</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSelection.html" title="org.apache.pekko.actor.ActorSelection"><code>ActorSelection</code> [...]
+<p>To acquire an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span> for an <code>ActorSelection</code> you  [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L644-L661" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.{ Actor, ActorIdentity, Identify, Props, Terminated }
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L644-L661" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.{ Actor, ActorIdentity, Identify, Props, Terminated }
 
 class Follower extends Actor {
   val identifyId = 1
@@ -1101,7 +1101,7 @@ class Follower extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L43-L45" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.ActorIdentity;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L43-L45" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.ActorIdentity;
 import org.apache.pekko.actor.ActorSelection;
 import org.apache.pekko.actor.Identify;
 static class Follower extends AbstractActor {
@@ -1140,15 +1140,15 @@ static class Follower extends AbstractActor {
   }
 }</code></pre></dd>
 </dl>
-<p>You can also acquire an <code>ActorRef</code> for an <code>ActorSelection</code> with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSelection.html#resolveOne(timeout:scala.concurrent.duration.FiniteDuration):scala.concurrent.Future[actor.ActorRef]" title="org.apache.pekko.actor.ActorSelection"><code>resolveOne</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a [...]
+<p>You can also acquire an <code>ActorRef</code> for an <code>ActorSelection</code> with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSelection.html#resolveOne(timeout:scala.concurrent.duration.FiniteDuration):scala.concurrent.Future[actor.ActorRef]" title="org.apache.pekko.actor.ActorSelection"><code>resolveOne</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0 [...]
 <p>Remote actor addresses may also be looked up, if <a href="remoting.html">remoting</a> is enabled:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L637" target="_blank" title="Go to snippet source">source</a><code class="language-scala">context.actorSelection(&quot;pekko://app@otherhost:1234/user/serviceB&quot;)</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L637" target="_blank" title="Go to snippet source">source</a><code class="language-scala">context.actorSelection(&quot;pekko://app@otherhost:1234/user/serviceB&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L346" target="_blank" title="Go to snippet source">source</a><code class="language-java">getContext().actorSelection(&quot;pekko://app@otherhost:1234/user/serviceB&quot;);</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L346" target="_blank" title="Go to snippet source">source</a><code class="language-java">getContext().actorSelection(&quot;pekko://app@otherhost:1234/user/serviceB&quot;);</code></pre></dd>
 </dl>
 <p>An example demonstrating actor look-up is given in <a href="remoting-artery.html#looking-up-remote-actors">Remoting Sample</a>.</p>
 <h2><a href="#messages-and-immutability" name="messages-and-immutability" class="anchor"><span class="anchor-link"></span></a>Messages and immutability</h2><div class="callout warning "><div class="callout-title">IMPORTANT</div>
@@ -1157,7 +1157,7 @@ static class Follower extends AbstractActor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L325-L328" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case class User(name: String)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L325-L328" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case class User(name: String)
 
 // define the case class
 case class Register(user: User)
@@ -1166,7 +1166,7 @@ val user = User(&quot;Mike&quot;)
 val message = Register(user)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ImmutableMessage.java#L21-L37" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class ImmutableMessage {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ImmutableMessage.java#L21-L37" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class ImmutableMessage {
   private final int sequenceNumber;
   private final List&lt;String&gt; values;
 
@@ -1191,18 +1191,18 @@ val message = Register(user)</code></pre></dd>
   <li><span class="group-scala"><code>?</code></span> <span class="group-java"><code>ask</code></span> sends a message asynchronously and returns a <span class="group-scala"><a href="http://www.scala-lang.org/api/2.13.8/scala/concurrent/Future.html" title="scala.concurrent.Future"><code>Future</code></a></span><span class="group-java"><a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/util/concurrent/CompletionStage.html" title="java.util.concurrent.CompletionStag [...]
 </ul>
 <p>Message ordering is guaranteed on a per-sender basis.</p><div class="callout note "><div class="callout-title">Note</div>
-<p>There are performance implications of using <code>ask</code> since something needs to keep track of when it times out, there needs to be something that bridges a <code>Promise</code> into an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/o [...]
-<p>In all these methods you have the option of passing along your own <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span>. Make it a pra [...]
+<p>There are performance implications of using <code>ask</code> since something needs to keep track of when it times out, there needs to be something that bridges a <code>Promise</code> into an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a [...]
+<p>In all these methods you have the option of passing along your own <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</cod [...]
 <a id="actors-tell-sender"></a>
 <h3><a href="#tell-fire-forget" name="tell-fire-forget" class="anchor"><span class="anchor-link"></span></a>Tell: Fire-forget</h3>
 <p>This is the preferred way of sending messages. No blocking waiting for a message. This gives the best concurrency and scalability characteristics.</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L485" target="_blank" title="Go to snippet source">source</a><code class="language-scala">actorRef ! message</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L485" target="_blank" title="Go to snippet source">source</a><code class="language-scala">actorRef ! message</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L317-L318" target="_blank" title="Go to snippet source">source</a><code class="language-java">// don’t forget to think about who is the sender (2nd argument)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L317-L318" target="_blank" title="Go to snippet source">source</a><code class="language-java">// don’t forget to think about who is the sender (2nd argument)
 target.tell(message, getSelf());</code></pre></dd>
 </dl><div class="group-scala">
 <p>If invoked from within an Actor, then the sending actor reference will be implicitly passed along with the message and available to the receiving Actor in its <code>sender(): ActorRef</code> member method. The target actor can use this to reply to the original sender, by using <code>sender() ! replyMsg</code>.</p>
@@ -1210,11 +1210,11 @@ target.tell(message, getSelf());</code></pre></dd>
 <p>The sender reference is passed along with the message and available within the receiving actor via its <a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#getSender()" title="pekko.actor.AbstractActor"><code>getSender()</code></a> method while processing this message. Inside of an actor it is usually <a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#getSelf()" title="pekko.actor.AbstractActor"><code>getSelf()</code></ [...]
 <a id="actors-ask"></a>
 <h3><a href="#ask-send-and-receive-future" name="ask-send-and-receive-future" class="anchor"><span class="anchor-link"></span></a>Ask: Send-And-Receive-Future</h3>
-<p>The <code>ask</code> pattern involves actors as well as futures, hence it is offered as a use pattern rather than a method on <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.acto [...]
+<p>The <code>ask</code> pattern involves actors as well as futures, hence it is offered as a use pattern rather than a method on <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html"  [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L692-L707" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.pattern.{ ask, pipe }
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L692-L707" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.pattern.{ ask, pipe }
 import system.dispatcher // The ExecutionContext that will be used
 final case class Result(x: Int, s: String, d: Double)
 case object Request
@@ -1232,7 +1232,7 @@ f.pipeTo(actorD) // .. or ..
 pipe(f) to actorD</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L48-L51" target="_blank" title="Go to snippet source">source</a><code class="language-java">import static org.apache.pekko.pattern.Patterns.ask;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L48-L51" target="_blank" title="Go to snippet source">source</a><code class="language-java">import static org.apache.pekko.pattern.Patterns.ask;
 import static org.apache.pekko.pattern.Patterns.pipe;
 
 import java.util.concurrent.CompletableFuture;
@@ -1252,12 +1252,12 @@ pipe(transformed, system.dispatcher()).to(actorC);</code></pre></dd>
 </dl>
 <p>This example demonstrates <code>ask</code> together with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/pattern/PipeToSupport$PipeableFuture.html#pipeTo(recipient:org.apache.pekko.actor.ActorRef)(implicitsender:org.apache.pekko.actor.ActorRef):scala.concurrent.Future[T]" title="pekko.pattern.PipeToSupport$PipeableFuture"><code>pipeTo</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/pattern/P [...]
 <p>Using <code>ask</code> will send a message to the receiving Actor as with <code>tell</code>, and the receiving actor must reply with <span class="group-scala"><code>sender() ! reply</code></span> <span class="group-java"><code>getSender().tell(reply, getSelf())</code> </span> in order to complete the returned <span class="group-scala"><code>Future</code></span><span class="group-java"><code>CompletionStage</code></span> with a value. The <code>ask</code> operation involves creating an [...]
-<p>To complete the <span class="group-scala"><a href="http://www.scala-lang.org/api/2.13.8/scala/concurrent/Future.html" title="scala.concurrent.Future"><code>Future</code></a></span><span class="group-java"><a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/util/concurrent/CompletionStage.html" title="java.util.concurrent.CompletionStage"><code>CompletionStage</code></a></span> with an exception you need to send an <span class="group-scala"><a href="https://doc.a [...]
+<p>To complete the <span class="group-scala"><a href="http://www.scala-lang.org/api/2.13.8/scala/concurrent/Future.html" title="scala.concurrent.Future"><code>Future</code></a></span><span class="group-java"><a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/util/concurrent/CompletionStage.html" title="java.util.concurrent.CompletionStage"><code>CompletionStage</code></a></span> with an exception you need to send an <span class="group-scala"><a href="https://doc.a [...]
 <p><span class="group-scala">Please note that Scala&rsquo;s <code>Try</code> sub types <a href="http://www.scala-lang.org/api/2.13.8/scala/util/Failure.html" title="scala.util.Failure"><code>scala.util.Failure</code></a> and <a href="http://www.scala-lang.org/api/2.13.8/scala/util/Success.html" title="scala.util.Success"><code>scala.util.Success</code></a> are not treated especially, and would complete the ask <span class="group-scala"><code>Future</code></span><span class="group-java">< [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L154-L161" target="_blank" title="Go to snippet source">source</a><code class="language-scala">try {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L154-L161" target="_blank" title="Go to snippet source">source</a><code class="language-scala">try {
   val result = operation()
   sender() ! result
 } catch {
@@ -1267,7 +1267,7 @@ pipe(transformed, system.dispatcher()).to(actorC);</code></pre></dd>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L359-L365" target="_blank" title="Go to snippet source">source</a><code class="language-java">try {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L359-L365" target="_blank" title="Go to snippet source">source</a><code class="language-java">try {
   String result = operation();
   getSender().tell(result, getSelf());
 } catch (Exception e) {
@@ -1279,13 +1279,13 @@ pipe(transformed, system.dispatcher()).to(actorC);</code></pre></dd>
 <ol>
   <li>
     <p>explicitly given timeout as in:</p>
-    <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L509-L511" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import scala.concurrent.duration._
+    <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L509-L511" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import scala.concurrent.duration._
 import org.apache.pekko.pattern.ask
 val future = myActor.ask(&quot;hello&quot;)(5 seconds)</code></pre>
   </li>
   <li>
     <p>implicit argument of type <code>org.apache.pekko.util.Timeout</code>, e.g.</p>
-    <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L495-L500" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import scala.concurrent.duration._
+    <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L495-L500" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import scala.concurrent.duration._
 import org.apache.pekko
 import pekko.util.Timeout
 import pekko.pattern.ask
@@ -1300,22 +1300,22 @@ val future = myActor ? &quot;hello&quot;</code></pre>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L452" target="_blank" title="Go to snippet source">source</a><code class="language-scala">target.forward(message)</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L452" target="_blank" title="Go to snippet source">source</a><code class="language-scala">target.forward(message)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L322" target="_blank" title="Go to snippet source">source</a><code class="language-java">target.forward(result, getContext());</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L322" target="_blank" title="Go to snippet source">source</a><code class="language-java">target.forward(result, getContext());</code></pre></dd>
 </dl>
 <h2><a href="#receive-messages" name="receive-messages" class="anchor"><span class="anchor-link"></span></a>Receive messages</h2>
 <p>An Actor has to <span class="group-scala">implement the <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#receive:org.apache.pekko.actor.Actor.Receive" title="pekko.actor.Actor"><code>receive</code></a> method to receive messages:</span> <span class="group-java">define its initial receive behavior by implementing the <a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#createReceive()" title="pekko.actor.AbstractActor"><code>cr [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/actor/src/main/scala/org/apache/pekko/actor/Actor.scala#L390-L533" target="_blank" title="Go to snippet source">source</a><code class="language-scala">type Receive = PartialFunction[Any, Unit]
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/actor/src/main/scala/org/apache/pekko/actor/Actor.scala#L390-L533" target="_blank" title="Go to snippet source">source</a><code class="language-scala">type Receive = PartialFunction[Any, Unit]
 
 def receive: Actor.Receive</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L101-L104" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L101-L104" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public Receive createReceive() {
   return receiveBuilder().match(String.class, s -&gt; System.out.println(s.toLowerCase())).build();
 }</code></pre></dd>
@@ -1325,7 +1325,7 @@ public Receive createReceive() {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L22-L26" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L22-L26" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.Actor
 import pekko.actor.Props
 import pekko.event.Logging
@@ -1340,7 +1340,7 @@ class MyActor extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/MyActor.java#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractActor;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/MyActor.java#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractActor;
 import org.apache.pekko.event.Logging;
 import org.apache.pekko.event.LoggingAdapter;
 
@@ -1361,7 +1361,7 @@ public class MyActor extends AbstractActor {
 }</code></pre></dd>
 </dl><div class="group-java">
 <p>In case you want to provide many <code>match</code> cases but want to avoid creating a long call trail, you can split the creation of the builder into multiple statements as in the example:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/GraduallyBuiltActor.java#L17-L21" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractActor;
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/GraduallyBuiltActor.java#L17-L21" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractActor;
 import org.apache.pekko.event.Logging;
 import org.apache.pekko.event.LoggingAdapter;
 import org.apache.pekko.japi.pf.ReceiveBuilder;
@@ -1387,7 +1387,7 @@ public class GraduallyBuiltActor extends AbstractActor {
   }
 }</code></pre>
 <p>Using small methods is a good practice, also in actors. It&rsquo;s recommended to delegate the actual work of the message processing to methods instead of defining a huge <code>ReceiveBuilder</code> with lots of code in each lambda. A well-structured actor can look like this:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L110-L138" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class WellStructuredActor extends AbstractActor {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L110-L138" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class WellStructuredActor extends AbstractActor {
 
   public static class Msg1 {}
 
@@ -1425,7 +1425,7 @@ public class GraduallyBuiltActor extends AbstractActor {
 </ul>
 <p>The <a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.Receive.html" title="pekko.actor.AbstractActor.Receive"><code>Receive</code></a> can be implemented in other ways than using the <code>ReceiveBuilder</code> since in the end, it is just a wrapper around a Scala <code>PartialFunction</code>. In Java, you can implement <code>PartialFunction</code> by extending <code>AbstractPartialFunction</code>. For example, one could implement an adapter to <a href="h [...]
 <p>If the validation of the <code>ReceiveBuilder</code> match logic turns out to be a bottleneck for some of your actors you can consider implementing it at a lower level by extending <a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/UntypedAbstractActor.html" title="pekko.actor.UntypedAbstractActor"><code>UntypedAbstractActor</code></a> instead of <a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html" title="pekko.actor.AbstractActor"><code [...]
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L143-L170" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class OptimizedActor extends UntypedAbstractActor {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L143-L170" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class OptimizedActor extends UntypedAbstractActor {
 
   public static class Msg1 {}
 
@@ -1459,20 +1459,20 @@ public class GraduallyBuiltActor extends AbstractActor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L720" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sender() ! x // replies will go to this actor</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L720" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sender() ! x // replies will go to this actor</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/MyActor.java#L36" target="_blank" title="Go to snippet source">source</a><code class="language-java">getSender().tell(s, getSelf());</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/MyActor.java#L36" target="_blank" title="Go to snippet source">source</a><code class="language-java">getSender().tell(s, getSelf());</code></pre></dd>
 </dl>
 <h2><a href="#receive-timeout" name="receive-timeout" class="anchor"><span class="anchor-link"></span></a>Receive timeout</h2>
-<p>The <span class="group-java"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/ActorContext.html#setReceiveTimeout(timeout:scala.concurrent.duration.Duration):Unit" title="pekko.actor.ActorContext"><code>ActorContext.setReceiveTimeout</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.ActorContext.html#setReceiveTimeout(java.time.Duration)" title="pekko.actor.AbstractActor.ActorContext"><code>ActorCo [...]
+<p>The <span class="group-java"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/ActorContext.html#setReceiveTimeout(timeout:scala.concurrent.duration.Duration):Unit" title="pekko.actor.ActorContext"><code>ActorContext.setReceiveTimeout</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.ActorContext.html#setReceiveTimeout(java.time.Duration)" title="pekko.actor.AbstractActor.ActorContext"><code>ActorCo [...]
 <p>Please note that the receive timeout might fire and enqueue the <code>ReceiveTimeout</code> message right after another message was enqueued; hence it is <strong>not guaranteed</strong> that upon reception of the receive timeout there must have been an idle period beforehand as configured via this method.</p>
 <p>Once set, the receive timeout stays in effect (i.e. continues firing repeatedly after inactivity periods).</p>
 <p>To cancel the sending of receive timeout notifications, use <code>cancelReceiveTimeout</code>.</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L518-L532" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.ReceiveTimeout
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L518-L532" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.ReceiveTimeout
 import scala.concurrent.duration._
 class MyActor extends Actor {
   // To set an initial delay
@@ -1489,7 +1489,7 @@ class MyActor extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L549-L582" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class ReceiveTimeoutActor extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L549-L582" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class ReceiveTimeoutActor extends AbstractActor {
   public ReceiveTimeoutActor() {
     // To set an initial delay
     getContext().setReceiveTimeout(Duration.ofSeconds(10));
@@ -1514,14 +1514,14 @@ class MyActor extends Actor {
   }
 }</code></pre></dd>
 </dl>
-<p>Messages marked with <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/NotInfluenceReceiveTimeout.html" title="org.apache.pekko.actor.NotInfluenceReceiveTimeout"><code>NotInfluenceReceiveTimeout</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/NotInfluenceReceiveTimeout.html" title="org.apache.pekko.actor.NotInfluenceReceiveTimeout"><co [...]
+<p>Messages marked with <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/NotInfluenceReceiveTimeout.html" title="org.apache.pekko.actor.NotInfluenceReceiveTimeout"><code>NotInfluenceReceiveTimeout</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/NotInfluenceReceiveTimeout.html" title="org.apache.pekko.actor.Not [...]
 <a id="actors-timers"></a>
 <h2><a href="#timers-scheduled-messages" name="timers-scheduled-messages" class="anchor"><span class="anchor-link"></span></a>Timers, scheduled messages</h2>
 <p>Messages can be scheduled to be sent at a later point by using the <a href="scheduler.html">Scheduler</a> directly, but when scheduling periodic or single messages in an actor to itself it&rsquo;s more convenient and safe to use the support for named timers. The lifecycle of scheduled messages can be difficult to manage when the actor is restarted and that is taken care of by the timers.</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/TimerDocSpec.scala#L18-L41" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import scala.concurrent.duration._
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/TimerDocSpec.scala#L18-L41" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import scala.concurrent.duration._
 
 import org.apache.pekko
 import pekko.actor.Actor
@@ -1547,7 +1547,7 @@ class MyActor extends Actor with Timers {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/TimerDocTest.java#L17-L54" target="_blank" title="Go to snippet source">source</a><code class="language-java">import java.time.Duration;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/TimerDocTest.java#L17-L54" target="_blank" title="Go to snippet source">source</a><code class="language-java">import java.time.Duration;
 import org.apache.pekko.actor.AbstractActorWithTimers;
 
 static class MyActor extends AbstractActorWithTimers {
@@ -1580,15 +1580,15 @@ static class MyActor extends AbstractActorWithTimers {
   }
 }</code></pre></dd>
 </dl>
-<p>The <a href="scheduler.html#schedule-periodically">Scheduler</a> documentation describes the difference between <code>fixed-delay</code> and <code>fixed-rate</code> scheduling. If you are uncertain of which one to use you should pick <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/TimerScheduler.html#startTimerWithFixedDelay(key:Any,msg:Any,initialDelay:scala.concurrent.duration.FiniteDuration,delay:scala.concurrent. [...]
+<p>The <a href="scheduler.html#schedule-periodically">Scheduler</a> documentation describes the difference between <code>fixed-delay</code> and <code>fixed-rate</code> scheduling. If you are uncertain of which one to use you should pick <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/TimerScheduler.html#startTimerWithFixedDelay(key:Any,msg:Any,initialDelay:scala.concurrent.duration.FiniteDuration,delay:sca [...]
 <p>Each timer has a key and can be replaced or cancelled. It&rsquo;s guaranteed that a message from the previous incarnation of the timer with the same key is not received, even though it might already be enqueued in the mailbox when it was cancelled or the new timer was started.</p>
-<p>The timers are bound to the lifecycle of the actor that owns it and thus are cancelled automatically when it is restarted or stopped. Note that the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/TimerScheduler.html" title="org.apache.pekko.actor.TimerScheduler"><code>TimerScheduler</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Tim [...]
+<p>The timers are bound to the lifecycle of the actor that owns it and thus are cancelled automatically when it is restarted or stopped. Note that the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/TimerScheduler.html" title="org.apache.pekko.actor.TimerScheduler"><code>TimerScheduler</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHO [...]
 <h2><a href="#stopping-actors" name="stopping-actors" class="anchor"><span class="anchor-link"></span></a>Stopping actors</h2>
-<p>Actors are stopped by invoking the <code>stop</code> method of a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRefFactory.html" title="org.apache.pekko.actor.ActorRefFactory"><code>ActorRefFactory</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRefFactory.html" title="org.apache.pekko.actor.ActorRefFactory"><code>ActorRef [...]
+<p>Actors are stopped by invoking the <code>stop</code> method of a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRefFactory.html" title="org.apache.pekko.actor.ActorRefFactory"><code>ActorRefFactory</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRefFactory.html" title="org.apache.pekko.actor.Act [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L171-L184" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class MyActor extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L171-L184" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class MyActor extends Actor {
 
   val child: ActorRef = ???
 
@@ -1604,7 +1604,7 @@ static class MyActor extends AbstractActorWithTimers {
 </code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/MyStoppingActor.java#L17-L33" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.ActorRef;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/MyStoppingActor.java#L17-L33" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.ActorRef;
 import org.apache.pekko.actor.AbstractActor;
 
 public class MyStoppingActor extends AbstractActor {
@@ -1622,19 +1622,19 @@ public class MyStoppingActor extends AbstractActor {
   }
 }</code></pre></dd>
 </dl>
-<p>Processing of the current message, if any, will continue before the actor is stopped, but additional messages in the mailbox will not be processed. By default, these messages are sent to the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html#deadLetters:org.apache.pekko.actor.ActorRef" title="org.apache.pekko.actor.ActorSystem"><code>deadLetters</code></a></span><span class="group-java"><a href="https:/ [...]
-<p>Termination of an actor proceeds in two steps: first the actor suspends its mailbox processing and sends a stop command to all its children, then it keeps processing the internal termination notifications from its children until the last one is gone, finally terminating itself (invoking <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#postStop():Unit" title="pekko.actor.Actor"><code>postStop</code></a></span><span class="group-java" [...]
-<p>Upon <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html#terminate():scala.concurrent.Future[actor.Terminated]" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem.terminate()</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html#terminate()" title="org.apache.pekko.actor.ActorSystem"><code>ActorSyste [...]
+<p>Processing of the current message, if any, will continue before the actor is stopped, but additional messages in the mailbox will not be processed. By default, these messages are sent to the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html#deadLetters:org.apache.pekko.actor.ActorRef" title="org.apache.pekko.actor.ActorSystem"><code>deadLetters</code></a></span><span class="group-java"><a [...]
+<p>Termination of an actor proceeds in two steps: first the actor suspends its mailbox processing and sends a stop command to all its children, then it keeps processing the internal termination notifications from its children until the last one is gone, finally terminating itself (invoking <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#postStop():Unit" title="pekko.actor.Actor"><code>postStop</code></a></span><span class="group-java" [...]
+<p>Upon <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html#terminate():scala.concurrent.Future[actor.Terminated]" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem.terminate()</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html#terminate()" title="org.apache.pekko.actor.A [...]
 <p>The <code>postStop()</code> hook is invoked after an actor is fully stopped. This enables cleaning up of resources:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L142-L146" target="_blank" title="Go to snippet source">source</a><code class="language-scala">override def postStop(): Unit = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L142-L146" target="_blank" title="Go to snippet source">source</a><code class="language-scala">override def postStop(): Unit = {
   ()
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L312-L326" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L312-L326" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public void postStop() {
   final String message = &quot;stopped&quot;;
   // don’t forget to think about who is the sender (2nd argument)
@@ -1644,27 +1644,27 @@ public void postStop() {
   target = null;
 }</code></pre></dd>
 </dl><div class="callout note "><div class="callout-title">Note</div>
-<p>Since stopping an actor is asynchronous, you cannot immediately reuse the name of the child you just stopped; this will result in an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/InvalidActorNameException.html" title="org.apache.pekko.actor.InvalidActorNameException"><code>InvalidActorNameException</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apac [...]
+<p>Since stopping an actor is asynchronous, you cannot immediately reuse the name of the child you just stopped; this will result in an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/InvalidActorNameException.html" title="org.apache.pekko.actor.InvalidActorNameException"><code>InvalidActorNameException</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+202 [...]
 <a id="poison-pill"></a>
 <h3><a href="#poisonpill" name="poisonpill" class="anchor"><span class="anchor-link"></span></a>PoisonPill</h3>
-<p>You can also send an actor the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/PoisonPill.html" title="org.apache.pekko.actor.PoisonPill"><code>PoisonPill</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/PoisonPill.html" title="org.apache.pekko.actor.PoisonPill"><code>PoisonPill</code></a></span> message, which will stop the actor whe [...]
+<p>You can also send an actor the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/PoisonPill.html" title="org.apache.pekko.actor.PoisonPill"><code>PoisonPill</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/PoisonPill.html" title="org.apache.pekko.actor.PoisonPill"><code>PoisonPill</code></a></span> message, w [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L412-L413" target="_blank" title="Go to snippet source">source</a><code class="language-scala">watch(victim)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L412-L413" target="_blank" title="Go to snippet source">source</a><code class="language-scala">watch(victim)
 victim ! PoisonPill</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L887" target="_blank" title="Go to snippet source">source</a><code class="language-java">victim.tell(org.apache.pekko.actor.PoisonPill.getInstance(), ActorRef.noSender());</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L887" target="_blank" title="Go to snippet source">source</a><code class="language-java">victim.tell(org.apache.pekko.actor.PoisonPill.getInstance(), ActorRef.noSender());</code></pre></dd>
 </dl>
 <a id="killing-actors"></a>
 <h3><a href="#killing-an-actor" name="killing-an-actor" class="anchor"><span class="anchor-link"></span></a>Killing an Actor</h3>
-<p>You can also &ldquo;kill&rdquo; an actor by sending a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Kill.html" title="org.apache.pekko.actor.Kill"><code>Kill</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Kill.html" title="org.apache.pekko.actor.Kill"><code>Kill</code></a></span> message. Unlike <code>PoisonPill</code> this will c [...]
+<p>You can also &ldquo;kill&rdquo; an actor by sending a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Kill.html" title="org.apache.pekko.actor.Kill"><code>Kill</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Kill.html" title="org.apache.pekko.actor.Kill"><code>Kill</code></a></span> message. Unlike <code>P [...]
 <p>Use <code>Kill</code> like this:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L612-L618" target="_blank" title="Go to snippet source">source</a><code class="language-scala">context.watch(victim) // watch the Actor to receive Terminated message once it dies
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L612-L618" target="_blank" title="Go to snippet source">source</a><code class="language-scala">context.watch(victim) // watch the Actor to receive Terminated message once it dies
 
 victim ! Kill
 
@@ -1673,7 +1673,7 @@ expectMsgPF(hint = &quot;expecting victim to terminate&quot;) {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L871-L874" target="_blank" title="Go to snippet source">source</a><code class="language-java">victim.tell(org.apache.pekko.actor.Kill.getInstance(), ActorRef.noSender());
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L871-L874" target="_blank" title="Go to snippet source">source</a><code class="language-java">victim.tell(org.apache.pekko.actor.Kill.getInstance(), ActorRef.noSender());
 
 // expecting the actor to indeed terminate:
 expectTerminated(Duration.ofSeconds(3), victim);</code></pre></dd>
@@ -1684,7 +1684,7 @@ expectTerminated(Duration.ofSeconds(3), victim);</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L675-L685" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.pattern.gracefulStop
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L675-L685" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.pattern.gracefulStop
 import scala.concurrent.Await
 
 try {
@@ -1697,7 +1697,7 @@ try {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L54-L57" target="_blank" title="Go to snippet source">source</a><code class="language-java">import static org.apache.pekko.pattern.Patterns.gracefulStop;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L54-L57" target="_blank" title="Go to snippet source">source</a><code class="language-java">import static org.apache.pekko.pattern.Patterns.gracefulStop;
 import org.apache.pekko.pattern.AskTimeoutException;
 import java.util.concurrent.CompletionStage;
 
@@ -1712,17 +1712,17 @@ try {
 </dl>
 <p>When <code>gracefulStop()</code> returns successfully, the actor’s <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#postStop():Unit" title="pekko.actor.Actor"><code>postStop</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActor.html#postStop()" title="pekko.actor.AbstractActor"><code>postStop</code></a></span> hook will have been executed: there exists a happens-bef [...]
 <p>In the above example, a custom <code>Manager.Shutdown</code> message is sent to the target actor to initiate the process of stopping the actor. You can use <code>PoisonPill</code> for this, but then you have limited possibilities to perform interactions with other actors before stopping the target actor. Simple cleanup tasks can be handled in <code>postStop</code>.</p><div class="callout warning "><div class="callout-title">Warning</div>
-<p>Keep in mind that an actor stopping and its name being deregistered are separate events that happen asynchronously from each other. Therefore it may be that you will find the name still in use after <code>gracefulStop()</code> returned. To guarantee proper deregistration, only reuse names from within a supervisor you control and only in response to a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Terminated.html" ti [...]
+<p>Keep in mind that an actor stopping and its name being deregistered are separate events that happen asynchronously from each other. Therefore it may be that you will find the name still in use after <code>gracefulStop()</code> returned. To guarantee proper deregistration, only reuse names from within a supervisor you control and only in response to a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Termi [...]
 <a id="actor-hotswap"></a>
 <h2><a href="#become-unbecome" name="become-unbecome" class="anchor"><span class="anchor-link"></span></a>Become/Unbecome</h2>
 <h3><a href="#upgrade" name="upgrade" class="anchor"><span class="anchor-link"></span></a>Upgrade</h3>
-<p>Pekko supports hotswapping the Actor’s message loop (e.g. its implementation) at runtime: invoke the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorContext.html#become(behavior:org.apache.pekko.actor.Actor.Receive,discardOld:Boolean):Unit" title="org.apache.pekko.actor.ActorContext"><code>context.become</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT [...]
+<p>Pekko supports hotswapping the Actor’s message loop (e.g. its implementation) at runtime: invoke the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorContext.html#become(behavior:org.apache.pekko.actor.Actor.Receive,discardOld:Boolean):Unit" title="org.apache.pekko.actor.ActorContext"><code>context.become</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec6 [...]
 <p>Please note that the actor will revert to its original behavior when restarted by its Supervisor.</p></div>
 <p>To hotswap the Actor behavior using <code>become</code>:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L537-L553" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class HotSwapActor extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L537-L553" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class HotSwapActor extends Actor {
   import context._
   def angry: Receive = {
     case &quot;foo&quot; =&gt; sender() ! &quot;I am already angry?&quot;
@@ -1741,7 +1741,7 @@ try {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L639-L680" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class HotSwapActor extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L639-L680" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class HotSwapActor extends AbstractActor {
   private AbstractActor.Receive angry;
   private AbstractActor.Receive happy;
 
@@ -1784,12 +1784,12 @@ try {
   }
 }</code></pre></dd>
 </dl>
-<p>This variant of the <code>become</code> method is useful for many different things, such as to implement a Finite State Machine (FSM). It will replace the current behavior (i.e. the top of the behavior stack), which means that you do not use <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorContext.html#unbecome():Unit" title="org.apache.pekko.actor.ActorContext"><code>unbecome</code></a></span><span class="group- [...]
+<p>This variant of the <code>become</code> method is useful for many different things, such as to implement a Finite State Machine (FSM). It will replace the current behavior (i.e. the top of the behavior stack), which means that you do not use <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorContext.html#unbecome():Unit" title="org.apache.pekko.actor.ActorContext"><code>unbecome</code></a></span><span [...]
 <p>The other way of using <code>become</code> does not replace but add to the top of the behavior stack. In this case, care must be taken to ensure that the number of “pop” operations (i.e. <code>unbecome</code>) matches the number of “push” ones in the long run, otherwise this amounts to a memory leak (which is why this behavior is not the default).</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L219-L244" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case object Swap
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L219-L244" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case object Swap
 class Swapper extends Actor {
   import context._
   val log = Logging(system, this)
@@ -1817,7 +1817,7 @@ object SwapperApp extends App {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L439-L479" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Swapper extends AbstractLoggingActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L439-L479" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Swapper extends AbstractLoggingActor {
   @Override
   public Receive createReceive() {
     return receiveBuilder()
@@ -1857,16 +1857,16 @@ static class SwapperApp {
 }</code></pre></dd>
 </dl>
 <h3><a href="#encoding-scala-actors-nested-receives-without-accidentally-leaking-memory" name="encoding-scala-actors-nested-receives-without-accidentally-leaking-memory" class="anchor"><span class="anchor-link"></span></a>Encoding Scala Actors nested receives without accidentally leaking memory</h3>
-<p>See this <a href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/UnnestedReceives.scala">Unnested receive example</a>.</p>
+<p>See this <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/UnnestedReceives.scala">Unnested receive example</a>.</p>
 <h2><a href="#stash" name="stash" class="anchor"><span class="anchor-link"></span></a>Stash</h2>
 <p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Stash.html" title="pekko.actor.Stash"><code>Stash</code></a> trait</span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActorWithStash.html" title="pekko.actor.AbstractActorWithStash"><code>AbstractActorWithStash</code></a> class</span> enables an actor to temporarily stash away messages that can not or should not be handled using the acto [...]
-<p>The trait <code>Stash</code> extends the marker trait <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/dispatch/RequiresMessageQueue.html" title="pekko.dispatch.RequiresMessageQueue"><code>RequiresMessageQueue</code></a>[<a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/dispatch/DequeBasedMessageQueueSemantics.html" title="org.apache.pekko.dispatch.DequeBasedMessageQueueSemantics"><code>DequeBasedMessageQueueSemantics</code></a>] which requ [...]
+<p>The trait <code>Stash</code> extends the marker trait <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/dispatch/RequiresMessageQueue.html" title="pekko.dispatch.RequiresMessageQueue"><code>RequiresMessageQueue</code></a>[<a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/dispatch/DequeBasedMessageQueueSemantics.html" title="org.apache.pekko.dispatch.DequeBasedMessageQueueSemantics"><code>DequeBasedMessageQueueSemantics</code></ [...]
 <p>The abstract class <a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActorWithStash.html" title="pekko.actor.AbstractActorWithStash"><code>AbstractActorWithStash</code></a> implements the marker interface <a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/dispatch/RequiresMessageQueue.html" title="pekko.dispatch.RequiresMessageQueue"><code>RequiresMessageQueue</code></a>&lt;<a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/dispatch/DequeBased [...]
 <p>Here is an example of the <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Stash.html" title="pekko.actor.Stash"><code>Stash</code></a> trait</span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActorWithStash.html" title="pekko.actor.AbstractActorWithStash"><code>AbstractActorWithStash</code></a> class</span> in action:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L562-L576" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Stash
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L562-L576" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Stash
 class ActorWithProtocol extends Actor with Stash {
   def receive = {
     case &quot;open&quot; =&gt;
@@ -1883,7 +1883,7 @@ class ActorWithProtocol extends Actor with Stash {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L704-L732" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class ActorWithProtocol extends AbstractActorWithStash {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L704-L732" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class ActorWithProtocol extends AbstractActorWithStash {
   @Override
   public Receive createReceive() {
     return receiveBuilder()
@@ -1913,10 +1913,10 @@ class ActorWithProtocol extends Actor with Stash {
   }
 }</code></pre></dd>
 </dl>
-<p>Invoking <code>stash()</code> adds the current message (the message that the actor received last) to the actor&rsquo;s stash. It is typically invoked when handling the default case in the actor&rsquo;s message handler to stash messages that aren&rsquo;t handled by the other cases. It is illegal to stash the same message twice; to do so results in an <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/IllegalStateException.html" title="java.lang.IllegalState [...]
+<p>Invoking <code>stash()</code> adds the current message (the message that the actor received last) to the actor&rsquo;s stash. It is typically invoked when handling the default case in the actor&rsquo;s message handler to stash messages that aren&rsquo;t handled by the other cases. It is illegal to stash the same message twice; to do so results in an <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/IllegalStateException.html" title="java.lang.IllegalState [...]
 <p>Invoking <code>unstashAll()</code> enqueues messages from the stash to the actor&rsquo;s mailbox until the capacity of the mailbox (if any) has been reached (note that messages from the stash are prepended to the mailbox). In case a bounded mailbox overflows, a <code>MessageQueueAppendFailedException</code> is thrown. The stash is guaranteed to be empty after calling <code>unstashAll()</code>.</p>
 <p>The stash is backed by a <a href="http://www.scala-lang.org/api/2.13.8/scala/collection/immutable/Vector.html" title="scala.collection.immutable.Vector"><code>scala.collection.immutable.Vector</code></a>. As a result, even a very large number of messages may be stashed without a major impact on performance.</p><div class="callout warning group-scala"><div class="callout-title">Warning</div>
-<p>Note that the <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Stash.html" title="pekko.actor.Stash"><code>Stash</code></a> trait must be mixed into (a subclass of) the <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html" title="pekko.actor.Actor"><code>Actor</code></a> trait before any trait/class that overrides the <a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html#preRestart(reason:Throwable, [...]
+<p>Note that the <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Stash.html" title="pekko.actor.Stash"><code>Stash</code></a> trait must be mixed into (a subclass of) the <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html" title="pekko.actor.Actor"><code>Actor</code></a> trait before any trait/class that overrides the <a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html#preRestart(rea [...]
 <p>Note that the stash is part of the ephemeral actor state, unlike the mailbox. Therefore, it should be managed like other parts of the actor&rsquo;s state which have the same property.</p>
 <p>However, the <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Stash.html" title="pekko.actor.Stash"><code>Stash</code></a> trait</span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/AbstractActorWithStash.html" title="pekko.actor.AbstractActorWithStash"><code>AbstractActorWithStash</code></a> class</span> implementation of <code>preRestart</code> will call <code>unstashAll()</code>. This means that  [...]
 <p>The result of this is that when an actor is restarted, any stashed messages will be delivered to the new incarnation of the actor. This is usually the desired behavior.</p><div class="callout note "><div class="callout-title">Note</div>
@@ -1924,7 +1924,7 @@ class ActorWithProtocol extends Actor with Stash {
 <h2><a href="#extending-actors-using-partialfunction-chaining" name="extending-actors-using-partialfunction-chaining" class="anchor"><span class="anchor-link"></span></a>Extending Actors using PartialFunction chaining</h2>
 <p>Sometimes it can be useful to share common behavior among a few actors, or compose one actor&rsquo;s behavior from multiple smaller functions. This is possible because an actor&rsquo;s <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#receive:org.apache.pekko.actor.Actor.Receive" title="pekko.actor.Actor"><code>receive</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/Abstract [...]
 <p>For example, imagine you have a set of actors which are either <code>Producers</code> or <code>Consumers</code>, yet sometimes it makes sense to have an actor share both behaviors. This can be achieved without having to duplicate code by extracting the behaviors to traits and implementing the actor&rsquo;s <code>receive</code> as a combination of these partial functions.</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L248-L286" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>trait ProducerBehavior {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L248-L286" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>trait ProducerBehavior {
   this: Actor =&gt;
 
   val producerBehavior: Receive = {
@@ -1964,7 +1964,7 @@ final case class Give(thing: Any)
 </code></pre>
 <p>Instead of inheritance the same pattern can be applied via composition - compose the receive method using partial functions from delegates.</p></div>
 <h2><a href="#initialization-patterns" name="initialization-patterns" class="anchor"><span class="anchor-link"></span></a>Initialization patterns</h2>
-<p>The rich lifecycle hooks of Actors provide a useful toolkit to implement various initialization patterns. During the lifetime of an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekk [...]
+<p>The rich lifecycle hooks of Actors provide a useful toolkit to implement various initialization patterns. During the lifetime of an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef. [...]
 <p>Initialization might be necessary every time an actor is instantiated, but sometimes one needs initialization to happen only at the birth of the first instance when the <code>ActorRef</code> is created. The following sections provide patterns for different initialization needs.</p>
 <h3><a href="#initialization-via-constructor" name="initialization-via-constructor" class="anchor"><span class="anchor-link"></span></a>Initialization via constructor</h3>
 <p>Using the constructor for initialization has various benefits. First of all, it makes it possible to use <code>val</code> fields to store any state that does not change during the life of the actor instance, making the implementation of the actor more robust. The constructor is invoked when an actor instance is created calling <code>actorOf</code> and also on restart, therefore the internals of the actor can always assume that proper initialization happened. This is also the drawback  [...]
@@ -1974,7 +1974,7 @@ final case class Give(thing: Any)
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/InitializationDocSpec.scala#L27-L41" target="_blank" title="Go to snippet source">source</a><code class="language-scala">override def preStart(): Unit = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/InitializationDocSpec.scala#L27-L41" target="_blank" title="Go to snippet source">source</a><code class="language-scala">override def preStart(): Unit = {
   // Initialize children here
 }
 
@@ -1991,7 +1991,7 @@ override def preRestart(reason: Throwable, message: Option[Any]): Unit = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/InitializationDocTest.java#L52-L69" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/InitializationDocTest.java#L52-L69" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public void preStart() {
   // Initialize children here
 }
@@ -2010,14 +2010,14 @@ public void preRestart(Throwable reason, Optional&lt;Object&gt; message) throws
   postStop();
 }</code></pre></dd>
 </dl>
-<p>Please note, that the child actors are <em>still restarted</em>, but no new <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span> is cr [...]
+<p>Please note, that the child actors are <em>still restarted</em>, but no new <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>Acto [...]
 <p>For more information see <a href="general/supervision.html#supervision-restart">What Restarting Means</a>.</p>
 <h3><a href="#initialization-via-message-passing" name="initialization-via-message-passing" class="anchor"><span class="anchor-link"></span></a>Initialization via message passing</h3>
-<p>There are cases when it is impossible to pass all the information needed for actor initialization in the constructor, for example in the presence of circular dependencies. In this case, the actor should listen for an initialization message, and use <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorContext.html#become(behavior:org.apache.pekko.actor.Actor.Receive,discardOld:Boolean):Unit" title="org.apache.pekko.ac [...]
+<p>There are cases when it is impossible to pass all the information needed for actor initialization in the constructor, for example in the presence of circular dependencies. In this case, the actor should listen for an initialization message, and use <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorContext.html#become(behavior:org.apache.pekko.actor.Actor.Receive,discardOld:Boolean):Unit" title="org.a [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/InitializationDocSpec.scala#L47-L58" target="_blank" title="Go to snippet source">source</a><code class="language-scala">var initializeMe: Option[String] = None
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/InitializationDocSpec.scala#L47-L58" target="_blank" title="Go to snippet source">source</a><code class="language-scala">var initializeMe: Option[String] = None
 
 override def receive = {
   case &quot;init&quot; =&gt;
@@ -2031,7 +2031,7 @@ def initialized: Receive = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/InitializationDocTest.java#L78-L96" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/InitializationDocTest.java#L78-L96" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public Receive createReceive() {
   return receiveBuilder()
       .matchEquals(
@@ -2052,9 +2052,9 @@ public Receive createReceive() {
 }</code></pre></dd>
 </dl>
 <p>If the actor may receive messages before it has been initialized, a useful tool can be the <code>Stash</code> to save messages until the initialization finishes, and replaying them after the actor became initialized.</p><div class="callout warning "><div class="callout-title">Warning</div>
-<p>This pattern should be used with care, and applied only when none of the patterns above are applicable. One of the potential issues is that messages might be lost when sent to remote actors. Also, publishing an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533 [...]
+<p>This pattern should be used with care, and applied only when none of the patterns above are applicable. One of the potential issues is that messages might be lost when sent to remote actors. Also, publishing an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/ak [...]
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/actors.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/actors.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -2152,7 +2152,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/additional/books.html b/content/additional/books.html
index aa32751..9725cdc 100644
--- a/content/additional/books.html
+++ b/content/additional/books.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -445,7 +445,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h2><a href="#blogs" name="blogs" class="anchor"><span class="anchor-link"></span></a>Blogs</h2>
 <p>A list of <a href="https://akka.io/blog/external-archive.html">blogs and presentations</a> curated by the Akka team.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/additional/books.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/additional/books.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -530,7 +530,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/additional/deploy.html b/content/additional/deploy.html
index 7dcc46a..87a813a 100644
--- a/content/additional/deploy.html
+++ b/content/additional/deploy.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -447,7 +447,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul>
 </div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/additional/deploy.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/additional/deploy.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -517,7 +517,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/additional/deploying.html b/content/additional/deploying.html
index 643cb37..658b865 100644
--- a/content/additional/deploying.html
+++ b/content/additional/deploying.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -436,7 +436,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>For multi-threaded applications such as the JVM, the CFS scheduler limits are an ill fit, because they will restrict the allowed CPU usage even when more CPU cycles are available from the host system. This means your application may be starved of CPU time, but your system appears idle.</p>
 <p>For this reason, it is best to avoid <code>--cpus</code> and <code>--cpu-quota</code> entirely, and instead specify relative container weights using <code>--cpu-shares</code> instead.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/additional/deploying.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/additional/deploying.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -520,7 +520,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/additional/faq.html b/content/additional/faq.html
index 7978f31..d87e4af 100644
--- a/content/additional/faq.html
+++ b/content/additional/faq.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -440,7 +440,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </code></pre>
 <p>Read more about it in the docs for <a href="../typed/logging.html">Logging</a>.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/additional/faq.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/additional/faq.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -527,7 +527,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/additional/ide.html b/content/additional/ide.html
index b5ab28b..704f129 100644
--- a/content/additional/ide.html
+++ b/content/additional/ide.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -423,7 +423,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p><img src="../images/idetip-auto-importer-solution.png" alt="idetip-auto-importer-solution.png" /></p>
 <p>Eclipse users can configure this aspect of the IDE by going to &ldquo;Window&rdquo; / &ldquo;Preferences&rdquo; / &ldquo;Java&rdquo; / &ldquo;Appearance&rdquo; / &ldquo;Type Filters&rdquo;. </p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/additional/ide.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/additional/ide.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -506,7 +506,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/additional/operations.html b/content/additional/operations.html
index b27e6c0..3d538d0 100644
--- a/content/additional/operations.html
+++ b/content/additional/operations.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -444,7 +444,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul>
 <p>Member nodes are identified by their address, in format <em><code>pekko://actor-system-name@hostname:port</code></em>.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/additional/operations.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/additional/operations.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -529,7 +529,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/additional/osgi.html b/content/additional/osgi.html
index dc7778a..8545f97 100644
--- a/content/additional/osgi.html
+++ b/content/additional/osgi.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -418,7 +418,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#pekko-in-osgi" name="pekko-in-osgi" class="anchor"><span class="anchor-link"></span></a>Pekko in OSGi</h1>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use Pekko in OSGi, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Pekko in OSGi, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-osgi" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -427,7 +427,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-osgi" % PekkoVersion</code><
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -442,7 +442,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-osgi" % PekkoVersion</code><
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-osgi_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -476,8 +476,8 @@ dependencies {
 <h2><a href="#intended-use" name="intended-use" class="anchor"><span class="anchor-link"></span></a>Intended Use</h2>
 <p>Pekko only supports the usage of an ActorSystem strictly confined to a single OSGi bundle, where that bundle contains or imports all of the actor system&rsquo;s requirements. This means that the approach of offering an ActorSystem as a service to which Actors can be deployed dynamically via other bundles is not recommended — an ActorSystem and its contained actors are not meant to be dynamic in this way. ActorRefs may safely be exposed to other bundles.</p>
 <h2><a href="#activator" name="activator" class="anchor"><span class="anchor-link"></span></a>Activator</h2>
-<p>To bootstrap Pekko inside an OSGi environment, you can use the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/osgi/ActorSystemActivator.html" title="org.apache.pekko.osgi.ActorSystemActivator"><code>osgi.ActorSystemActivator</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/osgi/ActorSystemActivator.html" title="org.apache.pekko.osgi.ActorSystemA [...]
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/osgi/src/test/scala/docs/osgi/Activator.scala#L25-L40" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+<p>To bootstrap Pekko inside an OSGi environment, you can use the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/osgi/ActorSystemActivator.html" title="org.apache.pekko.osgi.ActorSystemActivator"><code>osgi.ActorSystemActivator</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/osgi/ActorSystemActivator.html" title="org.ap [...]
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/osgi/src/test/scala/docs/osgi/Activator.scala#L25-L40" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.{ ActorSystem, Props }
 import org.osgi.framework.BundleContext
 import pekko.osgi.ActorSystemActivator
@@ -493,9 +493,9 @@ class Activator extends ActorSystemActivator {
   }
 
 }</code></pre>
-<p>The goal here is to map the OSGi lifecycle more directly to the Pekko lifecycle. The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/osgi/ActorSystemActivator.html" title="org.apache.pekko.osgi.ActorSystemActivator"><code>ActorSystemActivator</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/osgi/ActorSystemActivator.html" title="org.apache.pekko. [...]
+<p>The goal here is to map the OSGi lifecycle more directly to the Pekko lifecycle. The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/osgi/ActorSystemActivator.html" title="org.apache.pekko.osgi.ActorSystemActivator"><code>ActorSystemActivator</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/osgi/ActorSystemActivator.ht [...]
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/additional/osgi.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/additional/osgi.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -584,7 +584,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/additional/packaging.html b/content/additional/packaging.html
index 4441158..0795141 100644
--- a/content/additional/packaging.html
+++ b/content/additional/packaging.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -501,7 +501,7 @@ shadowJar {
 }
 </code></pre>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/additional/packaging.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/additional/packaging.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -586,7 +586,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/additional/rolling-updates.html b/content/additional/rolling-updates.html
index 719abc8..f549785 100644
--- a/content/additional/rolling-updates.html
+++ b/content/additional/rolling-updates.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -435,7 +435,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>To make use of this feature you need to define the <code>app-version</code> and increase it for each rolling update.</p>
 <pre><code>pekko.cluster.app-version = 1.2.3
 </code></pre>
-<p>To understand which is old and new it compares the version numbers using normal conventions, see <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/util/Version.html" title="org.apache.pekko.util.Version"><code>Version</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/util/Version.html" title="org.apache.pekko.util.Version"><code>Version</code></a></ [...]
+<p>To understand which is old and new it compares the version numbers using normal conventions, see <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/util/Version.html" title="org.apache.pekko.util.Version"><code>Version</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/util/Version.html" title="org.apache.pekko.util.Version [...]
 <p>Rebalance is also disabled during rolling updates, since shards from stopped nodes are anyway supposed to be started on new nodes. Messages to shards that were stopped on the old nodes will allocate corresponding shards on the new nodes, without waiting for rebalance actions. </p>
 <p>You should also enable the <a href="../typed/cluster-sharding.html#health-check">health check for Cluster Sharding</a> if you use Pekko Management. The readiness check will delay incoming traffic to the node until Sharding has been initialized and can accept messages.</p>
 <p>The <code>ShardCoordinator</code> is itself a cluster singleton. To minimize downtime of the shard coordinator, see the strategies about <a href="rolling-updates.html#cluster-singleton">ClusterSingleton</a> rolling updates below.</p>
@@ -478,7 +478,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h3><a href="#migrating-from-classic-sharding-to-typed-sharding" name="migrating-from-classic-sharding-to-typed-sharding" class="anchor"><span class="anchor-link"></span></a>Migrating from Classic Sharding to Typed Sharding</h3>
 <p>If you have been using classic sharding it is possible to do a rolling update to typed sharding using a 3 step procedure. The steps along with example commits are detailed in <a href="https://github.com/akka/akka-samples/pull/110">this sample PR</a> </p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/additional/rolling-updates.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/additional/rolling-updates.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -566,7 +566,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/cluster-client.html b/content/cluster-client.html
index a230c39..ec0e836 100644
--- a/content/cluster-client.html
+++ b/content/cluster-client.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>Cluster Client is deprecated in favor of using <a href="https://doc.akka.io/docs/akka-grpc/current/index.html">Pekko gRPC</a>. It is not advised to build new applications with Cluster Client, and existing users <a href="cluster-client.html#migration-to-pekko-grpc">should migrate</a>.</p></div><div class="callout note "><div class="callout-title">Note</div>
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2>
-<p>To use Cluster Client, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Cluster Client, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-cluster-tools" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -430,7 +430,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster-tools" % PekkoVersio
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -445,7 +445,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster-tools" % PekkoVersio
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-cluster-tools_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -453,7 +453,7 @@ dependencies {
 <tr><th colspan="2">Project Info: Pekko Cluster Tools (classic)</th></tr>
   <tr><th>Artifact</th><td><div>org.apache.pekko</div>
   <div>pekko-cluster-tools</div>
-  <div>0.0.0+26533-ec68a528-SNAPSHOT</div>
+  <div>0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT</div>
   <div><a href="project/links.html#snapshots-repository">Snapshots are available</a></div>
   </td></tr>
   <tr><th>JDK versions</th><td><div>Adopt OpenJDK 8</div><div>Adopt OpenJDK 11</div></td></tr>
@@ -468,33 +468,33 @@ dependencies {
   <div><a href="https://doc.akka.io/japi/akka/snapshot/akka/cluster/tools/package-summary.html" target="_blank" rel="noopener noreferrer">API (Javadoc)</a></div>
   </td></tr>
   <tr><th>Forums</th><td>
-  <div><a href="https://discuss.akka.io" target="_blank" rel="noopener noreferrer">Lightbend Discuss</a></div>
-  <div><a href="https://gitter.im/akka/akka" target="_blank" rel="noopener noreferrer">akka/akka Gitter channel</a></div>
+  <div><a href="https://lists.apache.org/list.html?dev@pekko.apache.org" target="_blank" rel="noopener noreferrer">Apache Pekko Dev mailing list</a></div>
+  <div><a href="https://github.com/apache/incubator-pekko/discussions" target="_blank" rel="noopener noreferrer">apache/incubator-pekko discussion</a></div>
   </td></tr>
   <tr><th>Release notes</th><td><a href="https://akka.io/blog/news-archive.html">akka.io blog</a></td></tr>
-  <tr><th>Issues</th><td><a href="https://github.com/akka/akka/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
+  <tr><th>Issues</th><td><a href="https://github.com/apache/incubator-pekko/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
   <tr><th>Sources</th><td><a href="https://github.com/apache/incubator-pekko" target="_blank" rel="noopener noreferrer">https://github.com/apache/incubator-pekko</a></td></tr>
 </table>
 
 <h2><a href="#introduction" name="introduction" class="anchor"><span class="anchor-link"></span></a>Introduction</h2>
 
-<p>An actor system that is not part of the cluster can communicate with actors somewhere in the cluster via the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html [...]
+<p>An actor system that is not part of the cluster can communicate with actors somewhere in the cluster via the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/clust [...]
 
-<p>Using the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span> for c [...]
+<p>Using the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterCl [...]
 
-<p>Additionally, since Pekko Remoting is primarily designed as a protocol for Pekko Cluster there is no explicit resource management, when a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/clus [...]
+<p>Additionally, since Pekko Remoting is primarily designed as a protocol for Pekko Cluster there is no explicit resource management, when a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SN [...]
 
-<p><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span> should not be u [...]
+<p><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code [...]
 
 <p>The connecting system must have its <code>org.apache.pekko.actor.provider</code> set to <code>remote</code> or <code>cluster</code> when using the cluster client.</p>
 
-<p>The receptionist is supposed to be started on all nodes, or all nodes with a specified role, in the cluster. The receptionist can be started with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterReceptionist.html" title="org.apache.pekko.cluster.client.ClusterReceptionist"><code>ClusterReceptionist</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528- [...]
+<p>The receptionist is supposed to be started on all nodes, or all nodes with a specified role, in the cluster. The receptionist can be started with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterReceptionist.html" title="org.apache.pekko.cluster.client.ClusterReceptionist"><code>ClusterReceptionist</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+2 [...]
 
-<p>You can send messages via the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</co [...]
+<p>You can send messages via the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterCli [...]
 
-<p>Both the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span> and th [...]
+<p>Both the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterCli [...]
 
-<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.cluster.client.ClusterClientReceptionist"><code>ClusterClientReceptionist</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.cluster.client.ClusterClientRec [...]
+<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.cluster.client.ClusterClientReceptionist"><code>ClusterClientReceptionist</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.clu [...]
 
 <ol>
   <li><strong>ClusterClient.Send</strong></li>
@@ -513,8 +513,8 @@ dependencies {
   <li><span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html" title="pekko.actor.Actor"><code>`sender()`</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/Actor.html" title="pekko.actor.Actor"><code>`getSender()`</code></a></span>, as seen by the destination actor, is not the client itself,  but the receptionist</li>
   <li><span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html" title="pekko.actor.Actor"><code>`sender()`</code></a></span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/Actor.html" title="pekko.actor.Actor"><code>`getSender()`</code></a></span> of the response messages, sent back from the destination and seen by the client,  is <code>deadLetters</code></li>
 </ul>
-<p>since the client should normally send subsequent messages via the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.Cl [...]
-<p>While establishing a connection to a receptionist the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient" [...]
+<p>since the client should normally send subsequent messages via the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.ap [...]
+<p>While establishing a connection to a receptionist the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.c [...]
 <p>It&rsquo;s worth noting that messages can always be lost because of the distributed nature of these actors. As always, additional logic should be implemented in the destination (acknowledgement) and in the client (retry) actors to ensure at-least-once message delivery.</p>
 <h2><a href="#an-example" name="an-example" class="anchor"><span class="anchor-link"></span></a>An Example</h2>
 <p>On the cluster nodes, first start the receptionist. Note, it is recommended to load the extension when the actor system is started by defining it in the <code>pekko.extensions</code> configuration property:</p>
@@ -524,7 +524,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala#L275-L283" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(host1) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala#L275-L283" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(host1) {
   val serviceA = system.actorOf(Props[Service](), &quot;serviceA&quot;)
   ClusterClientReceptionist(system).registerService(serviceA)
 }
@@ -535,17 +535,17 @@ runOn(host2, host3) {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java#L53-L57" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef serviceA = system.actorOf(Props.create(Service.class), &quot;serviceA&quot;);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java#L53-L57" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef serviceA = system.actorOf(Props.create(Service.class), &quot;serviceA&quot;);
 ClusterClientReceptionist.get(system).registerService(serviceA);
 
 ActorRef serviceB = system.actorOf(Props.create(Service.class), &quot;serviceB&quot;);
 ClusterClientReceptionist.get(system).registerService(serviceB);</code></pre></dd>
 </dl>
-<p>On the client, you create the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</co [...]
+<p>On the client, you create the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterCli [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala#L292-L298" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(client) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala#L292-L298" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(client) {
   val c = system.actorOf(
     ClusterClient.props(ClusterClientSettings(system).withInitialContacts(initialContacts)),
     &quot;client&quot;)
@@ -554,7 +554,7 @@ ClusterClientReceptionist.get(system).registerService(serviceB);</code></pre></d
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java#L61-L67" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef c =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java#L61-L67" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef c =
     system.actorOf(
         ClusterClient.props(
             ClusterClientSettings.create(system).withInitialContacts(initialContacts())),
@@ -566,13 +566,13 @@ c.tell(new ClusterClient.SendToAll(&quot;/user/serviceB&quot;, &quot;hi&quot;),
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala#L207-L210" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val initialContacts = Set(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala#L207-L210" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val initialContacts = Set(
   ActorPath.fromString(&quot;akka://OtherSys@host1:2552/system/receptionist&quot;),
   ActorPath.fromString(&quot;akka://OtherSys@host2:2552/system/receptionist&quot;))
 val settings = ClusterClientSettings(system).withInitialContacts(initialContacts)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java#L41-L46" target="_blank" title="Go to snippet source">source</a><code class="language-java">Set&lt;ActorPath&gt; initialContacts() {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java#L41-L46" target="_blank" title="Go to snippet source">source</a><code class="language-java">Set&lt;ActorPath&gt; initialContacts() {
   return new HashSet&lt;ActorPath&gt;(
       Arrays.asList(
           ActorPaths.fromString(&quot;akka://OtherSys@host1:2552/system/receptionist&quot;),
@@ -582,16 +582,16 @@ val settings = ClusterClientSettings(system).withInitialContacts(initialContacts
 <p>You will probably define the address information of the initial contact points in configuration or system property. See also <a href="cluster-client.html#cluster-client-config">Configuration</a>.</p>
 <h2><a href="#clusterclientreceptionist-extension" name="clusterclientreceptionist-extension" class="anchor"><span class="anchor-link"></span></a>ClusterClientReceptionist Extension</h2>
 <p>In the example above the receptionist is started and accessed with the <code>org.apache.pekko.cluster.client.ClusterClientReceptionist</code> extension. That is convenient and perfectly fine in most cases, but it can be good to know that it is possible to start the <code>org.apache.pekko.cluster.client.ClusterReceptionist</code> actor as an ordinary actor and you can have several different receptionists at the same time, serving different types of clients.</p>
-<p>Note that the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.cluster.client.ClusterClientReceptionist"><code>ClusterClientReceptionist</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.cluster.client.Cluste [...]
+<p>Note that the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.cluster.client.ClusterClientReceptionist"><code>ClusterClientReceptionist</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache [...]
 <p>It is recommended to load the extension when the actor system is started by defining it in the <code>pekko.extensions</code> configuration property:</p>
 <pre><code>pekko.extensions = [&quot;pekko.cluster.client.ClusterClientReceptionist&quot;]
 </code></pre>
 <h2><a href="#events" name="events" class="anchor"><span class="anchor-link"></span></a>Events</h2>
-<p>As mentioned earlier, both the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</c [...]
+<p>As mentioned earlier, both the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterClient"><code>ClusterClient</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClient.html" title="org.apache.pekko.cluster.client.ClusterCl [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala#L88-L106" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class ClientListener(targetClient: ActorRef) extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala#L88-L106" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class ClientListener(targetClient: ActorRef) extends Actor {
   override def preStart(): Unit =
     targetClient ! SubscribeContactPoints
 
@@ -612,7 +612,7 @@ val settings = ClusterClientSettings(system).withInitialContacts(initialContacts
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java#L81-L117" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class ClientListener extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java#L81-L117" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class ClientListener extends AbstractActor {
   private final ActorRef targetClient;
   private final Set&lt;ActorPath&gt; contactPoints = new HashSet&lt;&gt;();
 
@@ -650,11 +650,11 @@ val settings = ClusterClientSettings(system).withInitialContacts(initialContacts
   }
 }</code></pre></dd>
 </dl>
-<p>Similarly we can have an actor that behaves in a similar fashion for learning what cluster clients are connected to a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.cluster.client.ClusterClientReceptionist"><code>ClusterClientReceptionist</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/a [...]
+<p>Similarly we can have an actor that behaves in a similar fashion for learning what cluster clients are connected to a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.cluster.client.ClusterClientReceptionist"><code>ClusterClientReceptionist</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+ [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala#L127-L145" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class ReceptionistListener(targetReceptionist: ActorRef) extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/client/ClusterClientSpec.scala#L127-L145" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class ReceptionistListener(targetReceptionist: ActorRef) extends Actor {
   override def preStart(): Unit =
     targetReceptionist ! SubscribeClusterClients
 
@@ -675,7 +675,7 @@ val settings = ClusterClientSettings(system).withInitialContacts(initialContacts
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java#L121-L157" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class ReceptionistListener extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/client/ClusterClientTest.java#L121-L157" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class ReceptionistListener extends AbstractActor {
   private final ActorRef targetReceptionist;
   private final Set&lt;ActorRef&gt; clusterClients = new HashSet&lt;&gt;();
 
@@ -715,8 +715,8 @@ val settings = ClusterClientSettings(system).withInitialContacts(initialContacts
 </dl>
 <a id="cluster-client-config"></a>
 <h2><a href="#configuration" name="configuration" class="anchor"><span class="anchor-link"></span></a>Configuration</h2>
-<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.cluster.client.ClusterClientReceptionist"><code>ClusterClientReceptionist</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.cluster.client.ClusterClientRec [...]
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/main/resources/reference.conf#L57-L91" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># Settings for the ClusterClientReceptionist extension
+<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.cluster.client.ClusterClientReceptionist"><code>ClusterClientReceptionist</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientReceptionist.html" title="org.apache.pekko.clu [...]
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/main/resources/reference.conf#L57-L91" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># Settings for the ClusterClientReceptionist extension
 pekko.cluster.client.receptionist {
   # Actor name of the ClusterReceptionist actor, /system/receptionist
   name = receptionist
@@ -751,8 +751,8 @@ pekko.cluster.client.receptionist {
   # Failure detection checking interval for checking all ClusterClients
   failure-detection-interval = 2s
 }</code></pre>
-<p>The following configuration properties are read by the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientSettings.html" title="org.apache.pekko.cluster.client.ClusterClientSettings"><code>ClusterClientSettings</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientSettings.html" title="org.apache.pe [...]
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/main/resources/reference.conf#L95-L139" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># Settings for the ClusterClient
+<p>The following configuration properties are read by the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientSettings.html" title="org.apache.pekko.cluster.client.ClusterClientSettings"><code>ClusterClientSettings</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/client/ClusterClientSetting [...]
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/main/resources/reference.conf#L95-L139" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># Settings for the ClusterClient
 pekko.cluster.client {
   # Actor paths of the ClusterReceptionist actors on the servers (cluster nodes)
   # that the client will try to contact initially. It is mandatory to specify
@@ -836,7 +836,7 @@ pekko.cluster.client {
 <h5><a href="#failure-detection" name="failure-detection" class="anchor"><span class="anchor-link"></span></a>Failure detection</h5>
 <p>Heartbeat messages and failure detection of the connections have been removed since that should be handled by the gRPC connections.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/cluster-client.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/cluster-client.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -927,7 +927,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/cluster-dc.html b/content/cluster-dc.html
index 3221b10..fa8c20c 100644
--- a/content/cluster-dc.html
+++ b/content/cluster-dc.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -425,7 +425,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/ClusterDocSpec.scala#L42-L49" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val cluster = Cluster(system)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/ClusterDocSpec.scala#L42-L49" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val cluster = Cluster(system)
 // this node&#39;s data center
 val dc = cluster.selfDataCenter
 // all known data centers
@@ -435,7 +435,7 @@ val aMember = cluster.state.members.head
 val aDc = aMember.dataCenter</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/ClusterDocTest.java#L66-L73" target="_blank" title="Go to snippet source">source</a><code class="language-java">final Cluster cluster = Cluster.get(system);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/ClusterDocTest.java#L66-L73" target="_blank" title="Go to snippet source">source</a><code class="language-java">final Cluster cluster = Cluster.get(system);
 // this node&#39;s data center
 String dc = cluster.selfDataCenter();
 // all known data centers
@@ -450,14 +450,14 @@ String aDc = aMember.dataCenter();</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/singleton/ClusterSingletonManagerSpec.scala#L254-L258" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val proxyDcB = system.actorOf(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/singleton/ClusterSingletonManagerSpec.scala#L254-L258" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val proxyDcB = system.actorOf(
   ClusterSingletonProxy.props(
     singletonManagerPath = &quot;/user/consumer&quot;,
     settings = ClusterSingletonProxySettings(system).withDataCenter(&quot;B&quot;)),
   name = &quot;consumerProxyDcB&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/singleton/ClusterSingletonManagerTest.java#L51-L58" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef proxyDcB =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/singleton/ClusterSingletonManagerTest.java#L51-L58" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef proxyDcB =
     system.actorOf(
         ClusterSingletonProxy.props(
             &quot;/user/consumer&quot;,
@@ -473,7 +473,7 @@ String aDc = aMember.dataCenter();</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L764-L769" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val counterProxyDcB: ActorRef = ClusterSharding(system).startProxy(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L764-L769" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val counterProxyDcB: ActorRef = ClusterSharding(system).startProxy(
   typeName = &quot;Counter&quot;,
   role = None,
   dataCenter = Some(&quot;B&quot;),
@@ -481,7 +481,7 @@ String aDc = aMember.dataCenter();</code></pre></dd>
   extractShardId = extractShardId)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L111-L117" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef counterProxyDcB =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L111-L117" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef counterProxyDcB =
     ClusterSharding.get(system)
         .startProxy(
             &quot;Counter&quot;,
@@ -491,7 +491,7 @@ String aDc = aMember.dataCenter();</code></pre></dd>
 </dl>
 <p>For the full documentation of this feature and for new projects see <a href="typed/cluster-dc.html#cluster-sharding">Multi-DC Cluster</a>.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/cluster-dc.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/cluster-dc.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -576,7 +576,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/cluster-metrics.html b/content/cluster-metrics.html
index bf8225a..d3cb712 100644
--- a/content/cluster-metrics.html
+++ b/content/cluster-metrics.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -419,7 +419,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#classic-cluster-metrics-extension" name="classic-cluster-metrics-extension" class="anchor"><span class="anchor-link"></span></a>Classic Cluster Metrics Extension</h1>
 <h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2>
-<p>To use Cluster Metrics Extension, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Cluster Metrics Extension, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-cluster-metrics" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -428,7 +428,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster-metrics" % PekkoVers
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -443,7 +443,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster-metrics" % PekkoVers
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-cluster-metrics_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -454,7 +454,7 @@ dependencies {
 <tr><th colspan="2">Project Info: Pekko Cluster Metrics (classic)</th></tr>
   <tr><th>Artifact</th><td><div>org.apache.pekko</div>
   <div>pekko-cluster-metrics</div>
-  <div>0.0.0+26533-ec68a528-SNAPSHOT</div>
+  <div>0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT</div>
   <div><a href="project/links.html#snapshots-repository">Snapshots are available</a></div>
   </td></tr>
   <tr><th>JDK versions</th><td><div>Adopt OpenJDK 8</div><div>Adopt OpenJDK 11</div></td></tr>
@@ -469,11 +469,11 @@ dependencies {
   <div><a href="https://doc.akka.io/japi/akka/snapshot/akka/cluster/metrics/package-summary.html" target="_blank" rel="noopener noreferrer">API (Javadoc)</a></div>
   </td></tr>
   <tr><th>Forums</th><td>
-  <div><a href="https://discuss.akka.io" target="_blank" rel="noopener noreferrer">Lightbend Discuss</a></div>
-  <div><a href="https://gitter.im/akka/akka" target="_blank" rel="noopener noreferrer">akka/akka Gitter channel</a></div>
+  <div><a href="https://lists.apache.org/list.html?dev@pekko.apache.org" target="_blank" rel="noopener noreferrer">Apache Pekko Dev mailing list</a></div>
+  <div><a href="https://github.com/apache/incubator-pekko/discussions" target="_blank" rel="noopener noreferrer">apache/incubator-pekko discussion</a></div>
   </td></tr>
   <tr><th>Release notes</th><td><a href="https://akka.io/blog/news-archive.html">akka.io blog</a></td></tr>
-  <tr><th>Issues</th><td><a href="https://github.com/akka/akka/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
+  <tr><th>Issues</th><td><a href="https://github.com/apache/incubator-pekko/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
   <tr><th>Sources</th><td><a href="https://github.com/apache/incubator-pekko" target="_blank" rel="noopener noreferrer">https://github.com/apache/incubator-pekko</a></td></tr>
 </table>
 
@@ -554,7 +554,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/FactorialBackend.scala#L26-L47" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class FactorialBackend extends Actor with ActorLogging {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/FactorialBackend.scala#L26-L47" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class FactorialBackend extends Actor with ActorLogging {
 
   import context.dispatcher
 
@@ -578,7 +578,7 @@ dependencies {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/FactorialBackend.java#L23-L47" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class FactorialBackend extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/FactorialBackend.java#L23-L47" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class FactorialBackend extends AbstractActor {
 
   @Override
   public Receive createReceive() {
@@ -608,7 +608,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/FactorialFrontend.scala#L29-L56" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class FactorialFrontend(upToN: Int, repeat: Boolean) extends Actor with ActorLogging {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/FactorialFrontend.scala#L29-L56" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class FactorialFrontend(upToN: Int, repeat: Boolean) extends Actor with ActorLogging {
 
   val backend = context.actorOf(FromConfig.props(), name = &quot;factorialBackendRouter&quot;)
 
@@ -638,7 +638,7 @@ dependencies {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/FactorialFrontend.java#L39-L86" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class FactorialFrontend extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/FactorialFrontend.java#L39-L86" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class FactorialFrontend extends AbstractActor {
   final int upToN;
   final boolean repeat;
 
@@ -712,7 +712,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/FactorialFrontend.scala#L80-L95" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/FactorialFrontend.scala#L80-L95" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.cluster.routing.ClusterRouterGroup
 import pekko.cluster.routing.ClusterRouterGroupSettings
 import pekko.cluster.metrics.AdaptiveLoadBalancingGroup
@@ -744,7 +744,7 @@ val backend = context.actorOf(
   name = &quot;factorialBackendRouter3&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/FactorialFrontend.java#L92-L106" target="_blank" title="Go to snippet source">source</a><code class="language-java">int totalInstances = 100;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/FactorialFrontend.java#L92-L106" target="_blank" title="Go to snippet source">source</a><code class="language-java">int totalInstances = 100;
 Iterable&lt;String&gt; routeesPaths = Arrays.asList(&quot;/user/factorialBackend&quot;, &quot;&quot;);
 boolean allowLocalRoutees = true;
 Set&lt;String&gt; useRoles = new HashSet&lt;&gt;(Arrays.asList(&quot;backend&quot;));
@@ -779,7 +779,7 @@ ActorRef backend =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/MetricsListener.scala#L17-L59" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/MetricsListener.scala#L17-L59" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.ActorLogging
 import pekko.actor.Actor
 import pekko.cluster.Cluster
@@ -824,7 +824,7 @@ class MetricsListener extends Actor with ActorLogging {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/MetricsListener.java#L17-L82" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractActor;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/MetricsListener.java#L17-L82" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractActor;
 import org.apache.pekko.cluster.Cluster;
 import org.apache.pekko.cluster.ClusterEvent.CurrentClusterState;
 import org.apache.pekko.cluster.metrics.ClusterMetricsChanged;
@@ -898,7 +898,7 @@ public class MetricsListener extends AbstractActor {
 <p>Custom metrics collector implementation class must be specified in the <code>pekko.cluster.metrics.collector.provider</code> configuration property.</p>
 <h2><a href="#configuration" name="configuration" class="anchor"><span class="anchor-link"></span></a>Configuration</h2>
 <p>The Cluster metrics extension can be configured with the following properties:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">##############################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">##############################################
 # Pekko Cluster Metrics Reference Config File #
 ##############################################
 
@@ -1010,7 +1010,7 @@ pekko.actor {
   }
 }</code></pre>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/cluster-metrics.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/cluster-metrics.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -1101,7 +1101,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/cluster-routing.html b/content/cluster-routing.html
index a099189..8597010 100644
--- a/content/cluster-routing.html
+++ b/content/cluster-routing.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -428,7 +428,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <li><strong>Pool - router that creates routees as child actors and deploys them on remote nodes.</strong> Each router will have its own routee instances. For example, if you start a router on 3 nodes in a 10-node cluster, you will have 30 routees in total if the router is configured to use one instance per node. The routees created by the different routers will not be shared among the routers. One example of a use case for this type of router is a single master that coordinates jobs an [...]
 </ul>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use Cluster aware routers, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Cluster aware routers, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-cluster" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -437,7 +437,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster" % PekkoVersion</cod
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -452,7 +452,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster" % PekkoVersion</cod
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-cluster_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -477,7 +477,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsService.scala#L64-L76" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsService.scala#L64-L76" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.cluster.routing.{ ClusterRouterGroup, ClusterRouterGroupSettings }
 import pekko.routing.ConsistentHashingGroup
 
@@ -492,7 +492,7 @@ val workerRouter = context.actorOf(
   name = &quot;workerRouter2&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/StatsService.java#L71-L83" target="_blank" title="Go to snippet source">source</a><code class="language-java">int totalInstances = 100;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/StatsService.java#L71-L83" target="_blank" title="Go to snippet source">source</a><code class="language-java">int totalInstances = 100;
 Iterable&lt;String&gt; routeesPaths = Collections.singletonList(&quot;/user/statsWorker&quot;);
 boolean allowLocalRoutees = true;
 Set&lt;String&gt; useRoles = new HashSet&lt;&gt;(Arrays.asList(&quot;compute&quot;));
@@ -514,12 +514,12 @@ ActorRef workerRouter =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsMessages.scala#L19-L21" target="_blank" title="Go to snippet source">source</a><code class="language-scala">final case class StatsJob(text: String) extends CborSerializable
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsMessages.scala#L19-L21" target="_blank" title="Go to snippet source">source</a><code class="language-scala">final case class StatsJob(text: String) extends CborSerializable
 final case class StatsResult(meanWordLength: Double) extends CborSerializable
 final case class JobFailed(reason: String) extends CborSerializable</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/StatsMessages.java#L19-L66" target="_blank" title="Go to snippet source">source</a><code class="language-java">public interface StatsMessages {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/StatsMessages.java#L19-L66" target="_blank" title="Go to snippet source">source</a><code class="language-java">public interface StatsMessages {
 
   public static class StatsJob implements Serializable {
     private final String text;
@@ -572,7 +572,7 @@ final case class JobFailed(reason: String) extends CborSerializable</code></pre>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsWorker.scala#L19-L33" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class StatsWorker extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsWorker.scala#L19-L33" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class StatsWorker extends Actor {
   var cache = Map.empty[String, Int]
   def receive = {
     case word: String =&gt;
@@ -589,7 +589,7 @@ final case class JobFailed(reason: String) extends CborSerializable</code></pre>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/StatsWorker.java#L22-L41" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class StatsWorker extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/StatsWorker.java#L22-L41" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class StatsWorker extends AbstractActor {
 
   Map&lt;String, Integer&gt; cache = new HashMap&lt;String, Integer&gt;();
 
@@ -611,7 +611,7 @@ final case class JobFailed(reason: String) extends CborSerializable</code></pre>
 }</code></pre></dd>
 </dl>
 <p>The service that receives text from users and splits it up into words, delegates to workers and aggregates:</p><div class="group-scala">
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsService.scala#L24-L58" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class StatsService extends Actor {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsService.scala#L24-L58" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class StatsService extends Actor {
   // This router is used both with lookup and deploy of routees. If you
   // have a router with only lookup of routees you can use Props.empty
   // instead of Props[StatsWorker.class].
@@ -646,7 +646,7 @@ class StatsAggregator(expectedResults: Int, replyTo: ActorRef) extends Actor {
       context.stop(self)
   }
 }</code></pre></div><div class="group-java">
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/StatsService.java#L35-L65" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class StatsService extends AbstractActor {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/StatsService.java#L35-L65" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class StatsService extends AbstractActor {
 
   // This router is used both with lookup and deploy of routees. If you
   // have a router with only lookup of routees you can use Props.empty()
@@ -677,7 +677,7 @@ class StatsAggregator(expectedResults: Int, replyTo: ActorRef) extends Actor {
         .build();
   }
 }</code></pre>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/StatsAggregator.java#L27-L68" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class StatsAggregator extends AbstractActor {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/StatsAggregator.java#L27-L68" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class StatsAggregator extends AbstractActor {
 
   final int expectedResults;
   final ActorRef replyTo;
@@ -754,7 +754,7 @@ class StatsAggregator(expectedResults: Int, replyTo: ActorRef) extends Actor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsService.scala#L83-L92" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsService.scala#L83-L92" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.cluster.routing.{ ClusterRouterPool, ClusterRouterPoolSettings }
 import pekko.routing.ConsistentHashingPool
 
@@ -766,7 +766,7 @@ val workerRouter = context.actorOf(
   name = &quot;workerRouter3&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/StatsService.java#L90-L102" target="_blank" title="Go to snippet source">source</a><code class="language-java">int totalInstances = 100;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/StatsService.java#L90-L102" target="_blank" title="Go to snippet source">source</a><code class="language-java">int totalInstances = 100;
 int maxInstancesPerNode = 3;
 boolean allowLocalRoutees = false;
 Set&lt;String&gt; useRoles = new HashSet&lt;&gt;(Arrays.asList(&quot;compute&quot;));
@@ -796,7 +796,7 @@ ActorRef workerRouter =
 </code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/StatsSampleOneMasterMain.java#L49-L54" target="_blank" title="Go to snippet source">source</a><code class="language-java">ClusterSingletonManagerSettings settings =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/StatsSampleOneMasterMain.java#L49-L54" target="_blank" title="Go to snippet source">source</a><code class="language-java">ClusterSingletonManagerSettings settings =
     ClusterSingletonManagerSettings.create(system).withRole(&quot;compute&quot;);
 system.actorOf(
     ClusterSingletonManager.props(
@@ -815,7 +815,7 @@ system.actorOf(
 </code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/StatsSampleOneMasterMain.java#L58-L61" target="_blank" title="Go to snippet source">source</a><code class="language-java">ClusterSingletonProxySettings proxySettings =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/StatsSampleOneMasterMain.java#L58-L61" target="_blank" title="Go to snippet source">source</a><code class="language-java">ClusterSingletonProxySettings proxySettings =
     ClusterSingletonProxySettings.create(system).withRole(&quot;compute&quot;);
 system.actorOf(
     ClusterSingletonProxy.props(&quot;/user/statsService&quot;, proxySettings), &quot;statsServiceProxy&quot;);</code></pre></dd>
@@ -836,7 +836,7 @@ system.actorOf(
 </code></pre>
 <p>The easiest way to run <strong>Router Example with Pool of Routees</strong> example yourself is to try the <span class="group-scala"><a href="https://developer.lightbend.com/start/?group=akka&amp;project=pekko-samples-cluster-scala">Pekko Cluster Sample with Scala</a></span><span class="group-java"><a href="https://developer.lightbend.com/start/?group=akka&amp;project=pekko-samples-cluster-java">Pekko Cluster Sample with Java</a></span>. It contains instructions on how to run the <str [...]
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/cluster-routing.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/cluster-routing.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -921,7 +921,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/cluster-sharding.html b/content/cluster-sharding.html
index 056fa02..4309bfd 100644
--- a/content/cluster-sharding.html
+++ b/content/cluster-sharding.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <p>For the full documentation of this feature and for new projects see <a href="typed/cluster-sharding.html">Cluster Sharding</a>.</p>
 <h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2>
-<p>To use Cluster Sharding, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Cluster Sharding, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-cluster-sharding" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -430,7 +430,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster-sharding" % PekkoVer
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -445,7 +445,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster-sharding" % PekkoVer
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-cluster-sharding_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -453,7 +453,7 @@ dependencies {
 <tr><th colspan="2">Project Info: Pekko Cluster Sharding (classic)</th></tr>
   <tr><th>Artifact</th><td><div>org.apache.pekko</div>
   <div>pekko-cluster-sharding</div>
-  <div>0.0.0+26533-ec68a528-SNAPSHOT</div>
+  <div>0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT</div>
   <div><a href="project/links.html#snapshots-repository">Snapshots are available</a></div>
   </td></tr>
   <tr><th>JDK versions</th><td><div>Adopt OpenJDK 8</div><div>Adopt OpenJDK 11</div></td></tr>
@@ -468,11 +468,11 @@ dependencies {
   <div><a href="https://doc.akka.io/japi/akka/snapshot/akka/cluster/sharding/package-summary.html" target="_blank" rel="noopener noreferrer">API (Javadoc)</a></div>
   </td></tr>
   <tr><th>Forums</th><td>
-  <div><a href="https://discuss.akka.io" target="_blank" rel="noopener noreferrer">Lightbend Discuss</a></div>
-  <div><a href="https://gitter.im/akka/akka" target="_blank" rel="noopener noreferrer">akka/akka Gitter channel</a></div>
+  <div><a href="https://lists.apache.org/list.html?dev@pekko.apache.org" target="_blank" rel="noopener noreferrer">Apache Pekko Dev mailing list</a></div>
+  <div><a href="https://github.com/apache/incubator-pekko/discussions" target="_blank" rel="noopener noreferrer">apache/incubator-pekko discussion</a></div>
   </td></tr>
   <tr><th>Release notes</th><td><a href="https://akka.io/blog/news-archive.html">akka.io blog</a></td></tr>
-  <tr><th>Issues</th><td><a href="https://github.com/akka/akka/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
+  <tr><th>Issues</th><td><a href="https://github.com/apache/incubator-pekko/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
   <tr><th>Sources</th><td><a href="https://github.com/apache/incubator-pekko" target="_blank" rel="noopener noreferrer">https://github.com/apache/incubator-pekko</a></td></tr>
 </table>
 
@@ -487,7 +487,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L39-L79" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case object Increment
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L39-L79" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case object Increment
 case object Decrement
 final case class Get(counterId: Long)
 final case class EntityEnvelope(id: Long, payload: Any)
@@ -522,7 +522,7 @@ class Counter extends PersistentActor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L164-L246" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Counter extends AbstractPersistentActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L164-L246" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Counter extends AbstractPersistentActor {
 
   public enum CounterOp {
     INCREMENT,
@@ -612,7 +612,7 @@ class Counter extends PersistentActor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L687-L692" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val counterRegion: ActorRef = ClusterSharding(system).start(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L687-L692" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val counterRegion: ActorRef = ClusterSharding(system).start(
   typeName = &quot;Counter&quot;,
   entityProps = Props[Counter](),
   settings = ClusterShardingSettings(system),
@@ -620,7 +620,7 @@ class Counter extends PersistentActor {
   extractShardId = extractShardId)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L34-L93" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.japi.Option;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L34-L93" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.japi.Option;
 import org.apache.pekko.cluster.sharding.ClusterSharding;
 import org.apache.pekko.cluster.sharding.ClusterShardingSettings;
 
@@ -634,7 +634,7 @@ ActorRef startedCounterRegion =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L197-L211" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val extractEntityId: ShardRegion.ExtractEntityId = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L197-L211" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val extractEntityId: ShardRegion.ExtractEntityId = {
   case EntityEnvelope(id, payload) =&gt; (id.toString, payload)
   case msg @ Get(id)               =&gt; (id.toString, msg)
 }
@@ -651,7 +651,7 @@ val extractShardId: ShardRegion.ExtractShardId = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L29-L85" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.cluster.sharding.ShardRegion;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L29-L85" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.cluster.sharding.ShardRegion;
 
 ShardRegion.MessageExtractor messageExtractor =
     new ShardRegion.MessageExtractor() {
@@ -700,7 +700,7 @@ ShardRegion.MessageExtractor messageExtractor =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L715-L721" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val counterRegion: ActorRef = ClusterSharding(system).shardRegion(&quot;Counter&quot;)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L715-L721" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val counterRegion: ActorRef = ClusterSharding(system).shardRegion(&quot;Counter&quot;)
 counterRegion ! Get(123)
 expectMsg(0)
 
@@ -709,7 +709,7 @@ counterRegion ! Get(123)
 expectMsg(1)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L97-L101" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef counterRegion = ClusterSharding.get(system).shardRegion(&quot;Counter&quot;);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L97-L101" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef counterRegion = ClusterSharding.get(system).shardRegion(&quot;Counter&quot;);
 counterRegion.tell(new Counter.Get(123), getSelf());
 
 counterRegion.tell(new Counter.EntityEnvelope(123, Counter.CounterOp.INCREMENT), getSelf());
@@ -751,7 +751,7 @@ counterRegion.tell(new Counter.Get(123), getSelf());</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L216-L223" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val extractShardId: ShardRegion.ExtractShardId = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L216-L223" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val extractShardId: ShardRegion.ExtractShardId = {
   case EntityEnvelope(id, _)       =&gt; (id % numberOfShards).toString
   case Get(id)                     =&gt; (id % numberOfShards).toString
   case ShardRegion.StartEntity(id) =&gt;
@@ -761,7 +761,7 @@ counterRegion.tell(new Counter.Get(123), getSelf());</code></pre></dd>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L142-L157" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L142-L157" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public String shardId(Object message) {
   int numberOfShards = 100;
   if (message instanceof Counter.EntityEnvelope) {
@@ -783,7 +783,7 @@ public String shardId(Object message) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L106-L119" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class CounterSupervisor extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L106-L119" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class CounterSupervisor extends Actor {
   val counter = context.actorOf(Props[Counter](), &quot;theCounter&quot;)
 
   override val supervisorStrategy = OneForOneStrategy() {
@@ -799,7 +799,7 @@ public String shardId(Object message) {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L250-L274" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class CounterSupervisor extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L250-L274" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class CounterSupervisor extends AbstractActor {
 
   private final ActorRef counter =
       getContext().actorOf(Props.create(Counter.class), &quot;theCounter&quot;);
@@ -829,7 +829,7 @@ public String shardId(Object message) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L704-L709" target="_blank" title="Go to snippet source">source</a><code class="language-scala">ClusterSharding(system).start(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding/src/multi-jvm/scala/org/apache/pekko/cluster/sharding/ClusterShardingSpec.scala#L704-L709" target="_blank" title="Go to snippet source">source</a><code class="language-scala">ClusterSharding(system).start(
   typeName = &quot;SupervisedCounter&quot;,
   entityProps = Props[CounterSupervisor](),
   settings = ClusterShardingSettings(system),
@@ -837,7 +837,7 @@ public String shardId(Object message) {
   extractShardId = extractShardId)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L105-L107" target="_blank" title="Go to snippet source">source</a><code class="language-java">ClusterSharding.get(system)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/sharding/ClusterShardingTest.java#L105-L107" target="_blank" title="Go to snippet source">source</a><code class="language-java">ClusterSharding.get(system)
     .start(
         &quot;SupervisedCounter&quot;, Props.create(CounterSupervisor.class), settings, messageExtractor);</code></pre></dd>
 </dl>
@@ -862,7 +862,7 @@ public String shardId(Object message) {
 <p><code>ClusterShardingSettings</code> is a parameter to the <code>start</code> method of the <code>ClusterSharding</code> extension, i.e. each each entity type can be configured with different settings if needed.</p>
 <p>See <a href="typed/cluster-sharding.html#configuration">configuration</a> for more information.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/cluster-sharding.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/cluster-sharding.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -958,7 +958,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/cluster-singleton.html b/content/cluster-singleton.html
index 93993de..a7f1f25 100644
--- a/content/cluster-singleton.html
+++ b/content/cluster-singleton.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <p>For the full documentation of this feature and for new projects see <a href="typed/cluster-singleton.html">Cluster Singleton</a>.</p>
 <h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2>
-<p>To use Cluster Singleton, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Cluster Singleton, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-cluster-tools" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -430,7 +430,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster-tools" % PekkoVersio
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -445,7 +445,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster-tools" % PekkoVersio
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-cluster-tools_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -453,7 +453,7 @@ dependencies {
 <tr><th colspan="2">Project Info: Pekko Cluster Tools (classic)</th></tr>
   <tr><th>Artifact</th><td><div>org.apache.pekko</div>
   <div>pekko-cluster-tools</div>
-  <div>0.0.0+26533-ec68a528-SNAPSHOT</div>
+  <div>0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT</div>
   <div><a href="project/links.html#snapshots-repository">Snapshots are available</a></div>
   </td></tr>
   <tr><th>JDK versions</th><td><div>Adopt OpenJDK 8</div><div>Adopt OpenJDK 11</div></td></tr>
@@ -468,11 +468,11 @@ dependencies {
   <div><a href="https://doc.akka.io/japi/akka/snapshot/akka/cluster/tools/package-summary.html" target="_blank" rel="noopener noreferrer">API (Javadoc)</a></div>
   </td></tr>
   <tr><th>Forums</th><td>
-  <div><a href="https://discuss.akka.io" target="_blank" rel="noopener noreferrer">Lightbend Discuss</a></div>
-  <div><a href="https://gitter.im/akka/akka" target="_blank" rel="noopener noreferrer">akka/akka Gitter channel</a></div>
+  <div><a href="https://lists.apache.org/list.html?dev@pekko.apache.org" target="_blank" rel="noopener noreferrer">Apache Pekko Dev mailing list</a></div>
+  <div><a href="https://github.com/apache/incubator-pekko/discussions" target="_blank" rel="noopener noreferrer">apache/incubator-pekko discussion</a></div>
   </td></tr>
   <tr><th>Release notes</th><td><a href="https://akka.io/blog/news-archive.html">akka.io blog</a></td></tr>
-  <tr><th>Issues</th><td><a href="https://github.com/akka/akka/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
+  <tr><th>Issues</th><td><a href="https://github.com/apache/incubator-pekko/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
   <tr><th>Sources</th><td><a href="https://github.com/apache/incubator-pekko" target="_blank" rel="noopener noreferrer">https://github.com/apache/incubator-pekko</a></td></tr>
 </table>
 
@@ -495,7 +495,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/singleton/ClusterSingletonManagerSpec.scala#L62-L127" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object PointToPointChannel {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/singleton/ClusterSingletonManagerSpec.scala#L62-L127" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object PointToPointChannel {
   case object UnregistrationOk extends CborSerializable
 }
 object Consumer {
@@ -506,7 +506,7 @@ object Consumer {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/singleton/TestSingletonMessages.java#L17-L91" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class TestSingletonMessages {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/singleton/TestSingletonMessages.java#L17-L91" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class TestSingletonMessages {
   public static class UnregistrationOk {}
 
   public static class End {}
@@ -542,7 +542,7 @@ object Consumer {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/singleton/ClusterSingletonManagerSpec.scala#L232-L237" target="_blank" title="Go to snippet source">source</a><code class="language-scala">system.actorOf(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/singleton/ClusterSingletonManagerSpec.scala#L232-L237" target="_blank" title="Go to snippet source">source</a><code class="language-scala">system.actorOf(
   ClusterSingletonManager.props(
     singletonProps = Props(classOf[Consumer], queue, testActor),
     terminationMessage = End,
@@ -550,7 +550,7 @@ object Consumer {
   name = &quot;consumer&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/singleton/ClusterSingletonManagerTest.java#L30-L38" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ClusterSingletonManagerSettings settings =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/singleton/ClusterSingletonManagerTest.java#L30-L38" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ClusterSingletonManagerSettings settings =
     ClusterSingletonManagerSettings.create(system).withRole(&quot;worker&quot;);
 
 system.actorOf(
@@ -566,7 +566,7 @@ system.actorOf(
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/singleton/ClusterSingletonManagerSpec.scala#L159-L165" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case End =&gt;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/singleton/ClusterSingletonManagerSpec.scala#L159-L165" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case End =&gt;
   queue ! UnregisterConsumer
 case UnregistrationOk =&gt;
   stoppedBeforeUnregistration = false
@@ -575,7 +575,7 @@ case Ping =&gt;
   sender() ! Pong</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/singleton/Consumer.java#L62-L69" target="_blank" title="Go to snippet source">source</a><code class="language-java">.match(End.class, message -&gt; queue.tell(UnregisterConsumer.class, getSelf()))
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/singleton/Consumer.java#L62-L69" target="_blank" title="Go to snippet source">source</a><code class="language-java">.match(End.class, message -&gt; queue.tell(UnregisterConsumer.class, getSelf()))
 .match(
     UnregistrationOk.class,
     message -&gt; {
@@ -588,14 +588,14 @@ case Ping =&gt;
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/singleton/ClusterSingletonManagerSpec.scala#L243-L247" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val proxy = system.actorOf(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/singleton/ClusterSingletonManagerSpec.scala#L243-L247" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val proxy = system.actorOf(
   ClusterSingletonProxy.props(
     singletonManagerPath = &quot;/user/consumer&quot;,
     settings = ClusterSingletonProxySettings(system).withRole(&quot;worker&quot;)),
   name = &quot;consumerProxy&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/singleton/ClusterSingletonManagerTest.java#L42-L47" target="_blank" title="Go to snippet source">source</a><code class="language-java">ClusterSingletonProxySettings proxySettings =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/singleton/ClusterSingletonManagerTest.java#L42-L47" target="_blank" title="Go to snippet source">source</a><code class="language-java">ClusterSingletonProxySettings proxySettings =
     ClusterSingletonProxySettings.create(system).withRole(&quot;worker&quot;);
 
 ActorRef proxy =
@@ -614,7 +614,7 @@ ActorRef proxy =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/singleton/ClusterSingletonSupervision.scala#L17-L24" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.{ Actor, Props, SupervisorStrategy }
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/singleton/ClusterSingletonSupervision.scala#L17-L24" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.{ Actor, Props, SupervisorStrategy }
 class SupervisorActor(childProps: Props, override val supervisorStrategy: SupervisorStrategy) extends Actor {
   val child = context.actorOf(childProps, &quot;supervised-child&quot;)
 
@@ -624,7 +624,7 @@ class SupervisorActor(childProps: Props, override val supervisorStrategy: Superv
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/singleton/SupervisorActor.java#L17-L43" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractActor;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/singleton/SupervisorActor.java#L17-L43" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractActor;
 import org.apache.pekko.actor.AbstractActor.Receive;
 import org.apache.pekko.actor.ActorRef;
 import org.apache.pekko.actor.Props;
@@ -656,7 +656,7 @@ public class SupervisorActor extends AbstractActor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/singleton/ClusterSingletonSupervision.scala#L32-L40" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/singleton/ClusterSingletonSupervision.scala#L32-L40" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.{ PoisonPill, Props }
 import pekko.cluster.singleton.{ ClusterSingletonManager, ClusterSingletonManagerSettings }
 context.system.actorOf(
@@ -667,11 +667,11 @@ context.system.actorOf(
   name = name)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/singleton/ClusterSingletonSupervision.java#L22-L25" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.PoisonPill;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/singleton/ClusterSingletonSupervision.java#L22-L25" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.PoisonPill;
 import org.apache.pekko.actor.Props;
 import org.apache.pekko.cluster.singleton.ClusterSingletonManager;
 import org.apache.pekko.cluster.singleton.ClusterSingletonManagerSettings;</code></pre>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/singleton/ClusterSingletonSupervision.java#L32-L40" target="_blank" title="Go to snippet source">source</a><code class="language-java">return getContext()
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/singleton/ClusterSingletonSupervision.java#L32-L40" target="_blank" title="Go to snippet source">source</a><code class="language-java">return getContext()
     .system()
     .actorOf(
         ClusterSingletonManager.props(
@@ -684,7 +684,7 @@ import org.apache.pekko.cluster.singleton.ClusterSingletonManagerSettings;</code
 <h2><a href="#lease" name="lease" class="anchor"><span class="anchor-link"></span></a>Lease</h2>
 <p>For the full documentation of this feature and for new projects see <a href="typed/cluster-singleton.html#lease">Cluster Singleton - Lease</a>.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/cluster-singleton.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/cluster-singleton.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -772,7 +772,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/cluster-usage.html b/content/cluster-usage.html
index 591d41f..e8f10e4 100644
--- a/content/cluster-usage.html
+++ b/content/cluster-usage.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -430,7 +430,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul><div class="callout note "><div class="callout-title">Note</div>
 <p>You have to enable <a href="serialization.html">serialization</a> to send messages between ActorSystems in the Cluster. <a href="serialization-jackson.html">Serialization with Jackson</a> is a good choice in many cases, and our recommendation if you don&rsquo;t have other preferences or constraints.</p></div>
 <h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2>
-<p>To use Pekko Cluster add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Pekko Cluster add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-cluster" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -439,7 +439,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster" % PekkoVersion</cod
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -454,7 +454,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster" % PekkoVersion</cod
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-cluster_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -462,7 +462,7 @@ dependencies {
 <tr><th colspan="2">Project Info: Pekko Cluster (classic)</th></tr>
   <tr><th>Artifact</th><td><div>org.apache.pekko</div>
   <div>pekko-cluster</div>
-  <div>0.0.0+26533-ec68a528-SNAPSHOT</div>
+  <div>0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT</div>
   <div><a href="project/links.html#snapshots-repository">Snapshots are available</a></div>
   </td></tr>
   <tr><th>JDK versions</th><td><div>Adopt OpenJDK 8</div><div>Adopt OpenJDK 11</div></td></tr>
@@ -477,11 +477,11 @@ dependencies {
   <div><a href="https://doc.akka.io/japi/akka/snapshot/akka/cluster/package-summary.html" target="_blank" rel="noopener noreferrer">API (Javadoc)</a></div>
   </td></tr>
   <tr><th>Forums</th><td>
-  <div><a href="https://discuss.akka.io" target="_blank" rel="noopener noreferrer">Lightbend Discuss</a></div>
-  <div><a href="https://gitter.im/akka/akka" target="_blank" rel="noopener noreferrer">akka/akka Gitter channel</a></div>
+  <div><a href="https://lists.apache.org/list.html?dev@pekko.apache.org" target="_blank" rel="noopener noreferrer">Apache Pekko Dev mailing list</a></div>
+  <div><a href="https://github.com/apache/incubator-pekko/discussions" target="_blank" rel="noopener noreferrer">apache/incubator-pekko discussion</a></div>
   </td></tr>
   <tr><th>Release notes</th><td><a href="https://akka.io/blog/news-archive.html">akka.io blog</a></td></tr>
-  <tr><th>Issues</th><td><a href="https://github.com/akka/akka/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
+  <tr><th>Issues</th><td><a href="https://github.com/apache/incubator-pekko/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
   <tr><th>Sources</th><td><a href="https://github.com/apache/incubator-pekko" target="_blank" rel="noopener noreferrer">https://github.com/apache/incubator-pekko</a></td></tr>
 </table>
 
@@ -491,14 +491,14 @@ dependencies {
 
 <h2><a href="#cluster-api-extension" name="cluster-api-extension" class="anchor"><span class="anchor-link"></span></a>Cluster API Extension</h2>
 
-<p>The following configuration enables the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/Cluster.html" title="org.apache.pekko.cluster.Cluster"><code>Cluster</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/Cluster.html" title="org.apache.pekko.cluster.Cluster"><code>Cluster</code></a></span> extension to be used. It joins the clus [...]
+<p>The following configuration enables the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/Cluster.html" title="org.apache.pekko.cluster.Cluster"><code>Cluster</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/Cluster.html" title="org.apache.pekko.cluster.Cluster"><code>Cluster</code></a></span> extension t [...]
 
 <p>An actor that uses the cluster extension may look like this:</p>
 
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener.scala" target="_blank" title="Go to snippet source">source</a><code class="language-scala">/*
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener.scala" target="_blank" title="Go to snippet source">source</a><code class="language-scala">/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * license agreements; and to You under the Apache License, version 2.0:
  *
@@ -543,7 +543,7 @@ class SimpleClusterListener extends Actor with ActorLogging {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener.java" target="_blank" title="Go to snippet source">source</a><code class="language-java">/*
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener.java" target="_blank" title="Go to snippet source">source</a><code class="language-java">/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * license agreements; and to You under the Apache License, version 2.0:
  *
@@ -615,7 +615,7 @@ public class SimpleClusterListener extends AbstractActor {
 }</code></pre></dd>
 </dl>
 <p>And the minimum configuration required is to set a host/port for remoting and the <code>pekko.actor.provider = &quot;cluster&quot;</code>.</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-typed/src/test/scala/docs/org/apache/pekko/cluster/typed/BasicClusterExampleSpec.scala#L42-L60" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-typed/src/test/scala/docs/org/apache/pekko/cluster/typed/BasicClusterExampleSpec.scala#L42-L60" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko {
   actor {
     provider = &quot;cluster&quot;
   }
@@ -650,7 +650,7 @@ public class SimpleClusterListener extends AbstractActor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/ClusterDocSpec.scala#L56-L62" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/ClusterDocSpec.scala#L56-L62" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.Address
 import pekko.cluster.Cluster
 
@@ -659,7 +659,7 @@ val list: List[Address] = ??? // your method to dynamically get seed nodes
 cluster.joinSeedNodes(list)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/ClusterDocTest.java#L28-L30" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.Address;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/ClusterDocTest.java#L28-L30" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.Address;
 import org.apache.pekko.cluster.Cluster;
 
 final Cluster cluster = Cluster.get(system);
@@ -668,15 +668,15 @@ List&lt;Address&gt; list =
 cluster.joinSeedNodes(list);</code></pre></dd>
 </dl>
 <p>For more information see <a href="typed/cluster.html#tuning-joins">tuning joins</a></p>
-<p>It&rsquo;s also possible to specifically join a single node as illustrated in below example, but <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/Cluster.html#joinSeedNodes(seedNodes:Seq[org.apache.pekko.actor.Address]):Unit" title="org.apache.pekko.cluster.Cluster"><code>joinSeedNodes</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/clust [...]
+<p>It&rsquo;s also possible to specifically join a single node as illustrated in below example, but <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/Cluster.html#joinSeedNodes(seedNodes:Seq[org.apache.pekko.actor.Address]):Unit" title="org.apache.pekko.cluster.Cluster"><code>joinSeedNodes</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNA [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener2.scala#L23-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val cluster = Cluster(context.system)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener2.scala#L23-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val cluster = Cluster(context.system)
   cluster.join(cluster.selfAddress)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener2.java#L29-L36" target="_blank" title="Go to snippet source">source</a><code class="language-java">Cluster cluster = Cluster.get(getContext().getSystem());
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener2.java#L29-L36" target="_blank" title="Go to snippet source">source</a><code class="language-java">Cluster cluster = Cluster.get(getContext().getSystem());
   cluster.join(cluster.selfAddress());</code></pre></dd>
 </dl>
 <h2><a href="#leaving" name="leaving" class="anchor"><span class="anchor-link"></span></a>Leaving</h2>
@@ -689,22 +689,22 @@ cluster.joinSeedNodes(list);</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener2.scala#L33" target="_blank" title="Go to snippet source">source</a><code class="language-scala">cluster.subscribe(self, classOf[MemberEvent], classOf[UnreachableMember])</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener2.scala#L33" target="_blank" title="Go to snippet source">source</a><code class="language-scala">cluster.subscribe(self, classOf[MemberEvent], classOf[UnreachableMember])</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener2.java#L40" target="_blank" title="Go to snippet source">source</a><code class="language-java">cluster.subscribe(getSelf(), MemberEvent.class, UnreachableMember.class);</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener2.java#L40" target="_blank" title="Go to snippet source">source</a><code class="language-java">cluster.subscribe(getSelf(), MemberEvent.class, UnreachableMember.class);</code></pre></dd>
 </dl>
-<p>A snapshot of the full state, <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ClusterEvent$$CurrentClusterState.html" title="org.apache.pekko.cluster.ClusterEvent.CurrentClusterState"><code>CurrentClusterState</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ClusterEvent$$CurrentClusterState.html" title="org.apache.pekko.cluster.C [...]
-<p>Note that you may receive an empty <code>CurrentClusterState</code>, containing no members, followed by <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ClusterEvent$$MemberUp.html" title="org.apache.pekko.cluster.ClusterEvent.MemberUp"><code>MemberUp</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ClusterEvent$$MemberUp.html" tit [...]
+<p>A snapshot of the full state, <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ClusterEvent$$CurrentClusterState.html" title="org.apache.pekko.cluster.ClusterEvent.CurrentClusterState"><code>CurrentClusterState</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ClusterEvent$$CurrentClusterState.html" title [...]
+<p>Note that you may receive an empty <code>CurrentClusterState</code>, containing no members, followed by <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ClusterEvent$$MemberUp.html" title="org.apache.pekko.cluster.ClusterEvent.MemberUp"><code>MemberUp</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/Clus [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener2.scala#L23-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val cluster = Cluster(context.system)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener2.scala#L23-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val cluster = Cluster(context.system)
   cluster.join(cluster.selfAddress)
 cluster.subscribe(self, classOf[MemberEvent], classOf[UnreachableMember])</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener2.java#L29-L36" target="_blank" title="Go to snippet source">source</a><code class="language-java">Cluster cluster = Cluster.get(getContext().getSystem());
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener2.java#L29-L36" target="_blank" title="Go to snippet source">source</a><code class="language-java">Cluster cluster = Cluster.get(getContext().getSystem());
   cluster.join(cluster.selfAddress());
 cluster.subscribe(getSelf(), MemberEvent.class, UnreachableMember.class);</code></pre></dd>
 </dl>
@@ -712,26 +712,26 @@ cluster.subscribe(getSelf(), MemberEvent.class, UnreachableMember.class);</code>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener2.scala#L23-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val cluster = Cluster(context.system)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener2.scala#L23-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val cluster = Cluster(context.system)
   cluster.join(cluster.selfAddress)
 cluster.registerOnMemberUp {
   cluster.subscribe(self, classOf[MemberEvent], classOf[UnreachableMember])
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener2.java#L29-L36" target="_blank" title="Go to snippet source">source</a><code class="language-java">Cluster cluster = Cluster.get(getContext().getSystem());
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener2.java#L29-L36" target="_blank" title="Go to snippet source">source</a><code class="language-java">Cluster cluster = Cluster.get(getContext().getSystem());
   cluster.join(cluster.selfAddress());
 cluster.registerOnMemberUp(
     () -&gt; cluster.subscribe(getSelf(), MemberEvent.class, UnreachableMember.class));</code></pre></dd>
 </dl>
-<p>If you find it inconvenient to handle the <code>CurrentClusterState</code> you can use <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/cluster/ClusterEvent$$InitialStateAsEvents$.html" title="cluster.ClusterEvent$$InitialStateAsEvents"><code>ClusterEvent.InitialStateAsEvents</code></a></span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/cluster/ClusterEvent.html#initialStateAsEvents()" title="pekko.c [...]
+<p>If you find it inconvenient to handle the <code>CurrentClusterState</code> you can use <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/cluster/ClusterEvent$$InitialStateAsEvents$.html" title="cluster.ClusterEvent$$InitialStateAsEvents"><code>ClusterEvent.InitialStateAsEvents</code></a></span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/cluster/ClusterEvent.html#initialStateAsEvents()"  [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener.scala#L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">cluster.subscribe(self, initialStateMode = InitialStateAsEvents, classOf[MemberEvent], classOf[UnreachableMember])</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/SimpleClusterListener.scala#L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">cluster.subscribe(self, initialStateMode = InitialStateAsEvents, classOf[MemberEvent], classOf[UnreachableMember])</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener.java#L34-L35" target="_blank" title="Go to snippet source">source</a><code class="language-java">cluster.subscribe(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/SimpleClusterListener.java#L34-L35" target="_blank" title="Go to snippet source">source</a><code class="language-java">cluster.subscribe(
     getSelf(), ClusterEvent.initialStateAsEvents(), MemberEvent.class, UnreachableMember.class);</code></pre></dd>
 </dl>
 <h3><a href="#worker-dial-in-example" name="worker-dial-in-example" class="anchor"><span class="anchor-link"></span></a>Worker Dial-in Example</h3>
@@ -741,13 +741,13 @@ cluster.registerOnMemberUp(
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/TransformationMessages.scala#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-scala">final case class TransformationJob(text: String)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/TransformationMessages.scala#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-scala">final case class TransformationJob(text: String)
 final case class TransformationResult(text: String)
 final case class JobFailed(reason: String, job: TransformationJob)
 case object BackendRegistration</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/TransformationMessages.java#L19-L74" target="_blank" title="Go to snippet source">source</a><code class="language-java">public interface TransformationMessages {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/TransformationMessages.java#L19-L74" target="_blank" title="Go to snippet source">source</a><code class="language-java">public interface TransformationMessages {
 
   public static class TransformationJob implements Serializable {
     private final String text;
@@ -808,7 +808,7 @@ case object BackendRegistration</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/TransformationBackend.scala#L31-L51" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class TransformationBackend extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/TransformationBackend.scala#L31-L51" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class TransformationBackend extends Actor {
 
   val cluster = Cluster(context.system)
 
@@ -831,7 +831,7 @@ case object BackendRegistration</code></pre></dd>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/TransformationBackend.java#L27-L74" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class TransformationBackend extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/TransformationBackend.java#L27-L74" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class TransformationBackend extends AbstractActor {
 
   Cluster cluster = Cluster.get(getContext().getSystem());
 
@@ -885,7 +885,7 @@ case object BackendRegistration</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/TransformationFrontend.scala#L30-L50" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class TransformationFrontend extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/TransformationFrontend.scala#L30-L50" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class TransformationFrontend extends Actor {
 
   var backends = IndexedSeq.empty[ActorRef]
   var jobCounter = 0
@@ -908,7 +908,7 @@ case object BackendRegistration</code></pre></dd>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/TransformationFrontend.java#L28-L62" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class TransformationFrontend extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/TransformationFrontend.java#L28-L62" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class TransformationFrontend extends AbstractActor {
 
   List&lt;ActorRef&gt; backends = new ArrayList&lt;ActorRef&gt;();
   int jobCounter = 0;
@@ -944,7 +944,7 @@ case object BackendRegistration</code></pre></dd>
   }
 }</code></pre></dd>
 </dl>
-<p>Note that the <code>TransformationFrontend</code> actor watch the registered backend to be able to remove it from its list of available backend workers. Death watch uses the cluster failure detector for nodes in the cluster, i.e. it detects network failures and JVM crashes, in addition to graceful termination of watched actor. Death watch generates the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Terminated.html"  [...]
+<p>Note that the <code>TransformationFrontend</code> actor watch the registered backend to be able to remove it from its list of available backend workers. Death watch uses the cluster failure detector for nodes in the cluster, i.e. it detects network failures and JVM crashes, in addition to graceful termination of watched actor. Death watch generates the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Ter [...]
 <h2><a href="#node-roles" name="node-roles" class="anchor"><span class="anchor-link"></span></a>Node Roles</h2>
 <p>See <a href="typed/cluster.html#node-roles">Cluster Node Roles</a> in the documentation of the new APIs.</p>
 <a id="min-members"></a>
@@ -961,16 +961,16 @@ case object BackendRegistration</code></pre></dd>
   backend.min-nr-of-members = 2
 }
 </code></pre>
-<p>You can start actors or trigger any functions using the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/Cluster.html#registerOnMemberUp[T](code:=%3ET):Unit" title="org.apache.pekko.cluster.Cluster"><code>registerOnMemberUp</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/Cluster.html#registerOnMemberUp(java.lang.Runnable)" title=" [...]
+<p>You can start actors or trigger any functions using the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/Cluster.html#registerOnMemberUp[T](code:=%3ET):Unit" title="org.apache.pekko.cluster.Cluster"><code>registerOnMemberUp</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/Cluster.html#registerOnMemberUp( [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/cluster/FactorialFrontend.scala#L69-L71" target="_blank" title="Go to snippet source">source</a><code class="language-scala">Cluster(system).registerOnMemberUp {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/cluster/FactorialFrontend.scala#L69-L71" target="_blank" title="Go to snippet source">source</a><code class="language-scala">Cluster(system).registerOnMemberUp {
   system.actorOf(Props(classOf[FactorialFrontend], upToN, true), name = &quot;factorialFrontend&quot;)
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/cluster/FactorialFrontendMain.java#L36-L44" target="_blank" title="Go to snippet source">source</a><code class="language-java">Cluster.get(system)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/cluster/FactorialFrontendMain.java#L36-L44" target="_blank" title="Go to snippet source">source</a><code class="language-java">Cluster.get(system)
     .registerOnMemberUp(
         new Runnable() {
           @Override
@@ -981,7 +981,7 @@ case object BackendRegistration</code></pre></dd>
         });</code></pre></dd>
 </dl>
 <h2><a href="#how-to-cleanup-when-member-is-removed" name="how-to-cleanup-when-member-is-removed" class="anchor"><span class="anchor-link"></span></a>How To Cleanup when Member is Removed</h2>
-<p>You can do some clean up in a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/Cluster.html#registerOnMemberRemoved[T](code:=%3ET):Unit" title="org.apache.pekko.cluster.Cluster"><code>registerOnMemberRemoved</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/Cluster.html#registerOnMemberRemoved(java.lang.Runnable)" title="org.apache. [...]
+<p>You can do some clean up in a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/Cluster.html#registerOnMemberRemoved[T](code:=%3ET):Unit" title="org.apache.pekko.cluster.Cluster"><code>registerOnMemberRemoved</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/Cluster.html#registerOnMemberRemoved(java.lang.R [...]
 <p>An alternative is to register tasks to the <a href="coordinated-shutdown.html">Coordinated Shutdown</a>.</p><div class="callout note "><div class="callout-title">Note</div>
 <p>Register a OnMemberRemoved callback on a cluster that have been shutdown, the callback will be invoked immediately on the caller thread, otherwise it will be invoked later when the current member status changed to <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/cluster/MemberStatus$$Removed$.html" title="pekko.cluster.MemberStatus$$Removed"><code>Removed</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache [...]
 <h2><a href="#higher-level-cluster-tools" name="higher-level-cluster-tools" class="anchor"><span class="anchor-link"></span></a>Higher level Cluster tools</h2><h3><a href="#cluster-singleton" name="cluster-singleton" class="anchor"><span class="anchor-link"></span></a>Cluster Singleton</h3>
@@ -1015,7 +1015,7 @@ case object BackendRegistration</code></pre></dd>
 <p><a href="multi-node-testing.html">Multi Node Testing</a> is useful for testing cluster applications.</p>
 <p>Set up your project according to the instructions in <a href="multi-node-testing.html">Multi Node Testing</a> and <a href="multi-jvm-testing.html">Multi JVM Testing</a>, i.e. add the <code>sbt-multi-jvm</code> plugin and the dependency to <code>pekko-multi-node-testkit</code>.</p>
 <p>First, as described in <a href="multi-node-testing.html">Multi Node Testing</a>, we need some scaffolding to configure the <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/remote/testkit/MultiNodeSpec.html" title="pekko.remote.testkit.MultiNodeSpec"><code>MultiNodeSpec</code></a>. Define the participating <a href="typed/cluster.html#node-roles">roles</a> and their <a href="cluster-usage.html#configuration">configuration</a> in an object extending <a href="https://doc.akka.io [...]
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L25-L69" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.remote.testkit.MultiNodeConfig
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L25-L69" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.remote.testkit.MultiNodeConfig
 import com.typesafe.config.ConfigFactory
 
 object StatsSampleSpecConfig extends MultiNodeConfig {
@@ -1059,13 +1059,13 @@ object StatsSampleSpecConfig extends MultiNodeConfig {
 
 }</code></pre>
 <p>Define one concrete test class for each role/node. These will be instantiated on the different nodes (JVMs). They can be implemented differently, but often they are the same and extend an abstract test class, as illustrated here.</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L73-L76" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// need one concrete test class per node
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L73-L76" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// need one concrete test class per node
 class StatsSampleSpecMultiJvmNode1 extends StatsSampleSpec
 class StatsSampleSpecMultiJvmNode2 extends StatsSampleSpec
 class StatsSampleSpecMultiJvmNode3 extends StatsSampleSpec</code></pre>
 <p>Note the naming convention of these classes. The name of the classes must end with <code>MultiJvmNode1</code>, <code>MultiJvmNode2</code> and so on. It is possible to define another suffix to be used by the <code>sbt-multi-jvm</code>, but the default should be fine in most cases.</p>
 <p>Then the abstract <code>MultiNodeSpec</code>, which takes the <code>MultiNodeConfig</code> as constructor parameter.</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L80-L101" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L80-L101" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.remote.testkit.MultiNodeSpec
 import pekko.testkit.ImplicitSender
 import org.scalatest.BeforeAndAfterAll
@@ -1089,7 +1089,7 @@ abstract class StatsSampleSpec
 </code></pre>
 <p>Most of this can be extracted to a separate trait to avoid repeating this in all your tests.</p>
 <p>Typically you begin your test by starting up the cluster and let the members join, and create some actors. That can be done like this:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L107-L130" target="_blank" title="Go to snippet source">source</a><code class="language-scala">&quot;illustrate how to startup cluster&quot; in within(15 seconds) {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L107-L130" target="_blank" title="Go to snippet source">source</a><code class="language-scala">&quot;illustrate how to startup cluster&quot; in within(15 seconds) {
   Cluster(system).subscribe(testActor, classOf[MemberUp])
   expectMsgClass(classOf[CurrentClusterState])
 
@@ -1110,10 +1110,10 @@ abstract class StatsSampleSpec
   testConductor.enter(&quot;all-up&quot;)
 }</code></pre>
 <p>From the test you interact with the cluster using the <code>Cluster</code> extension, e.g. <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/cluster/Cluster.html#join(address:org.apache.pekko.actor.Address):Unit" title="pekko.cluster.Cluster"><code>join</code></a>.</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L118" target="_blank" title="Go to snippet source">source</a><code class="language-scala">Cluster(system).join(firstAddress)</code></pre>
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L118" target="_blank" title="Go to snippet source">source</a><code class="language-scala">Cluster(system).join(firstAddress)</code></pre>
 <p>Notice how the <em>testActor</em> from <a href="testing.html">testkit</a> is added as <a href="cluster-usage.html#cluster-subscriber">subscriber</a> to cluster changes and then waiting for certain events, such as in this case all members becoming &lsquo;Up&rsquo;.</p>
 <p>The above code was running for all roles (JVMs). <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/remote/testkit/MultiNodeSpec.html#runOn(nodes:org.apache.pekko.remote.testconductor.RoleName*)(thunk:=%3EUnit):Unit" title="pekko.remote.testkit.MultiNodeSpec"><code>runOn</code></a> is a convenient utility to declare that a certain block of code should only run for a specific role.</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L134-L151" target="_blank" title="Go to snippet source">source</a><code class="language-scala">&quot;show usage of the statsService from one node&quot; in within(15 seconds) {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L134-L151" target="_blank" title="Go to snippet source">source</a><code class="language-scala">&quot;show usage of the statsService from one node&quot; in within(15 seconds) {
   runOn(second) {
     assertServiceOk()
   }
@@ -1131,9 +1131,9 @@ def assertServiceOk(): Unit = {
   }
 
 }</code></pre>
-<p>Once again we take advantage of the facilities in <a href="testing.html">testkit</a> to verify expected behavior. Here using <code>testActor</code> as sender (via <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/testkit/ImplicitSender.html" title="pekko.testkit.ImplicitSender"><code>ImplicitSender</code></a>) and verifying the reply with <a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/testkit/TestKit.html#expectMsgType[T](max:scala.concur [...]
+<p>Once again we take advantage of the facilities in <a href="testing.html">testkit</a> to verify expected behavior. Here using <code>testActor</code> as sender (via <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/testkit/ImplicitSender.html" title="pekko.testkit.ImplicitSender"><code>ImplicitSender</code></a>) and verifying the reply with <a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/testkit/TestKit.html#expectMsgType[T](ma [...]
 <p>In the above code you can see <code>node(third)</code>, which is useful facility to get the root actor reference of the actor system for a specific role. This can also be used to grab the <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Address.html" title="pekko.actor.Address"><code>actor.Address</code></a> of that node.</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L112-L114" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val firstAddress = node(first).address
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/multi-jvm/scala/org/apache/pekko/cluster/metrics/sample/StatsSampleSpec.scala#L112-L114" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val firstAddress = node(first).address
 val secondAddress = node(second).address
 val thirdAddress = node(third).address</code></pre></div><div class="group-java">
 <p>Currently testing with the <code>sbt-multi-jvm</code> plugin is only documented for Scala. Go to the corresponding Scala version of this page for details.</p></div>
@@ -1142,7 +1142,7 @@ val thirdAddress = node(third).address</code></pre></div><div class="group-java"
 <a id="cluster-command-line"></a>
 <h3><a href="#command-line" name="command-line" class="anchor"><span class="anchor-link"></span></a>Command Line</h3><div class="callout warning "><div class="callout-title">Warning</div>
 <p><strong>Deprecation warning</strong> - The command line script has been deprecated and is scheduled for removal in the next major version. Use the <a href="additional/operations.html#http">HTTP management</a> API with <a href="https://curl.se/">curl</a> or similar instead.</p></div>
-<p>The cluster can be managed with the script <code>pekko-cluster</code> provided in the Pekko GitHub repository <a href="https://github.com/akka/akka/tree/main/cluster/jmx-client">here</a>. Place the script and the <code>jmxsh-R5.jar</code> library in the same directory.</p>
+<p>The cluster can be managed with the script <code>pekko-cluster</code> provided in the Pekko GitHub repository <a href="https://github.com/apache/incubator-pekko/tree/main/cluster/jmx-client">here</a>. Place the script and the <code>jmxsh-R5.jar</code> library in the same directory.</p>
 <p>Run it without parameters to see instructions about how to use the script:</p>
 <pre><code>Usage: ./pekko-cluster &lt;node-hostname&gt; &lt;jmx-port&gt; &lt;command&gt; ...
 
@@ -1171,7 +1171,7 @@ Examples: ./pekko-cluster localhost 9999 is-available
 <h2><a href="#configuration" name="configuration" class="anchor"><span class="anchor-link"></span></a>Configuration</h2>
 <p>There are several <a href="typed/cluster.html#configuration">configuration</a> properties for the cluster, and the full <a href="general/configuration-reference.html#config-pekko-cluster">reference configuration</a> for complete information. </p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/cluster-usage.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/cluster-usage.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -1269,7 +1269,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/common/binary-compatibility-rules.html b/content/common/binary-compatibility-rules.html
index 24d0235..4dad455 100644
--- a/content/common/binary-compatibility-rules.html
+++ b/content/common/binary-compatibility-rules.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -499,7 +499,7 @@ See also: https://doc.akka.io/docs/akka/current/common/binary-compatibility-rule
 <h2><a href="#serialization-compatibility-across-scala-versions" name="serialization-compatibility-across-scala-versions" class="anchor"><span class="anchor-link"></span></a>Serialization compatibility across Scala versions</h2>
 <p>Scala does not maintain serialization compatibility across major versions. This means that if Java serialization is used there is no guarantee objects can be cleanly deserialized if serialized with a different version of Scala.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/common/binary-compatibility-rules.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/common/binary-compatibility-rules.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -588,7 +588,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/common/circuitbreaker.html b/content/common/circuitbreaker.html
index 72c0614..ab2e957 100644
--- a/content/common/circuitbreaker.html
+++ b/content/common/circuitbreaker.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>A circuit breaker is used to provide stability and prevent cascading failures in distributed systems. These should be used in conjunction with judicious timeouts at the interfaces between remote systems to prevent the failure of a single component from bringing down all components.</p>
 <p>As an example, we have a web application interacting with a remote third party web service.<br/>Let&rsquo;s say the third party has oversold their capacity and their database melts down under load.<br/>Assume that the database fails in such a way that it takes a very long time to hand back an error to the third party web service. This in turn makes calls fail after a long period of time. Back to our web application, the users have noticed that their form submissions take much longer s [...]
 <p>Introducing circuit breakers on the web service call would cause the requests to begin to fail-fast, letting the user know that something is wrong and that they need not refresh their request. This also confines the failure behavior to only those users that are using functionality dependent on the third party, other users are no longer affected as there is no resource exhaustion. Circuit breakers can also allow savvy developers to mark portions of the site that use the functionality u [...]
-<p>The Pekko library provides an implementation of a circuit breaker called <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBreaker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko.pattern.CircuitBreaker"><co [...]
+<p>The Pekko library provides an implementation of a circuit breaker called <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBreaker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko [...]
 <h2><a href="#what-do-they-do-" name="what-do-they-do-" class="anchor"><span class="anchor-link"></span></a>What do they do?</h2>
 <ul>
   <li>
@@ -435,7 +435,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <li>
     <p>While in <em>Open</em> state:</p>
     <ul>
-      <li>All calls fail-fast with a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreakerOpenException.html" title="org.apache.pekko.pattern.CircuitBreakerOpenException"><code>CircuitBreakerOpenException</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreakerOpenException.html" title="org.apache.pekko.pattern.Circui [...]
+      <li>All calls fail-fast with a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreakerOpenException.html" title="org.apache.pekko.pattern.CircuitBreakerOpenException"><code>CircuitBreakerOpenException</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreakerOpenException.html" title="org [...]
       <li>After the configured <em>resetTimeout</em>, the circuit breaker enters a <em>Half-Open</em> state</li>
     </ul>
   </li>
@@ -451,7 +451,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <li>
     <p>State transition listeners:</p>
     <ul>
-      <li>Callbacks can be provided for every state entry via <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html#onOpen(callback:=%3EUnit):org.apache.pekko.pattern.CircuitBreaker" title="org.apache.pekko.pattern.CircuitBreaker"><code>onOpen</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html#addOnOpe [...]
+      <li>Callbacks can be provided for every state entry via <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html#onOpen(callback:=%3EUnit):org.apache.pekko.pattern.CircuitBreaker" title="org.apache.pekko.pattern.CircuitBreaker"><code>onOpen</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/ [...]
       <li>These are executed in the <a href="http://www.scala-lang.org/api/2.13.8/scala/concurrent/ExecutionContext.html" title="scala.concurrent.ExecutionContext"><code>ExecutionContext</code></a> provided.</li>
     </ul>
   </li>
@@ -459,7 +459,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
     <p>Calls result listeners:</p>
     <ul>
       <li>Callbacks can be used eg. to collect statistics about all invocations or to react on specific call results like success, failures or timeouts.</li>
-      <li>Supported callbacks are: <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html#onCallSuccess(callback:Long=%3EUnit):org.apache.pekko.pattern.CircuitBreaker" title="org.apache.pekko.pattern.CircuitBreaker"><code>onCallSuccess</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html#addOnCallSuccessL [...]
+      <li>Supported callbacks are: <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html#onCallSuccess(callback:Long=%3EUnit):org.apache.pekko.pattern.CircuitBreaker" title="org.apache.pekko.pattern.CircuitBreaker"><code>onCallSuccess</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBr [...]
       <li>These are executed in the <a href="http://www.scala-lang.org/api/2.13.8/scala/concurrent/ExecutionContext.html" title="scala.concurrent.ExecutionContext"><code>ExecutionContext</code></a> provided.</li>
     </ul>
   </li>
@@ -467,7 +467,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p><img src="../images/circuit-breaker-states.png" alt="circuit-breaker-states.png" /></p>
 <h2><a href="#examples" name="examples" class="anchor"><span class="anchor-link"></span></a>Examples</h2>
 <h3><a href="#initialization" name="initialization" class="anchor"><span class="anchor-link"></span></a>Initialization</h3>
-<p>Here&rsquo;s how a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBreaker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBreaker</code></a></span> would be configure [...]
+<p>Here&rsquo;s how a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBreaker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBreaker</code></ [...]
 <ul>
   <li>5 maximum failures</li>
   <li>a call timeout of 10 seconds</li>
@@ -476,7 +476,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/circuitbreaker/CircuitBreakerDocSpec.scala#L17-L25" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import scala.concurrent.duration._
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/circuitbreaker/CircuitBreakerDocSpec.scala#L17-L25" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import scala.concurrent.duration._
 import org.apache.pekko
 import pekko.pattern.CircuitBreaker
 import pekko.pattern.pipe
@@ -496,7 +496,7 @@ class DangerousActor extends Actor with ActorLogging {
     log.warning(&quot;My CircuitBreaker is now open, and will not close for one minute&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/circuitbreaker/DangerousJavaActor.java#L17-L27" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>import org.apache.pekko.actor.AbstractActor;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/circuitbreaker/DangerousJavaActor.java#L17-L27" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>import org.apache.pekko.actor.AbstractActor;
 import org.apache.pekko.event.LoggingAdapter;
 import java.time.Duration;
 import org.apache.pekko.pattern.CircuitBreaker;
@@ -532,7 +532,7 @@ public class DangerousJavaActor extends AbstractActor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/circuitbreaker/CircuitBreakerDocSpec.scala#L43-L50" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def dangerousCall: String = &quot;This really isn&#39;t that dangerous of a call after all&quot;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/circuitbreaker/CircuitBreakerDocSpec.scala#L43-L50" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def dangerousCall: String = &quot;This really isn&#39;t that dangerous of a call after all&quot;
 
 def receive = {
   case &quot;is my middle name&quot; =&gt;
@@ -542,7 +542,7 @@ def receive = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/circuitbreaker/DangerousJavaActor.java#L53-L76" target="_blank" title="Go to snippet source">source</a><code class="language-java">public String dangerousCall() {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/circuitbreaker/DangerousJavaActor.java#L53-L76" target="_blank" title="Go to snippet source">source</a><code class="language-java">public String dangerousCall() {
   return &quot;This really isn&#39;t that dangerous of a call after all&quot;;
 }
 
@@ -567,7 +567,7 @@ public Receive createReceive() {
       .build();
 }</code></pre></dd>
 </dl><div class="callout note "><div class="callout-title">Note</div>
-<p>Using the <span class="group-scala"><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker$.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBreaker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker$.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBreaker</code></a></span> [...]
+<p>Using the <span class="group-scala"><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker$.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBreaker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker$.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>Circ [...]
 <h3><a href="#control-failure-count-explicitly" name="control-failure-count-explicitly" class="anchor"><span class="anchor-link"></span></a>Control failure count explicitly</h3>
 <p>By default, the circuit breaker treats <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/Exception.html" title="java.lang.Exception"><code>Exception</code></a> as failure in synchronized API, or failed <span class="group-scala"><a href="http://www.scala-lang.org/api/2.13.8/scala/concurrent/Future.html" title="scala.concurrent.Future"><code>Future</code></a></span><span class="group-java"><a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.bas [...]
 <p>All methods above accept an argument <code>defineFailureFn</code></p>
@@ -576,7 +576,7 @@ public Receive createReceive() {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/circuitbreaker/CircuitBreakerDocSpec.scala#L88-L99" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def luckyNumber(): Future[Int] = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/circuitbreaker/CircuitBreakerDocSpec.scala#L88-L99" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def luckyNumber(): Future[Int] = {
   val evenNumberAsFailure: Try[Int] =&gt; Boolean = {
     case Success(n) =&gt; n % 2 == 0
     case Failure(_) =&gt; true
@@ -590,7 +590,7 @@ public Receive createReceive() {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/circuitbreaker/EvenNoFailureJavaExample.java#L25-L44" target="_blank" title="Go to snippet source">source</a><code class="language-java">private final CircuitBreaker breaker;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/circuitbreaker/EvenNoFailureJavaExample.java#L25-L44" target="_blank" title="Go to snippet source">source</a><code class="language-java">private final CircuitBreaker breaker;
 
 public EvenNoFailureJavaExample() {
   this.breaker =
@@ -612,13 +612,13 @@ public int luckyNumber() {
 </code></pre></dd>
 </dl>
 <h3><a href="#low-level-api" name="low-level-api" class="anchor"><span class="anchor-link"></span></a>Low level API</h3>
-<p>The low-level API allows you to describe the behavior of the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBreaker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBr [...]
-<p>As can be seen in the examples below, a <code>Tell Protection</code> pattern could be implemented by using the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html#succeed():Unit" title="org.apache.pekko.pattern.CircuitBreaker"><code>succeed</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html#succee [...]
+<p>The low-level API allows you to describe the behavior of the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko.pattern.CircuitBreaker"><code>CircuitBreaker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html" title="org.apache.pekko.pattern.Cir [...]
+<p>As can be seen in the examples below, a <code>Tell Protection</code> pattern could be implemented by using the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/pattern/CircuitBreaker.html#succeed():Unit" title="org.apache.pekko.pattern.CircuitBreaker"><code>succeed</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/patter [...]
 <p>The below example doesn&rsquo;t make a remote call when the state is <em>HalfOpen</em>. Using the power-user APIs, it is your responsibility to judge when to make remote calls in <em>HalfOpen</em>.</p></div>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/circuitbreaker/CircuitBreakerDocSpec.scala#L66-L81" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.ReceiveTimeout
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/circuitbreaker/CircuitBreakerDocSpec.scala#L66-L81" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.ReceiveTimeout
 
 def receive = {
   case &quot;call&quot; if breaker.isClosed =&gt; {
@@ -636,7 +636,7 @@ def receive = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/circuitbreaker/TellPatternJavaActor.java#L47-L58" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/circuitbreaker/TellPatternJavaActor.java#L47-L58" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public Receive createReceive() {
   return receiveBuilder()
       .match(
@@ -650,7 +650,7 @@ public Receive createReceive() {
 }</code></pre></dd>
 </dl>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/common/circuitbreaker.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/common/circuitbreaker.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -735,7 +735,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/common/io-layer.html b/content/common/io-layer.html
index 2f56ae8..116d33c 100644
--- a/content/common/io-layer.html
+++ b/content/common/io-layer.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -431,7 +431,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <li>extensibility for integrating new transports by way of a very lean SPI; the goal is to not force I/O mechanisms into a lowest common denominator but instead allow completely protocol-specific user-level APIs.</li>
 </ul>
 <h2><a href="#basic-architecture" name="basic-architecture" class="anchor"><span class="anchor-link"></span></a>Basic Architecture</h2>
-<p>Each transport implementation will be made available as a separate Pekko extension, offering an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</co [...]
+<p>Each transport implementation will be made available as a separate Pekko extension, offering an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor. [...]
 <p>The central element of the implementation is the transport-specific “selector” actor; in the case of TCP this would wrap a <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/nio/channels/Selector.html" title="java.nio.channels.Selector"><code>java.nio.channels.Selector</code></a>. The channel actors register their interest in readability or writability of their channel by sending corresponding messages to their assigned selector actor. However, the actual chann [...]
 <p>The assignment of channels to selectors is performed by the manager actor and remains unchanged for the entire lifetime of a channel. Thereby the management actor &ldquo;stripes&rdquo; new channels across one or more selector actors based on some implementation-specific distribution logic. This logic may be delegated (in part) to the selectors actors, which could, for example, choose to reject the assignment of a new channel when they consider themselves to be at capacity.</p>
 <p>The manager actor creates (and therefore supervises) the selector actors, which in turn create and supervise their channel actors. The actor hierarchy of one single transport implementation therefore consists of three distinct actor levels, with the management actor at the top-, the channel actors at the leaf- and the selector actors at the mid-level.</p>
@@ -439,11 +439,11 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h2><a href="#design-benefits" name="design-benefits" class="anchor"><span class="anchor-link"></span></a>Design Benefits</h2>
 <p>Staying within the actor model for the whole implementation allows us to remove the need for explicit thread handling logic, and it also means that there are no locks involved (besides those which are part of the underlying transport library). Writing only actor code results in a cleaner implementation, while Pekko’s efficient actor messaging does not impose a high tax for this benefit. In fact the event-based nature of I/O maps so well to the actor model that we expect clear performa [...]
 <p>Another benefit of supervision hierarchies is that clean-up of resources comes naturally: shutting down a selector actor will automatically clean up all channel actors, allowing proper closing of the channels and sending the appropriate messages to user-level client actors. DeathWatch allows the channel actors to notice the demise of their user-level handler actors and terminate in an orderly fashion in that case as well; this naturally reduces the chances of leaking open channels.</p>
-<p>The choice of using <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span> for exposing all functionality entails that these references  [...]
+<p>The choice of using <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span> for exposing all functionality en [...]
 <h2><a href="#how-to-go-about-adding-a-new-transport" name="how-to-go-about-adding-a-new-transport" class="anchor"><span class="anchor-link"></span></a>How to go about Adding a New Transport</h2>
 <p>The best start is to study the TCP reference implementation to get a good grip on the basic working principle and then design an implementation, which is similar in spirit, but adapted to the new protocol in question. There are vast differences between I/O mechanisms (e.g. compare file I/O to a message broker) and the goal of this I/O layer is explicitly <strong>not</strong> to shoehorn all of them into a uniform API, which is why only the basic architecture ideas are documented here.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/common/io-layer.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/common/io-layer.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -529,7 +529,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/common/may-change.html b/content/common/may-change.html
index 184fdf7..dba638e 100644
--- a/content/common/may-change.html
+++ b/content/common/may-change.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -434,7 +434,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <li><a href="../typed/reliable-delivery.html">Reliable Delivery</a></li>
 </ul>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/common/may-change.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/common/may-change.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -504,7 +504,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/common/other-modules.html b/content/common/other-modules.html
index 1a1cac1..f2712b4 100644
--- a/content/common/other-modules.html
+++ b/content/common/other-modules.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -454,7 +454,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <li><a href="https://doc.akka.io/docs/akka-enhancements/current/gdpr/index.html">Pekko GDPR for Persistence</a></li>
 </ul>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/common/other-modules.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/common/other-modules.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -548,7 +548,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/coordinated-shutdown.html b/content/coordinated-shutdown.html
index 4a1c2a0..eb63ea9 100644
--- a/content/coordinated-shutdown.html
+++ b/content/coordinated-shutdown.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -418,7 +418,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#coordinated-shutdown" name="coordinated-shutdown" class="anchor"><span class="anchor-link"></span></a>Coordinated Shutdown</h1>
 <p>Under normal conditions, when an <code>ActorSystem</code> is terminated or the JVM process is shut down, certain actors and services will be stopped in a specific order. </p>
-<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/CoordinatedShutdown$.html" title="org.apache.pekko.actor.CoordinatedShutdown"><code>CoordinatedShutdown</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/CoordinatedShutdown$.html" title="org.apache.pekko.actor.CoordinatedShutdown"><code>CoordinatedShutdown</code></a></span> extension [...]
+<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/CoordinatedShutdown$.html" title="org.apache.pekko.actor.CoordinatedShutdown"><code>CoordinatedShutdown</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/CoordinatedShutdown$.html" title="org.apache.pekko.actor.CoordinatedShutdown"><code>CoordinatedShutdown [...]
 <p>Especially the phases <code>before-service-unbind</code>, <code>before-cluster-shutdown</code> and <code>before-actor-system-terminate</code> are intended for application specific phases or tasks.</p>
 <p>The order of the shutdown phases is defined in configuration <code>pekko.coordinated-shutdown.phases</code>. See the default phases in the <code>reference.conf</code> tab:</p>
 <dl>
@@ -449,7 +449,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <dt>reference.conf (HOCON)
   </dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/actor/src/main/resources/reference.conf#L1203-L1306" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># CoordinatedShutdown is enabled by default and will run the tasks that
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/actor/src/main/resources/reference.conf#L1203-L1306" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># CoordinatedShutdown is enabled by default and will run the tasks that
 # are added to these phases by individual Pekko modules and user logic.
 #
 # The phases are ordered as a DAG by defining the dependencies between the phases
@@ -560,7 +560,7 @@ phases {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/typed/CoordinatedActorShutdownSpec.scala#L29-L56" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object MyActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/typed/CoordinatedActorShutdownSpec.scala#L29-L56" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object MyActor {
 
   trait Messages
   case class Stop(replyTo: ActorRef[Done]) extends Messages
@@ -582,7 +582,7 @@ phases {
   }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/typed/CoordinatedActorShutdownTest.java#L24-L86" target="_blank" title="Go to snippet source">source</a><code class="language-java">import static org.apache.pekko.actor.typed.javadsl.AskPattern.ask;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/typed/CoordinatedActorShutdownTest.java#L24-L86" target="_blank" title="Go to snippet source">source</a><code class="language-java">import static org.apache.pekko.actor.typed.javadsl.AskPattern.ask;
 
 public static class MyActor extends AbstractBehavior&lt;MyActor.Messages&gt; {
   interface Messages {}
@@ -623,7 +623,7 @@ public static class MyActor extends AbstractBehavior&lt;MyActor.Messages&gt; {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/typed/CoordinatedActorShutdownSpec.scala#L69-L78" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val c: Cancellable =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/typed/CoordinatedActorShutdownSpec.scala#L69-L78" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val c: Cancellable =
   CoordinatedShutdown(system).addCancellableTask(CoordinatedShutdown.PhaseBeforeServiceUnbind, &quot;cleanup&quot;) { () =&gt;
     Future {
       cleanup()
@@ -635,25 +635,25 @@ public static class MyActor extends AbstractBehavior&lt;MyActor.Messages&gt; {
 c.cancel()</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/typed/CoordinatedActorShutdownTest.java#L110-L115" target="_blank" title="Go to snippet source">source</a><code class="language-java">Cancellable cancellable =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/typed/CoordinatedActorShutdownTest.java#L110-L115" target="_blank" title="Go to snippet source">source</a><code class="language-java">Cancellable cancellable =
     CoordinatedShutdown.get(system)
         .addCancellableTask(
             CoordinatedShutdown.PhaseBeforeServiceUnbind(), &quot;someTaskCleanup&quot;, () -&gt; cleanup());
 // much later...
 cancellable.cancel();</code></pre></dd>
 </dl>
-<p>In the above example, it may be more convenient to simply stop the actor when it&rsquo;s done shutting down, rather than send back a done message, and for the shutdown task to not complete until the actor is terminated. A convenience method is provided that adds a task that sends a message to the actor and then watches its termination (there is currently no corresponding functionality for the new actors API <a href="https://github.com/akka/akka/issues/29056">see #29056</a>):</p>
+<p>In the above example, it may be more convenient to simply stop the actor when it&rsquo;s done shutting down, rather than send back a done message, and for the shutdown task to not complete until the actor is terminated. A convenience method is provided that adds a task that sends a message to the actor and then watches its termination (there is currently no corresponding functionality for the new actors API <a href="https://github.com/apache/incubator-pekko/issues/29056">see #29056</a>):</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L744-L748" target="_blank" title="Go to snippet source">source</a><code class="language-scala">CoordinatedShutdown(system).addActorTerminationTask(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/ActorDocSpec.scala#L744-L748" target="_blank" title="Go to snippet source">source</a><code class="language-scala">CoordinatedShutdown(system).addActorTerminationTask(
   CoordinatedShutdown.PhaseBeforeServiceUnbind,
   &quot;someTaskName&quot;,
   someActor,
   Some(&quot;stop&quot;))</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L900-L905" target="_blank" title="Go to snippet source">source</a><code class="language-java">CoordinatedShutdown.get(system)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/ActorDocTest.java#L900-L905" target="_blank" title="Go to snippet source">source</a><code class="language-java">CoordinatedShutdown.get(system)
     .addActorTerminationTask(
         CoordinatedShutdown.PhaseBeforeServiceUnbind(),
         &quot;someTaskName&quot;,
@@ -661,11 +661,11 @@ cancellable.cancel();</code></pre></dd>
         Optional.of(&quot;stop&quot;));</code></pre></dd>
 </dl>
 <p>Tasks should typically be registered as early as possible after system startup. When running the coordinated shutdown tasks that have been registered will be performed but tasks that are added too late will not be run.</p>
-<p>To start the coordinated shutdown process you can either invoke <code>terminate()</code> on the <code>ActorSystem</code>, or <span class="group-scala"><code>run</code></span> <span class="group-java"><code>runAll</code></span> on the <code>CoordinatedShutdown</code> extension and pass it a class implementing <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/CoordinatedShutdown$$Reason.html" title="org.apache.pekko.acto [...]
+<p>To start the coordinated shutdown process you can either invoke <code>terminate()</code> on the <code>ActorSystem</code>, or <span class="group-scala"><code>run</code></span> <span class="group-java"><code>runAll</code></span> on the <code>CoordinatedShutdown</code> extension and pass it a class implementing <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/CoordinatedShutdown$$Reason.html" title="org.apa [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/typed/CoordinatedActorShutdownSpec.scala#L90-L96" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// shut down with `ActorSystemTerminateReason`
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/typed/CoordinatedActorShutdownSpec.scala#L90-L96" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// shut down with `ActorSystemTerminateReason`
 system.terminate()
 
 // or define a specific reason
@@ -674,7 +674,7 @@ case object UserInitiatedShutdown extends CoordinatedShutdown.Reason
 val done: Future[Done] = CoordinatedShutdown(system).run(UserInitiatedShutdown)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/typed/CoordinatedActorShutdownTest.java#L126-L138" target="_blank" title="Go to snippet source">source</a><code class="language-java">// shut down with `ActorSystemTerminateReason`
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/typed/CoordinatedActorShutdownTest.java#L126-L138" target="_blank" title="Go to snippet source">source</a><code class="language-java">// shut down with `ActorSystemTerminateReason`
 system.terminate();
 
 // or define a specific reason
@@ -701,12 +701,12 @@ CompletionStage&lt;Done&gt; done =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/typed/CoordinatedActorShutdownSpec.scala#L82-L84" target="_blank" title="Go to snippet source">source</a><code class="language-scala">CoordinatedShutdown(system).addJvmShutdownHook {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/typed/CoordinatedActorShutdownSpec.scala#L82-L84" target="_blank" title="Go to snippet source">source</a><code class="language-scala">CoordinatedShutdown(system).addJvmShutdownHook {
   println(&quot;custom JVM shutdown hook...&quot;)
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/typed/CoordinatedActorShutdownTest.java#L119-L120" target="_blank" title="Go to snippet source">source</a><code class="language-java">CoordinatedShutdown.get(system)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/typed/CoordinatedActorShutdownTest.java#L119-L120" target="_blank" title="Go to snippet source">source</a><code class="language-java">CoordinatedShutdown.get(system)
     .addJvmShutdownHook(() -&gt; System.out.println(&quot;custom JVM shutdown hook...&quot;));</code></pre></dd>
 </dl>
 <p>For some tests it might be undesired to terminate the <code>ActorSystem</code> via <code>CoordinatedShutdown</code>. You can disable that by adding the following to the configuration of the <code>ActorSystem</code> that is used in the test:</p>
@@ -717,7 +717,7 @@ pekko.coordinated-shutdown.run-by-jvm-shutdown-hook = off
 pekko.cluster.run-coordinated-shutdown-when-down = off
 </code></pre>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/coordinated-shutdown.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/coordinated-shutdown.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -787,7 +787,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/coordination.html b/content/coordination.html
index b424623..278c769 100644
--- a/content/coordination.html
+++ b/content/coordination.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -418,12 +418,12 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#coordination" name="coordination" class="anchor"><span class="anchor-link"></span></a>Coordination</h1>
 <p>Pekko Coordination is a set of tools for distributed coordination.</p>
-<h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-coordination" % PekkoVersion</code></pre></dd><dt>Gradle</dt><dd><pre class="prettyprint"><code class="language-gradle">def versions = [
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-coordination_${versions.ScalaBinary}"
 }</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
@@ -434,7 +434,7 @@ dependencies {
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -450,7 +450,7 @@ dependencies {
 <tr><th colspan="2">Project Info: Pekko Coordination</th></tr>
   <tr><th>Artifact</th><td><div>org.apache.pekko</div>
   <div>pekko-coordination</div>
-  <div>0.0.0+26533-ec68a528-SNAPSHOT</div>
+  <div>0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT</div>
   <div><a href="project/links.html#snapshots-repository">Snapshots are available</a></div>
   </td></tr>
   <tr><th>JDK versions</th><td><div>Adopt OpenJDK 8</div><div>Adopt OpenJDK 11</div></td></tr>
@@ -465,11 +465,11 @@ dependencies {
   <div><a href="https://doc.akka.io/japi/akka/snapshot/akka/coordination/lease/package-summary.html" target="_blank" rel="noopener noreferrer">API (Javadoc)</a></div>
   </td></tr>
   <tr><th>Forums</th><td>
-  <div><a href="https://discuss.akka.io" target="_blank" rel="noopener noreferrer">Lightbend Discuss</a></div>
-  <div><a href="https://gitter.im/akka/akka" target="_blank" rel="noopener noreferrer">akka/akka Gitter channel</a></div>
+  <div><a href="https://lists.apache.org/list.html?dev@pekko.apache.org" target="_blank" rel="noopener noreferrer">Apache Pekko Dev mailing list</a></div>
+  <div><a href="https://github.com/apache/incubator-pekko/discussions" target="_blank" rel="noopener noreferrer">apache/incubator-pekko discussion</a></div>
   </td></tr>
   <tr><th>Release notes</th><td><a href="https://akka.io/blog/news-archive.html">akka.io blog</a></td></tr>
-  <tr><th>Issues</th><td><a href="https://github.com/akka/akka/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
+  <tr><th>Issues</th><td><a href="https://github.com/apache/incubator-pekko/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
   <tr><th>Sources</th><td><a href="https://github.com/apache/incubator-pekko" target="_blank" rel="noopener noreferrer">https://github.com/apache/incubator-pekko</a></td></tr>
 </table>
 
@@ -495,13 +495,13 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/coordination/LeaseDocSpec.scala#L81-L84" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val lease = LeaseProvider(system).getLease(&quot;&lt;name of the lease&gt;&quot;, &quot;docs-lease&quot;, &quot;owner&quot;)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/coordination/LeaseDocSpec.scala#L81-L84" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val lease = LeaseProvider(system).getLease(&quot;&lt;name of the lease&gt;&quot;, &quot;docs-lease&quot;, &quot;owner&quot;)
 val acquired: Future[Boolean] = lease.acquire()
 val stillAcquired: Boolean = lease.checkLease()
 val released: Future[Boolean] = lease.release()</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/coordination/LeaseDocTest.java#L88-L92" target="_blank" title="Go to snippet source">source</a><code class="language-java">Lease lease =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/coordination/LeaseDocTest.java#L88-L92" target="_blank" title="Go to snippet source">source</a><code class="language-java">Lease lease =
     LeaseProvider.get(system).getLease(&quot;&lt;name of the lease&gt;&quot;, &quot;jdocs-lease&quot;, &quot;&lt;owner name&gt;&quot;);
 CompletionStage&lt;Boolean&gt; acquired = lease.acquire();
 boolean stillAcquired = lease.checkLease();
@@ -514,10 +514,10 @@ CompletionStage&lt;Boolean&gt; released = lease.release();</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/coordination/LeaseDocSpec.scala#L92" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val owner = Cluster(system).selfAddress.hostPort</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/coordination/LeaseDocSpec.scala#L92" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val owner = Cluster(system).selfAddress.hostPort</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/coordination/LeaseDocTest.java#L100" target="_blank" title="Go to snippet source">source</a><code class="language-java">// String owner = Cluster.get(system).selfAddress().hostPort();</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/coordination/LeaseDocTest.java#L100" target="_blank" title="Go to snippet source">source</a><code class="language-java">// String owner = Cluster.get(system).selfAddress().hostPort();</code></pre></dd>
 </dl>
 <p>For use cases where multiple different leases on the same node then something unique must be added to the name. For example a lease can be used with Cluster Sharding and in this case the shard Id is included in the lease name for each shard.</p>
 <h3><a href="#setting-a-lease-heartbeat" name="setting-a-lease-heartbeat" class="anchor"><span class="anchor-link"></span></a>Setting a lease heartbeat</h3>
@@ -534,7 +534,7 @@ CompletionStage&lt;Boolean&gt; released = lease.release();</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/coordination/LeaseDocSpec.scala#L27-L44" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class SampleLease(settings: LeaseSettings) extends Lease(settings) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/coordination/LeaseDocSpec.scala#L27-L44" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class SampleLease(settings: LeaseSettings) extends Lease(settings) {
 
   override def acquire(): Future[Boolean] = {
     Future.successful(true)
@@ -554,7 +554,7 @@ CompletionStage&lt;Boolean&gt; released = lease.release();</code></pre></dd>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/coordination/LeaseDocTest.java#L35-L67" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class SampleLease extends Lease {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/coordination/LeaseDocTest.java#L35-L67" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class SampleLease extends Lease {
 
   private LeaseSettings settings;
 
@@ -598,7 +598,7 @@ CompletionStage&lt;Boolean&gt; released = lease.release();</code></pre></dd>
 <p>In addition, it is expected that a lease implementation will include a time to live mechanism meaning that a lease won&rsquo;t be held for ever in case the node crashes. If a user prefers to have outside intervention in this case for maximum safety then the time to live can be set to infinite.</p>
 <p>The configuration must define the <code>lease-class</code> property for the FQCN of the lease implementation.</p>
 <p>The lease implementation should have support for the following properties where the defaults come from <code>pekko.coordination.lease</code>:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/coordination/src/main/resources/reference.conf#L10-L19" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># if the node that acquired the leases crashes, how long should the lease be held before another owner can get it
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/coordination/src/main/resources/reference.conf#L10-L19" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># if the node that acquired the leases crashes, how long should the lease be held before another owner can get it
 heartbeat-timeout = 120s
 
 # interval for communicating with the third party to confirm the lease is still held
@@ -612,7 +612,7 @@ lease-operation-timeout = 5s
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/coordination/LeaseDocSpec.scala#L53-L60" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.actor.provider = cluster
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/coordination/LeaseDocSpec.scala#L53-L60" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.actor.provider = cluster
 docs-lease {
   lease-class = &quot;docs.coordination.SampleLease&quot;
   heartbeat-timeout = 100s
@@ -622,7 +622,7 @@ docs-lease {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/coordination/LeaseDocSpec.scala#L53-L60" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.actor.provider = cluster
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/coordination/LeaseDocSpec.scala#L53-L60" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.actor.provider = cluster
 docs-lease {
   lease-class = &quot;docs.coordination.SampleLease&quot;
   heartbeat-timeout = 100s
@@ -632,7 +632,7 @@ docs-lease {
 }</code></pre></dd>
 </dl>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/coordination.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/coordination.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -720,7 +720,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/discovery/index.html b/content/discovery/index.html
index 87452c6..84ddabd 100644
--- a/content/discovery/index.html
+++ b/content/discovery/index.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -431,12 +431,12 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <li><a href="https://doc.akka.io/docs/akka-management/current/discovery/consul.html">Consul</a></li>
   <li><a href="https://doc.akka.io/docs/akka-management/current/discovery/marathon.html">Marathon API</a></li>
 </ul>
-<h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-discovery" % PekkoVersion</code></pre></dd><dt>Gradle</dt><dd><pre class="prettyprint"><code class="language-gradle">def versions = [
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-discovery_${versions.ScalaBinary}"
 }</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
@@ -447,7 +447,7 @@ dependencies {
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -463,7 +463,7 @@ dependencies {
 <tr><th colspan="2">Project Info: Pekko Discovery</th></tr>
   <tr><th>Artifact</th><td><div>org.apache.pekko</div>
   <div>pekko-discovery</div>
-  <div>0.0.0+26533-ec68a528-SNAPSHOT</div>
+  <div>0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT</div>
   <div><a href="project/links.html#snapshots-repository">Snapshots are available</a></div>
   </td></tr>
   <tr><th>JDK versions</th><td><div>Adopt OpenJDK 8</div><div>Adopt OpenJDK 11</div></td></tr>
@@ -478,11 +478,11 @@ dependencies {
   <div><a href="https://doc.akka.io/japi/akka/snapshot/akka/discovery/package-summary.html" target="_blank" rel="noopener noreferrer">API (Javadoc)</a></div>
   </td></tr>
   <tr><th>Forums</th><td>
-  <div><a href="https://discuss.akka.io" target="_blank" rel="noopener noreferrer">Lightbend Discuss</a></div>
-  <div><a href="https://gitter.im/akka/akka" target="_blank" rel="noopener noreferrer">akka/akka Gitter channel</a></div>
+  <div><a href="https://lists.apache.org/list.html?dev@pekko.apache.org" target="_blank" rel="noopener noreferrer">Apache Pekko Dev mailing list</a></div>
+  <div><a href="https://github.com/apache/incubator-pekko/discussions" target="_blank" rel="noopener noreferrer">apache/incubator-pekko discussion</a></div>
   </td></tr>
   <tr><th>Release notes</th><td><a href="https://akka.io/blog/news-archive.html">akka.io blog</a></td></tr>
-  <tr><th>Issues</th><td><a href="https://github.com/akka/akka/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
+  <tr><th>Issues</th><td><a href="https://github.com/apache/incubator-pekko/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
   <tr><th>Sources</th><td><a href="https://github.com/apache/incubator-pekko" target="_blank" rel="noopener noreferrer">https://github.com/apache/incubator-pekko</a></td></tr>
 </table>
 
@@ -493,27 +493,27 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/discovery/src/test/scala/doc/org/apache/pekko/discovery/CompileOnlySpec.scala#L25-L28" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.discovery.Discovery
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/discovery/src/test/scala/doc/org/apache/pekko/discovery/CompileOnlySpec.scala#L25-L28" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.discovery.Discovery
 
 val system = ActorSystem()
 val serviceDiscovery = Discovery(system).discovery</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/discovery/src/test/java/jdoc/org/apache/pekko/discovery/CompileOnlyTest.java#L27-L28" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorSystem as = ActorSystem.create();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/discovery/src/test/java/jdoc/org/apache/pekko/discovery/CompileOnlyTest.java#L27-L28" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorSystem as = ActorSystem.create();
 ServiceDiscovery serviceDiscovery = Discovery.get(as).discovery();</code></pre></dd>
 </dl>
 <p>A <code>Lookup</code> contains a mandatory <code>serviceName</code> and an optional <code>portName</code> and <code>protocol</code>. How these are interpreted is discovery method dependent e.g.DNS does an A/AAAA record query if any of the fields are missing and an SRV query for a full look up:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/discovery/src/test/scala/doc/org/apache/pekko/discovery/CompileOnlySpec.scala#L32-L36" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.discovery.Lookup
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/discovery/src/test/scala/doc/org/apache/pekko/discovery/CompileOnlySpec.scala#L32-L36" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.discovery.Lookup
 
 serviceDiscovery.lookup(Lookup(&quot;pekko.io&quot;), 1.second)
 // Convenience for a Lookup with only a serviceName
 serviceDiscovery.lookup(&quot;pekko.io&quot;, 1.second)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/discovery/src/test/java/jdoc/org/apache/pekko/discovery/CompileOnlyTest.java#L32-L34" target="_blank" title="Go to snippet source">source</a><code class="language-java">serviceDiscovery.lookup(Lookup.create(&quot;pekko.io&quot;), Duration.ofSeconds(1));
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/discovery/src/test/java/jdoc/org/apache/pekko/discovery/CompileOnlyTest.java#L32-L34" target="_blank" title="Go to snippet source">source</a><code class="language-java">serviceDiscovery.lookup(Lookup.create(&quot;pekko.io&quot;), Duration.ofSeconds(1));
 // convenience for a Lookup with only a serviceName
 serviceDiscovery.lookup(&quot;pekko.io&quot;, Duration.ofSeconds(1));</code></pre></dd>
 </dl>
@@ -521,7 +521,7 @@ serviceDiscovery.lookup(&quot;pekko.io&quot;, Duration.ofSeconds(1));</code></pr
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/discovery/src/test/scala/doc/org/apache/pekko/discovery/CompileOnlySpec.scala#L40-L45" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/discovery/src/test/scala/doc/org/apache/pekko/discovery/CompileOnlySpec.scala#L40-L45" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.discovery.Lookup
 import pekko.discovery.ServiceDiscovery.Resolved
 
@@ -529,7 +529,7 @@ val lookup: Future[Resolved] =
   serviceDiscovery.lookup(Lookup(&quot;pekko.io&quot;).withPortName(&quot;remoting&quot;).withProtocol(&quot;tcp&quot;), 1.second)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/discovery/src/test/java/jdoc/org/apache/pekko/discovery/CompileOnlyTest.java#L38-L41" target="_blank" title="Go to snippet source">source</a><code class="language-java">CompletionStage&lt;ServiceDiscovery.Resolved&gt; lookup =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/discovery/src/test/java/jdoc/org/apache/pekko/discovery/CompileOnlyTest.java#L38-L41" target="_blank" title="Go to snippet source">source</a><code class="language-java">CompletionStage&lt;ServiceDiscovery.Resolved&gt; lookup =
     serviceDiscovery.lookup(
         Lookup.create(&quot;pekko.io&quot;).withPortName(&quot;remoting&quot;).withProtocol(&quot;tcp&quot;),
         Duration.ofSeconds(1));</code></pre></dd>
@@ -549,7 +549,7 @@ val lookup: Future[Resolved] =
   <li>SRV protocol = protocol</li>
 </ul>
 <p>Configure <code>pekko-dns</code> to be used as the discovery implementation in your <code>application.conf</code>:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/discovery/DnsDiscoveryDocSpec.scala#L25-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/discovery/DnsDiscoveryDocSpec.scala#L25-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko {
   discovery {
     method = pekko-dns
   }
@@ -558,7 +558,7 @@ val lookup: Future[Resolved] =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/discovery/DnsDiscoveryDocSpec.scala#L39-L45" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/discovery/DnsDiscoveryDocSpec.scala#L39-L45" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.discovery.Discovery
 import pekko.discovery.ServiceDiscovery
 
@@ -567,7 +567,7 @@ val discovery: ServiceDiscovery = Discovery(system).discovery
 val result: Future[ServiceDiscovery.Resolved] = discovery.lookup(&quot;pekko.io&quot;, resolveTimeout = 3.seconds)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/discovery/DnsDiscoveryDocTest.java#L18-L56" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.discovery.Discovery;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/discovery/DnsDiscoveryDocTest.java#L18-L56" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.discovery.Discovery;
 import org.apache.pekko.discovery.ServiceDiscovery;
 
 ServiceDiscovery discovery = Discovery.get(system).discovery();
@@ -689,7 +689,7 @@ a-double.pekko.test.     86400   IN      A       192.168.1.22
   <li><code>discovery-method</code> now has to be a configuration location under <code>pekko.discovery</code> with at minimum a property <code>class</code> specifying the fully qualified name of the implementation of <code>org.apache.pekko.discovery.ServiceDiscovery</code>.  Previous versions allowed this to be a class name or a fully qualified config location e.g. <code>pekko.discovery.kubernetes-api</code> rather than just <code>kubernetes-api</code></li>
 </ul>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/discovery/index.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/discovery/index.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -777,7 +777,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/dispatchers.html b/content/dispatchers.html
index ad17cba..399f66f 100644
--- a/content/dispatchers.html
+++ b/content/dispatchers.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <p>For the full documentation of this feature and for new projects see <a href="typed/dispatchers.html">Dispatchers</a>.</p>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>Dispatchers are part of core Pekko, which means that they are part of the pekko-actor dependency:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>Dispatchers are part of core Pekko, which means that they are part of the pekko-actor dependency:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -430,7 +430,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -445,7 +445,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -455,19 +455,19 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L350-L351" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// for use with Futures, Scheduler, etc.
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L350-L351" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// for use with Futures, Scheduler, etc.
 implicit val executionContext = system.dispatchers.lookup(&quot;my-dispatcher&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L100-L103" target="_blank" title="Go to snippet source">source</a><code class="language-java">// this is scala.concurrent.ExecutionContextExecutor, which implements
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L100-L103" target="_blank" title="Go to snippet source">source</a><code class="language-java">// this is scala.concurrent.ExecutionContextExecutor, which implements
 // both scala.concurrent.ExecutionContext (for use with Futures, Scheduler, etc.)
 // and java.util.concurrent.Executor (for use with CompletableFuture etc.)
 final ExecutionContextExecutor ex = system.dispatchers().lookup(&quot;my-dispatcher&quot;);</code></pre></dd>
 </dl>
 <h2><a href="#setting-the-dispatcher-for-an-actor" name="setting-the-dispatcher-for-an-actor" class="anchor"><span class="anchor-link"></span></a>Setting the dispatcher for an Actor</h2>
-<p>So in case you want to give your <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span> a different dispatcher than the default, you need to do two things [...]
+<p>So in case you want to give your <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span> a different dispatcher than the defaul [...]
 <!--same config text for Scala & Java-->
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L58-L76" target="_blank" title="Go to snippet source">source</a><code class="language-scala">my-dispatcher {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L58-L76" target="_blank" title="Go to snippet source">source</a><code class="language-scala">my-dispatcher {
   # Dispatcher is the name of the event-based dispatcher
   type = Dispatcher
   # What kind of ExecutionService to use
@@ -489,7 +489,7 @@ final ExecutionContextExecutor ex = system.dispatchers().lookup(&quot;my-dispatc
 <p>Note that the <code>parallelism-max</code> does not set the upper bound on the total number of threads allocated by the ForkJoinPool. It is a setting specifically talking about the number of <em>hot</em> threads the pool keep running in order to reduce the latency of handling a new incoming task. You can read more about parallelism in the JDK&rsquo;s <a href="https://docs.oracle.com/javase/8/docs/api/java/util/concurrent/ForkJoinPool.html">ForkJoinPool documentation</a>.</p></div>
 <p>Another example that uses the &ldquo;thread-pool-executor&rdquo;:</p>
 <!--same config text for Scala & Java-->
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L140-L147" target="_blank" title="Go to snippet source">source</a><code class="language-scala">blocking-io-dispatcher {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L140-L147" target="_blank" title="Go to snippet source">source</a><code class="language-scala">blocking-io-dispatcher {
   type = Dispatcher
   executor = &quot;thread-pool-executor&quot;
   thread-pool-executor {
@@ -503,14 +503,14 @@ final ExecutionContextExecutor ex = system.dispatchers().lookup(&quot;my-dispatc
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L306-L307" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Props
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L306-L307" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Props
 val myActor = context.actorOf(Props[MyActor](), &quot;myactor&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L66" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef myActor = system.actorOf(Props.create(MyActor.class), &quot;myactor&quot;);</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L66" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef myActor = system.actorOf(Props.create(MyActor.class), &quot;myactor&quot;);</code></pre></dd>
 </dl>
 <!--same config text for Scala & Java-->
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L179-L183" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.actor.deployment {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L179-L183" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.actor.deployment {
   /myactor {
     dispatcher = my-dispatcher
   }
@@ -519,17 +519,17 @@ val myActor = context.actorOf(Props[MyActor](), &quot;myactor&quot;)</code></pre
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L314-L316" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Props
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L314-L316" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Props
 val myActor =
   context.actorOf(Props[MyActor]().withDispatcher(&quot;my-dispatcher&quot;), &quot;myactor1&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L74-L75" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef myActor =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L74-L75" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef myActor =
     system.actorOf(Props.create(MyActor.class).withDispatcher(&quot;my-dispatcher&quot;), &quot;myactor3&quot;);</code></pre></dd>
 </dl><div class="callout note "><div class="callout-title">Note</div>
-<p>The dispatcher you specify in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Props.html#withDispatcher(d:String):org.apache.pekko.actor.Props" title="org.apache.pekko.actor.Props"><code>withDispatcher</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Props.html#withDispatcher(java.lang.String)" title="org.apache.pekko.actor.Props"><co [...]
+<p>The dispatcher you specify in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Props.html#withDispatcher(d:String):org.apache.pekko.actor.Props" title="org.apache.pekko.actor.Props"><code>withDispatcher</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Props.html#withDispatcher(java.lang.String)" title="org.a [...]
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/dispatchers.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/dispatchers.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -614,7 +614,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/distributed-data.html b/content/distributed-data.html
index 7837505..9c6816b 100644
--- a/content/distributed-data.html
+++ b/content/distributed-data.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <p>For the full documentation of this feature and for new projects see <a href="typed/distributed-data.html">Distributed Data</a>.</p>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use Pekko Distributed Data, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Pekko Distributed Data, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-distributed-data" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -430,7 +430,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-distributed-data" % PekkoVer
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -445,20 +445,20 @@ libraryDependencies += "org.apache.pekko" %% "pekko-distributed-data" % PekkoVer
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-distributed-data_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
 <h2><a href="#introduction" name="introduction" class="anchor"><span class="anchor-link"></span></a>Introduction</h2>
 <p>For the full documentation of this feature and for new projects see <a href="typed/distributed-data.html#introduction">Distributed Data - Introduction</a>.</p>
 <h2><a href="#using-the-replicator" name="using-the-replicator" class="anchor"><span class="anchor-link"></span></a>Using the Replicator</h2>
-<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator.html" title="org.apache.pekko.cluster.ddata.Replicator"><code>Replicator</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator.html" title="org.apache.pekko.cluster.ddata.Replicator"><code>Replicator</code></a></span> actor provides the API for intera [...]
+<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator.html" title="org.apache.pekko.cluster.ddata.Replicator"><code>Replicator</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator.html" title="org.apache.pekko.cluster.ddata.Replicator"><code>Replicator</code></a></span> actor [...]
 <p>Cluster members with status <a href="typed/cluster-membership.html#weakly-up">WeaklyUp</a>, will participate in Distributed Data. This means that the data will be replicated to the <code>WeaklyUp</code> nodes with the background gossip protocol. Note that it will not participate in any actions where the consistency mode is to read/write from all nodes or the majority of nodes. The <code>WeaklyUp</code> node is not counted as part of the cluster. So 3 nodes + 5 <code>WeaklyUp</code> is [...]
-<p>Below is an example of an actor that schedules tick messages to itself and for each tick adds or removes elements from a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/ORSet.html" title="org.apache.pekko.cluster.ddata.ORSet"><code>ORSet</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/ORSet.html" title="org.apache.pek [...]
+<p>Below is an example of an actor that schedules tick messages to itself and for each tick adds or removes elements from a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/ORSet.html" title="org.apache.pekko.cluster.ddata.ORSet"><code>ORSet</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/ORSet [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L57-L106" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import java.util.concurrent.ThreadLocalRandom
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L57-L106" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import java.util.concurrent.ThreadLocalRandom
 import org.apache.pekko
 import pekko.actor.Actor
 import pekko.actor.ActorLogging
@@ -510,7 +510,7 @@ class DataBot extends Actor with ActorLogging {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/DataBot.java#L17-L111" target="_blank" title="Go to snippet source">source</a><code class="language-java">import java.time.Duration;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/DataBot.java#L17-L111" target="_blank" title="Go to snippet source">source</a><code class="language-java">import java.time.Duration;
 import java.util.concurrent.ThreadLocalRandom;
 
 import org.apache.pekko.actor.AbstractActor;
@@ -609,14 +609,14 @@ public class DataBot extends AbstractActor {
 <a id="replicator-update"></a>
 <h3><a href="#update" name="update" class="anchor"><span class="anchor-link"></span></a>Update</h3>
 <p>For the full documentation of this feature and for new projects see <a href="typed/distributed-data.html#update">Distributed Data - Update</a>.</p>
-<p>To modify and replicate a data value you send a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" title="org.apache.pekko.cluster.ddata.Replicator.Update"><code>Replicator.Update</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" title="org.apache.pekko.cluster.ddata.Replic [...]
+<p>To modify and replicate a data value you send a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" title="org.apache.pekko.cluster.ddata.Replicator.Update"><code>Replicator.Update</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" title="org.apach [...]
 <p>The current data value for the <code>key</code> of the <code>Update</code> is passed as parameter to the <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/cluster/ddata/Replicator$$Update.html#modify:Option[A]=%3EA" title="pekko.cluster.ddata.Replicator.Update"><code>modify</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/cluster/ddata/Replicator.Update.html#modify()" title="pekko.cluster.ddata.Rep [...]
 <p>The <code>modify</code> function is called by the <code>Replicator</code> actor and must therefore be a pure function that only uses the data parameter and stable fields from enclosing scope. It must for example not access the sender (<span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/Actor.html#sender():org.apache.pekko.actor.ActorRef" title="pekko.actor.Actor"><code>sender()</code></a></span><span class="group-java"><a href="https://doc.akka.i [...]
-<p><code>Update</code> is intended to only be sent from an actor running in same local <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSyst [...]
+<p><code>Update</code> is intended to only be sent from an actor running in same local <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor. [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L119-L136" target="_blank" title="Go to snippet source">source</a><code class="language-scala">implicit val node: SelfUniqueAddress = DistributedData(system).selfUniqueAddress
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L119-L136" target="_blank" title="Go to snippet source">source</a><code class="language-scala">implicit val node: SelfUniqueAddress = DistributedData(system).selfUniqueAddress
 val replicator = DistributedData(system).replicator
 
 val Counter1Key = PNCounterKey(&quot;counter1&quot;)
@@ -636,7 +636,7 @@ val writeAll = WriteAll(timeout = 5.seconds)
 replicator ! Update(ActiveFlagKey, Flag.Disabled, writeAll)(_.switchOn)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L60-L132" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateUpdate extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L60-L132" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateUpdate extends AbstractActor {
   final SelfUniqueAddress node =
       DistributedData.get(getContext().getSystem()).selfUniqueAddress();
   final ActorRef replicator = DistributedData.get(getContext().getSystem()).replicator();
@@ -683,14 +683,14 @@ replicator ! Update(ActiveFlagKey, Flag.Disabled, writeAll)(_.switchOn)</code></
   }
 }</code></pre></dd>
 </dl>
-<p>As reply of the <code>Update</code> a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$UpdateSuccess.html" title="org.apache.pekko.cluster.ddata.Replicator.UpdateSuccess"><code>Replicator.UpdateSuccess</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$UpdateSuccess.html" title="org.apache.pekko.cl [...]
+<p>As reply of the <code>Update</code> a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$UpdateSuccess.html" title="org.apache.pekko.cluster.ddata.Replicator.UpdateSuccess"><code>Replicator.UpdateSuccess</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$UpdateSuccess.html [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L141" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case UpdateSuccess(Counter1Key, req) =&gt; // ok</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L141" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case UpdateSuccess(Counter1Key, req) =&gt; // ok</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L106-L111" target="_blank" title="Go to snippet source">source</a><code class="language-java">b.match(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L106-L111" target="_blank" title="Go to snippet source">source</a><code class="language-java">b.match(
     UpdateSuccess.class,
     a -&gt; a.key().equals(counter1Key),
     a -&gt; {
@@ -700,12 +700,12 @@ replicator ! Update(ActiveFlagKey, Flag.Disabled, writeAll)(_.switchOn)</code></
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L148-L150" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case UpdateSuccess(Set1Key, req) =&gt; // ok
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L148-L150" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case UpdateSuccess(Set1Key, req) =&gt; // ok
 case UpdateTimeout(Set1Key, req) =&gt;
 // write to 3 nodes failed within 1.second</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L115-L126" target="_blank" title="Go to snippet source">source</a><code class="language-java">b.match(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L115-L126" target="_blank" title="Go to snippet source">source</a><code class="language-java">b.match(
         UpdateSuccess.class,
         a -&gt; a.key().equals(set1Key),
         a -&gt; {
@@ -718,13 +718,13 @@ case UpdateTimeout(Set1Key, req) =&gt;
           // write to 3 nodes failed within 1.second
         });</code></pre></dd>
 </dl>
-<p>You will always see your own writes. For example if you send two <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" title="org.apache.pekko.cluster.ddata.Replicator.Update"><code>Replicator.Update</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" title="org.apache.pekko.clu [...]
-<p>It is possible to abort the <code>Update</code> when inspecting the state parameter that is passed in to the <code>modify</code> function by throwing an exception. That happens before the update is performed and a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$ModifyFailure.html" title="org.apache.pekko.cluster.ddata.Replicator.ModifyFailure"><code>Replicator.ModifyFailure</code></a></span><span  [...]
-<p>In the <code>Update</code> message you can pass an optional request context, which the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator.html" title="org.apache.pekko.cluster.ddata.Replicator"><code>Replicator</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator.html" title="org.apache.pekko.cluster.dda [...]
+<p>You will always see your own writes. For example if you send two <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" title="org.apache.pekko.cluster.ddata.Replicator.Update"><code>Replicator.Update</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" [...]
+<p>It is possible to abort the <code>Update</code> when inspecting the state parameter that is passed in to the <code>modify</code> function by throwing an exception. That happens before the update is performed and a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$ModifyFailure.html" title="org.apache.pekko.cluster.ddata.Replicator.ModifyFailure"><code>Replicator.ModifyFailure</code></a [...]
+<p>In the <code>Update</code> message you can pass an optional request context, which the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator.html" title="org.apache.pekko.cluster.ddata.Replicator"><code>Replicator</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator.html" title=" [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L164-L179" target="_blank" title="Go to snippet source">source</a><code class="language-scala">implicit val node = DistributedData(system).selfUniqueAddress
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L164-L179" target="_blank" title="Go to snippet source">source</a><code class="language-scala">implicit val node = DistributedData(system).selfUniqueAddress
 val replicator = DistributedData(system).replicator
 val writeTwo = WriteTo(n = 2, timeout = 3.second)
 val Counter1Key = PNCounterKey(&quot;counter1&quot;)
@@ -742,7 +742,7 @@ def receive: Receive = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L137-L178" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateUpdateWithRequestContext extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L137-L178" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateUpdateWithRequestContext extends AbstractActor {
   final SelfUniqueAddress node = DistributedData.get(system).selfUniqueAddress();
   final ActorRef replicator = DistributedData.get(getContext().getSystem()).replicator();
 
@@ -788,11 +788,11 @@ def receive: Receive = {
 <a id="replicator-get"></a>
 <h3><a href="#get" name="get" class="anchor"><span class="anchor-link"></span></a>Get</h3>
 <p>For the full documentation of this feature and for new projects see <a href="typed/distributed-data.html#get">Distributed Data - Get</a>.</p>
-<p>To retrieve the current value of a data you send <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Get.html" title="org.apache.pekko.cluster.ddata.Replicator.Get"><code>Replicator.Get</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Get.html" title="org.apache.pekko.cluster.ddata.Replicator.Get">< [...]
+<p>To retrieve the current value of a data you send <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Get.html" title="org.apache.pekko.cluster.ddata.Replicator.Get"><code>Replicator.Get</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Get.html" title="org.apache.pekko.clu [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L188-L203" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val replicator = DistributedData(system).replicator
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L188-L203" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val replicator = DistributedData(system).replicator
 val Counter1Key = PNCounterKey(&quot;counter1&quot;)
 val Set1Key = GSetKey[String](&quot;set1&quot;)
 val Set2Key = ORSetKey[String](&quot;set2&quot;)
@@ -810,7 +810,7 @@ val readAll = ReadAll(timeout = 5.seconds)
 replicator ! Get(ActiveFlagKey, readAll)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L183-L253" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateGet extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L183-L253" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateGet extends AbstractActor {
   final ActorRef replicator = DistributedData.get(getContext().getSystem()).replicator();
 
   final Key&lt;PNCounter&gt; counter1Key = PNCounterKey.create(&quot;counter1&quot;);
@@ -841,16 +841,16 @@ replicator ! Get(ActiveFlagKey, readAll)</code></pre></dd>
   }
 }</code></pre></dd>
 </dl>
-<p>As reply of the <code>Get</code> a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$GetSuccess.html" title="org.apache.pekko.cluster.ddata.Replicator.GetSuccess"><code>Replicator.GetSuccess</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$GetSuccess.html" title="org.apache.pekko.cluster.ddata.Rep [...]
+<p>As reply of the <code>Get</code> a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$GetSuccess.html" title="org.apache.pekko.cluster.ddata.Replicator.GetSuccess"><code>Replicator.GetSuccess</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$GetSuccess.html" title="org.ap [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L208-L210" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case g @ GetSuccess(Counter1Key, req) =&gt;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L208-L210" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case g @ GetSuccess(Counter1Key, req) =&gt;
   val value = g.get(Counter1Key).value
 case NotFound(Counter1Key, req) =&gt; // key counter1 does not exist</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L213-L225" target="_blank" title="Go to snippet source">source</a><code class="language-java">b.match(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L213-L225" target="_blank" title="Go to snippet source">source</a><code class="language-java">b.match(
         GetSuccess.class,
         a -&gt; a.key().equals(counter1Key),
         a -&gt; {
@@ -867,14 +867,14 @@ case NotFound(Counter1Key, req) =&gt; // key counter1 does not exist</code></pre
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L217-L221" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case g @ GetSuccess(Set1Key, req) =&gt;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L217-L221" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case g @ GetSuccess(Set1Key, req) =&gt;
   val elements = g.get(Set1Key).elements
 case GetFailure(Set1Key, req) =&gt;
 // read from 3 nodes failed within 1.second
 case NotFound(Set1Key, req) =&gt; // key set1 does not exist</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L229-L247" target="_blank" title="Go to snippet source">source</a><code class="language-java">b.match(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L229-L247" target="_blank" title="Go to snippet source">source</a><code class="language-java">b.match(
         GetSuccess.class,
         a -&gt; a.key().equals(set1Key),
         a -&gt; {
@@ -894,11 +894,11 @@ case NotFound(Set1Key, req) =&gt; // key set1 does not exist</code></pre></dd>
           // key set1 does not exist
         });</code></pre></dd>
 </dl>
-<p>In the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Get.html" title="org.apache.pekko.cluster.ddata.Replicator.Get"><code>Replicator.Get</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Get.html" title="org.apache.pekko.cluster.ddata.Replicator.Get"><code>Replicator.Get</code></a></span> mess [...]
+<p>In the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Get.html" title="org.apache.pekko.cluster.ddata.Replicator.Get"><code>Replicator.Get</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Get.html" title="org.apache.pekko.cluster.ddata.Replicator.Get"><code>Replicato [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L236-L253" target="_blank" title="Go to snippet source">source</a><code class="language-scala">implicit val node = DistributedData(system).selfUniqueAddress
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L236-L253" target="_blank" title="Go to snippet source">source</a><code class="language-scala">implicit val node = DistributedData(system).selfUniqueAddress
 val replicator = DistributedData(system).replicator
 val readTwo = ReadFrom(n = 2, timeout = 3.second)
 val Counter1Key = PNCounterKey(&quot;counter1&quot;)
@@ -918,7 +918,7 @@ def receive: Receive = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L258-L300" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateGetWithRequestContext extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L258-L300" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateGetWithRequestContext extends AbstractActor {
   final ActorRef replicator = DistributedData.get(getContext().getSystem()).replicator();
 
   final ReadConsistency readTwo = new ReadFrom(2, Duration.ofSeconds(3));
@@ -964,12 +964,12 @@ def receive: Receive = {
 </dl>
 <h3><a href="#subscribe" name="subscribe" class="anchor"><span class="anchor-link"></span></a>Subscribe</h3>
 <p>For the full documentation of this feature and for new projects see <a href="typed/distributed-data.html#subscribe">Distributed Data - Subscribe</a>.</p>
-<p>You may also register interest in change notifications by sending <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Subscribe.html" title="org.apache.pekko.cluster.ddata.Replicator.Subscribe"><code>Replicator.Subscribe</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Subscribe.html" title="org.apa [...]
-<p>The subscriber is automatically removed if the subscriber is terminated. A subscriber can also be deregistered with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Unsubscribe.html" title="org.apache.pekko.cluster.ddata.Replicator.Unsubscribe"><code>Replicator.Unsubscribe</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pe [...]
+<p>You may also register interest in change notifications by sending <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Subscribe.html" title="org.apache.pekko.cluster.ddata.Replicator.Subscribe"><code>Replicator.Subscribe</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Su [...]
+<p>The subscriber is automatically removed if the subscriber is terminated. A subscriber can also be deregistered with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Unsubscribe.html" title="org.apache.pekko.cluster.ddata.Replicator.Unsubscribe"><code>Replicator.Unsubscribe</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119 [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L264-L276" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val replicator = DistributedData(system).replicator
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L264-L276" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val replicator = DistributedData(system).replicator
 val Counter1Key = PNCounterKey(&quot;counter1&quot;)
 // subscribe to changes of the Counter1Key value
 replicator ! Subscribe(Counter1Key, self)
@@ -984,7 +984,7 @@ def receive: Receive = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L305-L336" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateSubscribe extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L305-L336" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateSubscribe extends AbstractActor {
   final ActorRef replicator = DistributedData.get(getContext().getSystem()).replicator();
   final Key&lt;PNCounter&gt; counter1Key = PNCounterKey.create(&quot;counter1&quot;);
 
@@ -1019,22 +1019,22 @@ def receive: Receive = {
 </dl>
 <h3><a href="#consistency" name="consistency" class="anchor"><span class="anchor-link"></span></a>Consistency</h3>
 <p>For the full documentation of this feature and for new projects see <a href="typed/distributed-data.html#consistency">Distributed Data Consistency</a>.</p>
-<p>Here is an example of using <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$WriteMajority.html" title="org.apache.pekko.cluster.ddata.Replicator.WriteMajority"><code>Replicator.WriteMajority</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$WriteMajority.html" title="org.apache.pekko.cluster.ddat [...]
+<p>Here is an example of using <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$WriteMajority.html" title="org.apache.pekko.cluster.ddata.Replicator.WriteMajority"><code>Replicator.WriteMajority</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$WriteMajority.html" title="o [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/ShoppingCart.scala#L39-L41" target="_blank" title="Go to snippet source">source</a><code class="language-scala">private val timeout = 3.seconds
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/ShoppingCart.scala#L39-L41" target="_blank" title="Go to snippet source">source</a><code class="language-scala">private val timeout = 3.seconds
 private val readMajority = ReadMajority(timeout)
 private val writeMajority = WriteMajority(timeout)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/ShoppingCart.java#L43-L44" target="_blank" title="Go to snippet source">source</a><code class="language-java">private final WriteConsistency writeMajority = new WriteMajority(Duration.ofSeconds(3));
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/ShoppingCart.java#L43-L44" target="_blank" title="Go to snippet source">source</a><code class="language-java">private final WriteConsistency writeMajority = new WriteMajority(Duration.ofSeconds(3));
 private static final ReadConsistency readMajority = new ReadMajority(Duration.ofSeconds(3));</code></pre></dd>
 </dl>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/ShoppingCart.scala#L62-L77" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def receiveGetCart: Receive = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/ShoppingCart.scala#L62-L77" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def receiveGetCart: Receive = {
   case GetCart =&gt;
     replicator ! Get(DataKey, readMajority, Some(sender()))
 
@@ -1052,7 +1052,7 @@ private static final ReadConsistency readMajority = new ReadMajority(Duration.of
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/ShoppingCart.java#L147-L193" target="_blank" title="Go to snippet source">source</a><code class="language-java">private Receive matchGetCart() {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/ShoppingCart.java#L147-L193" target="_blank" title="Go to snippet source">source</a><code class="language-java">private Receive matchGetCart() {
   return receiveBuilder()
       .matchEquals(GET_CART, s -&gt; receiveGetCart())
       .match(
@@ -1103,7 +1103,7 @@ private void receiveGetFailure(GetFailure&lt;LWWMap&lt;String, LineItem&gt;&gt;
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/ShoppingCart.scala#L81-L87" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def receiveAddItem: Receive = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/ShoppingCart.scala#L81-L87" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def receiveAddItem: Receive = {
   case cmd @ AddItem(item) =&gt;
     val update = Update(DataKey, LWWMap.empty[String, LineItem], writeMajority, Some(cmd)) { cart =&gt;
       updateCart(cart, item)
@@ -1112,7 +1112,7 @@ private void receiveGetFailure(GetFailure&lt;LWWMap&lt;String, LineItem&gt;&gt;
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/ShoppingCart.java#L197-L206" target="_blank" title="Go to snippet source">source</a><code class="language-java">private Receive matchAddItem() {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/ShoppingCart.java#L197-L206" target="_blank" title="Go to snippet source">source</a><code class="language-java">private Receive matchAddItem() {
   return receiveBuilder().match(AddItem.class, this::receiveAddItem).build();
 }
 
@@ -1123,12 +1123,12 @@ private void receiveAddItem(AddItem add) {
 }
 </code></pre></dd>
 </dl>
-<p>In some rare cases, when performing an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" title="org.apache.pekko.cluster.ddata.Replicator.Update"><code>Replicator.Update</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" title="org.apache.pekko.cluster.ddata.Replicator.Upda [...]
+<p>In some rare cases, when performing an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" title="org.apache.pekko.cluster.ddata.Replicator.Update"><code>Replicator.Update</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/Replicator$$Update.html" title="org.apache.pekko.c [...]
 <p>The following example illustrates how to do that:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/ShoppingCart.scala#L98-L117" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def receiveRemoveItem: Receive = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/ShoppingCart.scala#L98-L117" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def receiveRemoveItem: Receive = {
   case cmd @ RemoveItem(productId) =&gt;
     // Try to fetch latest from a majority of nodes first, since ORMap
     // remove must have seen the item to be able to remove it.
@@ -1150,7 +1150,7 @@ private void receiveAddItem(AddItem add) {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/ShoppingCart.java#L241-L269" target="_blank" title="Go to snippet source">source</a><code class="language-java">private void receiveRemoveItem(RemoveItem rm) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/ShoppingCart.java#L241-L269" target="_blank" title="Go to snippet source">source</a><code class="language-java">private void receiveRemoveItem(RemoveItem rm) {
   // Try to fetch latest from a majority of nodes first, since ORMap
   // remove must have seen the item to be able to remove it.
   Optional&lt;Object&gt; ctx = Optional.of(rm);
@@ -1186,7 +1186,7 @@ private boolean isResponseToRemoveItem(GetResponse&lt;?&gt; response) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L285-L292" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val replicator = DistributedData(system).replicator
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/ddata/DistributedDataDocSpec.scala#L285-L292" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val replicator = DistributedData(system).replicator
 val Counter1Key = PNCounterKey(&quot;counter1&quot;)
 val Set2Key = ORSetKey[String](&quot;set2&quot;)
 
@@ -1196,7 +1196,7 @@ val writeMajority = WriteMajority(timeout = 5.seconds)
 replicator ! Delete(Set2Key, writeMajority)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L341-L361" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateDelete extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/ddata/DistributedDataDocTest.java#L341-L361" target="_blank" title="Go to snippet source">source</a><code class="language-java">class DemonstrateDelete extends AbstractActor {
   final ActorRef replicator = DistributedData.get(getContext().getSystem()).replicator();
 
   final Key&lt;PNCounter&gt; counter1Key = PNCounterKey.create(&quot;counter1&quot;);
@@ -1218,7 +1218,7 @@ replicator ! Delete(Set2Key, writeMajority)</code></pre></dd>
   }
 }</code></pre></dd>
 </dl><div class="callout warning "><div class="callout-title">Warning</div>
-<p>As deleted keys continue to be included in the stored data on each node as well as in gossip messages, a continuous series of updates and deletes of top-level entities will result in growing memory usage until an ActorSystem runs out of memory. To use Pekko Distributed Data where frequent adds and removes are required, you should use a fixed number of top-level data types that support both updates and removals, for example <span class="group-scala"><a href="https://doc.akka.io/api/akk [...]
+<p>As deleted keys continue to be included in the stored data on each node as well as in gossip messages, a continuous series of updates and deletes of top-level entities will result in growing memory usage until an ActorSystem runs out of memory. To use Pekko Distributed Data where frequent adds and removes are required, you should use a fixed number of top-level data types that support both updates and removals, for example <span class="group-scala"><a href="https://doc.akka.io/api/akk [...]
 <h2><a href="#replicated-data-types" name="replicated-data-types" class="anchor"><span class="anchor-link"></span></a>Replicated data types</h2>
 <p>Pekko contains a set of useful replicated data types and it is fully possible to implement custom replicated data types. For the full documentation of this feature and for new projects see <a href="typed/distributed-data.html#replicated-data-types">Distributed Data Replicated data types</a>.</p>
 <h3><a href="#delta-crdt" name="delta-crdt" class="anchor"><span class="anchor-link"></span></a>Delta-CRDT</h3>
@@ -1236,8 +1236,8 @@ replicator ! Delete(Set2Key, writeMajority)</code></pre></dd>
   <li><a href="https://hal.inria.fr/file/index/docid/555588/filename/techreport.pdf">A comprehensive study of Convergent and Commutative Replicated Data Types</a> paper by Mark Shapiro et. al.</li>
 </ul>
 <h2><a href="#configuration" name="configuration" class="anchor"><span class="anchor-link"></span></a>Configuration</h2>
-<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/DistributedData.html" title="org.apache.pekko.cluster.ddata.DistributedData"><code>DistributedData</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ddata/DistributedData.html" title="org.apache.pekko.cluster.ddata.DistributedData"><code>DistributedData</code></a></span> ext [...]
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/distributed-data/src/main/resources/reference.conf#L10-L142" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># Settings for the DistributedData extension
+<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/DistributedData.html" title="org.apache.pekko.cluster.ddata.DistributedData"><code>DistributedData</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ddata/DistributedData.html" title="org.apache.pekko.cluster.ddata.DistributedData"><code>Distribut [...]
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/distributed-data/src/main/resources/reference.conf#L10-L142" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># Settings for the DistributedData extension
 pekko.cluster.distributed-data {
   # Actor name of the Replicator actor, /system/ddataReplicator
   name = ddataReplicator
@@ -1371,7 +1371,7 @@ pekko.cluster.distributed-data {
   
 }</code></pre>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/distributed-data.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/distributed-data.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -1461,7 +1461,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/distributed-pub-sub.html b/content/distributed-pub-sub.html
index 444cf6b..623cea4 100644
--- a/content/distributed-pub-sub.html
+++ b/content/distributed-pub-sub.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <p>For the new API see <a href="typed/distributed-pub-sub.html">Distributed Publish Subscribe in Cluster</a> </p>
 <h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2>
-<p>To use Distributed Publish Subscribe you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Distributed Publish Subscribe you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-cluster-tools" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -430,7 +430,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster-tools" % PekkoVersio
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -445,7 +445,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-cluster-tools" % PekkoVersio
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-cluster-tools_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -453,7 +453,7 @@ dependencies {
 <tr><th colspan="2">Project Info: Pekko Cluster Tools (classic)</th></tr>
   <tr><th>Artifact</th><td><div>org.apache.pekko</div>
   <div>pekko-cluster-tools</div>
-  <div>0.0.0+26533-ec68a528-SNAPSHOT</div>
+  <div>0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT</div>
   <div><a href="project/links.html#snapshots-repository">Snapshots are available</a></div>
   </td></tr>
   <tr><th>JDK versions</th><td><div>Adopt OpenJDK 8</div><div>Adopt OpenJDK 11</div></td></tr>
@@ -468,11 +468,11 @@ dependencies {
   <div><a href="https://doc.akka.io/japi/akka/snapshot/akka/cluster/tools/package-summary.html" target="_blank" rel="noopener noreferrer">API (Javadoc)</a></div>
   </td></tr>
   <tr><th>Forums</th><td>
-  <div><a href="https://discuss.akka.io" target="_blank" rel="noopener noreferrer">Lightbend Discuss</a></div>
-  <div><a href="https://gitter.im/akka/akka" target="_blank" rel="noopener noreferrer">akka/akka Gitter channel</a></div>
+  <div><a href="https://lists.apache.org/list.html?dev@pekko.apache.org" target="_blank" rel="noopener noreferrer">Apache Pekko Dev mailing list</a></div>
+  <div><a href="https://github.com/apache/incubator-pekko/discussions" target="_blank" rel="noopener noreferrer">apache/incubator-pekko discussion</a></div>
   </td></tr>
   <tr><th>Release notes</th><td><a href="https://akka.io/blog/news-archive.html">akka.io blog</a></td></tr>
-  <tr><th>Issues</th><td><a href="https://github.com/akka/akka/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
+  <tr><th>Issues</th><td><a href="https://github.com/apache/incubator-pekko/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
   <tr><th>Sources</th><td><a href="https://github.com/apache/incubator-pekko" target="_blank" rel="noopener noreferrer">https://github.com/apache/incubator-pekko</a></td></tr>
 </table>
 
@@ -482,9 +482,9 @@ dependencies {
 
 <p>How do I send messages to all actors in the cluster that have registered interest in a named topic?</p>
 
-<p>This pattern provides a mediator actor, <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator"><code>cluster.pubsub.DistributedPubSubMediator</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator.html" titl [...]
+<p>This pattern provides a mediator actor, <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator"><code>cluster.pubsub.DistributedPubSubMediator</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/Distribu [...]
 
-<p>The <code>DistributedPubSubMediator</code> actor is supposed to be started on all nodes, or all nodes with specified role, in the cluster. The mediator can be started with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSub.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSub"><code>DistributedPubSub</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0 [...]
+<p>The <code>DistributedPubSubMediator</code> actor is supposed to be started on all nodes, or all nodes with specified role, in the cluster. The mediator can be started with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSub.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSub"><code>DistributedPubSub</code></a></span><span class="group-java"><a href="https://doc.akka [...]
 
 <p>The registry is eventually consistent, i.e. changes are not immediately visible at other nodes, but typically they will be fully replicated to all other nodes after a few seconds. Changes are only performed in the own part of the registry and those changes are versioned. Deltas are disseminated in a scalable way to other nodes with a gossip protocol.</p>
 
@@ -500,14 +500,14 @@ dependencies {
 <p>This is the true pub/sub mode. A typical usage of this mode is a chat room in an instant messaging application.</p>
 <p>Actors are registered to a named topic. This enables many subscribers on each node. The message will be delivered to all subscribers of the topic.</p>
 <p>For efficiency the message is sent over the wire only once per node (that has a matching topic), and then delivered to all subscribers of the local topic representation.</p>
-<p>You register actors to the local mediator with <code>DistributedPubSubMediator.Subscribe</code>. Successful <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Subscribe.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Subscribe"><code>DistributedPubSubMediator.Subscribe</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec [...]
-<p>You publish messages by sending <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Publish.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Publish"><code>DistributedPubSubMediator.Publish</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Publish [...]
+<p>You register actors to the local mediator with <code>DistributedPubSubMediator.Subscribe</code>. Successful <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Subscribe.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Subscribe"><code>DistributedPubSubMediator.Subscribe</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/ [...]
+<p>You publish messages by sending <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Publish.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Publish"><code>DistributedPubSubMediator.Publish</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/Distri [...]
 <p>Actors are automatically removed from the registry when they are terminated, or you can explicitly remove entries with <code>DistributedPubSubMediator.Unsubscribe</code>.</p>
 <p>An example of a subscriber actor:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L91-L103" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Subscriber extends Actor with ActorLogging {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L91-L103" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Subscriber extends Actor with ActorLogging {
   import DistributedPubSubMediator.{ Subscribe, SubscribeAck }
   val mediator = DistributedPubSub(context.system).mediator
   // subscribe to the topic named &quot;content&quot;
@@ -522,7 +522,7 @@ dependencies {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L77-L94" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Subscriber extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L77-L94" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Subscriber extends AbstractActor {
   LoggingAdapter log = Logging.getLogger(getContext().system(), this);
 
   public Subscriber() {
@@ -545,7 +545,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L361-L367" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(first) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L361-L367" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(first) {
   system.actorOf(Props[Subscriber](), &quot;subscriber1&quot;)
 }
 runOn(second) {
@@ -554,7 +554,7 @@ runOn(second) {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L47-L50" target="_blank" title="Go to snippet source">source</a><code class="language-java">system.actorOf(Props.create(Subscriber.class), &quot;subscriber1&quot;);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L47-L50" target="_blank" title="Go to snippet source">source</a><code class="language-java">system.actorOf(Props.create(Subscriber.class), &quot;subscriber1&quot;);
 // another node
 system.actorOf(Props.create(Subscriber.class), &quot;subscriber2&quot;);
 system.actorOf(Props.create(Subscriber.class), &quot;subscriber3&quot;);</code></pre></dd>
@@ -563,7 +563,7 @@ system.actorOf(Props.create(Subscriber.class), &quot;subscriber3&quot;);</code><
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L77-L87" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Publisher extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L77-L87" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Publisher extends Actor {
   import DistributedPubSubMediator.Publish
   // activate the extension
   val mediator = DistributedPubSub(context.system).mediator
@@ -576,7 +576,7 @@ system.actorOf(Props.create(Subscriber.class), &quot;subscriber3&quot;);</code><
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L98-L114" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Publisher extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L98-L114" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Publisher extends AbstractActor {
 
   // activate the extension
   ActorRef mediator = DistributedPubSub.get(getContext().system()).mediator();
@@ -598,7 +598,7 @@ system.actorOf(Props.create(Subscriber.class), &quot;subscriber3&quot;);</code><
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L371-L376" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(third) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L371-L376" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(third) {
   val publisher = system.actorOf(Props[Publisher](), &quot;publisher&quot;)
   later()
   // after a while the subscriptions are replicated
@@ -606,28 +606,28 @@ system.actorOf(Props.create(Subscriber.class), &quot;subscriber3&quot;);</code><
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L54-L57" target="_blank" title="Go to snippet source">source</a><code class="language-java">// somewhere else
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L54-L57" target="_blank" title="Go to snippet source">source</a><code class="language-java">// somewhere else
 ActorRef publisher = system.actorOf(Props.create(Publisher.class), &quot;publisher&quot;);
 // after a while the subscriptions are replicated
 publisher.tell(&quot;hello&quot;, null);</code></pre></dd>
 </dl>
 <h3><a href="#topic-groups" name="topic-groups" class="anchor"><span class="anchor-link"></span></a>Topic Groups</h3>
-<p>Actors may also be subscribed to a named topic with a <code>group</code> id. If subscribing with a group id, each message published to a topic with the <code>sendOneMessageToEachGroup</code> flag set to <code>true</code> is delivered via the supplied <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/routing/RoutingLogic.html" title="org.apache.pekko.routing.RoutingLogic"><code>RoutingLogic</code></a></span><span class="group [...]
-<p>If all the subscribed actors have the same group id, then this works just like <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Send.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Send"><code>DistributedPubSubMediator.Send</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pub [...]
-<p>If all the subscribed actors have different group names, then this works like normal <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Publish.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Publish"><code>DistributedPubSubMediator.Publish</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pe [...]
+<p>Actors may also be subscribed to a named topic with a <code>group</code> id. If subscribing with a group id, each message published to a topic with the <code>sendOneMessageToEachGroup</code> flag set to <code>true</code> is delivered via the supplied <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/routing/RoutingLogic.html" title="org.apache.pekko.routing.RoutingLogic"><code>RoutingLogic</code></a></span><spa [...]
+<p>If all the subscribed actors have the same group id, then this works just like <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Send.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Send"><code>DistributedPubSubMediator.Send</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/ [...]
+<p>If all the subscribed actors have different group names, then this works like normal <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Publish.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Publish"><code>DistributedPubSubMediator.Publish</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119 [...]
 <p>Note that if the group id is used it is part of the topic identifier. Messages published with <code>sendOneMessageToEachGroup=false</code> will not be delivered to subscribers that subscribed with a group id. Messages published with <code>sendOneMessageToEachGroup=true</code> will not be delivered to subscribers that subscribed without a group id.</p></div>
 <a id="distributed-pub-sub-send"></a>
 <h2><a href="#send" name="send" class="anchor"><span class="anchor-link"></span></a>Send</h2>
 <p>This is a point-to-point mode where each message is delivered to one destination, but you still do not have to know where the destination is located. A typical usage of this mode is private chat to one other user in an instant messaging application. It can also be used for distributing tasks to registered workers, like a cluster aware router where the routees dynamically can register themselves.</p>
-<p>The message will be delivered to one recipient with a matching path, if any such exists in the registry. If several entries match the path because it has been registered on several nodes the message will be sent via the supplied <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/routing/RoutingLogic.html" title="org.apache.pekko.routing.RoutingLogic"><code>RoutingLogic</code></a></span><span class="group-java"><a href="https: [...]
-<p>You register actors to the local mediator with <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Put.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Put"><code>DistributedPubSubMediator.Put</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Put. [...]
-<p>You send messages by sending <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Send.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Send"><code>DistributedPubSubMediator.Send</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Send.html" title="o [...]
-<p>Actors are automatically removed from the registry when they are terminated, or you can explicitly remove entries with <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Remove.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Remove"><code>DistributedPubSubMediator.Remove</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533- [...]
+<p>The message will be delivered to one recipient with a matching path, if any such exists in the registry. If several entries match the path because it has been registered on several nodes the message will be sent via the supplied <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/routing/RoutingLogic.html" title="org.apache.pekko.routing.RoutingLogic"><code>RoutingLogic</code></a></span><span class="group-java">< [...]
+<p>You register actors to the local mediator with <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Put.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Put"><code>DistributedPubSubMediator.Put</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/Dis [...]
+<p>You send messages by sending <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Send.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Send"><code>DistributedPubSubMediator.Send</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubM [...]
+<p>Actors are automatically removed from the registry when they are terminated, or you can explicitly remove entries with <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Remove.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Remove"><code>DistributedPubSubMediator.Remove</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akk [...]
 <p>An example of a destination actor:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L121-L131" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Destination extends Actor with ActorLogging {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L121-L131" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Destination extends Actor with ActorLogging {
   import DistributedPubSubMediator.Put
   val mediator = DistributedPubSub(context.system).mediator
   // register to the path
@@ -640,7 +640,7 @@ publisher.tell(&quot;hello&quot;, null);</code></pre></dd>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L118-L132" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Destination extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L118-L132" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Destination extends AbstractActor {
   LoggingAdapter log = Logging.getLogger(getContext().system(), this);
 
   public Destination() {
@@ -660,7 +660,7 @@ publisher.tell(&quot;hello&quot;, null);</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L388-L393" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(first) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L388-L393" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(first) {
   system.actorOf(Props[Destination](), &quot;destination&quot;)
 }
 runOn(second) {
@@ -668,7 +668,7 @@ runOn(second) {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L63-L65" target="_blank" title="Go to snippet source">source</a><code class="language-java">system.actorOf(Props.create(Destination.class), &quot;destination&quot;);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L63-L65" target="_blank" title="Go to snippet source">source</a><code class="language-java">system.actorOf(Props.create(Destination.class), &quot;destination&quot;);
 // another node
 system.actorOf(Props.create(Destination.class), &quot;destination&quot;);</code></pre></dd>
 </dl>
@@ -676,7 +676,7 @@ system.actorOf(Props.create(Destination.class), &quot;destination&quot;);</code>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L107-L117" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Sender extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L107-L117" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Sender extends Actor {
   import DistributedPubSubMediator.Send
   // activate the extension
   val mediator = DistributedPubSub(context.system).mediator
@@ -689,7 +689,7 @@ system.actorOf(Props.create(Destination.class), &quot;destination&quot;);</code>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L136-L155" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Sender extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L136-L155" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Sender extends AbstractActor {
 
   // activate the extension
   ActorRef mediator = DistributedPubSub.get(getContext().system()).mediator();
@@ -714,7 +714,7 @@ system.actorOf(Props.create(Destination.class), &quot;destination&quot;);</code>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L397-L402" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(third) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/multi-jvm/scala/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorSpec.scala#L397-L402" target="_blank" title="Go to snippet source">source</a><code class="language-scala">runOn(third) {
   val sender = system.actorOf(Props[Sender](), &quot;sender&quot;)
   later()
   // after a while the destinations are replicated
@@ -722,17 +722,17 @@ system.actorOf(Props.create(Destination.class), &quot;destination&quot;);</code>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L69-L72" target="_blank" title="Go to snippet source">source</a><code class="language-java">// somewhere else
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/test/java/org/apache/pekko/cluster/pubsub/DistributedPubSubMediatorTest.java#L69-L72" target="_blank" title="Go to snippet source">source</a><code class="language-java">// somewhere else
 ActorRef sender = system.actorOf(Props.create(Publisher.class), &quot;sender&quot;);
 // after a while the destinations are replicated
 sender.tell(&quot;hello&quot;, null);</code></pre></dd>
 </dl>
-<p>It is also possible to broadcast messages to the actors that have been registered with <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Put.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Put"><code>DistributedPubSubMediator.Put</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluste [...]
+<p>It is also possible to broadcast messages to the actors that have been registered with <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSubMediator$$Put.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSubMediator.Put"><code>DistributedPubSubMediator.Put</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAP [...]
 <p>Typical usage of this mode is to broadcast messages to all replicas with the same path, e.g. 3 actors on different nodes that all perform the same actions, for redundancy. You can also optionally specify a property (<code>allButSelf</code>) deciding if the message should be sent to a matching path on the self node or not.</p>
 <h2><a href="#distributedpubsub-extension" name="distributedpubsub-extension" class="anchor"><span class="anchor-link"></span></a>DistributedPubSub Extension</h2>
-<p>In the example above the mediator is started and accessed with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSub.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSub"><code>cluster.pubsub.DistributedPubSub</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSub.html" title="or [...]
+<p>In the example above the mediator is started and accessed with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/DistributedPubSub.html" title="org.apache.pekko.cluster.pubsub.DistributedPubSub"><code>cluster.pubsub.DistributedPubSub</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/pubsub/Distr [...]
 <p>The <code>DistributedPubSub</code> extension can be configured with the following properties:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/main/resources/reference.conf#L9-L38" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># Settings for the DistributedPubSub extension
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/main/resources/reference.conf#L9-L38" target="_blank" title="Go to snippet source">source</a><code class="language-conf"># Settings for the DistributedPubSub extension
 pekko.cluster.pub-sub {
   # Actor name of the mediator actor, /system/distributedPubSubMediator
   name = distributedPubSubMediator
@@ -769,7 +769,7 @@ pekko.cluster.pub-sub {
 <p>As in <a href="general/message-delivery-reliability.html">Message Delivery Reliability</a> of Pekko, message delivery guarantee in distributed pub sub modes is <strong>at-most-once delivery</strong>. In other words, messages can be lost over the wire.</p>
 <p>If you are looking for at-least-once delivery guarantee, we recommend <a href="https://doc.akka.io/docs/alpakka-kafka/current/">Pekko Connectors</a>.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/distributed-pub-sub.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/distributed-pub-sub.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -857,7 +857,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/durable-state/persistence-query.html b/content/durable-state/persistence-query.html
index 4b814d6..6f05d29 100644
--- a/content/durable-state/persistence-query.html
+++ b/content/durable-state/persistence-query.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -418,7 +418,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#persistence-query" name="persistence-query" class="anchor"><span class="anchor-link"></span></a>Persistence Query</h1>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use Persistence Query, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Persistence Query, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-persistence-query" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -427,7 +427,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-persistence-query" % PekkoVe
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -442,7 +442,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-persistence-query" % PekkoVe
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-persistence-query_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -457,7 +457,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding-typed/src/test/scala/docs/org/apache/pekko/cluster/sharding/typed/DurableStateStoreQueryUsageCompileOnlySpec.scala#L27-L39" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding-typed/src/test/scala/docs/org/apache/pekko/cluster/sharding/typed/DurableStateStoreQueryUsageCompileOnlySpec.scala#L27-L39" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.persistence.state.DurableStateStoreRegistry
 import pekko.persistence.query.scaladsl.DurableStateStoreQuery
 import pekko.persistence.query.DurableStateChange
@@ -472,7 +472,7 @@ source.map {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding-typed/src/test/java/jdocs/org/apache/pekko/cluster/sharding/typed/DurableStateStoreQueryUsageCompileOnlyTest.java#L22-L48" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.persistence.state.DurableStateStoreRegistry;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding-typed/src/test/java/jdocs/org/apache/pekko/cluster/sharding/typed/DurableStateStoreQueryUsageCompileOnlyTest.java#L22-L48" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.persistence.state.DurableState [...]
 import org.apache.pekko.persistence.query.javadsl.DurableStateStoreQuery;
 import org.apache.pekko.persistence.query.DurableStateChange;
 import org.apache.pekko.persistence.query.UpdatedDurableState;
@@ -492,9 +492,9 @@ source.map(
       }
     });</code></pre></dd>
 </dl>
-<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/query/DurableStateChange.html" title="org.apache.pekko.persistence.query.DurableStateChange"><code>DurableStateChange</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/query/DurableStateChange.html" title="org.apache.pekko.persistence.query.DurableStateChange"><code>Durabl [...]
+<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/query/DurableStateChange.html" title="org.apache.pekko.persistence.query.DurableStateChange"><code>DurableStateChange</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/query/DurableStateChange.html" title="org.apache.pekko.persistence.query.Dura [...]
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/durable-state/persistence-query.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/durable-state/persistence-query.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -579,7 +579,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/event-bus.html b/content/event-bus.html
index db9e0fc..3bf30e5 100644
--- a/content/event-bus.html
+++ b/content/event-bus.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -422,7 +422,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/actor/src/main/scala/org/apache/pekko/event/EventBus.scala#L39-L61" target="_blank" title="Go to snippet source">source</a><code class="language-scala">/**
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/actor/src/main/scala/org/apache/pekko/event/EventBus.scala#L39-L61" target="_blank" title="Go to snippet source">source</a><code class="language-scala">/**
  * Attempts to register the subscriber to the specified Classifier
  * @return true if successful and false if not (because it was already
  *   subscribed to that Classifier, or otherwise)
@@ -447,7 +447,7 @@ def unsubscribe(subscriber: Subscriber): Unit
 def publish(event: Event): Unit</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L62-L95" target="_blank" title="Go to snippet source">source</a><code class="language-java">/**
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L62-L95" target="_blank" title="Go to snippet source">source</a><code class="language-java">/**
  * Attempts to register the subscriber to the specified Classifier
  *
  * @return true if successful and false if not (because it was already subscribed to that
@@ -480,14 +480,14 @@ public void publish(Event event);
 </ul>
 <p>The traits below are still generic in these types, but they need to be defined for any concrete implementation.</p>
 <h2><a href="#classifiers" name="classifiers" class="anchor"><span class="anchor-link"></span></a>Classifiers</h2>
-<p>The classifiers presented here are part of the Pekko distribution, but rolling your own in case you do not find a perfect match is not difficult, check the implementation of the existing ones on <a href="https://github.com/akka/akka/tree/main/pekko-actor/src/main/scala/org/apache/pekko/event/EventBus.scala">github</a> </p>
+<p>The classifiers presented here are part of the Pekko distribution, but rolling your own in case you do not find a perfect match is not difficult, check the implementation of the existing ones on <a href="https://github.com/apache/incubator-pekko/tree/main/pekko-actor/src/main/scala/org/apache/pekko/event/EventBus.scala">github</a> </p>
 <h3><a href="#lookup-classification" name="lookup-classification" class="anchor"><span class="anchor-link"></span></a>Lookup Classification</h3>
-<p>The simplest classification is just to extract an arbitrary classifier from each event and maintaining a set of subscribers for each possible classifier. This can be compared to tuning in on a radio station. The <span class="group-scala">trait <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/event/LookupClassification.html" title="pekko.event.LookupClassification"><code>LookupClassification</code></a></span><span class="group-java">abstract class <a href="https://doc.akka.io [...]
+<p>The simplest classification is just to extract an arbitrary classifier from each event and maintaining a set of subscribers for each possible classifier. This can be compared to tuning in on a radio station. The <span class="group-scala">trait <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/event/LookupClassification.html" title="pekko.event.LookupClassification"><code>LookupClassification</code></a></span><span class="group-java">abstract class <a href="https://doc.akka.io [...]
 <p>The necessary methods to be implemented are illustrated with the following example:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L24-L58" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L24-L58" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.event.EventBus
 import pekko.event.LookupClassification
 
@@ -524,7 +524,7 @@ class LookupBusImpl extends EventBus with LookupClassification {
 </code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L31-L147" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.event.japi.LookupEventBus;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L31-L147" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.event.japi.LookupEventBus;
 
 static class MsgEnvelope {
   public final String topic;
@@ -574,14 +574,14 @@ static class LookupBusImpl extends LookupEventBus&lt;MsgEnvelope, ActorRef, Stri
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L163-L167" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val lookupBus = new LookupBusImpl
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L163-L167" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val lookupBus = new LookupBusImpl
 lookupBus.subscribe(testActor, &quot;greetings&quot;)
 lookupBus.publish(MsgEnvelope(&quot;time&quot;, System.currentTimeMillis()))
 lookupBus.publish(MsgEnvelope(&quot;greetings&quot;, &quot;hello&quot;))
 expectMsg(&quot;hello&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L282-L286" target="_blank" title="Go to snippet source">source</a><code class="language-java">LookupBusImpl lookupBus = new LookupBusImpl();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L282-L286" target="_blank" title="Go to snippet source">source</a><code class="language-java">LookupBusImpl lookupBus = new LookupBusImpl();
 lookupBus.subscribe(getTestActor(), &quot;greetings&quot;);
 lookupBus.publish(new MsgEnvelope(&quot;time&quot;, System.currentTimeMillis()));
 lookupBus.publish(new MsgEnvelope(&quot;greetings&quot;, &quot;hello&quot;));
@@ -594,7 +594,7 @@ expectMsgEquals(&quot;hello&quot;);</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L62-L96" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.util.Subclassification
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L62-L96" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.util.Subclassification
 
 class StartsWithSubclassification extends Subclassification[String] {
   override def isEqual(x: String, y: String): Boolean =
@@ -631,7 +631,7 @@ class SubchannelBusImpl extends EventBus with SubchannelClassification {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L36-L193" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.event.japi.SubchannelEventBus;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L36-L193" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.event.japi.SubchannelEventBus;
 
 static class StartsWithSubclassification implements Subclassification&lt;String&gt; {
   @Override
@@ -676,7 +676,7 @@ static class SubchannelBusImpl extends SubchannelEventBus&lt;MsgEnvelope, ActorR
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L173-L180" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val subchannelBus = new SubchannelBusImpl
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L173-L180" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val subchannelBus = new SubchannelBusImpl
 subchannelBus.subscribe(testActor, &quot;abc&quot;)
 subchannelBus.publish(MsgEnvelope(&quot;xyzabc&quot;, &quot;x&quot;))
 subchannelBus.publish(MsgEnvelope(&quot;bcdef&quot;, &quot;b&quot;))
@@ -686,7 +686,7 @@ subchannelBus.publish(MsgEnvelope(&quot;abcdef&quot;, &quot;d&quot;))
 expectMsg(&quot;d&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L297-L304" target="_blank" title="Go to snippet source">source</a><code class="language-java">SubchannelBusImpl subchannelBus = new SubchannelBusImpl();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L297-L304" target="_blank" title="Go to snippet source">source</a><code class="language-java">SubchannelBusImpl subchannelBus = new SubchannelBusImpl();
 subchannelBus.subscribe(getTestActor(), &quot;abc&quot;);
 subchannelBus.publish(new MsgEnvelope(&quot;xyzabc&quot;, &quot;x&quot;));
 subchannelBus.publish(new MsgEnvelope(&quot;bcdef&quot;, &quot;b&quot;));
@@ -702,7 +702,7 @@ expectMsgEquals(&quot;d&quot;);</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L100-L130" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.event.ScanningClassification
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L100-L130" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.event.ScanningClassification
 
 /**
  * Publishes String messages with length less than or equal to the length
@@ -735,7 +735,7 @@ class ScanningBusImpl extends EventBus with ScanningClassification {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L41-L230" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.event.japi.ScanningEventBus;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L41-L230" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.event.japi.ScanningEventBus;
 
 /**
  * Publishes String messages with length less than or equal to the length specified when
@@ -775,7 +775,7 @@ static class ScanningBusImpl extends ScanningEventBus&lt;String, ActorRef, Integ
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L186-L192" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val scanningBus = new ScanningBusImpl
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L186-L192" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val scanningBus = new ScanningBusImpl
 scanningBus.subscribe(testActor, 3)
 scanningBus.publish(&quot;xyzabc&quot;)
 scanningBus.publish(&quot;ab&quot;)
@@ -784,7 +784,7 @@ scanningBus.publish(&quot;abc&quot;)
 expectMsg(&quot;abc&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L315-L321" target="_blank" title="Go to snippet source">source</a><code class="language-java">ScanningBusImpl scanningBus = new ScanningBusImpl();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L315-L321" target="_blank" title="Go to snippet source">source</a><code class="language-java">ScanningBusImpl scanningBus = new ScanningBusImpl();
 scanningBus.subscribe(getTestActor(), 3);
 scanningBus.publish(&quot;xyzabc&quot;);
 scanningBus.publish(&quot;ab&quot;);
@@ -794,13 +794,13 @@ expectMsgEquals(&quot;abc&quot;);</code></pre></dd>
 </dl>
 <p>This classifier takes always a time which is proportional to the number of subscriptions, independent of how many actually match.</p>
 <h3><a href="#actor-classification" name="actor-classification" class="anchor"><span class="anchor-link"></span></a>Actor Classification</h3>
-<p>This classification was originally developed specifically for implementing <a href="actors.html#deathwatch">DeathWatch</a>: subscribers as well as classifiers are of type <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/acto [...]
-<p>This classification requires an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></span> in order to perform book-keepin [...]
+<p>This classification was originally developed specifically for implementing <a href="actors.html#deathwatch">DeathWatch</a>: subscribers as well as classifiers are of type <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html" title="org.apache.pekko.actor.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SN [...]
+<p>This classification requires an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></span> in  [...]
 <p>The necessary methods to be implemented are illustrated with the following example:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L134-L153" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L134-L153" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.event.ActorEventBus
 import pekko.event.ManagedActorClassification
 import pekko.event.ActorClassifier
@@ -822,7 +822,7 @@ class ActorBusImpl(val system: ActorSystem)
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L46-L268" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.event.japi.ManagedActorEventBus;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L46-L268" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.event.japi.ManagedActorEventBus;
 
 static class Notification {
   public final ActorRef ref;
@@ -859,7 +859,7 @@ static class ActorBusImpl extends ManagedActorEventBus&lt;Notification&gt; {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L198-L213" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val observer1 = TestProbe().ref
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/EventBusDocSpec.scala#L198-L213" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val observer1 = TestProbe().ref
 val observer2 = TestProbe().ref
 val probe1 = TestProbe()
 val probe2 = TestProbe()
@@ -877,7 +877,7 @@ probe2.expectMsg(Notification(observer2, 101))
 probe1.expectNoMessage(500.millis)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L330-L347" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef observer1 = new TestKit(system).getRef();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/EventBusDocTest.java#L330-L347" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef observer1 = new TestKit(system).getRef();
 ActorRef observer2 = new TestKit(system).getRef();
 TestKit probe1 = new TestKit(system);
 TestKit probe2 = new TestKit(system);
@@ -898,8 +898,8 @@ probe1.expectNoMessage(Duration.ofMillis(500));</code></pre></dd>
 </dl>
 <p>This classifier is still is generic in the event type, and it is efficient for all use cases.</p>
 <h2><a href="#event-stream" name="event-stream" class="anchor"><span class="anchor-link"></span></a>Event Stream</h2>
-<p>The event stream is the main event bus of each actor system: it is used for carrying <a href="logging.html">log messages</a> and <a href="event-bus.html#dead-letters">Dead Letters</a> and may be used by the user code for other purposes as well. It uses <a href="event-bus.html#subchannel-classification">Subchannel Classification</a> which enables registering to related sets of channels (as is used for <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528- [...]
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L131-L180" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.{ Actor, DeadLetter, Props }
+<p>The event stream is the main event bus of each actor system: it is used for carrying <a href="logging.html">log messages</a> and <a href="event-bus.html#dead-letters">Dead Letters</a> and may be used by the user code for other purposes as well. It uses <a href="event-bus.html#subchannel-classification">Subchannel Classification</a> which enables registering to related sets of channels (as is used for <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+ [...]
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L131-L180" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.{ Actor, DeadLetter, Props }
 
 class DeadLetterListener extends Actor {
   def receive = {
@@ -909,9 +909,9 @@ class DeadLetterListener extends Actor {
 
 val listener = system.actorOf(Props[DeadLetterListener]())
 system.eventStream.subscribe(listener, classOf[DeadLetter])</code></pre></div><div class="group-java">
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L44-L45" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.ActorRef;
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L44-L45" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.ActorRef;
 import org.apache.pekko.actor.ActorSystem;</code></pre>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L258-L269" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class DeadLetterActor extends AbstractActor {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L258-L269" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class DeadLetterActor extends AbstractActor {
   @Override
   public Receive createReceive() {
     return receiveBuilder()
@@ -924,14 +924,14 @@ import org.apache.pekko.actor.ActorSystem;</code></pre>
   }
 }</code></pre>
 <p>it can be subscribed like this:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L69-L71" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorSystem system = ActorSystem.create(&quot;DeadLetters&quot;);
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L69-L71" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorSystem system = ActorSystem.create(&quot;DeadLetters&quot;);
 final ActorRef actor = system.actorOf(Props.create(DeadLetterActor.class));
 system.getEventStream().subscribe(actor, DeadLetter.class);</code></pre></div>
 <p>It is also worth pointing out that thanks to the way the subchannel classification is implemented in the event stream, it is possible to subscribe to a group of events, by subscribing to their common superclass as demonstrated in the following example:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L141-L197" target="_blank" title="Go to snippet source">source</a><code class="language-scala">abstract class AllKindsOfMusic { def artist: String }
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L141-L197" target="_blank" title="Go to snippet source">source</a><code class="language-scala">abstract class AllKindsOfMusic { def artist: String }
 case class Jazz(artist: String) extends AllKindsOfMusic
 case class Electronic(artist: String) extends AllKindsOfMusic
 
@@ -954,7 +954,7 @@ system.eventStream.publish(Electronic(&quot;Parov Stelar&quot;))
 system.eventStream.publish(Jazz(&quot;Sonny Rollins&quot;))</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L77-L127" target="_blank" title="Go to snippet source">source</a><code class="language-java">interface AllKindsOfMusic {}
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L77-L127" target="_blank" title="Go to snippet source">source</a><code class="language-java">interface AllKindsOfMusic {}
 
 class Jazz implements AllKindsOfMusic {
   public final String artist;
@@ -1000,7 +1000,7 @@ static class Listener extends AbstractActor {
   system.getEventStream().publish(new Jazz(&quot;Sonny Rollins&quot;));
 </code></pre></dd>
 </dl>
-<p>Similarly to <a href="event-bus.html#actor-classification">Actor Classification</a>, <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/EventStream.html" title="org.apache.pekko.event.EventStream"><code>EventStream</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/EventStream.html" title="org.apache.pekko.event.EventStream"><code>EventStr [...]
+<p>Similarly to <a href="event-bus.html#actor-classification">Actor Classification</a>, <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/EventStream.html" title="org.apache.pekko.event.EventStream"><code>EventStream</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/EventStream.html" title="org.apache.pekko.event [...]
 <p>The event stream is a <em>local facility</em>, meaning that it will <em>not</em> distribute events to other nodes in a clustered environment (unless you subscribe a Remote Actor to the stream explicitly). If you need to broadcast events in a Pekko cluster, <em>without</em> knowing your recipients explicitly (i.e. obtaining their ActorRefs), you may want to look into: <a href="distributed-pub-sub.html">Distributed Publish Subscribe in Cluster</a>.</p></div>
 <h3><a href="#default-handlers" name="default-handlers" class="anchor"><span class="anchor-link"></span></a>Default Handlers</h3>
 <p>Upon start-up the actor system creates and subscribes actors to the event stream for logging: these are the handlers which are configured for example in <code>application.conf</code>:</p>
@@ -1021,32 +1021,32 @@ static class Listener extends AbstractActor {
 </dl>
 <p>This means that log events for a level which will not be logged are typically not dispatched at all (unless manual subscriptions to the respective event class have been done)</p>
 <h3><a href="#dead-letters" name="dead-letters" class="anchor"><span class="anchor-link"></span></a>Dead Letters</h3>
-<p>As described at <a href="actors.html#stopping-actors">Stopping actors</a>, messages queued when an actor terminates or sent after its death are re-routed to the dead letter mailbox, which by default will publish the messages wrapped in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/DeadLetter.html" title="org.apache.pekko.actor.DeadLetter"><code>DeadLetter</code></a></span><span class="group-java"><a href="https://d [...]
-<p>Some internal messages (marked with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/DeadLetterSuppression.html" title="org.apache.pekko.actor.DeadLetterSuppression"><code>DeadLetterSuppression</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/DeadLetterSuppression.html" title="org.apache.pekko.actor.DeadLetterSuppression"><code>Dea [...]
+<p>As described at <a href="actors.html#stopping-actors">Stopping actors</a>, messages queued when an actor terminates or sent after its death are re-routed to the dead letter mailbox, which by default will publish the messages wrapped in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/DeadLetter.html" title="org.apache.pekko.actor.DeadLetter"><code>DeadLetter</code></a></span><span class="group-java"><a h [...]
+<p>Some internal messages (marked with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/DeadLetterSuppression.html" title="org.apache.pekko.actor.DeadLetterSuppression"><code>DeadLetterSuppression</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/DeadLetterSuppression.html" title="org.apache.pekko.actor.Dead [...]
 <p>However, in case you find yourself in need of debugging these kinds of low level suppressed dead letters, it&rsquo;s still possible to subscribe to them explicitly:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L206-L207" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.SuppressedDeadLetter
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L206-L207" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.SuppressedDeadLetter
 system.eventStream.subscribe(listener, classOf[SuppressedDeadLetter])</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L138" target="_blank" title="Go to snippet source">source</a><code class="language-java">system.getEventStream().subscribe(actor, SuppressedDeadLetter.class);</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L138" target="_blank" title="Go to snippet source">source</a><code class="language-java">system.getEventStream().subscribe(actor, SuppressedDeadLetter.class);</code></pre></dd>
 </dl>
 <p>or all dead letters (including the suppressed ones):</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L211-L212" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.AllDeadLetters
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L211-L212" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.AllDeadLetters
 system.eventStream.subscribe(listener, classOf[AllDeadLetters])</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L150" target="_blank" title="Go to snippet source">source</a><code class="language-java">system.getEventStream().subscribe(actor, AllDeadLetters.class);</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L150" target="_blank" title="Go to snippet source">source</a><code class="language-java">system.getEventStream().subscribe(actor, AllDeadLetters.class);</code></pre></dd>
 </dl>
 <h3><a href="#other-uses" name="other-uses" class="anchor"><span class="anchor-link"></span></a>Other Uses</h3>
 <p>The event stream is always there and ready to be used, you can publish your own events (it accepts <span class="group-scala"><a href="http://www.scala-lang.org/api/2.13.8/scala/AnyRef.html" title="scala.AnyRef"><code>AnyRef</code></a></span><span class="group-java"><a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/Object.html" title="java.lang.Object"><code>Object</code></a></span>) and subscribe listeners to the corresponding JVM classes.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/event-bus.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/event-bus.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -1130,7 +1130,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/extending-pekko.html b/content/extending-pekko.html
index c9d8c31..83955c7 100644
--- a/content/extending-pekko.html
+++ b/content/extending-pekko.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -418,16 +418,16 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="page-content row">
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#classic-pekko-extensions" name="classic-pekko-extensions" class="anchor"><span class="anchor-link"></span></a>Classic Pekko Extensions</h1>
-<p>If you want to add features to Pekko, there is a very elegant, but powerful mechanism for doing so. It&rsquo;s called Pekko Extensions and comprises 2 basic components: an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Extension.html" title="org.apache.pekko.actor.Extension"><code>Extension</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/ [...]
-<p>Extensions will only be loaded once per <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></span>, which will be managed  [...]
+<p>If you want to add features to Pekko, there is a very elegant, but powerful mechanism for doing so. It&rsquo;s called Pekko Extensions and comprises 2 basic components: an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Extension.html" title="org.apache.pekko.actor.Extension"><code>Extension</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-144 [...]
+<p>Extensions will only be loaded once per <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></s [...]
 <p>Since an extension is a way to hook into Pekko itself, the implementor of the extension needs to ensure the thread safety of his/her extension.</p></div>
 <h2><a href="#building-an-extension" name="building-an-extension" class="anchor"><span class="anchor-link"></span></a>Building an Extension</h2>
 <p>So let&rsquo;s create a sample extension that lets us count the number of times something has happened.</p>
-<p>First, we define what our <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Extension.html" title="org.apache.pekko.actor.Extension"><code>Extension</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Extension.html" title="org.apache.pekko.actor.Extension"><code>Extension</code></a></span> should do:</p>
+<p>First, we define what our <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Extension.html" title="org.apache.pekko.actor.Extension"><code>Extension</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Extension.html" title="org.apache.pekko.actor.Extension"><code>Extension</code></a></span> should do:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L23-L32" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Extension
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L23-L32" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Extension
 
 class CountExtensionImpl extends Extension {
   // Since this Extension is a shared instance
@@ -439,7 +439,7 @@ class CountExtensionImpl extends Extension {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/extension/ExtensionDocTest.java#L17-L19" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.*;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/extension/ExtensionDocTest.java#L17-L19" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.*;
 import java.util.concurrent.atomic.AtomicLong;
 
 static class CountExtensionImpl implements Extension {
@@ -454,11 +454,11 @@ static class CountExtensionImpl implements Extension {
 }
 </code></pre></dd>
 </dl>
-<p>Then we need to create an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ExtensionId.html" title="org.apache.pekko.actor.ExtensionId"><code>ExtensionId</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ExtensionId.html" title="org.apache.pekko.actor.ExtensionId"><code>ExtensionId</code></a></span> for our extension so we can grab a ho [...]
+<p>Then we need to create an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ExtensionId.html" title="org.apache.pekko.actor.ExtensionId"><code>ExtensionId</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ExtensionId.html" title="org.apache.pekko.actor.ExtensionId"><code>ExtensionId</code></a></span> for our e [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L36-L58" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L36-L58" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.ActorSystem
 import pekko.actor.ExtensionId
 import pekko.actor.ExtensionIdProvider
@@ -483,7 +483,7 @@ object CountExtension extends ExtensionId[CountExtensionImpl] with ExtensionIdPr
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/extension/ExtensionDocTest.java#L17-L19" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.*;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/extension/ExtensionDocTest.java#L17-L19" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.*;
 import java.util.concurrent.atomic.AtomicLong;
 
 static class CountExtension extends AbstractExtensionId&lt;CountExtensionImpl&gt;
@@ -513,10 +513,10 @@ static class CountExtension extends AbstractExtensionId&lt;CountExtensionImpl&gt
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L98" target="_blank" title="Go to snippet source">source</a><code class="language-scala">CountExtension(system).increment()</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L98" target="_blank" title="Go to snippet source">source</a><code class="language-scala">CountExtension(system).increment()</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/extension/ExtensionDocTest.java#L91-L93" target="_blank" title="Go to snippet source">source</a><code class="language-java">// typically you would use static import of the
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/extension/ExtensionDocTest.java#L91-L93" target="_blank" title="Go to snippet source">source</a><code class="language-java">// typically you would use static import of the
 // CountExtension.CountExtensionProvider field
 CountExtension.CountExtensionProvider.get(system).increment();</code></pre></dd>
 </dl>
@@ -524,7 +524,7 @@ CountExtension.CountExtensionProvider.get(system).increment();</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L72-L78" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>class MyActor extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L72-L78" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>class MyActor extends Actor {
   def receive = {
     case someMessage =&gt;
       CountExtension(context.system).increment()
@@ -532,7 +532,7 @@ CountExtension.CountExtensionProvider.get(system).increment();</code></pre></dd>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/extension/ExtensionDocTest.java#L70-L83" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyActor extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/extension/ExtensionDocTest.java#L70-L83" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyActor extends AbstractActor {
   @Override
   public Receive createReceive() {
     return receiveBuilder()
@@ -548,7 +548,7 @@ CountExtension.CountExtensionProvider.get(system).increment();</code></pre></dd>
 </code></pre></dd>
 </dl><div class="group-scala">
 <p>You can also hide extension behind traits:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L82-L90" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>trait Counting { self: Actor =&gt;
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L82-L90" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>trait Counting { self: Actor =&gt;
   def increment() = CountExtension(context.system).increment()
 }
 class MyCounterActor extends Actor with Counting {
@@ -559,11 +559,11 @@ class MyCounterActor extends Actor with Counting {
 <p>That&rsquo;s all there is to it!</p>
 <a id="loading"></a>
 <h2><a href="#loading-from-configuration" name="loading-from-configuration" class="anchor"><span class="anchor-link"></span></a>Loading from Configuration</h2>
-<p>To be able to load extensions from your Pekko configuration you must add FQCNs of implementations of either <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ExtensionId.html" title="org.apache.pekko.actor.ExtensionId"><code>ExtensionId</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ExtensionId.html" title="org.apache.pekko.actor.Exte [...]
+<p>To be able to load extensions from your Pekko configuration you must add FQCNs of implementations of either <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ExtensionId.html" title="org.apache.pekko.actor.ExtensionId"><code>ExtensionId</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ExtensionId.html" title= [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L65-L67" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/extension/ExtensionDocSpec.scala#L65-L67" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko {
   extensions = [&quot;docs.extension.CountExtension&quot;]
 }</code></pre></dd>
   <dt>Java</dt>
@@ -579,7 +579,7 @@ class MyCounterActor extends Actor with Counting {
 <h3><a href="#application-specific-settings" name="application-specific-settings" class="anchor"><span class="anchor-link"></span></a>Application specific settings</h3>
 <p>The <a href="general/configuration.html">configuration</a> can be used for application specific settings. A good practice is to place those settings in an Extension.</p>
 <p>Sample configuration:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/extension/SettingsExtensionDocSpec.scala#L63-L70" target="_blank" title="Go to snippet source">source</a><code class="language-scala">myapp {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/extension/SettingsExtensionDocSpec.scala#L63-L70" target="_blank" title="Go to snippet source">source</a><code class="language-scala">myapp {
   db {
     uri = &quot;mongodb://example1.com:27017,example2.com:27017&quot;
   }
@@ -587,11 +587,11 @@ class MyCounterActor extends Actor with Counting {
     timeout = 30 seconds
   }
 }</code></pre>
-<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Extension.html" title="org.apache.pekko.actor.Extension"><code>Extension</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Extension.html" title="org.apache.pekko.actor.Extension"><code>Extension</code></a></span>:</p>
+<p>The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Extension.html" title="org.apache.pekko.actor.Extension"><code>Extension</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Extension.html" title="org.apache.pekko.actor.Extension"><code>Extension</code></a></span>:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/extension/SettingsExtensionDocSpec.scala#L17-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/extension/SettingsExtensionDocSpec.scala#L17-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.ActorSystem
 import pekko.actor.Extension
 import pekko.actor.ExtensionId
@@ -624,7 +624,7 @@ object Settings extends ExtensionId[SettingsImpl] with ExtensionIdProvider {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/extension/SettingsExtensionDocTest.java#L17-L25" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.Extension;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/extension/SettingsExtensionDocTest.java#L17-L25" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.Extension;
 import org.apache.pekko.actor.AbstractExtensionId;
 import org.apache.pekko.actor.ExtensionIdProvider;
 import org.apache.pekko.actor.ActorSystem;
@@ -665,13 +665,13 @@ static class Settings extends AbstractExtensionId&lt;SettingsImpl&gt; implements
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/extension/SettingsExtensionDocSpec.scala#L75-L79" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>class MyActor extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/extension/SettingsExtensionDocSpec.scala#L75-L79" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>class MyActor extends Actor {
   val settings = Settings(context.system)
   val connection = connect(settings.DbUri, settings.CircuitBreakerTimeout)
 </code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/extension/SettingsExtensionDocTest.java#L71-L87" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyActor extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/extension/SettingsExtensionDocTest.java#L71-L87" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyActor extends AbstractActor {
   // typically you would use static import of the Settings.SettingsProvider field
   final SettingsImpl settings = Settings.SettingsProvider.get(getContext().getSystem());
   Connection connection = connect(settings.DB_URI, settings.CIRCUIT_BREAKER_TIMEOUT);
@@ -685,7 +685,7 @@ static class Settings extends AbstractExtensionId&lt;SettingsImpl&gt; implements
 <p>As there is no way to selectively remove such extensions, it should be used with care and only when there is no case where the user would ever want it disabled or have specific support for disabling such sub-features. One example where this could be important is in tests.</p><div class="callout warning "><div class="callout-title">Warning</div>
 <p>The<code>pekko.library-extensions</code> must never be assigned (<code>= [&quot;Extension&quot;]</code>) instead of appending as this will break the library-extension mechanism and make behavior depend on class path ordering.</p></div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/extending-pekko.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/extending-pekko.md">here</a>.
 </div>
 
 </div>
@@ -768,7 +768,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/fault-tolerance-sample.html b/content/fault-tolerance-sample.html
index dd4b450..25d0757 100644
--- a/content/fault-tolerance-sample.html
+++ b/content/fault-tolerance-sample.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Diagrams of the Fault Tolerance Sample
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -69,7 +69,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Diagrams of the Fault Tolerance Sample
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -177,7 +177,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSample.scala#L20-L307" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSample.scala#L20-L307" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor._
 import pekko.actor.SupervisorStrategy._
 import scala.concurrent.duration._
@@ -457,7 +457,7 @@ object DummyDB {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingDocSample.java#L18-L536" target="_blank" title="Go to snippet source">source</a><code class="language-java">import java.util.ArrayList;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingDocSample.java#L18-L536" target="_blank" title="Go to snippet source">source</a><code class="language-java">import java.util.ArrayList;
 import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
@@ -967,7 +967,7 @@ public class FaultHandlingDocSample {
 }</code></pre></dd>
 </dl>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/fault-tolerance-sample.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/fault-tolerance-sample.md">here</a>.
 </div>
 
 </div>
@@ -1047,7 +1047,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/fault-tolerance.html b/content/fault-tolerance.html
index 3d3e7f7..e1ac0ee 100644
--- a/content/fault-tolerance.html
+++ b/content/fault-tolerance.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <p>For the full documentation of this feature and for new projects see <a href="typed/fault-tolerance.html">fault tolerance</a>.</p>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>The concept of fault tolerance relates to actors, so in order to use these make sure to depend on actors:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>The concept of fault tolerance relates to actors, so in order to use these make sure to depend on actors:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -430,7 +430,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -445,7 +445,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -460,7 +460,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L36-L47" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L36-L47" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.OneForOneStrategy
 import pekko.actor.SupervisorStrategy._
 import scala.concurrent.duration._
@@ -474,7 +474,7 @@ override val supervisorStrategy =
   }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L67-L81" target="_blank" title="Go to snippet source">source</a><code class="language-java">private static SupervisorStrategy strategy =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L67-L81" target="_blank" title="Go to snippet source">source</a><code class="language-java">private static SupervisorStrategy strategy =
     new OneForOneStrategy(
         10,
         Duration.ofMinutes(1),
@@ -523,7 +523,7 @@ public SupervisorStrategy supervisorStrategy() {
 </ul>
 <p>If the exception escalate all the way up to the root guardian it will handle it in the same way as the default strategy defined above.</p><div class="group-scala">
 <p>You can combine your own strategy with the default strategy:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L83-L93" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L83-L93" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.OneForOneStrategy
 import pekko.actor.SupervisorStrategy._
 import scala.concurrent.duration._
@@ -548,7 +548,7 @@ override val supervisorStrategy =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L31-L53" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Actor
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L31-L53" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Actor
 
 class Supervisor extends Actor {
   import org.apache.pekko
@@ -570,7 +570,7 @@ class Supervisor extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L41-L95" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.japi.pf.DeciderBuilder;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L41-L95" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.japi.pf.DeciderBuilder;
 import org.apache.pekko.actor.SupervisorStrategy;
 
 static class Supervisor extends AbstractActor {
@@ -608,7 +608,7 @@ static class Supervisor extends AbstractActor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L31-L107" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Actor
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L31-L107" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Actor
 
 class Child extends Actor {
   var state = 0
@@ -620,7 +620,7 @@ class Child extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L141-L157" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Child extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L141-L157" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Child extends AbstractActor {
   int state = 0;
 
   @Override
@@ -642,7 +642,7 @@ class Child extends Actor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L21-L206" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import com.typesafe.config.{ Config, ConfigFactory }
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L21-L206" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import com.typesafe.config.{ Config, ConfigFactory }
 import org.scalatest.BeforeAndAfterAll
 import org.scalatest.matchers.should.Matchers
 import org.scalatest.wordspec.AnyWordSpecLike
@@ -678,7 +678,7 @@ class FaultHandlingDocSpec(_system: ActorSystem)
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L28-L232" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.testkit.TestProbe;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L28-L232" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.testkit.TestProbe;
 import org.apache.pekko.testkit.ErrorFilter;
 import org.apache.pekko.testkit.EventFilter;
 import org.apache.pekko.testkit.TestEvent;
@@ -714,13 +714,13 @@ public class FaultHandlingTest extends AbstractJavaTest {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L144-L147" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val supervisor = system.actorOf(Props[Supervisor](), &quot;supervisor&quot;)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L144-L147" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val supervisor = system.actorOf(Props[Supervisor](), &quot;supervisor&quot;)
 
 supervisor ! Props[Child]()
 val child = expectMsgType[ActorRef] // retrieve answer from TestKit’s testActor</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L188-L191" target="_blank" title="Go to snippet source">source</a><code class="language-java">Props superprops = Props.create(Supervisor.class);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L188-L191" target="_blank" title="Go to snippet source">source</a><code class="language-java">Props superprops = Props.create(Supervisor.class);
 ActorRef supervisor = system.actorOf(superprops, &quot;supervisor&quot;);
 ActorRef child =
     (ActorRef) Await.result(ask(supervisor, Props.create(Child.class), 5000), timeout);</code></pre></dd>
@@ -729,7 +729,7 @@ ActorRef child =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L151-L157" target="_blank" title="Go to snippet source">source</a><code class="language-scala">child ! 42 // set state to 42
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L151-L157" target="_blank" title="Go to snippet source">source</a><code class="language-scala">child ! 42 // set state to 42
 child ! &quot;get&quot;
 expectMsg(42)
 
@@ -738,7 +738,7 @@ child ! &quot;get&quot;
 expectMsg(42)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L195-L198" target="_blank" title="Go to snippet source">source</a><code class="language-java">child.tell(42, ActorRef.noSender());
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L195-L198" target="_blank" title="Go to snippet source">source</a><code class="language-java">child.tell(42, ActorRef.noSender());
 assertEquals(42, Await.result(ask(child, &quot;get&quot;, 5000), timeout));
 child.tell(new ArithmeticException(), ActorRef.noSender());
 assertEquals(42, Await.result(ask(child, &quot;get&quot;, 5000), timeout));</code></pre></dd>
@@ -747,24 +747,24 @@ assertEquals(42, Await.result(ask(child, &quot;get&quot;, 5000), timeout));</cod
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L162-L164" target="_blank" title="Go to snippet source">source</a><code class="language-scala">child ! new NullPointerException // crash it harder
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L162-L164" target="_blank" title="Go to snippet source">source</a><code class="language-scala">child ! new NullPointerException // crash it harder
 child ! &quot;get&quot;
 expectMsg(0)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L202-L203" target="_blank" title="Go to snippet source">source</a><code class="language-java">child.tell(new NullPointerException(), ActorRef.noSender());
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L202-L203" target="_blank" title="Go to snippet source">source</a><code class="language-java">child.tell(new NullPointerException(), ActorRef.noSender());
 assertEquals(0, Await.result(ask(child, &quot;get&quot;, 5000), timeout));</code></pre></dd>
 </dl>
 <p>And finally in case of the fatal <code>IllegalArgumentException</code> the child will be terminated by the supervisor:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L169-L171" target="_blank" title="Go to snippet source">source</a><code class="language-scala">watch(child) // have testActor watch “child”
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L169-L171" target="_blank" title="Go to snippet source">source</a><code class="language-scala">watch(child) // have testActor watch “child”
 child ! new IllegalArgumentException // break it
 expectMsgPF() { case Terminated(`child`) =&gt; () }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L207-L210" target="_blank" title="Go to snippet source">source</a><code class="language-java">final TestProbe probe = new TestProbe(system);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L207-L210" target="_blank" title="Go to snippet source">source</a><code class="language-java">final TestProbe probe = new TestProbe(system);
 probe.watch(child);
 child.tell(new IllegalArgumentException(), ActorRef.noSender());
 probe.expectMsgClass(Terminated.class);</code></pre></dd>
@@ -773,7 +773,7 @@ probe.expectMsgClass(Terminated.class);</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L176-L185" target="_blank" title="Go to snippet source">source</a><code class="language-scala">supervisor ! Props[Child]() // create new child
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L176-L185" target="_blank" title="Go to snippet source">source</a><code class="language-scala">supervisor ! Props[Child]() // create new child
 val child2 = expectMsgType[ActorRef]
 watch(child2)
 child2 ! &quot;get&quot; // verify it is alive
@@ -785,7 +785,7 @@ expectMsgPF() {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L214-L218" target="_blank" title="Go to snippet source">source</a><code class="language-java">child = (ActorRef) Await.result(ask(supervisor, Props.create(Child.class), 5000), timeout);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L214-L218" target="_blank" title="Go to snippet source">source</a><code class="language-java">child = (ActorRef) Await.result(ask(supervisor, Props.create(Child.class), 5000), timeout);
 probe.watch(child);
 assertEquals(0, Await.result(ask(child, &quot;get&quot;, 5000), timeout));
 child.tell(new Exception(), ActorRef.noSender());
@@ -796,7 +796,7 @@ probe.expectMsgClass(Terminated.class);</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L57-L78" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Supervisor2 extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L57-L78" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Supervisor2 extends Actor {
   import org.apache.pekko
   import pekko.actor.OneForOneStrategy
   import pekko.actor.SupervisorStrategy._
@@ -818,7 +818,7 @@ probe.expectMsgClass(Terminated.class);</code></pre></dd>
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L100-L136" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Supervisor2 extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L100-L136" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Supervisor2 extends AbstractActor {
 
   private static SupervisorStrategy strategy =
       new OneForOneStrategy(
@@ -858,7 +858,7 @@ probe.expectMsgClass(Terminated.class);</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L188-L199" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val supervisor2 = system.actorOf(Props[Supervisor2](), &quot;supervisor2&quot;)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FaultHandlingDocSpec.scala#L188-L199" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val supervisor2 = system.actorOf(Props[Supervisor2](), &quot;supervisor2&quot;)
 
 supervisor2 ! Props[Child]()
 val child3 = expectMsgType[ActorRef]
@@ -872,7 +872,7 @@ child3 ! &quot;get&quot;
 expectMsg(0)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L222-L228" target="_blank" title="Go to snippet source">source</a><code class="language-java">superprops = Props.create(Supervisor2.class);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/FaultHandlingTest.java#L222-L228" target="_blank" title="Go to snippet source">source</a><code class="language-java">superprops = Props.create(Supervisor2.class);
 supervisor = system.actorOf(superprops);
 child = (ActorRef) Await.result(ask(supervisor, Props.create(Child.class), 5000), timeout);
 child.tell(23, ActorRef.noSender());
@@ -897,18 +897,18 @@ assertEquals(0, Await.result(ask(child, &quot;get&quot;, 5000), timeout));</code
 <h3><a href="#sharding" name="sharding" class="anchor"><span class="anchor-link"></span></a>Sharding</h3>
 <p>If the &lsquo;on stop&rsquo; strategy is used for sharded actors a final termination message should be configured and used to terminate the actor on passivation. Otherwise the supervisor will just stop and start the actor again.</p>
 <p>The termination message is configured with:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L125-L128" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val supervisor = BackoffSupervisor.props(
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L125-L128" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val supervisor = BackoffSupervisor.props(
   BackoffOpts
     .onStop(childProps, childName = &quot;myEcho&quot;, minBackoff = 3.seconds, maxBackoff = 30.seconds, randomFactor = 0.2)
     .withFinalStopMessage(_ == StopMessage))</code></pre>
 <p>And must be used for passivation:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L132" target="_blank" title="Go to snippet source">source</a><code class="language-scala">context.parent ! Passivate(StopMessage)</code></pre>
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L132" target="_blank" title="Go to snippet source">source</a><code class="language-scala">context.parent ! Passivate(StopMessage)</code></pre>
 <h3><a href="#simple-backoff" name="simple-backoff" class="anchor"><span class="anchor-link"></span></a>Simple backoff</h3>
 <p>The following snippet shows how to create a backoff supervisor which will start the given echo actor after it has stopped because of a failure, in increasing intervals of 3, 6, 12, 24 and finally 30 seconds:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L28-L39" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val childProps = Props(classOf[EchoActor])
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L28-L39" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val childProps = Props(classOf[EchoActor])
 
 val supervisor = BackoffSupervisor.props(
   BackoffOpts.onStop(
@@ -922,7 +922,7 @@ val supervisor = BackoffSupervisor.props(
 system.actorOf(supervisor, name = &quot;echoSupervisor&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/pattern/BackoffSupervisorDocTest.java#L28-L39" target="_blank" title="Go to snippet source">source</a><code class="language-java">final Props childProps = Props.create(EchoActor.class);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/pattern/BackoffSupervisorDocTest.java#L28-L39" target="_blank" title="Go to snippet source">source</a><code class="language-java">final Props childProps = Props.create(EchoActor.class);
 
 final Props supervisorProps =
     BackoffSupervisor.props(
@@ -941,7 +941,7 @@ system.actorOf(supervisorProps, &quot;echoSupervisor&quot;);</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L48-L59" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val childProps = Props(classOf[EchoActor])
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L48-L59" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val childProps = Props(classOf[EchoActor])
 
 val supervisor = BackoffSupervisor.props(
   BackoffOpts.onFailure(
@@ -955,7 +955,7 @@ val supervisor = BackoffSupervisor.props(
 system.actorOf(supervisor, name = &quot;echoSupervisor&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/pattern/BackoffSupervisorDocTest.java#L45-L56" target="_blank" title="Go to snippet source">source</a><code class="language-java">final Props childProps = Props.create(EchoActor.class);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/pattern/BackoffSupervisorDocTest.java#L45-L56" target="_blank" title="Go to snippet source">source</a><code class="language-java">final Props childProps = Props.create(EchoActor.class);
 
 final Props supervisorProps =
     BackoffSupervisor.props(
@@ -972,7 +972,7 @@ system.actorOf(supervisorProps, &quot;echoSupervisor&quot;);</code></pre></dd>
 <p>The <code>org.apache.pekko.pattern.BackoffOnFailureOptions</code> and <code>org.apache.pekko.pattern.BackoffOnRestartOptions</code> can be used to customize the behavior of the back-off supervisor actor. Options are: * <code>withAutoReset</code>: The backoff is reset if no failure/stop occurs within the duration. This is the default behaviour with <code>minBackoff</code> as default value * <code>withManualReset</code>: The child must send <code>BackoffSupervisor.Reset</code> to its ba [...]
 <p>Only available on <code>BackoffOnStopOptions</code>: * <code>withDefaultStoppingStrategy</code>: Sets a <code>OneForOneStrategy</code> with the stopping decider that stops the child on all exceptions. * <code>withFinalStopMessage</code>: Allows to define a predicate to decide on finally stopping the child (and supervisor). Used for passivate sharded actors - see above.</p>
 <p>Some examples:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L70-L81" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val supervisor = BackoffSupervisor.props(
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L70-L81" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val supervisor = BackoffSupervisor.props(
   BackoffOpts
     .onStop(
       childProps,
@@ -985,7 +985,7 @@ system.actorOf(supervisorProps, &quot;echoSupervisor&quot;);</code></pre></dd>
     .withDefaultStoppingStrategy // Stop at any Exception thrown
 )</code></pre>
 <p>The above code sets up a back-off supervisor that requires the child actor to send a <code>org.apache.pekko.pattern.BackoffSupervisor.Reset</code> message to its parent when a message is successfully processed, resetting the back-off. It also uses a default stopping strategy, any exception will cause the child to stop.</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L94-L107" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val supervisor = BackoffSupervisor.props(
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/pattern/BackoffSupervisorDocSpec.scala#L94-L107" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val supervisor = BackoffSupervisor.props(
   BackoffOpts
     .onFailure(
       childProps,
@@ -1001,7 +1001,7 @@ system.actorOf(supervisorProps, &quot;echoSupervisor&quot;);</code></pre></dd>
     }))</code></pre>
 <p>The above code sets up a back-off supervisor that stops and starts the child after back-off if MyException is thrown, any other exception will be escalated. The back-off is automatically reset if the child does not throw any errors within 10 seconds.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/fault-tolerance.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/fault-tolerance.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -1090,7 +1090,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/fsm.html b/content/fsm.html
index ec12ace..fe7cbe3 100644
--- a/content/fsm.html
+++ b/content/fsm.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <p>For the documentation of the new API of this feature and for new projects see <a href="typed/fsm.html">fsm</a>.</p>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use Finite State Machine actors, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Finite State Machine actors, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -430,7 +430,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -445,7 +445,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -465,11 +465,11 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L57-L58" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import pekko.actor.{ ActorRef, FSM }
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L57-L58" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import pekko.actor.{ ActorRef, FSM }
 import scala.concurrent.duration._</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L17-L23" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractFSM;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L17-L23" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.AbstractFSM;
 import org.apache.pekko.actor.ActorRef;
 import org.apache.pekko.japi.pf.UnitMatch;
 import java.util.Arrays;
@@ -481,7 +481,7 @@ import java.time.Duration;</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L31-L37" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// received events
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L31-L37" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// received events
 final case class SetTarget(ref: ActorRef)
 final case class Queue(obj: Any)
 case object Flush
@@ -490,7 +490,7 @@ case object Flush
 final case class Batch(obj: immutable.Seq[Any])</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/Events.java#L23-L116" target="_blank" title="Go to snippet source">source</a><code class="language-java">static final class SetTarget {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/Events.java#L23-L116" target="_blank" title="Go to snippet source">source</a><code class="language-java">static final class SetTarget {
   private final ActorRef ref;
 
   public SetTarget(ActorRef ref) {
@@ -574,7 +574,7 @@ static enum Flush {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L40-L47" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// states
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L40-L47" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// states
 sealed trait State
 case object Idle extends State
 case object Active extends State
@@ -584,7 +584,7 @@ case object Uninitialized extends Data
 final case class Todo(target: ActorRef, queue: immutable.Seq[Any]) extends Data</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L104-L163" target="_blank" title="Go to snippet source">source</a><code class="language-java">// states
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L104-L163" target="_blank" title="Go to snippet source">source</a><code class="language-java">// states
 enum State {
   Idle,
   Active
@@ -639,7 +639,7 @@ final class Todo implements Data {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L61-L104" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Buncher extends FSM[State, Data] {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L61-L104" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Buncher extends FSM[State, Data] {
 
   startWith(Idle, Uninitialized)
 
@@ -675,7 +675,7 @@ final class Todo implements Data {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L33-L166" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class Buncher extends AbstractFSM&lt;State, Data&gt; {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L33-L166" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class Buncher extends AbstractFSM&lt;State, Data&gt; {
   {
     startWith(Idle, Uninitialized);
 
@@ -746,7 +746,7 @@ final class Todo implements Data {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L91-L99" target="_blank" title="Go to snippet source">source</a><code class="language-scala">whenUnhandled {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L91-L99" target="_blank" title="Go to snippet source">source</a><code class="language-scala">whenUnhandled {
   // common code for both states
   case Event(Queue(obj), t @ Todo(_, v)) =&gt;
     goto(Active).using(t.copy(queue = v :+ obj))
@@ -757,7 +757,7 @@ final class Todo implements Data {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L80-L94" target="_blank" title="Go to snippet source">source</a><code class="language-java">whenUnhandled(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L80-L94" target="_blank" title="Go to snippet source">source</a><code class="language-java">whenUnhandled(
     matchEvent(
             Queue.class,
             Todo.class,
@@ -778,7 +778,7 @@ final class Todo implements Data {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L74-L80" target="_blank" title="Go to snippet source">source</a><code class="language-scala">onTransition {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L74-L80" target="_blank" title="Go to snippet source">source</a><code class="language-scala">onTransition {
   case Active -&gt; Idle =&gt;
     stateData match {
       case Todo(ref, queue) =&gt; ref ! Batch(queue)
@@ -787,7 +787,7 @@ final class Todo implements Data {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L49-L68" target="_blank" title="Go to snippet source">source</a><code class="language-java">onTransition(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L49-L68" target="_blank" title="Go to snippet source">source</a><code class="language-java">onTransition(
     matchState(
             Active,
             Idle,
@@ -814,7 +814,7 @@ final class Todo implements Data {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L22-L242" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L22-L242" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.Props
 import scala.collection.immutable
 
@@ -977,7 +977,7 @@ class FSMDocSpec extends MyFavoriteTestFrameWorkPlusPekkoTestKit {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/BuncherTest.java#L32-L88" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class BuncherTest extends AbstractJavaTest {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/BuncherTest.java#L32-L88" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class BuncherTest extends AbstractJavaTest {
 
   static ActorSystem system;
 
@@ -1041,7 +1041,7 @@ class FSMDocSpec extends MyFavoriteTestFrameWorkPlusPekkoTestKit {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L61-L104" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Buncher extends FSM[State, Data] {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L61-L104" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Buncher extends FSM[State, Data] {
 
   startWith(Idle, Uninitialized)
 
@@ -1077,7 +1077,7 @@ class FSMDocSpec extends MyFavoriteTestFrameWorkPlusPekkoTestKit {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L33-L166" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class Buncher extends AbstractFSM&lt;State, Data&gt; {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L33-L166" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class Buncher extends AbstractFSM&lt;State, Data&gt; {
   {
     startWith(Idle, Uninitialized);
 
@@ -1155,7 +1155,7 @@ class FSMDocSpec extends MyFavoriteTestFrameWorkPlusPekkoTestKit {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L67-L87" target="_blank" title="Go to snippet source">source</a><code class="language-scala">when(Idle) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L67-L87" target="_blank" title="Go to snippet source">source</a><code class="language-scala">when(Idle) {
   case Event(SetTarget(ref), Uninitialized) =&gt;
     stay().using(Todo(ref, Vector.empty))
 }
@@ -1166,7 +1166,7 @@ when(Active, stateTimeout = 1 second) {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L39-L45" target="_blank" title="Go to snippet source">source</a><code class="language-java">when(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/Buncher.java#L39-L45" target="_blank" title="Go to snippet source">source</a><code class="language-java">when(
     Idle,
     matchEvent(
         SetTarget.class,
@@ -1180,10 +1180,10 @@ when(Active, stateTimeout = 1 second) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L218" target="_blank" title="Go to snippet source">source</a><code class="language-scala">when(SomeState)(FSM.NullFunction)</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L218" target="_blank" title="Go to snippet source">source</a><code class="language-scala">when(SomeState)(FSM.NullFunction)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L86" target="_blank" title="Go to snippet source">source</a><code class="language-java">when(SomeState, AbstractFSM.NullFunction());</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L86" target="_blank" title="Go to snippet source">source</a><code class="language-java">when(SomeState, AbstractFSM.NullFunction());</code></pre></dd>
 </dl>
 <h3><a href="#defining-the-initial-state" name="defining-the-initial-state" class="anchor"><span class="anchor-link"></span></a>Defining the Initial State</h3>
 <p>Each FSM needs a starting point, which is declared using</p>
@@ -1195,7 +1195,7 @@ when(Active, stateTimeout = 1 second) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L180-L187" target="_blank" title="Go to snippet source">source</a><code class="language-scala">whenUnhandled {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L180-L187" target="_blank" title="Go to snippet source">source</a><code class="language-scala">whenUnhandled {
   case Event(x: X, data) =&gt;
     log.info(&quot;Received unhandled event: &quot; + x)
     stay()
@@ -1205,7 +1205,7 @@ when(Active, stateTimeout = 1 second) {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L134-L146" target="_blank" title="Go to snippet source">source</a><code class="language-java">  whenUnhandled(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L134-L146" target="_blank" title="Go to snippet source">source</a><code class="language-java">  whenUnhandled(
       matchEvent(
               X.class,
               (x, data) -&gt; {
@@ -1232,13 +1232,13 @@ when(Active, stateTimeout = 1 second) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L121-L124" target="_blank" title="Go to snippet source">source</a><code class="language-scala">when(SomeState) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L121-L124" target="_blank" title="Go to snippet source">source</a><code class="language-scala">when(SomeState) {
   case Event(msg, _) =&gt;
     goto(Processing).using(newData).forMax(5 seconds).replying(WillDo)
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L74-L82" target="_blank" title="Go to snippet source">source</a><code class="language-java">when(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L74-L82" target="_blank" title="Go to snippet source">source</a><code class="language-java">when(
     SomeState,
     matchAnyEvent(
         (msg, data) -&gt; {
@@ -1260,14 +1260,14 @@ when(Active, stateTimeout = 1 second) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L128-L132" target="_blank" title="Go to snippet source">source</a><code class="language-scala">onTransition {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L128-L132" target="_blank" title="Go to snippet source">source</a><code class="language-scala">onTransition {
   case Idle -&gt; Active =&gt; startTimerWithFixedDelay(&quot;timeout&quot;, Tick, 1 second)
   case Active -&gt; _    =&gt; cancelTimer(&quot;timeout&quot;)
   case x -&gt; Idle      =&gt; log.info(&quot;entering Idle from &quot; + x)
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L90-L96" target="_blank" title="Go to snippet source">source</a><code class="language-java">onTransition(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L90-L96" target="_blank" title="Go to snippet source">source</a><code class="language-java">onTransition(
     matchState(
             Idle,
             Active,
@@ -1280,14 +1280,14 @@ when(Active, stateTimeout = 1 second) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L136-L140" target="_blank" title="Go to snippet source">source</a><code class="language-scala">onTransition(handler _)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L136-L140" target="_blank" title="Go to snippet source">source</a><code class="language-scala">onTransition(handler _)
 
 def handler(from: StateType, to: StateType): Unit = {
   // handle it here ...
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L67-L100" target="_blank" title="Go to snippet source">source</a><code class="language-java">public void handler(StateType from, StateType to) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L67-L100" target="_blank" title="Go to snippet source">source</a><code class="language-java">public void handler(StateType from, StateType to) {
   // handle transition here
 }
 
@@ -1302,14 +1302,14 @@ def handler(from: StateType, to: StateType): Unit = {
 <p>Stopping a listener without unregistering will not remove the listener from the subscription list; use <code>UnsubscribeTransitionCallback</code> before stopping the listener.</p><div class="group-scala">
 <h3><a href="#transforming-state" name="transforming-state" class="anchor"><span class="anchor-link"></span></a>Transforming State</h3>
 <p>The partial functions supplied as argument to the <code>when()</code> blocks can be transformed using Scala’s full supplement of functional programming tools. In order to retain type inference, there is a helper function which may be used in case some common handling logic shall be applied to different clauses:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L152-L157" target="_blank" title="Go to snippet source">source</a><code class="language-scala">when(SomeState)(transform {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L152-L157" target="_blank" title="Go to snippet source">source</a><code class="language-scala">when(SomeState)(transform {
   case Event(bytes: ByteString, read) =&gt; stay().using(read + bytes.length)
 }.using {
   case s @ FSM.State(state, read, timeout, stopReason, replies) if read &gt; 1000 =&gt;
     goto(Processing)
 })</code></pre>
 <p>It goes without saying that the arguments to this method may also be stored, to be used several times, e.g. when applying the same transformation to several <code>when()</code> blocks:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L161-L168" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val processingTrigger: PartialFunction[State, State] = {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L161-L168" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val processingTrigger: PartialFunction[State, State] = {
   case s @ FSM.State(state, read, timeout, stopReason, replies) if read &gt; 1000 =&gt;
     goto(Processing)
 }
@@ -1341,14 +1341,14 @@ startTimerWithFixedDelay(name, msg, interval)
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L144-L148" target="_blank" title="Go to snippet source">source</a><code class="language-scala">when(Error) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L144-L148" target="_blank" title="Go to snippet source">source</a><code class="language-scala">when(Error) {
   case Event(&quot;stop&quot;, _) =&gt;
     // do cleanup ...
     stop()
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L104-L111" target="_blank" title="Go to snippet source">source</a><code class="language-java">when(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L104-L111" target="_blank" title="Go to snippet source">source</a><code class="language-java">when(
     Error,
     matchEventEquals(
         &quot;stop&quot;,
@@ -1361,14 +1361,14 @@ startTimerWithFixedDelay(name, msg, interval)
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L172-L176" target="_blank" title="Go to snippet source">source</a><code class="language-scala">onTermination {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L172-L176" target="_blank" title="Go to snippet source">source</a><code class="language-scala">onTermination {
   case StopEvent(FSM.Normal, state, data)         =&gt; // ...
   case StopEvent(FSM.Shutdown, state, data)       =&gt; // ...
   case StopEvent(FSM.Failure(cause), state, data) =&gt; // ...
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L115-L130" target="_blank" title="Go to snippet source">source</a><code class="language-java">onTermination(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L115-L130" target="_blank" title="Go to snippet source">source</a><code class="language-java">onTermination(
     matchStop(
             Normal(),
             (state, data) -&gt; {
@@ -1396,7 +1396,7 @@ startTimerWithFixedDelay(name, msg, interval)
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L193-L206" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.LoggingFSM
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L193-L206" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.LoggingFSM
 class MyFSM extends LoggingFSM[StateType, Data] {
   override def logDepth = 12
   onTermination {
@@ -1410,7 +1410,7 @@ class MyFSM extends LoggingFSM[StateType, Data] {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L152-L209" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyFSM extends AbstractLoggingFSM&lt;StateType, Data&gt; {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L152-L209" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyFSM extends AbstractLoggingFSM&lt;StateType, Data&gt; {
   @Override
   public int logDepth() {
     return 12;
@@ -1448,7 +1448,7 @@ class MyFSM extends LoggingFSM[StateType, Data] {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L193-L206" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.LoggingFSM
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/FSMDocSpec.scala#L193-L206" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.LoggingFSM
 class MyFSM extends LoggingFSM[StateType, Data] {
   override def logDepth = 12
   onTermination {
@@ -1462,7 +1462,7 @@ class MyFSM extends LoggingFSM[StateType, Data] {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L152-L209" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyFSM extends AbstractLoggingFSM&lt;StateType, Data&gt; {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java#L152-L209" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyFSM extends AbstractLoggingFSM&lt;StateType, Data&gt; {
   @Override
   public int logDepth() {
     return 12;
@@ -1492,7 +1492,7 @@ class MyFSM extends LoggingFSM[StateType, Data] {
 <p>The log buffer is allocated during actor creation, which is why the configuration is done using a virtual method call. If you want to override with a <code>val</code>, make sure that its initialization happens before the initializer of <code>LoggingFSM</code> runs, and do not change the value returned by <code>logDepth</code> after the buffer has been allocated.</p></div>
 <p>The contents of the event log are available using method <code>getLog</code>, which returns an <code>IndexedSeq[LogEntry]</code> where the oldest entry is at index zero.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/fsm.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/fsm.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -1579,7 +1579,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/futures.html b/content/futures.html
index 4bb6f9e..b1d025b 100644
--- a/content/futures.html
+++ b/content/futures.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -418,7 +418,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#futures-patterns" name="futures-patterns" class="anchor"><span class="anchor-link"></span></a>Futures patterns</h1>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>Pekko offers tiny helpers for use with <span class="group-scala"><a href="http://www.scala-lang.org/api/2.13.8/scala/concurrent/Future.html" title="scala.concurrent.Future"><code>Future</code></a>s</span><span class="group-java"><a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/util/concurrent/CompletionStage.html" title="java.util.concurrent.CompletionStage"><code>CompletionStage</code></a></span>. These are part of Pekko&rsquo;s core module:</p><dl class="de [...]
+<p>Pekko offers tiny helpers for use with <span class="group-scala"><a href="http://www.scala-lang.org/api/2.13.8/scala/concurrent/Future.html" title="scala.concurrent.Future"><code>Future</code></a>s</span><span class="group-java"><a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/util/concurrent/CompletionStage.html" title="java.util.concurrent.CompletionStage"><code>CompletionStage</code></a></span>. These are part of Pekko&rsquo;s core module:</p><dl class="de [...]
 libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -427,7 +427,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -442,7 +442,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -451,14 +451,14 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/future/FutureDocSpec.scala#L498-L502" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val delayed =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/future/FutureDocSpec.scala#L498-L502" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val delayed =
   pekko.pattern.after(200.millis)(Future.failed(new IllegalStateException(&quot;OHNOES&quot;)))
 
 val future = Future { Thread.sleep(1000); &quot;foo&quot; }
 val result = Future.firstCompletedOf(Seq(future, delayed))</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/future/FutureDocTest.java#L39" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>CompletionStage&lt;String&gt; failWithException =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/future/FutureDocTest.java#L39" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>CompletionStage&lt;String&gt; failWithException =
     CompletableFuture.supplyAsync(
         () -&gt; {
           throw new IllegalStateException(&quot;OHNOES1&quot;);
@@ -471,7 +471,7 @@ CompletionStage&lt;String&gt; delayed =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/future/FutureDocSpec.scala#L511-L526" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/future/FutureDocSpec.scala#L511-L526" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.typed.scaladsl.adapter._
 implicit val scheduler: pekko.actor.Scheduler = system.scheduler.toClassic
 implicit val ec: ExecutionContext = system.executionContext
@@ -489,13 +489,13 @@ def futureToAttempt() = {
 val retried: Future[Int] = pekko.pattern.retry(() =&gt; futureToAttempt(), attempts = 10, 100 milliseconds)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/future/FutureDocTest.java#L39" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>Callable&lt;CompletionStage&lt;String&gt;&gt; attempt = () -&gt; CompletableFuture.completedFuture(&quot;test&quot;);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/future/FutureDocTest.java#L39" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>Callable&lt;CompletionStage&lt;String&gt;&gt; attempt = () -&gt; CompletableFuture.completedFuture(&quot;test&quot;);
 
 CompletionStage&lt;String&gt; retriedFuture =
     Patterns.retry(attempt, 3, java.time.Duration.ofMillis(200), system);</code></pre></dd>
 </dl>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/futures.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/futures.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -580,7 +580,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/actor-systems.html b/content/general/actor-systems.html
index 6703cf9..ce8581d 100644
--- a/content/general/actor-systems.html
+++ b/content/general/actor-systems.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -442,10 +442,10 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h2><a href="#what-you-should-not-concern-yourself-with" name="what-you-should-not-concern-yourself-with" class="anchor"><span class="anchor-link"></span></a>What you should not concern yourself with</h2>
 <p>An actor system manages the resources it is configured to use in order to run the actors which it contains. There may be millions of actors within one such system, after all the mantra is to view them as abundant and they weigh in at an overhead of only roughly 300 bytes per instance. Naturally, the exact order in which messages are processed in large systems is not controllable by the application author, but this is also not intended. Take a step back and relax while Pekko does the h [...]
 <h2><a href="#terminating-actorsystem" name="terminating-actorsystem" class="anchor"><span class="anchor-link"></span></a>Terminating ActorSystem</h2>
-<p>When you know everything is done for your application, you can have the user guardian  actor stop, or call the <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/typed/ActorSystem.html#terminate():Unit" title="pekko.actor.typed.ActorSystem"><code>terminate</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/typed/ActorSystem.html#terminate()" title="pekko.actor.typed.ActorSystem"><code>term [...]
-<p>If you want to execute some operations while terminating <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem< [...]
+<p>When you know everything is done for your application, you can have the user guardian  actor stop, or call the <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/typed/ActorSystem.html#terminate():Unit" title="pekko.actor.typed.ActorSystem"><code>terminate</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/actor/typed/ActorSystem.html#terminate()" title="pekko.actor.typed.ActorSystem"><code>term [...]
+<p>If you want to execute some operations while terminating <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.Act [...]
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/actor-systems.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/actor-systems.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -532,7 +532,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/actors.html b/content/general/actors.html
index 678940a..4afe53e 100644
--- a/content/general/actors.html
+++ b/content/general/actors.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -451,7 +451,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h2><a href="#when-an-actor-terminates" name="when-an-actor-terminates" class="anchor"><span class="anchor-link"></span></a>When an Actor Terminates</h2>
 <p>Once an actor terminates, i.e. fails in a way which is not handled by a restart, stops itself or is stopped by its supervisor, it will free up its resources, draining all remaining messages from its mailbox into the system’s “dead letter mailbox” which will forward them to the EventStream as DeadLetters. The mailbox is then replaced within the actor reference with a system mailbox, redirecting all new messages to the EventStream as DeadLetters. This is done on a best effort basis, tho [...]
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/actors.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/actors.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -540,7 +540,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/addressing.html b/content/general/addressing.html
index ee1733e..8714780 100644
--- a/content/general/addressing.html
+++ b/content/general/addressing.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p><img src="../images/actor-paths-overview.png" alt="actor-paths-overview.png" /></p>
 <p>The above image displays the relationship between the most important entities within an actor system, please read on for the details.</p>
 <h2><a href="#what-is-an-actor-reference" name="what-is-an-actor-reference" class="anchor"><span class="anchor-link"></span></a>What is an Actor Reference</h2>
-<p>An actor reference is a subtype of <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRef"><code>ActorRef</code></a></span>, whose foremost purpos [...]
+<p>An actor reference is a subtype of <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRef"><code>ActorRef</code></a></ [...]
 <p>There are several different types of actor references that are supported depending on the configuration of the actor system:</p>
 <ul>
   <li>Purely local actor references are used by actor systems which are not configured to support networking functions. These actor references will not function if sent across a network connection to a remote JVM.</li>
@@ -437,7 +437,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <li>And then there are some one-off internal implementations which you should never really see:
     <ul>
       <li>There is an actor reference which does not represent an actor but acts only as a pseudo-supervisor for the root guardian, we call it “the one who walks the bubbles of space-time”.</li>
-      <li>The first logging service started before actually firing up actor creation facilities is a fake actor reference which accepts log events and prints them directly to standard output; it is <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/Logging$$StandardOutLogger.html" title="org.apache.pekko.event.Logging.StandardOutLogger"><code>Logging.StandardOutLogger</code></a></span><span class="group-java"><a href="http [...]
+      <li>The first logging service started before actually firing up actor creation facilities is a fake actor reference which accepts log events and prints them directly to standard output; it is <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/Logging$$StandardOutLogger.html" title="org.apache.pekko.event.Logging.StandardOutLogger"><code>Logging.StandardOutLogger</code></a></span><span class="group-java" [...]
     </ul>
   </li>
 </ul>
@@ -460,8 +460,8 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h2><a href="#how-are-actor-references-obtained-" name="how-are-actor-references-obtained-" class="anchor"><span class="anchor-link"></span></a>How are Actor References obtained?</h2>
 <p>There are two general categories to how actor references may be obtained: by <a href="../typed/actor-lifecycle.html#creating-actors">creating actors</a> or by looking them up through the <a href="../typed/actor-discovery.html#receptionist">Receptionist</a>.</p>
 <h2><a href="#actor-reference-and-path-equality" name="actor-reference-and-path-equality" class="anchor"><span class="anchor-link"></span></a>Actor Reference and Path Equality</h2>
-<p>Equality of <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRef"><code>ActorRef</code></a></span> match the intention that an <span class="grou [...]
-<p>If you need to keep track of actor references in a collection and do not care about the exact actor incarnation you can use the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorPath.html" title="org.apache.pekko.actor.ActorPath"><code>ActorPath</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorPath.html" title="org.apache.pekk [...]
+<p>Equality of <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRef"><code>ActorRef</code></a></span> match the intenti [...]
+<p>If you need to keep track of actor references in a collection and do not care about the exact actor incarnation you can use the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorPath.html" title="org.apache.pekko.actor.ActorPath"><code>ActorPath</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorPath. [...]
 <h2><a href="#reusing-actor-paths" name="reusing-actor-paths" class="anchor"><span class="anchor-link"></span></a>Reusing Actor Paths</h2>
 <p>When an actor is terminated, its reference will point to the dead letter mailbox, DeathWatch will publish its final transition and in general it is not expected to come back to life again (since the actor life cycle does not allow this).</p>
 <h2><a href="#what-is-the-address-part-used-for-" name="what-is-the-address-part-used-for-" class="anchor"><span class="anchor-link"></span></a>What is the Address part used for?</h2>
@@ -470,7 +470,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h2><a href="#top-level-scopes-for-actor-paths" name="top-level-scopes-for-actor-paths" class="anchor"><span class="anchor-link"></span></a>Top-Level Scopes for Actor Paths</h2>
 <p>At the root of the path hierarchy resides the root guardian above which all other actors are found; its name is <code>&quot;/&quot;</code>. The next level consists of the following:</p>
 <ul>
-  <li><code>&quot;/user&quot;</code> is the guardian actor for all user-created top-level actors; actors created using <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRefFactory.html#actorOf(props:org.apache.pekko.actor.Props):org.apache.pekko.actor.ActorRef" title="org.apache.pekko.actor.ActorRefFactory"><code>ActorSystem.actorOf</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0 [...]
+  <li><code>&quot;/user&quot;</code> is the guardian actor for all user-created top-level actors; actors created using <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRefFactory.html#actorOf(props:org.apache.pekko.actor.Props):org.apache.pekko.actor.ActorRef" title="org.apache.pekko.actor.ActorRefFactory"><code>ActorSystem.actorOf</code></a></span><span class="group-java"><a href="https://doc.akka.io/ [...]
   <li><code>&quot;/system&quot;</code> is the guardian actor for all system-created top-level actors, e.g. logging listeners or actors automatically deployed by configuration at the start of the actor system.</li>
   <li><code>&quot;/deadLetters&quot;</code> is the dead letter actor, which is where all messages sent to stopped or non-existing actors are re-routed (on a best-effort basis: messages may be lost even within the local JVM).</li>
   <li><code>&quot;/temp&quot;</code> is the guardian for all short-lived system-created actors, e.g. those which are used in the implementation of <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/pattern/AskableActorRef.html#ask(message:Any)(implicittimeout:org.apache.pekko.util.Timeout,implicitsender:org.apache.pekko.actor.ActorRef):scala.concurrent.Future[Any]" title="pekko.pattern.AskableActorRef"><code>ActorRef.ask</code></a></span><span class="gro [...]
@@ -478,7 +478,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul>
 <p>The need to structure the name space for actors like this arises from a central and very simple design goal: everything in the hierarchy is an actor, and all actors function in the same way. </p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/addressing.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/addressing.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -567,7 +567,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/configuration-reference.html b/content/general/configuration-reference.html
index f7dbc86..b822267 100644
--- a/content/general/configuration-reference.html
+++ b/content/general/configuration-reference.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -422,7 +422,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>The purpose of <code>reference.conf</code> files is for libraries, like Pekko, to define default values that are used if an application doesn&rsquo;t define a more specific value. It&rsquo;s also a good place to document the existence and meaning of the configuration properties. One library must not try to override properties in its own <code>reference.conf</code> for properties originally defined by another library&rsquo;s <code>reference.conf</code>, because the effective value woul [...]
 <a id="config-pekko-actor"></a>
 <h3><a href="#pekko-actor" name="pekko-actor" class="anchor"><span class="anchor-link"></span></a>pekko-actor</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/actor/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">####################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/actor/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">####################################
 # Pekko Actor Reference Config File #
 ####################################
 
@@ -1775,7 +1775,7 @@ pekko {
 }</code></pre>
 <a id="config-pekko-actor-typed"></a>
 <h3><a href="#pekko-actor-typed" name="pekko-actor-typed" class="anchor"><span class="anchor-link"></span></a>pekko-actor-typed</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/actor-typed/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">pekko.actor.typed {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/actor-typed/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">pekko.actor.typed {
 
   # List FQCN of `org.apache.pekko.actor.typed.ExtensionId`s which shall be loaded at actor system startup.
   # Should be on the format: &#39;extensions = [&quot;com.example.MyExtId1&quot;, &quot;com.example.MyExtId2&quot;]&#39; etc.
@@ -1906,7 +1906,7 @@ pekko.reliable-delivery {
 }</code></pre>
 <a id="config-pekko-cluster-typed"></a>
 <h3><a href="#pekko-cluster-typed" name="pekko-cluster-typed" class="anchor"><span class="anchor-link"></span></a>pekko-cluster-typed</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-typed/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">############################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-typed/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">############################################
 # Pekko Cluster Typed Reference Config File #
 ############################################
 
@@ -1974,7 +1974,7 @@ pekko {
 }</code></pre>
 <a id="config-pekko-cluster"></a>
 <h3><a href="#pekko-cluster" name="pekko-cluster" class="anchor"><span class="anchor-link"></span></a>pekko-cluster</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">######################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">######################################
 # Pekko Cluster Reference Config File #
 ######################################
 
@@ -2480,7 +2480,7 @@ pekko.cluster.split-brain-resolver.lease-majority {
 #//#lease-majority</code></pre>
 <a id="config-pekko-discovery"></a>
 <h3><a href="#pekko-discovery" name="pekko-discovery" class="anchor"><span class="anchor-link"></span></a>pekko-discovery</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/discovery/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">######################################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/discovery/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">######################################################
 # Pekko Discovery Config                              #
 ######################################################
 
@@ -2557,7 +2557,7 @@ pekko.discovery {
 </code></pre>
 <a id="config-pekko-coordination"></a>
 <h3><a href="#pekko-coordination" name="pekko-coordination" class="anchor"><span class="anchor-link"></span></a>pekko-coordination</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/coordination/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">pekko.coordination {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/coordination/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">pekko.coordination {
 
   # Defaults for any lease implementation that doesn&#39;t include these properties
   lease {
@@ -2581,7 +2581,7 @@ pekko.discovery {
 }</code></pre>
 <a id="config-pekko-multi-node-testkit"></a>
 <h3><a href="#pekko-multi-node-testkit" name="pekko-multi-node-testkit" class="anchor"><span class="anchor-link"></span></a>pekko-multi-node-testkit</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/multi-node-testkit/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">#############################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/multi-node-testkit/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">#############################################
 # Pekko Remote Testing Reference Config File #
 #############################################
 
@@ -2648,7 +2648,7 @@ pekko {
 }</code></pre>
 <a id="config-pekko-persistence-typed"></a>
 <h3><a href="#pekko-persistence-typed" name="pekko-persistence-typed" class="anchor"><span class="anchor-link"></span></a>pekko-persistence-typed</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">pekko.actor {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">pekko.actor {
 
   serialization-identifiers.&quot;org.apache.pekko.persistence.typed.serialization.ReplicatedEventSourcingSerializer&quot; = 40
 
@@ -2727,7 +2727,7 @@ pekko.reliable-delivery {
 }</code></pre>
 <a id="config-pekko-persistence"></a>
 <h3><a href="#pekko-persistence" name="pekko-persistence" class="anchor"><span class="anchor-link"></span></a>pekko-persistence</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">###########################################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">###########################################################
 # Pekko Persistence Extension Reference Configuration File #
 ###########################################################
 
@@ -3084,7 +3084,7 @@ pekko.persistence.snapshot-store.proxy {
 #        &lt;/dependency&gt;</code></pre>
 <a id="config-pekko-persistence-query"></a>
 <h3><a href="#pekko-persistence-query" name="pekko-persistence-query" class="anchor"><span class="anchor-link"></span></a>pekko-persistence-query</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-query/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">#######################################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-query/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">#######################################################
 # Pekko Persistence Query Reference Configuration File #
 #######################################################
 
@@ -3128,7 +3128,7 @@ pekko.actor {
 }</code></pre>
 <a id="config-pekko-persistence-testkit"></a>
 <h3><a href="#pekko-persistence-testkit" name="pekko-persistence-testkit" class="anchor"><span class="anchor-link"></span></a>pekko-persistence-testkit</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-testkit/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">##################################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-testkit/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">##################################################
 # Pekko Persistence Testkit Reference Config File #
 ##################################################
 
@@ -3168,7 +3168,7 @@ pekko.persistence.testkit.state {
 }</code></pre>
 <a id="config-pekko-remote-artery"></a>
 <h3><a href="#pekko-remote-artery" name="pekko-remote-artery" class="anchor"><span class="anchor-link"></span></a>pekko-remote artery</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/remote/src/main/resources/reference.conf#L2-L263" target="_blank" title="Go to snippet source">source</a><code class="language-none">#####################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/remote/src/main/resources/reference.conf#L2-L263" target="_blank" title="Go to snippet source">source</a><code class="language-none">#####################################
 # Pekko Remote Reference Config File #
 #####################################
 
@@ -3953,7 +3953,7 @@ pekko {
 }</code></pre>
 <a id="config-pekko-remote"></a>
 <h3><a href="#pekko-remote-classic-deprecated-" name="pekko-remote-classic-deprecated-" class="anchor"><span class="anchor-link"></span></a>pekko-remote classic (deprecated)</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/remote/src/main/resources/reference.conf#L2-L263" target="_blank" title="Go to snippet source">source</a><code class="language-none">#####################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/remote/src/main/resources/reference.conf#L2-L263" target="_blank" title="Go to snippet source">source</a><code class="language-none">#####################################
 # Pekko Remote Reference Config File #
 #####################################
 
@@ -4680,7 +4680,7 @@ pekko {
 }</code></pre>
 <a id="config-pekko-testkit"></a>
 <h3><a href="#pekko-testkit" name="pekko-testkit" class="anchor"><span class="anchor-link"></span></a>pekko-testkit</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/testkit/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">######################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/testkit/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">######################################
 # Pekko Testkit Reference Config File #
 ######################################
 
@@ -4730,7 +4730,7 @@ pekko {
 }</code></pre>
 <a id="config-cluster-metrics"></a>
 <h3><a href="#pekko-cluster-metrics" name="pekko-cluster-metrics" class="anchor"><span class="anchor-link"></span></a>pekko-cluster-metrics</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-metrics/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">##############################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-metrics/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">##############################################
 # Pekko Cluster Metrics Reference Config File #
 ##############################################
 
@@ -4843,7 +4843,7 @@ pekko.actor {
 }</code></pre>
 <a id="config-cluster-tools"></a>
 <h3><a href="#pekko-cluster-tools" name="pekko-cluster-tools" class="anchor"><span class="anchor-link"></span></a>pekko-cluster-tools</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-tools/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">############################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-tools/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">############################################
 # Pekko Cluster Tools Reference Config File #
 ############################################
 
@@ -5076,7 +5076,7 @@ pekko.actor {
 }</code></pre>
 <a id="config-cluster-sharding-typed"></a>
 <h3><a href="#pekko-cluster-sharding-typed" name="pekko-cluster-sharding-typed" class="anchor"><span class="anchor-link"></span></a>pekko-cluster-sharding-typed</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding-typed/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf"><br/># //#sharding-ext-config
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding-typed/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf"><br/># //#sharding-ext-config
 # //#number-of-shards
 pekko.cluster.sharding {
   # Number of shards used by the default HashCodeMessageExtractor
@@ -5156,7 +5156,7 @@ pekko.reliable-delivery {
 }</code></pre>
 <a id="config-cluster-sharding"></a>
 <h3><a href="#pekko-cluster-sharding" name="pekko-cluster-sharding" class="anchor"><span class="anchor-link"></span></a>pekko-cluster-sharding</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/cluster-sharding/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">###############################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/cluster-sharding/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">###############################################
 # Pekko Cluster Sharding Reference Config File #
 ###############################################
 
@@ -5631,7 +5631,7 @@ pekko.actor {
 }</code></pre>
 <a id="config-distributed-data"></a>
 <h3><a href="#pekko-distributed-data" name="pekko-distributed-data" class="anchor"><span class="anchor-link"></span></a>pekko-distributed-data</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/distributed-data/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">##############################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/distributed-data/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">##############################################
 # Pekko Distributed DataReference Config File #
 ##############################################
 
@@ -5792,7 +5792,7 @@ pekko.actor {
 }</code></pre>
 <a id="config-pekko-stream"></a>
 <h3><a href="#pekko-stream" name="pekko-stream" class="anchor"><span class="anchor-link"></span></a>pekko-stream</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/stream/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">#####################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/stream/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">#####################################
 # Pekko Stream Reference Config File #
 #####################################
 
@@ -5994,11 +5994,11 @@ ssl-config {
 }</code></pre>
 <a id="config-pekko-stream-testkit"></a>
 <h3><a href="#pekko-stream-testkit" name="pekko-stream-testkit" class="anchor"><span class="anchor-link"></span></a>pekko-stream-testkit</h3>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/stream-testkit/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">pekko.stream.testkit {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/stream-testkit/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">pekko.stream.testkit {
   all-stages-stopped-timeout = 5 s
 }</code></pre>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/configuration-reference.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/configuration-reference.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -6101,7 +6101,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/configuration.html b/content/general/configuration.html
index 9454256..e540394 100644
--- a/content/general/configuration.html
+++ b/content/general/configuration.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -426,7 +426,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul>
 <p>Pekko uses the <a href="https://github.com/lightbend/config">Typesafe Config Library</a>, which might also be a good choice for the configuration of your own application or library built with or without Pekko. This library is implemented in Java with no external dependencies; This is only a summary of the most important parts for more details see <a href="https://github.com/lightbend/config/blob/master/README.md">the config library docs</a>.</p>
 <h2><a href="#where-configuration-is-read-from" name="where-configuration-is-read-from" class="anchor"><span class="anchor-link"></span></a>Where configuration is read from</h2>
-<p>All configuration for Pekko is held within instances of <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem</ [...]
+<p>All configuration for Pekko is held within instances of <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.Acto [...]
 <pre class="prettyprint"><code class="language-scala">appConfig.withFallback(ConfigFactory.defaultReference(classLoader))
 </code></pre>
 <p>The philosophy is that code never contains default values, but instead relies upon their presence in the <code>reference.conf</code> supplied with the library in question.</p>
@@ -517,19 +517,19 @@ res1: java.lang.String =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/config/ConfigDocSpec.scala#L42-L43" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val system = ActorSystem(rootBehavior, &quot;MySystem&quot;)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/config/ConfigDocSpec.scala#L42-L43" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val system = ActorSystem(rootBehavior, &quot;MySystem&quot;)
 system.logConfiguration()</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/config/ConfigDocTest.java#L44-L45" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorSystem&lt;Void&gt; system = ActorSystem.create(rootBehavior, &quot;MySystem&quot;);
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/config/ConfigDocTest.java#L44-L45" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorSystem&lt;Void&gt; system = ActorSystem.create(rootBehavior, &quot;MySystem&quot;);
 system.logConfiguration();</code></pre></dd>
 </dl>
 <h2><a href="#a-word-about-classloaders" name="a-word-about-classloaders" class="anchor"><span class="anchor-link"></span></a>A Word About ClassLoaders</h2>
-<p>In several places of the configuration file it is possible to specify the fully-qualified class name of something to be instantiated by Pekko. This is done using Java reflection, which in turn uses a <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/ClassLoader.html" title="java.lang.ClassLoader"><code>ClassLoader</code></a>. Getting the right one in challenging environments like application containers or OSGi bundles is not always trivial, the current ap [...]
+<p>In several places of the configuration file it is possible to specify the fully-qualified class name of something to be instantiated by Pekko. This is done using Java reflection, which in turn uses a <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/ClassLoader.html" title="java.lang.ClassLoader"><code>ClassLoader</code></a>. Getting the right one in challenging environments like application containers or OSGi bundles is not always trivial, the current ap [...]
 <h2><a href="#application-specific-settings" name="application-specific-settings" class="anchor"><span class="anchor-link"></span></a>Application specific settings</h2>
 <p>The configuration can also be used for application specific settings. A good practice is to place those settings in an <a href="../extending-pekko.html#extending-pekko-settings">Extension</a>.</p>
 <h2><a href="#configuring-multiple-actorsystem" name="configuring-multiple-actorsystem" class="anchor"><span class="anchor-link"></span></a>Configuring multiple ActorSystem</h2>
-<p>If you have more than one <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem</code></a></span> (or you&rsquo [...]
+<p>If you have more than one <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem</co [...]
 <p>Given that <a href="https://lightbend.github.io/config/latest/api/com/typesafe/config/ConfigFactory.html#load--">ConfigFactory.load()</a> merges all resources with matching name from the whole class path, it is easiest to utilize that functionality and differentiate actor systems within the hierarchy of the configuration:</p>
 <pre><code>myapp1 {
   pekko.loglevel = &quot;WARNING&quot;
@@ -545,13 +545,13 @@ my.other.setting = &quot;hello&quot;
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/config/ConfigDocSpec.scala#L49-L52" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val config = ConfigFactory.load()
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/config/ConfigDocSpec.scala#L49-L52" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val config = ConfigFactory.load()
 val app1 = ActorSystem(rootBehavior, &quot;MyApp1&quot;, config.getConfig(&quot;myapp1&quot;).withFallback(config))
 val app2 =
   ActorSystem(rootBehavior, &quot;MyApp2&quot;, config.getConfig(&quot;myapp2&quot;).withOnlyPath(&quot;pekko&quot;).withFallback(config))</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/config/ConfigDocTest.java#L51-L58" target="_blank" title="Go to snippet source">source</a><code class="language-java">Config config = ConfigFactory.load();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/config/ConfigDocTest.java#L51-L58" target="_blank" title="Go to snippet source">source</a><code class="language-java">Config config = ConfigFactory.load();
 ActorSystem&lt;Void&gt; app1 =
     ActorSystem.create(rootBehavior, &quot;MyApp1&quot;, config.getConfig(&quot;myapp1&quot;).withFallback(config));
 ActorSystem&lt;Void&gt; app2 =
@@ -573,11 +573,11 @@ my.other.setting = &quot;hello&quot;
 // plus myapp1 and myapp2 subtrees
 </code></pre><div class="callout note "><div class="callout-title">Note</div>
 <p>The configuration library is really powerful, explaining all features exceeds the scope affordable here. In particular not covered are how to include other configuration files within other files (see a small example at <a href="#including-files">Including files</a>) and copying parts of the configuration tree by way of path substitutions.</p></div>
-<p>You may also specify and parse the configuration programmatically in other ways when instantiating the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pek [...]
+<p>You may also specify and parse the configuration programmatically in other ways when instantiating the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem.html" title="org.apache.pekko.actor.typed.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorSystem [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/config/ConfigDocSpec.scala#L22-L23" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.typed.ActorSystem
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/config/ConfigDocSpec.scala#L22-L23" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.typed.ActorSystem
 import com.typesafe.config.ConfigFactory
 val customConf = ConfigFactory.parseString(&quot;&quot;&quot;
   pekko.log-config-on-start = on
@@ -587,7 +587,7 @@ val customConf = ConfigFactory.parseString(&quot;&quot;&quot;
 val system = ActorSystem(rootBehavior, &quot;MySystem&quot;, ConfigFactory.load(customConf))</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/config/ConfigDocTest.java#L17-L22" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.typed.ActorSystem;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/config/ConfigDocTest.java#L17-L22" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.typed.ActorSystem;
 import org.apache.pekko.actor.typed.Behavior;
 import org.apache.pekko.actor.typed.javadsl.Behaviors;
 import com.typesafe.config.Config;
@@ -612,7 +612,7 @@ ActorSystem&lt;Void&gt; system =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/config/ConfigDocSpec.scala#L58-L69" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// make a Config with just your special setting
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/config/ConfigDocSpec.scala#L58-L69" target="_blank" title="Go to snippet source">source</a><code class="language-scala">// make a Config with just your special setting
 val myConfig = ConfigFactory.parseString(&quot;something=somethingElse&quot;);
 // load the normal config stack (system props,
 // then application.conf, then reference.conf)
@@ -626,7 +626,7 @@ val complete = ConfigFactory.load(combined);
 val system = ActorSystem(rootBehavior, &quot;myname&quot;, complete);</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/config/ConfigDocTest.java#L64-L75" target="_blank" title="Go to snippet source">source</a><code class="language-java">// make a Config with just your special setting
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/config/ConfigDocTest.java#L64-L75" target="_blank" title="Go to snippet source">source</a><code class="language-java">// make a Config with just your special setting
 Config myConfig = ConfigFactory.parseString(&quot;something=somethingElse&quot;);
 // load the normal config stack (system props,
 // then application.conf, then reference.conf)
@@ -656,7 +656,7 @@ ActorSystem system = ActorSystem.create(rootBehavior, &quot;myname&quot;, comple
 <h2><a href="#listing-of-the-reference-configuration" name="listing-of-the-reference-configuration" class="anchor"><span class="anchor-link"></span></a>Listing of the Reference Configuration</h2>
 <p>Each Pekko module has a reference configuration file with the default values. Those <code>reference.conf</code> files are listed in <a href="configuration-reference.html">Default configuration</a></p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/configuration.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/configuration.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -748,7 +748,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/index.html b/content/general/index.html
index 2e3de07..7868ba7 100644
--- a/content/general/index.html
+++ b/content/general/index.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -525,7 +525,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul>
 </div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/index.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/index.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -595,7 +595,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/jmm.html b/content/general/jmm.html
index 08ae643..6c076ca 100644
--- a/content/general/jmm.html
+++ b/content/general/jmm.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -454,7 +454,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/typed/SharedMutableStateDocSpec.scala#L41-L101" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class MyActor(context: ActorContext[MyActor.Command]) extends AbstractBehavior[MyActor.Command](context) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/typed/SharedMutableStateDocSpec.scala#L41-L101" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class MyActor(context: ActorContext[MyActor.Command]) extends AbstractBehavior[MyActor.Command](context) {
   import MyActor._
 
   var state = &quot;&quot;
@@ -517,7 +517,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/typed/SharedMutableStateDocTest.java#L44-L148" target="_blank" title="Go to snippet source">source</a><code class="language-java">class MyActor extends AbstractBehavior&lt;MyActor.Command&gt; {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/typed/SharedMutableStateDocTest.java#L44-L148" target="_blank" title="Go to snippet source">source</a><code class="language-java">class MyActor extends AbstractBehavior&lt;MyActor.Command&gt; {
 
   interface Command {}
 
@@ -627,7 +627,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <li>Messages <strong>should</strong> be immutable, this is to avoid the shared mutable state trap.</li>
 </ul>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/jmm.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/jmm.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -713,7 +713,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/message-delivery-reliability.html b/content/general/message-delivery-reliability.html
index cd61f50..4937daf 100644
--- a/content/general/message-delivery-reliability.html
+++ b/content/general/message-delivery-reliability.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -488,7 +488,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h3><a href="#be-careful-what-you-do-with-this-section-" name="be-careful-what-you-do-with-this-section-" class="anchor"><span class="anchor-link"></span></a>Be careful what you do with this section!</h3>
 <p>Relying on the stronger reliability in this section is not recommended since it will bind your application to local-only deployment: an application may have to be designed differently (as opposed to just employing some message exchange patterns local to some actors) in order to be fit for running on a cluster of machines. Our credo is “design once, deploy any way you wish”, and to achieve this you should only rely on <a href="message-delivery-reliability.html#the-general-rules">The Ge [...]
 <h3><a href="#reliability-of-local-message-sends" name="reliability-of-local-message-sends" class="anchor"><span class="anchor-link"></span></a>Reliability of Local Message Sends</h3>
-<p>The Pekko test suite relies on not losing messages in the local context (and for non-error condition tests also for remote deployment), meaning that we actually do apply the best effort to keep our tests stable. A local <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRef.html#tell(msg:Any,sender:org.apache.pekko.actor.ActorRef):Unit" title="org.apache.pekko.actor.ActorRef"><code>tell</code></a></span><span class [...]
+<p>The Pekko test suite relies on not losing messages in the local context (and for non-error condition tests also for remote deployment), meaning that we actually do apply the best effort to keep our tests stable. A local <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRef.html#tell(msg:Any,sender:org.apache.pekko.actor.ActorRef):Unit" title="org.apache.pekko.actor.ActorRef"><code>tell</code></a></sp [...]
 <ul>
   <li><a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/StackOverflowError.html" title="java.lang.StackOverflowError"><code>StackOverflowError</code></a></li>
   <li><a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/OutOfMemoryError.html" title="java.lang.OutOfMemoryError"><code>OutOfMemoryError</code></a></li>
@@ -496,7 +496,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul>
 <p>In addition, local sends can fail in Pekko-specific ways:</p>
 <ul>
-  <li>if the mailbox does not accept the message (e.g. full <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/dispatch/BoundedMailbox.html" title="org.apache.pekko.dispatch.BoundedMailbox"><code>BoundedMailbox</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/dispatch/BoundedMailbox.html" title="org.apache.pekko.dispatch.BoundedMailbox"><code>BoundedMa [...]
+  <li>if the mailbox does not accept the message (e.g. full <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/dispatch/BoundedMailbox.html" title="org.apache.pekko.dispatch.BoundedMailbox"><code>BoundedMailbox</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/dispatch/BoundedMailbox.html" title="org.apache.pekko.dispatch.Bou [...]
   <li>if the receiving actor fails while processing the message or is already terminated</li>
 </ul>
 <p>While the first is a matter of configuration the second deserves some thought: the sender of a message does not get feedback if there was an exception while processing, that notification goes to the supervisor instead. This is in general not distinguishable from a lost message for an outside observer.</p>
@@ -542,11 +542,11 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>The main use of this facility is for debugging, especially if an actor send does not arrive consistently (where usually inspecting the dead letters will tell you that the sender or recipient was set wrong somewhere along the way). In order to be useful for this purpose it is good practice to avoid sending to deadLetters where possible, i.e. run your application with a suitable dead letter logger (see more below) from time to time and clean up the log output. This exercise—like all els [...]
 <p>The dead letter service follows the same rules with respect to delivery guarantees as all other message sends, hence it cannot be used to implement guaranteed delivery.</p>
 <h3><a href="#how-do-i-receive-dead-letters-" name="how-do-i-receive-dead-letters-" class="anchor"><span class="anchor-link"></span></a>How do I Receive Dead Letters?</h3>
-<p>An actor can subscribe to class <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/DeadLetter.html" title="org.apache.pekko.actor.DeadLetter"><code>actor.DeadLetter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/DeadLetter.html" title="org.apache.pekko.actor.DeadLetter"><code>actor.DeadLetter</code></a></span> on the event stream, see  [...]
+<p>An actor can subscribe to class <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/DeadLetter.html" title="org.apache.pekko.actor.DeadLetter"><code>actor.DeadLetter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/DeadLetter.html" title="org.apache.pekko.actor.DeadLetter"><code>actor.DeadLetter</code></a></spa [...]
 <h3><a href="#dead-letters-which-are-usually-not-worrisome" name="dead-letters-which-are-usually-not-worrisome" class="anchor"><span class="anchor-link"></span></a>Dead Letters Which are (Usually) not Worrisome</h3>
-<p>Every time an actor does not terminate by its own decision, there is a chance that some messages which it sends to itself are lost. There is one which happens quite easily in complex shutdown scenarios that is usually benign: seeing instances of a graceful stop command for an actor being dropped means that two stop requests were given, but only one can succeed. In the same vein, you might see <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT [...]
+<p>Every time an actor does not terminate by its own decision, there is a chance that some messages which it sends to itself are lost. There is one which happens quite easily in complex shutdown scenarios that is usually benign: seeing instances of a graceful stop command for an actor being dropped means that two stop requests were given, but only one can succeed. In the same vein, you might see <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119 [...]
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/message-delivery-reliability.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/message-delivery-reliability.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -632,7 +632,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/remoting.html b/content/general/remoting.html
index e87a1c0..f66f412 100644
--- a/content/general/remoting.html
+++ b/content/general/remoting.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -435,7 +435,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h2><a href="#marking-points-for-scaling-up-with-routers" name="marking-points-for-scaling-up-with-routers" class="anchor"><span class="anchor-link"></span></a>Marking Points for Scaling Up with Routers</h2>
 <p>In addition to being able to run different parts of an actor system on different nodes of a cluster, it is also possible to scale up onto more cores by multiplying actor sub-trees which support parallelization (think for example a search engine processing different queries in parallel). The clones can then be routed to in different fashions, e.g. round-robin. See <a href="../typed/routers.html">Routing</a> for more details.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/remoting.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/remoting.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -521,7 +521,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/stream/stream-configuration.html b/content/general/stream/stream-configuration.html
index ce7db8a..b9ca7f7 100644
--- a/content/general/stream/stream-configuration.html
+++ b/content/general/stream/stream-configuration.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -417,7 +417,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="page-content row">
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#configuration" name="configuration" class="anchor"><span class="anchor-link"></span></a>Configuration</h1>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/stream/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">#####################################
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/stream/src/main/resources/reference.conf" target="_blank" title="Go to snippet source">source</a><code class="language-conf">#####################################
 # Pekko Stream Reference Config File #
 #####################################
 
@@ -618,7 +618,7 @@ ssl-config {
   logger = &quot;com.typesafe.sslconfig.pekko.util.PekkoLoggerBridge&quot;
 }</code></pre>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/stream/stream-configuration.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/stream/stream-configuration.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -688,7 +688,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/stream/stream-design.html b/content/general/stream/stream-design.html
index 6ae5deb..9f677eb 100644
--- a/content/general/stream/stream-design.html
+++ b/content/general/stream/stream-design.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -441,16 +441,16 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>Compositionality entails reusability of partial stream topologies, which led us to the lifted approach of describing data flows as (partial) graphs that can act as composite sources, flows (a.k.a. pipes) and sinks of data. These building blocks shall then be freely shareable, with the ability to combine them freely to form larger graphs. The representation of these pieces must therefore be an immutable blueprint that is materialized in an explicit step in order to start the stream pro [...]
 <p>The process of materialization will often create specific objects that are useful to interact with the processing engine once it is running, for example for shutting it down or for extracting metrics. This means that the materialization function produces a result termed the <em>materialized value of a graph</em>.</p>
 <h2><a href="#interoperation-with-other-reactive-streams-implementations" name="interoperation-with-other-reactive-streams-implementations" class="anchor"><span class="anchor-link"></span></a>Interoperation with other Reactive Streams implementations</h2>
-<p>Pekko Streams fully implement the Reactive Streams specification and interoperate with all other conformant implementations. We chose to completely separate the Reactive Streams interfaces from the user-level API because we regard them to be an SPI that is not targeted at endusers. In order to obtain a <a href="https://javadoc.io/doc/org.reactivestreams/reactive-streams/latest/org/reactivestreams/Publisher.html">Publisher</a> or <a href="https://javadoc.io/doc/org.reactivestreams/reac [...]
-<p>All stream Processors produced by the default materialization of Pekko Streams are restricted to having a single Subscriber, additional Subscribers will be rejected. The reason for this is that the stream topologies described using our DSL never require fan-out behavior from the Publisher sides of the elements, all fan-out is done using explicit elements like <span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/javadsl/Br [...]
+<p>Pekko Streams fully implement the Reactive Streams specification and interoperate with all other conformant implementations. We chose to completely separate the Reactive Streams interfaces from the user-level API because we regard them to be an SPI that is not targeted at endusers. In order to obtain a <a href="https://javadoc.io/doc/org.reactivestreams/reactive-streams/latest/org/reactivestreams/Publisher.html">Publisher</a> or <a href="https://javadoc.io/doc/org.reactivestreams/reac [...]
+<p>All stream Processors produced by the default materialization of Pekko Streams are restricted to having a single Subscriber, additional Subscribers will be rejected. The reason for this is that the stream topologies described using our DSL never require fan-out behavior from the Publisher sides of the elements, all fan-out is done using explicit elements like <span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/str [...]
 <p>This means that <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/stream/scaladsl/Sink$.html#asPublisher[T](fanout:Boolean):org.apache.pekko.stream.scaladsl.Sink[T,org.reactivestreams.Publisher[T]]" title="pekko.stream.scaladsl.Sink"><code>Sink.asPublisher(true)</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/stream/javadsl/Sink.html#asPublisher(org.apache.pekko.stream.javadsl.AsPublisher)" title= [...]
 <h3><a href="#rationale-and-benefits-from-sink-source-flow-not-directly-extending-reactive-streams-interfaces" name="rationale-and-benefits-from-sink-source-flow-not-directly-extending-reactive-streams-interfaces" class="anchor"><span class="anchor-link"></span></a>Rationale and benefits from Sink/Source/Flow not directly extending Reactive Streams interfaces</h3>
 <p>A sometimes overlooked crucial piece of information about <a href="https://github.com/reactive-streams/reactive-streams-jvm/">Reactive Streams</a> is that they are a <a href="https://en.m.wikipedia.org/wiki/Service_provider_interface">Service Provider Interface</a>, as explained in depth in one of the <a href="https://github.com/reactive-streams/reactive-streams-jvm/pull/25">early discussions</a> about the specification. Pekko Streams was designed during the development of Reactive St [...]
 <p>It may be enlightening to learn that even within the Reactive Specification the types had initially attempted to hide <code>Publisher</code>, <code>Subscriber</code> and the other SPI types from users of the API. Though since those internal SPI types would end up surfacing to end users of the standard in some cases, it was decided to <a href="https://github.com/reactive-streams/reactive-streams-jvm/pull/25">remove the API types, and only keep the SPI types</a> which are the <code>Publ [...]
 <p>With this historical knowledge and context about the purpose of the standard – being an internal detail of interoperable libraries - we can with certainty say that it can&rsquo;t be really said that a direct <em>inheritance</em> relationship with these types can be considered some form of advantage or meaningful differentiator between libraries. Rather, it could be seen that APIs which expose those SPI types to end-users are leaking internal implementation details accidentally. </p>
-<p>The <span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/javadsl/Source.html" title="org.apache.pekko.stream.javadsl.Source"><code>Source</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/scaladsl/Source.html" title="org.apache.pekko.stream.scaladsl.Source"><code>Source</code></a></span>, <span class="group-java"><a href="https://doc.akka [...]
+<p>The <span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/javadsl/Source.html" title="org.apache.pekko.stream.javadsl.Source"><code>Source</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/scaladsl/Source.html" title="org.apache.pekko.stream.scaladsl.Source"><code>Source</code></a></span>, <span class="group-jav [...]
 <p>Another not obvious gain from hiding the Reactive Streams interfaces comes from the fact that <code>org.reactivestreams.Subscriber</code> (et al) have now been included in Java 9+, and thus become part of Java itself, so libraries should migrate to using the <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/util/concurrent/Flow.Subscriber.html" title="java.util.concurrent.Flow.Subscriber"><code>java.util.concurrent.Flow.Subscriber</code></a> instead of <code>o [...]
-<p>The other, and perhaps more important reason for hiding the Reactive Streams interfaces comes back to the first points of this explanation: the fact of Reactive Streams being an SPI, and as such is hard to &ldquo;get right&rdquo; in ad-hoc implementations. Thus Pekko Streams discourages the use of the hard to implement pieces of the underlying infrastructure, and offers simpler, more type-safe, yet more powerful abstractions for users to work with: <span class="group-scala"><a href="h [...]
+<p>The other, and perhaps more important reason for hiding the Reactive Streams interfaces comes back to the first points of this explanation: the fact of Reactive Streams being an SPI, and as such is hard to &ldquo;get right&rdquo; in ad-hoc implementations. Thus Pekko Streams discourages the use of the hard to implement pieces of the underlying infrastructure, and offers simpler, more type-safe, yet more powerful abstractions for users to work with: <span class="group-scala"><a href="h [...]
 <h2><a href="#what-shall-users-of-streaming-libraries-expect-" name="what-shall-users-of-streaming-libraries-expect-" class="anchor"><span class="anchor-link"></span></a>What shall users of streaming libraries expect?</h2>
 <p>We expect libraries to be built on top of Pekko Streams, in fact Pekko HTTP is one such example that lives within the Pekko project itself. In order to allow users to profit from the principles that are described for Pekko Streams above, the following rules are established:</p>
 <ul>
@@ -464,11 +464,11 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h3><a href="#resulting-implementation-constraints" name="resulting-implementation-constraints" class="anchor"><span class="anchor-link"></span></a>Resulting Implementation Constraints</h3>
 <p>Pekko Streams must enable a library to express any stream processing utility in terms of immutable blueprints. The most common building blocks are</p>
 <ul>
-  <li><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/javadsl/Source.html" title="org.apache.pekko.stream.javadsl.Source"><code>Source</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/scaladsl/Source.html" title="org.apache.pekko.stream.scaladsl.Source"><code>Source</code></a></span>: something with exactly one output stream</li>
-  <li><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/javadsl/Sink.html" title="org.apache.pekko.stream.javadsl.Sink"><code>Sink</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/scaladsl/Sink.html" title="org.apache.pekko.stream.scaladsl.Sink"><code>Sink</code></a></span>: something with exactly one input stream</li>
-  <li><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/javadsl/Flow.html" title="org.apache.pekko.stream.javadsl.Flow"><code>Flow</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/scaladsl/Flow.html" title="org.apache.pekko.stream.scaladsl.Flow"><code>Flow</code></a></span>: something with exactly one input and one output stream</li>
-  <li><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/javadsl/BidiFlow.html" title="org.apache.pekko.stream.javadsl.BidiFlow"><code>BidiFlow</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/scaladsl/BidiFlow.html" title="org.apache.pekko.stream.scaladsl.BidiFlow"><code>BidiFlow</code></a></span>: something with exactly two input stream [...]
-  <li><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/Graph.html" title="org.apache.pekko.stream.Graph"><code>Graph</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/stream/Graph.html" title="org.apache.pekko.stream.Graph"><code>Graph</code></a></span>: a packaged stream processing topology that exposes a certain set of input and output ports, [...]
+  <li><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/javadsl/Source.html" title="org.apache.pekko.stream.javadsl.Source"><code>Source</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/scaladsl/Source.html" title="org.apache.pekko.stream.scaladsl.Source"><code>Source</code></a></span>: something with exactly  [...]
+  <li><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/javadsl/Sink.html" title="org.apache.pekko.stream.javadsl.Sink"><code>Sink</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/scaladsl/Sink.html" title="org.apache.pekko.stream.scaladsl.Sink"><code>Sink</code></a></span>: something with exactly one input st [...]
+  <li><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/javadsl/Flow.html" title="org.apache.pekko.stream.javadsl.Flow"><code>Flow</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/scaladsl/Flow.html" title="org.apache.pekko.stream.scaladsl.Flow"><code>Flow</code></a></span>: something with exactly one input an [...]
+  <li><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/javadsl/BidiFlow.html" title="org.apache.pekko.stream.javadsl.BidiFlow"><code>BidiFlow</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/scaladsl/BidiFlow.html" title="org.apache.pekko.stream.scaladsl.BidiFlow"><code>BidiFlow</code></a></span>: something w [...]
+  <li><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/Graph.html" title="org.apache.pekko.stream.Graph"><code>Graph</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/stream/Graph.html" title="org.apache.pekko.stream.Graph"><code>Graph</code></a></span>: a packaged stream processing topology that exposes a certain se [...]
 </ul><div class="callout note "><div class="callout-title">Note</div>
 <p>A source that emits a stream of streams is still a normal Source, the kind of elements that are produced does not play a role in the static stream topology that is being expressed.</p></div>
 <h2><a href="#the-difference-between-error-and-failure" name="the-difference-between-error-and-failure" class="anchor"><span class="anchor-link"></span></a>The difference between Error and Failure</h2>
@@ -480,7 +480,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>A recovery element (i.e. any transformation that absorbs an <code>onError</code> signal and turns that into possibly more data elements followed normal stream completion) acts as a bulkhead that confines a stream collapse to a given region of the stream topology. Within the collapsed region buffered elements may be lost, but the outside is not affected by the failure.</p>
 <p>This works in the same fashion as a <code>try</code>–<code>catch</code> expression: it marks a region in which exceptions are caught, but the exact amount of code that was skipped within this region in case of a failure might not be known precisely—the placement of statements matters.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/stream/stream-design.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/stream/stream-design.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -566,7 +566,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/supervision.html b/content/general/supervision.html
index 0f96f42..0db8767 100644
--- a/content/general/supervision.html
+++ b/content/general/supervision.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -448,11 +448,11 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <li>(Transient) failure of some external resource used during processing the message</li>
   <li>Corrupt internal state of the actor</li>
 </ul>
-<p>Unless the failure is specifically recognizable, the third cause cannot be ruled out, which leads to the conclusion that the internal state needs to be cleared out. If the supervisor decides that its other children or itself is not affected by the corruption—e.g. because of conscious application of the error kernel pattern—it is therefore best to restart the actor. This is carried out by creating a new instance of the underlying <span class="group-scala"><a href="https://doc.akka.io/a [...]
+<p>Unless the failure is specifically recognizable, the third cause cannot be ruled out, which leads to the conclusion that the internal state needs to be cleared out. If the supervisor decides that its other children or itself is not affected by the corruption—e.g. because of conscious application of the error kernel pattern—it is therefore best to restart the actor. This is carried out by creating a new instance of the underlying <span class="group-scala"><a href="https://doc.akka.io/a [...]
 <h2><a href="#what-lifecycle-monitoring-means" name="what-lifecycle-monitoring-means" class="anchor"><span class="anchor-link"></span></a>What Lifecycle Monitoring Means</h2><div class="callout note "><div class="callout-title">Note</div>
 <p>Lifecycle Monitoring in Pekko is usually referred to as <code>DeathWatch</code></p></div>
 <p>In contrast to the special relationship between parent and child described above, each actor may monitor any other actor. Since actors emerge from creation fully alive and restarts are not visible outside of the affected supervisors, the only state change available for monitoring is the transition from alive to dead. Monitoring is thus used to tie one actor to another so that it may react to the other actor’s termination, in contrast to supervision which reacts to failure.</p>
-<p>Lifecycle monitoring is implemented using a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/Terminated.html" title="org.apache.pekko.actor.typed.Terminated"><code>Terminated</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/Terminated.html" title="org.apache.pekko.actor.typed.Terminated"><code>Terminated</code></a></span> m [...]
+<p>Lifecycle monitoring is implemented using a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/Terminated.html" title="org.apache.pekko.actor.typed.Terminated"><code>Terminated</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/Terminated.html" title="org.apache.pekko.actor.typed.Terminated"><code>Te [...]
 <h2><a href="#actors-and-exceptions" name="actors-and-exceptions" class="anchor"><span class="anchor-link"></span></a>Actors and exceptions</h2>
 <p>It can happen that while a message is being processed by an actor, that some kind of exception is thrown, e.g. a database exception.</p>
 <h3><a href="#what-happens-to-the-message" name="what-happens-to-the-message" class="anchor"><span class="anchor-link"></span></a>What happens to the Message</h3>
@@ -462,7 +462,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h3><a href="#what-happens-to-the-actor" name="what-happens-to-the-actor" class="anchor"><span class="anchor-link"></span></a>What happens to the actor</h3>
 <p>If code within an actor throws an exception, that actor is suspended and the supervision process is started. Depending on the supervisor’s decision the actor is resumed (as if nothing happened), restarted (wiping out its internal state and starting from scratch) or terminated.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/supervision.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/supervision.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -549,7 +549,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/general/terminology.html b/content/general/terminology.html
index c77ec82..7f79ff5 100644
--- a/content/general/terminology.html
+++ b/content/general/terminology.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -450,7 +450,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
   <li>Java Concurrency in Practice, B. Goetz, T. Peierls, J. Bloch, J. Bowbeer, D. Holmes and D. Lea, 2006. ISBN 978-0321349606</li>
 </ul>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/general/terminology.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/general/terminology.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -539,7 +539,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="../lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="../lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/index-actors.html b/content/index-actors.html
index adf64d3..4a65306 100644
--- a/content/index-actors.html
+++ b/content/index-actors.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -419,7 +419,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h1><a href="#classic-actors" name="classic-actors" class="anchor"><span class="anchor-link"></span></a>Classic Actors</h1><div class="callout note "><div class="callout-title">Note</div>
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use Classic Pekko Actors, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Classic Pekko Actors, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies ++= Seq(
   "org.apache.pekko" %% "pekko-actor" % PekkoVersion,
   "org.apache.pekko" %% "pekko-testkit" % PekkoVersion % Test
@@ -431,7 +431,7 @@ libraryDependencies ++= Seq(
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -451,7 +451,7 @@ libraryDependencies ++= Seq(
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
   testImplementation "org.apache.pekko:pekko-testkit_${versions.ScalaBinary}"
@@ -564,7 +564,7 @@ dependencies {
 </ul>
 </div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/index-actors.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/index-actors.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -647,7 +647,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/index-classic.html b/content/index-classic.html
index a8ef934..c350968 100644
--- a/content/index-classic.html
+++ b/content/index-classic.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -464,7 +464,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul>
 </div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/index-classic.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/index-classic.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -534,7 +534,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/index-cluster.html b/content/index-cluster.html
index 2ad3f0a..645299f 100644
--- a/content/index-cluster.html
+++ b/content/index-cluster.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -530,7 +530,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul>
 </div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/index-cluster.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/index-cluster.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -600,7 +600,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/index-network.html b/content/index-network.html
index 45e4488..1264f58 100644
--- a/content/index-network.html
+++ b/content/index-network.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -456,7 +456,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul>
 </div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/index-network.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/index-network.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -526,7 +526,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/index-utilities-classic.html b/content/index-utilities-classic.html
index 9cc2591..6840b4a 100644
--- a/content/index-utilities-classic.html
+++ b/content/index-utilities-classic.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -418,7 +418,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#classic-utilities" name="classic-utilities" class="anchor"><span class="anchor-link"></span></a>Classic Utilities</h1>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use Utilities, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Utilities, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies ++= Seq(
   "org.apache.pekko" %% "pekko-actor" % PekkoVersion,
   "org.apache.pekko" %% "pekko-testkit" % PekkoVersion % Test
@@ -430,7 +430,7 @@ libraryDependencies ++= Seq(
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -450,7 +450,7 @@ libraryDependencies ++= Seq(
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
   testImplementation "org.apache.pekko:pekko-testkit_${versions.ScalaBinary}"
@@ -490,7 +490,7 @@ dependencies {
 </ul>
 </div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/index-utilities-classic.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/index-utilities-classic.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -573,7 +573,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/index-utilities.html b/content/index-utilities.html
index b311b3c..aba087f 100644
--- a/content/index-utilities.html
+++ b/content/index-utilities.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -448,7 +448,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul>
 </div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/index-utilities.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/index-utilities.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -518,7 +518,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/index.html b/content/index.html
index 5fc9dfd..54ae2f0 100644
--- a/content/index.html
+++ b/content/index.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -601,7 +601,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 </ul>
 </div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/index.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/index.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -671,7 +671,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/io-dns.html b/content/io-dns.html
index 7c8c1e2..7982760 100644
--- a/content/io-dns.html
+++ b/content/io-dns.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -439,11 +439,11 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/io/dns/DnsCompileOnlyDocSpec.scala#L33-L34" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val initial: Option[Dns.Resolved] = Dns(system).cache.resolve(&quot;google.com&quot;)(system, actorRef)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/io/dns/DnsCompileOnlyDocSpec.scala#L33-L34" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val initial: Option[Dns.Resolved] = Dns(system).cache.resolve(&quot;google.com&quot;)(system, actorRef)
 val cached: Option[Dns.Resolved] = Dns(system).cache.cached(&quot;google.com&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/io/dns/DnsCompileOnlyDocTest.java#L36-L46" target="_blank" title="Go to snippet source">source</a><code class="language-java">Option&lt;DnsProtocol.Resolved&gt; initial =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/io/dns/DnsCompileOnlyDocTest.java#L36-L46" target="_blank" title="Go to snippet source">source</a><code class="language-java">Option&lt;DnsProtocol.Resolved&gt; initial =
     Dns.get(system)
         .cache()
         .resolve(
@@ -460,10 +460,10 @@ Option&lt;DnsProtocol.Resolved&gt; cached =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/io/dns/DnsCompileOnlyDocSpec.scala#L39" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val resolved: Future[Dns.Resolved] = (IO(Dns) ? Dns.Resolve(&quot;google.com&quot;)).mapTo[Dns.Resolved]</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/io/dns/DnsCompileOnlyDocSpec.scala#L39" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val resolved: Future[Dns.Resolved] = (IO(Dns) ? Dns.Resolve(&quot;google.com&quot;)).mapTo[Dns.Resolved]</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/io/dns/DnsCompileOnlyDocTest.java#L51-L56" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef dnsManager = Dns.get(system).manager();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/io/dns/DnsCompileOnlyDocTest.java#L51-L56" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef dnsManager = Dns.get(system).manager();
 CompletionStage&lt;Object&gt; resolved =
     ask(
         dnsManager,
@@ -474,11 +474,11 @@ CompletionStage&lt;Object&gt; resolved =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/io/dns/DnsCompileOnlyDocSpec.scala#L46-L47" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val resolved: Future[DnsProtocol.Resolved] =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/io/dns/DnsCompileOnlyDocSpec.scala#L46-L47" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val resolved: Future[DnsProtocol.Resolved] =
   (IO(Dns) ? DnsProtocol.Resolve(&quot;google.com&quot;)).mapTo[DnsProtocol.Resolved]</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/io/dns/DnsCompileOnlyDocTest.java#L63-L65" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef dnsManager = Dns.get(system).manager();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/io/dns/DnsCompileOnlyDocTest.java#L63-L65" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef dnsManager = Dns.get(system).manager();
 CompletionStage&lt;Object&gt; resolved =
     ask(dnsManager, DnsProtocol.resolve(&quot;google.com&quot;), timeout);</code></pre></dd>
 </dl>
@@ -493,17 +493,17 @@ CompletionStage&lt;Object&gt; resolved =
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/actor/io/dns/DnsCompileOnlyDocSpec.scala#L53-L54" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val resolved: Future[DnsProtocol.Resolved] =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/actor/io/dns/DnsCompileOnlyDocSpec.scala#L53-L54" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val resolved: Future[DnsProtocol.Resolved] =
   (IO(Dns) ? DnsProtocol.Resolve(&quot;your-service&quot;, Srv)).mapTo[DnsProtocol.Resolved]</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/io/dns/DnsCompileOnlyDocTest.java#L71-L73" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef dnsManager = Dns.get(system).manager();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/io/dns/DnsCompileOnlyDocTest.java#L71-L73" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef dnsManager = Dns.get(system).manager();
 CompletionStage&lt;Object&gt; resolved =
     ask(dnsManager, DnsProtocol.resolve(&quot;google.com&quot;, DnsProtocol.srvRequestType()), timeout);</code></pre></dd>
 </dl>
 <p>The <code>DnsProtocol.Resolved</code> will contain <code>org.apache.pekko.io.dns.SRVRecord</code>s.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/io-dns.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/io-dns.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -586,7 +586,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/io-tcp.html b/content/io-tcp.html
index ac76144..f85efc2 100644
--- a/content/io-tcp.html
+++ b/content/io-tcp.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -419,7 +419,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#using-tcp" name="using-tcp" class="anchor"><span class="anchor-link"></span></a>Using TCP</h1>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use TCP, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use TCP, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -428,7 +428,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -443,7 +443,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -452,14 +452,14 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L17-L21" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L17-L21" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.{ Actor, ActorRef, Props }
 import pekko.io.{ IO, Tcp }
 import pekko.util.ByteString
 import java.net.InetSocketAddress</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/IODocTest.java#L23-L35" target="_blank" title="Go to snippet source">source</a><code class="language-java">import java.net.InetSocketAddress;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/IODocTest.java#L23-L35" target="_blank" title="Go to snippet source">source</a><code class="language-java">import java.net.InetSocketAddress;
 import org.apache.pekko.actor.ActorRef;
 import org.apache.pekko.actor.ActorSystem;
 import org.apache.pekko.actor.Props;
@@ -477,20 +477,20 @@ import org.apache.pekko.util.ByteString;</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L29-L32" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.io.{ IO, Tcp }
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L29-L32" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.io.{ IO, Tcp }
 import context.system // implicitly used by IO(Tcp)
 
 val manager = IO(Tcp)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/EchoManager.java#L48" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef tcpManager = Tcp.get(getContext().getSystem()).manager();</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/EchoManager.java#L48" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef tcpManager = Tcp.get(getContext().getSystem()).manager();</code></pre></dd>
 </dl>
 <p>The manager is an actor that handles the underlying low level I/O resources (selectors, channels) and instantiates workers for specific tasks, such as listening to incoming connections.</p>
 <h2><a href="#connecting" name="connecting" class="anchor"><span class="anchor-link"></span></a>Connecting</h2>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L77-L113" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object Client {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L77-L113" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object Client {
   def props(remote: InetSocketAddress, replies: ActorRef) =
     Props(classOf[Client], remote, replies)
 }
@@ -529,7 +529,7 @@ class Client(remote: InetSocketAddress, listener: ActorRef) extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/IODocTest.java#L116-L181" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Client extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/IODocTest.java#L116-L181" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Client extends AbstractActor {
 
   final InetSocketAddress remote;
   final ActorRef listener;
@@ -606,7 +606,7 @@ class Client(remote: InetSocketAddress, listener: ActorRef) extends Actor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L39-L63" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Server extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L39-L63" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Server extends Actor {
 
   import Tcp._
   import context.system
@@ -628,7 +628,7 @@ class Client(remote: InetSocketAddress, listener: ActorRef) extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/IODocTest.java#L47-L88" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Server extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/IODocTest.java#L47-L88" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class Server extends AbstractActor {
 
   final ActorRef manager;
 
@@ -677,7 +677,7 @@ class Client(remote: InetSocketAddress, listener: ActorRef) extends Actor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L67-L73" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class SimplisticHandler extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L67-L73" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class SimplisticHandler extends Actor {
   import Tcp._
   def receive = {
     case Received(data) =&gt; sender() ! Write(data)
@@ -686,7 +686,7 @@ class Client(remote: InetSocketAddress, listener: ActorRef) extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/IODocTest.java#L93-L111" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class SimplisticHandler extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/IODocTest.java#L93-L111" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class SimplisticHandler extends AbstractActor {
   @Override
   public Receive createReceive() {
     return receiveBuilder()
@@ -742,7 +742,7 @@ class Client(remote: InetSocketAddress, listener: ActorRef) extends Actor {
   <li><em>NACK-based:</em> every write which arrives while a previous write is not yet completed will be replied to with a <code>CommandFailed</code> message containing the failed write. Just relying on this mechanism requires the implemented protocol to tolerate skipping writes (e.g. if each write is a valid message on its own and it is not required that all are delivered). This mode is enabled by setting the <code>useResumeWriting</code> flag to <code>false</code> within the <span clas [...]
   <li><em>NACK-based with write suspending:</em> this mode is very similar to the NACK-based one, but once a single write has failed no further writes will succeed until a <span class="group-scala"><code>ResumeWriting</code> message</span><span class="group-java">message by the <code>TcpMessage.resumeWriting</code> method</span> is received. This message will be answered with a <code>WritingResumed</code> message once the last accepted write has completed. If the actor driving the connec [...]
 </ul>
-<p>These write back-pressure models (with the exception of the second which is rather specialised) are demonstrated in complete examples below. The full and contiguous source is available <span class="group-scala"><a href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/EchoServer.scala">on GitHub</a></span><span class="group-java"><a href="https://github.com/akka/akka/tree/main/docs/rst/java/code/jdocs/io/japi">on GitHub</a></span>.</p>
+<p>These write back-pressure models (with the exception of the second which is rather specialised) are demonstrated in complete examples below. The full and contiguous source is available <span class="group-scala"><a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/EchoServer.scala">on GitHub</a></span><span class="group-java"><a href="https://github.com/apache/incubator-pekko/tree/main/docs/rst/java/code/jdocs/io/japi">on GitHub</a></span>.</p>
 <p>For back-pressuring reads there are two modes of operation</p>
 <ul>
   <li><em>Push-reading:</em> in this mode the connection actor sends the registered reader actor incoming data as soon as available as <code>Received</code> events. Whenever the reader actor wants to signal back-pressure to the remote TCP endpoint it can send a <span class="group-scala"><code>SuspendReading</code> message</span><span class="group-java">message by the <code>TcpMessage.suspendReading</code> method</span> to the connection actor to indicate that it wants to suspend the rece [...]
@@ -754,13 +754,13 @@ class Client(remote: InetSocketAddress, listener: ActorRef) extends Actor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L63-L66" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case Connected(remote, local) =&gt;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L63-L66" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case Connected(remote, local) =&gt;
   log.info(&quot;received connection from {}&quot;, remote)
   val handler = context.actorOf(Props(handlerClass, sender(), remote))
   sender() ! Register(handler, keepOpenOnPeerClosed = true)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/EchoManager.java#L87-L91" target="_blank" title="Go to snippet source">source</a><code class="language-java">connection.tell(
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/EchoManager.java#L87-L91" target="_blank" title="Go to snippet source">source</a><code class="language-java">connection.tell(
     TcpMessage.register(
         handler, true, // &lt;-- keepOpenOnPeerClosed flag
         true),
@@ -770,7 +770,7 @@ class Client(remote: InetSocketAddress, listener: ActorRef) extends Actor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L225-L301" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class SimpleEchoHandler(connection: ActorRef, remote: InetSocketAddress) extends Actor with ActorLogging {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L225-L301" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class SimpleEchoHandler(connection: ActorRef, remote: InetSocketAddress) extends Actor with ActorLogging {
 
   import Tcp._
 
@@ -845,7 +845,7 @@ class Client(remote: InetSocketAddress, listener: ActorRef) extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/SimpleEchoHandler.java#L31-L149" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class SimpleEchoHandler extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/SimpleEchoHandler.java#L31-L149" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class SimpleEchoHandler extends AbstractActor {
 
   final LoggingAdapter log = Logging.getLogger(getContext().getSystem(), getSelf());
 
@@ -965,7 +965,7 @@ class Client(remote: InetSocketAddress, listener: ActorRef) extends Actor {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L264-L298" target="_blank" title="Go to snippet source">source</a><code class="language-scala">private def buffer(data: ByteString): Unit = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L264-L298" target="_blank" title="Go to snippet source">source</a><code class="language-scala">private def buffer(data: ByteString): Unit = {
   storage :+= data
   stored += data.size
 
@@ -1002,7 +1002,7 @@ private def acknowledge(): Unit = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/SimpleEchoHandler.java#L111-L146" target="_blank" title="Go to snippet source">source</a><code class="language-java">protected void buffer(ByteString data) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/SimpleEchoHandler.java#L111-L146" target="_blank" title="Go to snippet source">source</a><code class="language-java">protected void buffer(ByteString data) {
   storage.add(data);
   stored += data.size();
 
@@ -1045,7 +1045,7 @@ protected void acknowledge() {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L73-L221" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object EchoHandler {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L73-L221" target="_blank" title="Go to snippet source">source</a><code class="language-scala">object EchoHandler {
   final case class Ack(offset: Int) extends Tcp.Event
 
   def props(connection: ActorRef, remote: InetSocketAddress): Props =
@@ -1186,7 +1186,7 @@ class EchoHandler(connection: ActorRef, remote: InetSocketAddress) extends Actor
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/EchoHandler.java#L37-L267" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class EchoHandler extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/EchoHandler.java#L37-L267" target="_blank" title="Go to snippet source">source</a><code class="language-java">public class EchoHandler extends AbstractActor {
 
   final LoggingAdapter log = Logging.getLogger(getContext().getSystem(), getSelf());
 
@@ -1414,7 +1414,7 @@ class EchoHandler(connection: ActorRef, remote: InetSocketAddress) extends Actor
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L111-L135" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def buffering(nack: Int): Receive = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L111-L135" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def buffering(nack: Int): Receive = {
   var toAck = 10
   var peerClosed = false
 
@@ -1441,7 +1441,7 @@ class EchoHandler(connection: ActorRef, remote: InetSocketAddress) extends Actor
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/EchoHandler.java#L119-L172" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>static final class BufferingState {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/EchoHandler.java#L119-L172" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>static final class BufferingState {
   int toAck = 10;
   boolean peerClosed = false;
 }
@@ -1499,7 +1499,7 @@ protected Receive buffering(final Ack nack) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L139-L155" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def closing: Receive = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L139-L155" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def closing: Receive = {
   case CommandFailed(_: Write) =&gt;
     connection ! ResumeWriting
     context.become({
@@ -1518,7 +1518,7 @@ protected Receive buffering(final Ack nack) {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/EchoHandler.java#L176-L208" target="_blank" title="Go to snippet source">source</a><code class="language-java">protected Receive closing() {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/EchoHandler.java#L176-L208" target="_blank" title="Go to snippet source">source</a><code class="language-java">protected Receive closing() {
   return receiveBuilder()
       .match(
           CommandFailed.class,
@@ -1557,7 +1557,7 @@ protected Receive closeResend() {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L176-L207" target="_blank" title="Go to snippet source">source</a><code class="language-scala">private def buffer(data: ByteString): Unit = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/EchoServer.scala#L176-L207" target="_blank" title="Go to snippet source">source</a><code class="language-scala">private def buffer(data: ByteString): Unit = {
   storage :+= data
   stored += data.size
 
@@ -1591,7 +1591,7 @@ private def acknowledge(ack: Int): Unit = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/EchoHandler.java#L219-L248" target="_blank" title="Go to snippet source">source</a><code class="language-java">protected void buffer(ByteString data) {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/EchoHandler.java#L219-L248" target="_blank" title="Go to snippet source">source</a><code class="language-java">protected void buffer(ByteString data) {
   storage.add(data);
   stored += data.size();
 
@@ -1628,7 +1628,7 @@ protected void acknowledge(int ack) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/ReadBackPressure.scala#L63-L68" target="_blank" title="Go to snippet source">source</a><code class="language-scala">override def preStart(): Unit = connection ! ResumeReading
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/ReadBackPressure.scala#L63-L68" target="_blank" title="Go to snippet source">source</a><code class="language-scala">override def preStart(): Unit = connection ! ResumeReading
 
 def receive = {
   case Received(data) =&gt; connection ! Write(data, Ack)
@@ -1636,7 +1636,7 @@ def receive = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/JavaReadBackPressure.java#L92-L112" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/JavaReadBackPressure.java#L92-L112" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public void preStart() throws Exception {
   connection.tell(TcpMessage.resumeReading(), getSelf());
 }
@@ -1663,10 +1663,10 @@ public Receive createReceive() {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/ReadBackPressure.scala#L82" target="_blank" title="Go to snippet source">source</a><code class="language-scala">IO(Tcp) ! Connect(listenAddress, pullMode = true)</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/ReadBackPressure.scala#L82" target="_blank" title="Go to snippet source">source</a><code class="language-scala">IO(Tcp) ! Connect(listenAddress, pullMode = true)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/JavaReadBackPressure.java#L72-L77" target="_blank" title="Go to snippet source">source</a><code class="language-java">final List&lt;Inet.SocketOption&gt; options = new ArrayList&lt;Inet.SocketOption&gt;();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/JavaReadBackPressure.java#L72-L77" target="_blank" title="Go to snippet source">source</a><code class="language-java">final List&lt;Inet.SocketOption&gt; options = new ArrayList&lt;Inet.SocketOption&gt;();
 Duration timeout = null;
 tcp.tell(
     TcpMessage.connect(
@@ -1678,10 +1678,10 @@ tcp.tell(
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/ReadBackPressure.scala#L34" target="_blank" title="Go to snippet source">source</a><code class="language-scala">IO(Tcp) ! Bind(self, new InetSocketAddress(&quot;localhost&quot;, 0), pullMode = true)</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/ReadBackPressure.scala#L34" target="_blank" title="Go to snippet source">source</a><code class="language-scala">IO(Tcp) ! Bind(self, new InetSocketAddress(&quot;localhost&quot;, 0), pullMode = true)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/JavaReadBackPressure.java#L62-L66" target="_blank" title="Go to snippet source">source</a><code class="language-java">tcp = Tcp.get(getContext().getSystem()).manager();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/JavaReadBackPressure.java#L62-L66" target="_blank" title="Go to snippet source">source</a><code class="language-java">tcp = Tcp.get(getContext().getSystem()).manager();
 final List&lt;Inet.SocketOption&gt; options = new ArrayList&lt;Inet.SocketOption&gt;();
 tcp.tell(
     TcpMessage.bind(getSelf(), new InetSocketAddress(&quot;localhost&quot;, 0), 100, options, true),
@@ -1693,7 +1693,7 @@ tcp.tell(
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/ReadBackPressure.scala#L39-L42" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case Bound(localAddress) =&gt;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/ReadBackPressure.scala#L39-L42" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case Bound(localAddress) =&gt;
   // Accept connections one by one
   sender() ! ResumeAccepting(batchSize = 1)
   context.become(listening(sender()))
@@ -1705,7 +1705,7 @@ def listening(listener: ActorRef): Receive = {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/JavaReadBackPressure.java#L38-L56" target="_blank" title="Go to snippet source">source</a><code class="language-java">public Receive createReceive() {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/JavaReadBackPressure.java#L38-L56" target="_blank" title="Go to snippet source">source</a><code class="language-java">public Receive createReceive() {
   return receiveBuilder()
       .match(
           Tcp.Bound.class,
@@ -1728,7 +1728,7 @@ def listening(listener: ActorRef): Receive = {
 <p>As shown in the example, after handling an incoming connection we need to resume accepting again.</p>
 <p>The <span class="group-scala"><code>ResumeAccepting</code></span><span class="group-java"><code>TcpMessage.resumeAccepting</code> method</span> accepts a <code>batchSize</code> parameter that specifies how many new connections are accepted before a next <code>ResumeAccepting</code> message is needed to resume handling of new connections.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/io-tcp.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/io-tcp.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -1820,7 +1820,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/io-udp.html b/content/io-udp.html
index 141660e..9d870e3 100644
--- a/content/io-udp.html
+++ b/content/io-udp.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -419,7 +419,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#using-udp" name="using-udp" class="anchor"><span class="anchor-link"></span></a>Using UDP</h1>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use UDP, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use UDP, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -428,7 +428,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -443,7 +443,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -459,7 +459,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/UdpDocSpec.scala#L32-L51" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class SimpleSender(remote: InetSocketAddress) extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/UdpDocSpec.scala#L32-L51" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class SimpleSender(remote: InetSocketAddress) extends Actor {
   import context.system
   IO(Udp) ! Udp.SimpleSender
 
@@ -475,7 +475,7 @@ dependencies {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/UdpDocTest.java#L32-L72" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class SimpleSender extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/UdpDocTest.java#L32-L72" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class SimpleSender extends AbstractActor {
   final InetSocketAddress remote;
 
   public SimpleSender(InetSocketAddress remote) {
@@ -514,7 +514,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/UdpDocSpec.scala#L55-L78" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Listener(nextActor: ActorRef) extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/UdpDocSpec.scala#L55-L78" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Listener(nextActor: ActorRef) extends Actor {
   import context.system
   IO(Udp) ! Udp.Bind(self, new InetSocketAddress(&quot;localhost&quot;, 0))
 
@@ -534,7 +534,7 @@ dependencies {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/UdpDocTest.java#L76-L127" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class Listener extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/UdpDocTest.java#L76-L127" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class Listener extends AbstractActor {
   final ActorRef nextActor;
 
   public Listener(ActorRef nextActor) {
@@ -589,7 +589,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/UdpDocSpec.scala#L82-L107" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Connected(remote: InetSocketAddress) extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/UdpDocSpec.scala#L82-L107" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class Connected(remote: InetSocketAddress) extends Actor {
   import context.system
   IO(UdpConnected) ! UdpConnected.Connect(self, remote)
 
@@ -610,7 +610,7 @@ dependencies {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/UdpDocTest.java#L131-L187" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class Connected extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/UdpDocTest.java#L131-L187" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class Connected extends AbstractActor {
   final InetSocketAddress remote;
 
   public Connected(InetSocketAddress remote) {
@@ -666,13 +666,13 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/ScalaUdpMulticast.scala#L26-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">final case class Inet6ProtocolFamily() extends DatagramChannelCreator {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/ScalaUdpMulticast.scala#L26-L29" target="_blank" title="Go to snippet source">source</a><code class="language-scala">final case class Inet6ProtocolFamily() extends DatagramChannelCreator {
   override def create() =
     DatagramChannel.open(StandardProtocolFamily.INET6)
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/JavaUdpMulticast.java#L38-L43" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class Inet6ProtocolFamily extends Inet.DatagramChannelCreator {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/JavaUdpMulticast.java#L38-L43" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class Inet6ProtocolFamily extends Inet.DatagramChannelCreator {
   @Override
   public DatagramChannel create() throws Exception {
     return DatagramChannel.open(StandardProtocolFamily.INET6);
@@ -683,7 +683,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/ScalaUdpMulticast.scala#L33-L39" target="_blank" title="Go to snippet source">source</a><code class="language-scala">final case class MulticastGroup(address: String, interface: String) extends SocketOptionV2 {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/ScalaUdpMulticast.scala#L33-L39" target="_blank" title="Go to snippet source">source</a><code class="language-scala">final case class MulticastGroup(address: String, interface: String) extends SocketOptionV2 {
   override def afterBind(s: DatagramSocket): Unit = {
     val group = InetAddress.getByName(address)
     val networkInterface = NetworkInterface.getByName(interface)
@@ -692,7 +692,7 @@ dependencies {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/JavaUdpMulticast.java#L47-L66" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class MulticastGroup extends Inet.AbstractSocketOptionV2 {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/JavaUdpMulticast.java#L47-L66" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class MulticastGroup extends Inet.AbstractSocketOptionV2 {
   private String address;
   private String interf;
 
@@ -717,12 +717,12 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/ScalaUdpMulticast.scala#L44-L46" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import context.system
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/ScalaUdpMulticast.scala#L44-L46" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import context.system
 val opts = List(Inet6ProtocolFamily(), MulticastGroup(group, iface))
 IO(Udp) ! Udp.Bind(self, new InetSocketAddress(port), opts)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/JavaUdpMulticast.java#L78-L85" target="_blank" title="Go to snippet source">source</a><code class="language-java">List&lt;Inet.SocketOption&gt; options = new ArrayList&lt;&gt;();
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/JavaUdpMulticast.java#L78-L85" target="_blank" title="Go to snippet source">source</a><code class="language-java">List&lt;Inet.SocketOption&gt; options = new ArrayList&lt;&gt;();
 options.add(new Inet6ProtocolFamily());
 options.add(new MulticastGroup(group, iface));
 
@@ -732,7 +732,7 @@ InetSocketAddress endpoint = new InetSocketAddress(port);
 mgr.tell(UdpMessage.bind(getSelf(), endpoint, options), getSelf());</code></pre></dd>
 </dl>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/io-udp.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/io-udp.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -819,7 +819,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/io.html b/content/io.html
index f4c3f99..57d5665 100644
--- a/content/io.html
+++ b/content/io.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -419,7 +419,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#i-o" name="i-o" class="anchor"><span class="anchor-link"></span></a>I/O</h1>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use I/O, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use I/O, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -428,7 +428,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -443,7 +443,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -451,19 +451,19 @@ dependencies {
 <p>The <code>pekko.io</code> package design combines experiences from the <code>spray-io</code> module with improvements that were jointly developed for more general consumption as an actor-based service.</p>
 <p>The guiding design goal for this I/O implementation was to reach extreme scalability, make no compromises in providing an API correctly matching the underlying transport mechanism and to be fully event-driven, non-blocking and asynchronous. The API is meant to be a solid foundation for the implementation of network protocols and building higher abstractions; it is not meant to be a full-service high-level NIO wrapper for end users.</p>
 <h2><a href="#terminology-concepts" name="terminology-concepts" class="anchor"><span class="anchor-link"></span></a>Terminology, Concepts</h2>
-<p>The I/O API is completely actor based, meaning that all operations are implemented with message passing instead of direct method calls. Every I/O driver (TCP, UDP) has a special actor, called a <em>manager</em> that serves as an entry point for the API. I/O is broken into several drivers. The manager for a particular driver is accessible <span class="group-scala">through the <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/io/IO$.html" title="pekko.io.IO"><code>IO</code></a> [...]
+<p>The I/O API is completely actor based, meaning that all operations are implemented with message passing instead of direct method calls. Every I/O driver (TCP, UDP) has a special actor, called a <em>manager</em> that serves as an entry point for the API. I/O is broken into several drivers. The manager for a particular driver is accessible <span class="group-scala">through the <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/io/IO$.html" title="pekko.io.IO"><code>IO</code></a> [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L29-L32" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.io.{ IO, Tcp }
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/io/IODocSpec.scala#L29-L32" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.io.{ IO, Tcp }
 import context.system // implicitly used by IO(Tcp)
 
 val manager = IO(Tcp)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/io/japi/EchoManager.java#L48" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef tcpManager = Tcp.get(getContext().getSystem()).manager();</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/io/japi/EchoManager.java#L48" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef tcpManager = Tcp.get(getContext().getSystem()).manager();</code></pre></dd>
 </dl>
-<p>The manager receives I/O command messages and instantiates worker actors in response. The worker actors present themselves to the API user in the reply to the command that was sent. For example after a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/io/Tcp$$Connect.html" title="org.apache.pekko.io.Tcp.Connect"><code>Connect</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528 [...]
+<p>The manager receives I/O command messages and instantiates worker actors in response. The worker actors present themselves to the API user in the reply to the command that was sent. For example after a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/io/Tcp$$Connect.html" title="org.apache.pekko.io.Tcp.Connect"><code>Connect</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+ [...]
 <h3><a href="#deathwatch-and-resource-management" name="deathwatch-and-resource-management" class="anchor"><span class="anchor-link"></span></a>DeathWatch and Resource Management</h3>
 <p>I/O worker actors receive commands and also send out events. They usually need a user-side counterpart actor listening for these events (such events could be inbound connections, incoming bytes or acknowledgements for writes). These worker actors <em>watch</em> their listener counterparts. If the listener stops then the worker will automatically release any resources that it holds. This design makes the API more robust against resource leaks.</p>
 <p>Thanks to the completely actor based approach of the I/O API the opposite direction works as well: a user actor responsible for handling a connection can watch the connection actor to be notified if it unexpectedly terminates.</p>
@@ -475,16 +475,16 @@ val manager = IO(Tcp)</code></pre></dd>
   <li><em>Nack-based</em>, where the driver notifies the writer when writes have failed.</li>
 </ul>
 <p>Each of these models is available in both the TCP and the UDP implementations of Pekko I/O.</p>
-<p>Individual writes can be acknowledged by providing an ack object in the write message (<span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/io/Tcp$$Write.html" title="org.apache.pekko.io.Tcp.Write"><code>Write</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/io/Tcp$$Write.html" title="org.apache.pekko.io.Tcp.Write"><code>Write</code></a></span> in the [...]
+<p>Individual writes can be acknowledged by providing an ack object in the write message (<span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/io/Tcp$$Write.html" title="org.apache.pekko.io.Tcp.Write"><code>Write</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/io/Tcp$$Write.html" title="org.apache.pekko.io.Tcp.Write"><code>Wr [...]
 <p>If a write (or any other command) fails, the driver notifies the actor that sent the command with a special message (<code>CommandFailed</code> in the case of UDP and TCP). This message will also notify the writer of a failed write, serving as a nack for that write. Please note, that in a nack-based flow-control setting the writer has to be prepared for the fact that the failed write might not be the most recent write it sent. For example, the failure notification for a write <code>W1 [...]
 <p>An acknowledged write does not mean acknowledged delivery or storage; receiving an ack for a write signals that the I/O driver has successfully processed the write. The Ack/Nack protocol described here is a means of flow control not error handling. In other words, data may still be lost, even if every write is acknowledged.</p></div>
 <h3><a href="#bytestring" name="bytestring" class="anchor"><span class="anchor-link"></span></a>ByteString</h3>
-<p>To maintain isolation, actors should communicate with immutable objects only. <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/util/ByteString.html" title="org.apache.pekko.util.ByteString"><code>ByteString</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/util/ByteString.html" title="org.apache.pekko.util.ByteString"><code>ByteString</code></a></s [...]
-<p><code>ByteString</code> is a <a href="https://en.wikipedia.org/wiki/Rope_(computer_science)">rope-like</a> data structure that is immutable and provides fast concatenation and slicing operations (perfect for I/O). When two <code>ByteString</code>s are concatenated together they are both stored within the resulting <code>ByteString</code> instead of copying both to a new <span class="group-scala"><code>Array</code></span><span class="group-java">array</span>. Operations such as <span c [...]
-<p><code>ByteString</code> inherits all methods from <a href="http://www.scala-lang.org/api/2.13.8/scala/collection/immutable/IndexedSeq.html" title="scala.collection.immutable.IndexedSeq"><code>IndexedSeq</code></a>, and it also has some new ones. For more information, look up the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/util/ByteString.html" title="org.apache.pekko.util.ByteString"><code>util.ByteString</code></a></s [...]
-<p><code>ByteString</code> also comes with its own optimized builder and iterator classes <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/util/ByteStringBuilder.html" title="org.apache.pekko.util.ByteStringBuilder"><code>ByteStringBuilder</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/util/ByteStringBuilder.html" title="org.apache.pekko.util.ByteS [...]
+<p>To maintain isolation, actors should communicate with immutable objects only. <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/util/ByteString.html" title="org.apache.pekko.util.ByteString"><code>ByteString</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/util/ByteString.html" title="org.apache.pekko.util.ByteString"><c [...]
+<p><code>ByteString</code> is a <a href="https://en.wikipedia.org/wiki/Rope_(computer_science)">rope-like</a> data structure that is immutable and provides fast concatenation and slicing operations (perfect for I/O). When two <code>ByteString</code>s are concatenated together they are both stored within the resulting <code>ByteString</code> instead of copying both to a new <span class="group-scala"><code>Array</code></span><span class="group-java">array</span>. Operations such as <span c [...]
+<p><code>ByteString</code> inherits all methods from <a href="http://www.scala-lang.org/api/2.13.8/scala/collection/immutable/IndexedSeq.html" title="scala.collection.immutable.IndexedSeq"><code>IndexedSeq</code></a>, and it also has some new ones. For more information, look up the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/util/ByteString.html" title="org.apache.pekko.util.ByteString"><code>util.ByteString [...]
+<p><code>ByteString</code> also comes with its own optimized builder and iterator classes <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/util/ByteStringBuilder.html" title="org.apache.pekko.util.ByteStringBuilder"><code>ByteStringBuilder</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/util/ByteStringBuilder.html" title= [...]
 <h4><a href="#compatibility-with-java-io" name="compatibility-with-java-io" class="anchor"><span class="anchor-link"></span></a>Compatibility with java.io</h4>
-<p>A <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/util/ByteStringBuilder.html" title="org.apache.pekko.util.ByteStringBuilder"><code>ByteStringBuilder</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/util/ByteStringBuilder.html" title="org.apache.pekko.util.ByteStringBuilder"><code>ByteStringBuilder</code></a></span> can be wrapped in a <a href=" [...]
+<p>A <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/util/ByteStringBuilder.html" title="org.apache.pekko.util.ByteStringBuilder"><code>ByteStringBuilder</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/util/ByteStringBuilder.html" title="org.apache.pekko.util.ByteStringBuilder"><code>ByteStringBuilder</code></a></span> c [...]
 <h2><a href="#architecture-in-depth" name="architecture-in-depth" class="anchor"><span class="anchor-link"></span></a>Architecture in-depth</h2>
 <p>For further details on the design and internal architecture see <a href="common/io-layer.html">I/O Layer Design</a>.</p>
 <div class="toc ">
@@ -499,7 +499,7 @@ val manager = IO(Tcp)</code></pre></dd>
 </ul>
 </div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/io.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/io.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -585,7 +585,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/logging.html b/content/logging.html
index 3f7cd52..23104c8 100644
--- a/content/logging.html
+++ b/content/logging.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <p>For the new API see <a href="typed/logging.html">Logging</a>.</p>
 <h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2>
-<p>To use Logging, you must at least use the Pekko actors dependency in your project, and will most likely want to configure logging via the SLF4J module (<a href="logging.html#slf4j">see below</a>).</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Logging, you must at least use the Pekko actors dependency in your project, and will most likely want to configure logging via the SLF4J module (<a href="logging.html#slf4j">see below</a>).</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -430,7 +430,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -445,7 +445,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -453,7 +453,7 @@ dependencies {
 <tr><th colspan="2">Project Info: Pekko Logging (classic)</th></tr>
   <tr><th>Artifact</th><td><div>org.apache.pekko</div>
   <div>pekko-slf4j</div>
-  <div>0.0.0+26533-ec68a528-SNAPSHOT</div>
+  <div>0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT</div>
   <div><a href="project/links.html#snapshots-repository">Snapshots are available</a></div>
   </td></tr>
   <tr><th>JDK versions</th><td><div>Adopt OpenJDK 8</div><div>Adopt OpenJDK 11</div></td></tr>
@@ -468,11 +468,11 @@ dependencies {
   <div><a href="https://doc.akka.io/japi/akka/snapshot/akka/event/slf4j/package-summary.html" target="_blank" rel="noopener noreferrer">API (Javadoc)</a></div>
   </td></tr>
   <tr><th>Forums</th><td>
-  <div><a href="https://discuss.akka.io" target="_blank" rel="noopener noreferrer">Lightbend Discuss</a></div>
-  <div><a href="https://gitter.im/akka/akka" target="_blank" rel="noopener noreferrer">akka/akka Gitter channel</a></div>
+  <div><a href="https://lists.apache.org/list.html?dev@pekko.apache.org" target="_blank" rel="noopener noreferrer">Apache Pekko Dev mailing list</a></div>
+  <div><a href="https://github.com/apache/incubator-pekko/discussions" target="_blank" rel="noopener noreferrer">apache/incubator-pekko discussion</a></div>
   </td></tr>
   <tr><th>Release notes</th><td><a href="https://akka.io/blog/news-archive.html">akka.io blog</a></td></tr>
-  <tr><th>Issues</th><td><a href="https://github.com/akka/akka/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
+  <tr><th>Issues</th><td><a href="https://github.com/apache/incubator-pekko/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
   <tr><th>Sources</th><td><a href="https://github.com/apache/incubator-pekko" target="_blank" rel="noopener noreferrer">https://github.com/apache/incubator-pekko</a></td></tr>
 </table>
 
@@ -482,12 +482,12 @@ dependencies {
 
 <h2><a href="#how-to-log" name="how-to-log" class="anchor"><span class="anchor-link"></span></a>How to Log</h2>
 
-<p>Create a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/LoggingAdapter.html" title="org.apache.pekko.event.LoggingAdapter"><code>LoggingAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/LoggingAdapter.html" title="org.apache.pekko.event.LoggingAdapter"><code>LoggingAdapter</code></a></span> and use the <code>error</code>, <cod [...]
+<p>Create a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/LoggingAdapter.html" title="org.apache.pekko.event.LoggingAdapter"><code>LoggingAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/LoggingAdapter.html" title="org.apache.pekko.event.LoggingAdapter"><code>LoggingAdapter</code></a></span> and use  [...]
 
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L23-L37" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.event.Logging
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L23-L37" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.event.Logging
 
 class MyActor extends Actor {
   val log = Logging(context.system, this)
@@ -504,11 +504,11 @@ class MyActor extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.*;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.*;
 import org.apache.pekko.event.Logging;
 import org.apache.pekko.event.LoggingAdapter;
 </code></pre>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L167-L192" target="_blank" title="Go to snippet source">source</a><code class="language-java">class MyActor extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L167-L192" target="_blank" title="Go to snippet source">source</a><code class="language-java">class MyActor extends AbstractActor {
   LoggingAdapter log = Logging.getLogger(getContext().getSystem(), this);
 
   @Override
@@ -540,7 +540,7 @@ import org.apache.pekko.event.LoggingAdapter;
   ...
 }
 </code></pre></div>
-<p>The first parameter to <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/event/Logging$.html#apply[T](bus:org.apache.pekko.event.LoggingBus,logSource:T)(implicitevidence$5:org.apache.pekko.event.LogSource[T]):org.apache.pekko.event.LoggingAdapter" title="pekko.event.Logging"><code>Logging</code></a></span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/event/Logging.html#getLogger(org.apache.pekko.event.LoggingBu [...]
+<p>The first parameter to <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/event/Logging$.html#apply[T](bus:org.apache.pekko.event.LoggingBus,logSource:T)(implicitevidence$5:org.apache.pekko.event.LogSource[T]):org.apache.pekko.event.LoggingAdapter" title="pekko.event.Logging"><code>Logging</code></a></span> <span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/event/Logging.html#getLogger(org.apache.pekko.event.LoggingBu [...]
 <ul>
   <li>if it is an Actor or ActorRef, its path is used</li>
   <li>in case of a String it is used as is</li>
@@ -551,14 +551,14 @@ import org.apache.pekko.event.LoggingAdapter;
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L218-L219" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val args = Array(&quot;The&quot;, &quot;brown&quot;, &quot;fox&quot;, &quot;jumps&quot;, 42)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L218-L219" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val args = Array(&quot;The&quot;, &quot;brown&quot;, &quot;fox&quot;, &quot;jumps&quot;, 42)
 system.log.debug(&quot;five parameters: {}, {}, {}, {}, {}&quot;, args)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L160-L161" target="_blank" title="Go to snippet source">source</a><code class="language-java">final Object[] args = new Object[] {&quot;The&quot;, &quot;brown&quot;, &quot;fox&quot;, &quot;jumps&quot;, 42};
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L160-L161" target="_blank" title="Go to snippet source">source</a><code class="language-java">final Object[] args = new Object[] {&quot;The&quot;, &quot;brown&quot;, &quot;fox&quot;, &quot;jumps&quot;, 42};
 system.log().debug(&quot;five parameters: {}, {}, {}, {}, {}&quot;, args);</code></pre></dd>
 </dl>
-<p>The Java <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/Class.html" title="java.lang.Class"><code>Class</code></a> of the log source is also included in the generated <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/Logging$$LogEvent.html" title="org.apache.pekko.event.Logging.LogEvent"><code>Logging.LogEvent</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/ak [...]
+<p>The Java <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/Class.html" title="java.lang.Class"><code>Class</code></a> of the log source is also included in the generated <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/Logging$$LogEvent.html" title="org.apache.pekko.event.Logging.LogEvent"><code>Logging.LogEvent</code></a></span><span class="group-java"><a href="https://doc. [...]
 <h3><a href="#logging-of-dead-letters" name="logging-of-dead-letters" class="anchor"><span class="anchor-link"></span></a>Logging of Dead Letters</h3>
 <p>By default messages sent to dead letters are logged at <code>INFO</code> level. Existence of dead letters does not necessarily indicate a problem, but they are logged by default for the sake of caution. After a few messages this logging is turned off, to avoid flooding the logs. You can disable this logging completely or adjust how many dead letters are logged. During system shutdown it is likely that you see dead letters, since pending messages in the actor mailboxes are sent to dead [...]
 <pre class="prettyprint"><code class="language-ruby">pekko {
@@ -661,7 +661,7 @@ system.log().debug(&quot;five parameters: {}, {}, {}, {}, {}&quot;, args);</code
 <p>Also see the <a href="testing.html#actor-logging">logging options for TestKit</a>.</p><div class="group-scala">
 <h3><a href="#translating-log-source-to-string-and-class" name="translating-log-source-to-string-and-class" class="anchor"><span class="anchor-link"></span></a>Translating Log Source to String and Class</h3>
 <p>The rules for translating the source object to the source string and class which are inserted into the <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/event/Logging$$LogEvent.html" title="pekko.event.Logging.LogEvent"><code>LogEvent</code></a> during runtime are implemented using implicit parameters and thus fully customizable: create your own instance of <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/event/LogSource.html" title="pekko.event.LogSource"><code>Log [...]
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L108-L124" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L108-L124" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.actor.ActorSystem
 import pekko.event.LogSource
 
@@ -692,7 +692,7 @@ class MyType(system: ActorSystem) {
 <h2><a href="#loggers" name="loggers" class="anchor"><span class="anchor-link"></span></a>Loggers</h2>
 <p>Logging is performed asynchronously through an event bus. Log events are processed by an event handler actor that receives the log events in the same order they were emitted.</p><div class="callout note "><div class="callout-title">Note</div>
 <p>The event handler actor does not have a bounded inbox and is run on the default dispatcher. This means that logging extreme amounts of data may affect your application badly. This can be somewhat mitigated by using an async logging backend though. (See <a href="logging.html#slf4j-directly">Using the SLF4J API directly</a>)</p></div>
-<p>You can configure which event handlers are created at system start-up and listen to logging events. That is done using the <code>loggers</code> element in the <a href="general/configuration.html">configuration</a>. Here you can also define the log level. More fine grained filtering based on the log source can be implemented in a custom <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/LoggingFilter.html" title="org.apa [...]
+<p>You can configure which event handlers are created at system start-up and listen to logging events. That is done using the <code>loggers</code> element in the <a href="general/configuration.html">configuration</a>. Here you can also define the log level. More fine grained filtering based on the log source can be implemented in a custom <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/LoggingFilter.html"  [...]
 <pre class="prettyprint"><code class="language-ruby">pekko {
   # Loggers to register at boot time (org.apache.pekko.event.Logging$DefaultLogger logs
   # to STDOUT)
@@ -707,7 +707,7 @@ class MyType(system: ActorSystem) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L88-L104" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L88-L104" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.event.Logging.Debug
 import pekko.event.Logging.Error
 import pekko.event.Logging.Info
@@ -726,7 +726,7 @@ class MyEventListener extends Actor {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.*;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.actor.*;
 import org.apache.pekko.event.Logging;
 import org.apache.pekko.event.LoggingAdapter;
 
@@ -736,7 +736,7 @@ import org.apache.pekko.event.Logging.Warning;
 import org.apache.pekko.event.Logging.Info;
 import org.apache.pekko.event.Logging.Debug;
 </code></pre>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L222-L253" target="_blank" title="Go to snippet source">source</a><code class="language-java">class MyEventListener extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L222-L253" target="_blank" title="Go to snippet source">source</a><code class="language-java">class MyEventListener extends AbstractActor {
   @Override
   public Receive createReceive() {
     return receiveBuilder()
@@ -772,7 +772,7 @@ import org.apache.pekko.event.Logging.Debug;
 <h2><a href="#logging-to-stdout-during-startup-and-shutdown" name="logging-to-stdout-during-startup-and-shutdown" class="anchor"><span class="anchor-link"></span></a>Logging to stdout during startup and shutdown</h2>
 <p>When the actor system is starting up and shutting down the configured <code>loggers</code> are not used. Instead log messages are printed to stdout (System.out). The default log level for this stdout logger is <code>WARNING</code> and it can be silenced completely by setting <code>pekko.stdout-loglevel=OFF</code>.</p>
 <h2><a href="#slf4j" name="slf4j" class="anchor"><span class="anchor-link"></span></a>SLF4J</h2>
-<p>Pekko provides a logger for <a href="https://www.slf4j.org/">SLF4J</a>. This module is available in the &lsquo;pekko-slf4j.jar&rsquo;. It has a single dependency: the slf4j-api jar. In your runtime, you also need a SLF4J backend. We recommend <a href="https://logback.qos.ch/">Logback</a>:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>Pekko provides a logger for <a href="https://www.slf4j.org/">SLF4J</a>. This module is available in the &lsquo;pekko-slf4j.jar&rsquo;. It has a single dependency: the slf4j-api jar. In your runtime, you also need a SLF4J backend. We recommend <a href="https://logback.qos.ch/">Logback</a>:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies ++= Seq(
   "org.apache.pekko" %% "pekko-slf4j" % PekkoVersion,
   "ch.qos.logback" % "logback-classic" % "1.2.11"
@@ -784,7 +784,7 @@ libraryDependencies ++= Seq(
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -804,12 +804,12 @@ libraryDependencies ++= Seq(
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-slf4j_${versions.ScalaBinary}"
   implementation "ch.qos.logback:logback-classic:1.2.11"
 }</code></pre></dd></dl>
-<p>You need to enable the Slf4jLogger in the <code>loggers</code> element in the <a href="general/configuration.html">configuration</a>. Here you can also define the log level of the event bus. More fine grained log levels can be defined in the configuration of the SLF4J backend (e.g. logback.xml). You should also define <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/slf4j/Slf4jLoggingFilter.html" title="org.apache.pek [...]
+<p>You need to enable the Slf4jLogger in the <code>loggers</code> element in the <a href="general/configuration.html">configuration</a>. Here you can also define the log level of the event bus. More fine grained log levels can be defined in the configuration of the SLF4J backend (e.g. logback.xml). You should also define <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/slf4j/Slf4jLoggingFilter.html" title=" [...]
 <p>If you set the <code>loglevel</code> to a higher level than <code>DEBUG</code>, any <code>DEBUG</code> events will be filtered out already at the source and will never reach the logging backend, regardless of how the backend is configured.</p>
 <p>You can enable <code>DEBUG</code> level for <code>pekko.loglevel</code> and control the actual level in the SLF4J backend without any significant overhead, also for production.</p></div>
 <pre class="prettyprint"><code class="language-ruby">pekko {
@@ -819,8 +819,8 @@ dependencies {
 }
 </code></pre>
 <p>One gotcha is that the timestamp is attributed in the event handler, not when actually doing the logging.</p>
-<p>The SLF4J logger selected for each log event is chosen based on the <span class="group-scala"><code>Class[_]</code></span> <span class="group-java"><code>Class</code></span> of the log source specified when creating the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/LoggingAdapter.html" title="org.apache.pekko.event.LoggingAdapter"><code>LoggingAdapter</code></a></span><span class="group-java"><a href="https://doc.a [...]
-<p>Beware that the actor system’s name is appended to a <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/String.html" title="java.lang.String"><code>String</code></a> log source if the LoggingAdapter was created giving an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></span><span class="group-java">< [...]
+<p>The SLF4J logger selected for each log event is chosen based on the <span class="group-scala"><code>Class[_]</code></span> <span class="group-java"><code>Class</code></span> of the log source specified when creating the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/LoggingAdapter.html" title="org.apache.pekko.event.LoggingAdapter"><code>LoggingAdapter</code></a></span><span class="group-java"><a href= [...]
+<p>Beware that the actor system’s name is appended to a <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/lang/String.html" title="java.lang.String"><code>String</code></a> log source if the LoggingAdapter was created giving an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>ActorSystem</code></a></span><span class= [...]
 <dl>
   <dt>Scala</dt>
   <dd>
@@ -837,9 +837,9 @@ dependencies {
 <p>This can be avoided by configuring the logging implementation to use a non-blocking appender. Logback provides <a href="https://logback.qos.ch/manual/appenders.html#AsyncAppender">AsyncAppender</a> that does this.</p>
 <h3><a href="#logback-configuration" name="logback-configuration" class="anchor"><span class="anchor-link"></span></a>Logback configuration</h3>
 <p>Logback has flexible configuration options and details can be found in the <a href="https://logback.qos.ch/manual/configuration.html">Logback manual</a> and other external resources.</p>
-<p>One part that is important to highlight is the importance of configuring an <a href="https://logback.qos.ch/manual/appenders.html#AsyncAppender">AsyncAppender</a>, because it offloads rendering of logging events to a background thread, increasing performance. It doesn&rsquo;t block the threads of the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSystem"><code>Act [...]
+<p>One part that is important to highlight is the importance of configuring an <a href="https://logback.qos.ch/manual/appenders.html#AsyncAppender">AsyncAppender</a>, because it offloads rendering of logging events to a background thread, increasing performance. It doesn&rsquo;t block the threads of the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorSystem.html" title="org.apache.pekko.actor.ActorSys [...]
 <p>A starting point for configuration of <code>logback.xml</code> for production:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/actor-typed-tests/src/test/resources/logback-doc-prod.xml" target="_blank" title="Go to snippet source">source</a><code class="language-xml">&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot;?&gt;
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/actor-typed-tests/src/test/resources/logback-doc-prod.xml" target="_blank" title="Go to snippet source">source</a><code class="language-xml">&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot;?&gt;
 &lt;configuration&gt;
 
     &lt;appender name=&quot;FILE&quot; class=&quot;ch.qos.logback.core.rolling.RollingFileAppender&quot;&gt;
@@ -864,7 +864,7 @@ dependencies {
     &lt;/root&gt;
 &lt;/configuration&gt;</code></pre>
 <p>For development you might want to log to standard out, but also have all <code>DEBUG</code> level logging to file, like in this example:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/actor-typed-tests/src/test/resources/logback-doc-dev.xml" target="_blank" title="Go to snippet source">source</a><code class="language-xml">&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot;?&gt;
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/actor-typed-tests/src/test/resources/logback-doc-dev.xml" target="_blank" title="Go to snippet source">source</a><code class="language-xml">&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot;?&gt;
 &lt;configuration&gt;
 
     &lt;appender name=&quot;STDOUT&quot; class=&quot;ch.qos.logback.core.ConsoleAppender&quot;&gt;
@@ -909,7 +909,7 @@ dependencies {
 <h3><a href="#more-accurate-timestamps-for-log-output-in-mdc" name="more-accurate-timestamps-for-log-output-in-mdc" class="anchor"><span class="anchor-link"></span></a>More accurate timestamps for log output in MDC</h3>
 <p>Pekko&rsquo;s logging is asynchronous which means that the timestamp of a log entry is taken from when the underlying logger implementation is called, which can be surprising at first. If you want to more accurately output the timestamp, use the MDC attribute <code>pekkoTimestamp</code>.</p>
 <h3><a href="#mdc-values-defined-by-the-application" name="mdc-values-defined-by-the-application" class="anchor"><span class="anchor-link"></span></a>MDC values defined by the application</h3>
-<p>One useful feature available in Slf4j is <a href="https://logback.qos.ch/manual/mdc.html">MDC</a>, Pekko has a way to let the application specify custom values, for this you need to use a specialized <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/LoggingAdapter.html" title="org.apache.pekko.event.LoggingAdapter"><code>LoggingAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0. [...]
+<p>One useful feature available in Slf4j is <a href="https://logback.qos.ch/manual/mdc.html">MDC</a>, Pekko has a way to let the application specify custom values, for this you need to use a specialized <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/LoggingAdapter.html" title="org.apache.pekko.event.LoggingAdapter"><code>LoggingAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io [...]
 <dl>
   <dt>Scala</dt>
   <dd>
@@ -923,11 +923,11 @@ final DiagnosticLoggingAdapter log = Logging.getLogger(this);
 </code></pre></dd>
 </dl>
 <p>Once you have the logger, you need to add the custom values before you log something. This way, the values will be put in the SLF4J MDC right before appending the log and removed after.</p><div class="callout note "><div class="callout-title">Note</div>
-<p>The cleanup (removal) should be done in the actor at the end, otherwise, next message will log with same MDC values, if it is not set to a new map. Use <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/DiagnosticLoggingAdapter.html#clearMDC():Unit" title="org.apache.pekko.event.DiagnosticLoggingAdapter"><code>log.clearMDC()</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68 [...]
+<p>The cleanup (removal) should be done in the actor at the end, otherwise, next message will log with same MDC values, if it is not set to a new map. Use <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/DiagnosticLoggingAdapter.html#clearMDC():Unit" title="org.apache.pekko.event.DiagnosticLoggingAdapter"><code>log.clearMDC()</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0. [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L48-L54" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val mdc = Map(&quot;requestId&quot; -&gt; 1234, &quot;visitorId&quot; -&gt; 5678)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L48-L54" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val mdc = Map(&quot;requestId&quot; -&gt; 1234, &quot;visitorId&quot; -&gt; 5678)
 log.mdc(mdc)
 
 // Log something
@@ -936,10 +936,10 @@ log.info(&quot;Starting new request&quot;)
 log.clearMDC()</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L38-L40" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.event.DiagnosticLoggingAdapter;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L38-L40" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.event.DiagnosticLoggingAdapter;
 import java.util.HashMap;
 import java.util.Map;</code></pre>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L196-L218" target="_blank" title="Go to snippet source">source</a><code class="language-java">class MdcActor extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/event/LoggingDocTest.java#L196-L218" target="_blank" title="Go to snippet source">source</a><code class="language-java">class MdcActor extends AbstractActor {
 
   final DiagnosticLoggingAdapter log = Logging.getLogger(this);
 
@@ -964,7 +964,7 @@ import java.util.Map;</code></pre>
 </code></pre></dd>
 </dl><div class="group-scala">
 <p>For convenience, you can mix in the <code>log</code> member into actors, instead of defining it as above. This trait also lets you override <a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/actor/DiagnosticActorLogging.html#mdc(currentMessage:Any):org.apache.pekko.event.Logging.MDC" title="pekko.actor.DiagnosticActorLogging"><code>mdc(msg: Any)</code></a> for specifying MDC values depending on current message and lets you forget about the cleanup as well, since it already doe [...]
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L61-L84" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import Logging.MDC
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/event/LoggingDocSpec.scala#L61-L84" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import Logging.MDC
 
 final case class Req(work: String, visitorId: Int)
 
@@ -1004,15 +1004,15 @@ class MdcActorMixin extends Actor with pekko.actor.DiagnosticActorLogging {
 </code></pre>
 <h3><a href="#using-markers" name="using-markers" class="anchor"><span class="anchor-link"></span></a>Using Markers</h3>
 <p>Some logging libraries allow, in addition to MDC data, attaching so called &ldquo;markers&rdquo; to log statements. These are used to filter out rare and special events, for example you might want to mark logs that detect some malicious activity and mark them with a <code>SECURITY</code> tag, and in your appender configuration make these trigger emails and other notifications immediately.</p>
-<p>Markers are available through the LoggingAdapters, when obtained via <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/Logging$.html#withMarker(logSource:org.apache.pekko.actor.Actor):org.apache.pekko.event.DiagnosticMarkerBusLoggingAdapter" title="org.apache.pekko.event.Logging"><code>Logging.withMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/ap [...]
+<p>Markers are available through the LoggingAdapters, when obtained via <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/Logging$.html#withMarker(logSource:org.apache.pekko.actor.Actor):org.apache.pekko.event.DiagnosticMarkerBusLoggingAdapter" title="org.apache.pekko.event.Logging"><code>Logging.withMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+2 [...]
 <p>The slf4j bridge provided by Pekko in <code>pekko-slf4j</code> will automatically pick up this marker value and make it available to SLF4J.</p>
 <p>Pekko is logging some events with markers. Some of these events also include structured MDC properties. </p>
 <ul>
   <li>The &ldquo;SECURITY&rdquo; marker is used for highlighting security related events or incidents.</li>
-  <li>Pekko Actor is using the markers defined in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorLogMarker$.html" title="org.apache.pekko.actor.ActorLogMarker"><code>ActorLogMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorLogMarker$.html" title="org.apache.pekko.actor.ActorLogMarker"><code>ActorLogMarker</code></a></sp [...]
-  <li>Pekko Cluster is using the markers defined in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ClusterLogMarker$.html" title="org.apache.pekko.cluster.ClusterLogMarker"><code>ClusterLogMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/ClusterLogMarker$.html" title="org.apache.pekko.cluster.ClusterLogMarker"><code>ClusterLo [...]
-  <li>Pekko Remoting is using the markers defined in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/remote/RemoteLogMarker$.html" title="org.apache.pekko.remote.RemoteLogMarker"><code>RemoteLogMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/remote/RemoteLogMarker$.html" title="org.apache.pekko.remote.RemoteLogMarker"><code>RemoteLogMarker</ [...]
-  <li>Pekko Cluster Sharding is using the markers defined in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/sharding/ShardingLogMarker$.html" title="org.apache.pekko.cluster.sharding.ShardingLogMarker"><code>ShardingLogMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/cluster/sharding/ShardingLogMarker$.html" title="org.apache.pekko.c [...]
+  <li>Pekko Actor is using the markers defined in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorLogMarker$.html" title="org.apache.pekko.actor.ActorLogMarker"><code>ActorLogMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorLogMarker$.html" title="org.apache.pekko.actor.ActorLogMarker"><code>A [...]
+  <li>Pekko Cluster is using the markers defined in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ClusterLogMarker$.html" title="org.apache.pekko.cluster.ClusterLogMarker"><code>ClusterLogMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/ClusterLogMarker$.html" title="org.apache.pekko.cluster.Clust [...]
+  <li>Pekko Remoting is using the markers defined in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/remote/RemoteLogMarker$.html" title="org.apache.pekko.remote.RemoteLogMarker"><code>RemoteLogMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/remote/RemoteLogMarker$.html" title="org.apache.pekko.remote.RemoteLogMar [...]
+  <li>Pekko Cluster Sharding is using the markers defined in <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/sharding/ShardingLogMarker$.html" title="org.apache.pekko.cluster.sharding.ShardingLogMarker"><code>ShardingLogMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/cluster/sharding/ShardingLogMarker$.htm [...]
 </ul>
 <p>Markers and MDC properties are automatically picked up by the <a href="https://github.com/logstash/logstash-logback-encoder">Logstash Logback encoder</a>.</p>
 <p>The marker can be included in the Logback output with <code>%marker</code> and all MDC properties as key-value entries with <code>%mdc</code>.</p>
@@ -1021,10 +1021,10 @@ class MdcActorMixin extends Actor with pekko.actor.DiagnosticActorLogging {
   &lt;/encoder&gt;
 </code></pre>
 <h4><a href="#using-slf4js-markers" name="using-slf4js-markers" class="anchor"><span class="anchor-link"></span></a>Using SLF4J&rsquo;s Markers</h4>
-<p>It is also possible to use the <a href="https://www.javadoc.io/doc/org.slf4j/slf4j-api/latest/org.slf4j/org/slf4j/Marker.html" title="org.slf4j.Marker"><code>org.slf4j.Marker</code></a> with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/LoggingAdapter.html" title="org.apache.pekko.event.LoggingAdapter"><code>LoggingAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+265 [...]
-<p>Since the pekko-actor library avoids depending on any specific logging library, the support for this is included in <code>pekko-slf4j</code>, which provides the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/event/slf4j/Slf4jLogMarker.html" title="org.apache.pekko.event.slf4j.Slf4jLogMarker"><code>Slf4jLogMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/o [...]
+<p>It is also possible to use the <a href="https://www.javadoc.io/doc/org.slf4j/slf4j-api/latest/org.slf4j/org/slf4j/Marker.html" title="org.slf4j.Marker"><code>org.slf4j.Marker</code></a> with the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/LoggingAdapter.html" title="org.apache.pekko.event.LoggingAdapter"><code>LoggingAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/ [...]
+<p>Since the pekko-actor library avoids depending on any specific logging library, the support for this is included in <code>pekko-slf4j</code>, which provides the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/event/slf4j/Slf4jLogMarker.html" title="org.apache.pekko.event.slf4j.Slf4jLogMarker"><code>Slf4jLogMarker</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a [...]
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/logging.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/logging.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -1112,7 +1112,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/mailboxes.html b/content/mailboxes.html
index a36f46d..b487a28 100644
--- a/content/mailboxes.html
+++ b/content/mailboxes.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -421,7 +421,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <p>For the full documentation of this feature and for new projects see <a href="typed/mailboxes.html">mailboxes</a>.</p>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use Mailboxes, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Mailboxes, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -430,7 +430,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -445,42 +445,42 @@ libraryDependencies += "org.apache.pekko" %% "pekko-actor" % PekkoVersion</code>
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-actor_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
 <h2><a href="#introduction" name="introduction" class="anchor"><span class="anchor-link"></span></a>Introduction</h2>
-<p>A Pekko <code>Mailbox</code> holds the messages that are destined for an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span>. Normally each <code>Actor [...]
+<p>A Pekko <code>Mailbox</code> holds the messages that are destined for an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Actor.html" title="org.apache.pekko.actor.Actor"><code>Actor</code></a></span [...]
 <p>For more details on advanced mailbox config and custom mailbox implementations, see <a href="typed/mailboxes.html#mailbox-implementations">Mailboxes</a>.</p>
 <h2><a href="#mailbox-selection" name="mailbox-selection" class="anchor"><span class="anchor-link"></span></a>Mailbox Selection</h2>
 <h3><a href="#default-mailbox" name="default-mailbox" class="anchor"><span class="anchor-link"></span></a>Default Mailbox</h3>
 <p>The default mailbox is used when the mailbox is not specified. This is an unbounded mailbox, backed by a <a href="https://docs.oracle.com/en/java/javase/11/docs/api/java.base/java/util/concurrent/ConcurrentLinkedQueue.html" title="java.util.concurrent.ConcurrentLinkedQueue"><code>java.util.concurrent.ConcurrentLinkedQueue</code></a>.</p>
-<p><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/dispatch/SingleConsumerOnlyUnboundedMailbox.html" title="org.apache.pekko.dispatch.SingleConsumerOnlyUnboundedMailbox"><code>SingleConsumerOnlyUnboundedMailbox</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/dispatch/SingleConsumerOnlyUnboundedMailbox.html" title="org.apache.pekko.dispatch.SingleCo [...]
+<p><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/dispatch/SingleConsumerOnlyUnboundedMailbox.html" title="org.apache.pekko.dispatch.SingleConsumerOnlyUnboundedMailbox"><code>SingleConsumerOnlyUnboundedMailbox</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/dispatch/SingleConsumerOnlyUnboundedMailbox.html" title="org.ap [...]
 <p>Configuration of <code>SingleConsumerOnlyUnboundedMailbox</code> as default mailbox:</p>
 <pre><code>pekko.actor.default-mailbox {
   mailbox-type = &quot;org.apache.pekko.dispatch.SingleConsumerOnlyUnboundedMailbox&quot;
 }
 </code></pre>
 <h3><a href="#requiring-a-message-queue-type-for-an-actor" name="requiring-a-message-queue-type-for-an-actor" class="anchor"><span class="anchor-link"></span></a>Requiring a Message Queue Type for an Actor</h3>
-<p>It is possible to require a certain type of message queue for a certain type of actor by having that actor <span class="group-scala">extend</span><span class="group-java">implement</span> the parameterized <span class="group-scala">trait</span><span class="group-java">interface</span> <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/dispatch/RequiresMessageQueue.html" title="org.apache.pekko.dispatch.RequiresMessageQueue">< [...]
+<p>It is possible to require a certain type of message queue for a certain type of actor by having that actor <span class="group-scala">extend</span><span class="group-java">implement</span> the parameterized <span class="group-scala">trait</span><span class="group-java">interface</span> <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/dispatch/RequiresMessageQueue.html" title="org.apache.pekko.dispatch.RequiresM [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L280-L284" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L280-L284" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.dispatch.RequiresMessageQueue
 import pekko.dispatch.BoundedMessageQueueSemantics
 
 class MyBoundedActor extends MyActor with RequiresMessageQueue[BoundedMessageQueueSemantics]</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/actor/MyBoundedActor.java#L17-L21" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.dispatch.BoundedMessageQueueSemantics;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/actor/MyBoundedActor.java#L17-L21" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.dispatch.BoundedMessageQueueSemantics;
 import org.apache.pekko.dispatch.RequiresMessageQueue;
 
 public class MyBoundedActor extends MyActor
     implements RequiresMessageQueue&lt;BoundedMessageQueueSemantics&gt; {}</code></pre></dd>
 </dl>
 <p>The type parameter to the <code>RequiresMessageQueue</code> <span class="group-scala">trait</span><span class="group-java">interface</span> needs to be mapped to a mailbox in configuration like this:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L203-L206" target="_blank" title="Go to snippet source">source</a><code class="language-scala">bounded-mailbox {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L203-L206" target="_blank" title="Go to snippet source">source</a><code class="language-scala">bounded-mailbox {
   mailbox-type = &quot;org.apache.pekko.dispatch.NonBlockingBoundedMailbox&quot;
   mailbox-capacity = 1000 
 }
@@ -498,10 +498,10 @@ pekko.actor.mailbox.requirements {
 </code></pre>
 <p>The given requirement names a class or interface which will then be ensured to be a supertype of the message queue&rsquo;s implementation. In case of a conflict—e.g. if the actor requires a mailbox type which does not satisfy this requirement—then actor creation will fail.</p>
 <h3><a href="#how-the-mailbox-type-is-selected" name="how-the-mailbox-type-is-selected" class="anchor"><span class="anchor-link"></span></a>How the Mailbox Type is Selected</h3>
-<p>When an actor is created, the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRefProvider.html" title="org.apache.pekko.actor.ActorRefProvider"><code>ActorRefProvider</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRefProvider.html" title="org.apache.pekko.actor.ActorRefProvider"><code>ActorRefProvider</code></a></span> fir [...]
+<p>When an actor is created, the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRefProvider.html" title="org.apache.pekko.actor.ActorRefProvider"><code>ActorRefProvider</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRefProvider.html" title="org.apache.pekko.actor.ActorRefProvider"><code>ActorRefPr [...]
 <ol>
   <li>If the actor&rsquo;s deployment configuration section contains a <code>mailbox</code> key, this refers to a configuration section describing the mailbox type.</li>
-  <li>If the actor&rsquo;s <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span> contains a mailbox selection then that names a configuration section descri [...]
+  <li>If the actor&rsquo;s <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/Props.html" title="org.apache.pekko.actor.Props"><code>Props</code></a></span> contains a mailbox selection then that names a  [...]
   <li>If the dispatcher&rsquo;s configuration section contains a <code>mailbox-type</code> key the same section will be used to configure the mailbox type.</li>
   <li>If the actor requires a mailbox type as described above then the mapping for that requirement will be used to determine the mailbox type to be used; if that fails then the dispatcher&rsquo;s requirement—if any—will be tried instead.</li>
   <li>If the dispatcher requires a mailbox type as described above then the mapping for that requirement will be used to determine the mailbox type to be used.</li>
@@ -513,7 +513,7 @@ pekko.actor.mailbox.requirements {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L242-L264" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L242-L264" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.dispatch.PriorityGenerator
 import pekko.dispatch.UnboundedStablePriorityMailbox
 import com.typesafe.config.Config
@@ -538,7 +538,7 @@ class MyPrioMailbox(settings: ActorSystem.Settings, config: Config)
       })</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L228-L246" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyPrioMailbox extends UnboundedStablePriorityMailbox {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L228-L246" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyPrioMailbox extends UnboundedStablePriorityMailbox {
   // needed for reflective instantiation
   public MyPrioMailbox(ActorSystem.Settings settings, Config config) {
     // Create a new PriorityGenerator, lower prio means more important
@@ -559,7 +559,7 @@ class MyPrioMailbox(settings: ActorSystem.Settings, config: Config)
 }</code></pre></dd>
 </dl>
 <p>And then add it to the configuration:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L172-L175" target="_blank" title="Go to snippet source">source</a><code class="language-scala">prio-dispatcher {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L172-L175" target="_blank" title="Go to snippet source">source</a><code class="language-scala">prio-dispatcher {
   mailbox-type = &quot;docs.dispatcher.DispatcherDocSpec$MyPrioMailbox&quot;
   //Other dispatcher configuration goes here
 }</code></pre>
@@ -567,7 +567,7 @@ class MyPrioMailbox(settings: ActorSystem.Settings, config: Config)
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L379-L409" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>// We create a new Actor that just prints out what it processes
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L379-L409" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>// We create a new Actor that just prints out what it processes
 class Logger extends Actor {
   val log: LoggingAdapter = Logging(context.system, this)
 
@@ -599,7 +599,7 @@ val a = system.actorOf(Props(classOf[Logger], this).withDispatcher(&quot;prio-di
  */</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L133-L177" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>class Demo extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L133-L177" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>class Demo extends AbstractActor {
   LoggingAdapter log = Logging.getLogger(getContext().getSystem(), this);
 
   {
@@ -648,7 +648,7 @@ Logs:
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L187-L190" target="_blank" title="Go to snippet source">source</a><code class="language-scala">prio-mailbox {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L187-L190" target="_blank" title="Go to snippet source">source</a><code class="language-scala">prio-mailbox {
   mailbox-type = &quot;docs.dispatcher.DispatcherDocSpec$MyPrioMailbox&quot;
   //Other mailbox configuration goes here
 }
@@ -660,7 +660,7 @@ pekko.actor.deployment {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L33-L36" target="_blank" title="Go to snippet source">source</a><code class="language-scala">prio-mailbox {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L33-L36" target="_blank" title="Go to snippet source">source</a><code class="language-scala">prio-mailbox {
   mailbox-type = &quot;docs.dispatcher.DispatcherDocSpec$MyPrioMailbox&quot;
   //Other mailbox configuration goes here
 }
@@ -675,45 +675,45 @@ pekko.actor.deployment {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L358-L359" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Props
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L358-L359" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Props
 val myActor = context.actorOf(Props[MyActor](), &quot;priomailboxactor&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L111" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef myActor = system.actorOf(Props.create(MyActor.class), &quot;priomailboxactor&quot;);</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L111" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef myActor = system.actorOf(Props.create(MyActor.class), &quot;priomailboxactor&quot;);</code></pre></dd>
 </dl>
 <p>Or code like this:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L366-L367" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Props
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L366-L367" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.actor.Props
 val myActor = context.actorOf(Props[MyActor]().withMailbox(&quot;prio-mailbox&quot;))</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L119" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef myActor = system.actorOf(Props.create(MyActor.class).withMailbox(&quot;prio-mailbox&quot;));</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L119" target="_blank" title="Go to snippet source">source</a><code class="language-java">ActorRef myActor = system.actorOf(Props.create(MyActor.class).withMailbox(&quot;prio-mailbox&quot;));</code></pre></dd>
 </dl>
 <h3><a href="#controlawaremailbox" name="controlawaremailbox" class="anchor"><span class="anchor-link"></span></a>ControlAwareMailbox</h3>
 <p>A <code>ControlAwareMailbox</code> can be very useful if an actor needs to be able to receive control messages immediately no matter how many other messages are already in its mailbox.</p>
 <p>It can be configured like this:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L233-L236" target="_blank" title="Go to snippet source">source</a><code class="language-scala">control-aware-dispatcher {
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L233-L236" target="_blank" title="Go to snippet source">source</a><code class="language-scala">control-aware-dispatcher {
   mailbox-type = &quot;org.apache.pekko.dispatch.UnboundedControlAwareMailbox&quot;
   //Other dispatcher configuration goes here
 }</code></pre>
-<p>Control messages need to extend the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/dispatch/ControlMessage.html" title="org.apache.pekko.dispatch.ControlMessage"><code>ControlMessage</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/dispatch/ControlMessage.html" title="org.apache.pekko.dispatch.ControlMessage"><code>ControlMessage</code></a></spa [...]
+<p>Control messages need to extend the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/dispatch/ControlMessage.html" title="org.apache.pekko.dispatch.ControlMessage"><code>ControlMessage</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/dispatch/ControlMessage.html" title="org.apache.pekko.dispatch.ControlMessage"><code>Co [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L268-L270" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.dispatch.ControlMessage
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L268-L270" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.dispatch.ControlMessage
 
 case object MyControlMessage extends ControlMessage</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L251" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyControlMessage implements ControlMessage {}</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L251" target="_blank" title="Go to snippet source">source</a><code class="language-java">static class MyControlMessage implements ControlMessage {}</code></pre></dd>
 </dl>
 <p>And then an example on how you would use it:</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L420-L441" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>// We create a new Actor that just prints out what it processes
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/dispatcher/DispatcherDocSpec.scala#L420-L441" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>// We create a new Actor that just prints out what it processes
 class Logger extends Actor {
   val log: LoggingAdapter = Logging(context.system, this)
 
@@ -736,7 +736,7 @@ val a = system.actorOf(Props(classOf[Logger], this).withDispatcher(&quot;control
  */</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L188-L219" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>class Demo extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/dispatcher/DispatcherDocTest.java#L188-L219" target="_blank" title="Go to snippet source">source</a><code class="language-java"><br/>class Demo extends AbstractActor {
   LoggingAdapter log = Logging.getLogger(getContext().getSystem(), this);
 
   {
@@ -769,7 +769,7 @@ Logs:
 */</code></pre></dd>
 </dl>
 <h2><a href="#special-semantics-of-system-actorof" name="special-semantics-of-system-actorof" class="anchor"><span class="anchor-link"></span></a>Special Semantics of <code>system.actorOf</code></h2>
-<p>In order to make <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRefFactory.html#actorOf(props:org.apache.pekko.actor.Props):org.apache.pekko.actor.ActorRef" title="org.apache.pekko.actor.ActorRefFactory"><code>system.actorOf</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/ActorRefFactory.html#actorOf(org.apache.pekko.actor.Prop [...]
+<p>In order to make <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRefFactory.html#actorOf(props:org.apache.pekko.actor.Props):org.apache.pekko.actor.ActorRef" title="org.apache.pekko.actor.ActorRefFactory"><code>system.actorOf</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/ActorRefFactory.html#actorOf [...]
 <dl>
   <dt>Scala</dt>
   <dd>
@@ -788,7 +788,7 @@ assert(MyCustomMailbox.getInstance().getLastEnqueued().equals(&quot;bang&quot;))
 </dl>
 <p>will probably fail; you will have to allow for some time to pass and retry the check à la <span class="group-scala"><a href="https://doc.akka.io/api/akka/2.6/org/apache/pekko/testkit/TestKit.html#awaitCond(p:=%3EBoolean,max:scala.concurrent.duration.Duration,interval:scala.concurrent.duration.Duration,message:String):Unit" title="pekko.testkit.TestKit"><code>TestKit.awaitCond</code></a></span><span class="group-java"><a href="https://doc.akka.io/japi/akka/2.6/org/apache/pekko/testkit/ [...]
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/mailboxes.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/mailboxes.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -875,7 +875,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/multi-jvm-testing.html b/content/multi-jvm-testing.html
index adb7923..e58fbaa 100644
--- a/content/multi-jvm-testing.html
+++ b/content/multi-jvm-testing.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -544,7 +544,7 @@ class SpecMultiJvmNode2 extends AnyWordSpec with Matchers {
 <p><a href="https://developer.lightbend.com/start/?group=akka&amp;project=pekko-samples-cluster-scala">Cluster example project</a> is an example project that can be downloaded, and with instructions of how to run.</p>
 <p>This project illustrates Cluster features and also includes Multi JVM Testing with the <code>sbt-multi-jvm</code> plugin.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/multi-jvm-testing.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/multi-jvm-testing.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -634,7 +634,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/multi-node-testing.html b/content/multi-node-testing.html
index 22c5cba..e3ae0db 100644
--- a/content/multi-node-testing.html
+++ b/content/multi-node-testing.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -418,7 +418,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <div class="small-12 large-9 column" id="docs">
 <h1><a href="#multi-node-testing" name="multi-node-testing" class="anchor"><span class="anchor-link"></span></a>Multi Node Testing</h1>
 <h2><a href="#module-info" name="module-info" class="anchor"><span class="anchor-link"></span></a>Module info</h2>
-<p>To use Multi Node Testing, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Multi Node Testing, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-multi-node-testkit" % PekkoVersion % Test</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -427,7 +427,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-multi-node-testkit" % PekkoV
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -443,7 +443,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-multi-node-testkit" % PekkoV
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   testImplementation "org.apache.pekko:pekko-multi-node-testkit_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -451,7 +451,7 @@ dependencies {
 <tr><th colspan="2">Project Info: Pekko Multi-node Testkit</th></tr>
   <tr><th>Artifact</th><td><div>org.apache.pekko</div>
   <div>pekko-multi-node-testkit</div>
-  <div>0.0.0+26533-ec68a528-SNAPSHOT</div>
+  <div>0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT</div>
   <div><a href="project/links.html#snapshots-repository">Snapshots are available</a></div>
   </td></tr>
   <tr><th>JDK versions</th><td><div>Adopt OpenJDK 8</div><div>Adopt OpenJDK 11</div></td></tr>
@@ -466,11 +466,11 @@ dependencies {
   <div><a href="https://doc.akka.io/japi/akka/snapshot/akka/remote/testkit/package-summary.html" target="_blank" rel="noopener noreferrer">API (Javadoc)</a></div>
   </td></tr>
   <tr><th>Forums</th><td>
-  <div><a href="https://discuss.akka.io" target="_blank" rel="noopener noreferrer">Lightbend Discuss</a></div>
-  <div><a href="https://gitter.im/akka/akka" target="_blank" rel="noopener noreferrer">akka/akka Gitter channel</a></div>
+  <div><a href="https://lists.apache.org/list.html?dev@pekko.apache.org" target="_blank" rel="noopener noreferrer">Apache Pekko Dev mailing list</a></div>
+  <div><a href="https://github.com/apache/incubator-pekko/discussions" target="_blank" rel="noopener noreferrer">apache/incubator-pekko discussion</a></div>
   </td></tr>
   <tr><th>Release notes</th><td><a href="https://akka.io/blog/news-archive.html">akka.io blog</a></td></tr>
-  <tr><th>Issues</th><td><a href="https://github.com/akka/akka/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
+  <tr><th>Issues</th><td><a href="https://github.com/apache/incubator-pekko/issues" target="_blank" rel="noopener noreferrer">Github issues</a></td></tr>
   <tr><th>Sources</th><td><a href="https://github.com/apache/incubator-pekko" target="_blank" rel="noopener noreferrer">https://github.com/apache/incubator-pekko</a></td></tr>
 </table>
 
@@ -480,11 +480,11 @@ dependencies {
 
 <ul>
   <li><a href="multi-node-testing.html#the-test-conductor">The Test Conductor</a>. that coordinates and controls the nodes under test.</li>
-  <li><a href="multi-node-testing.html#the-multi-node-spec">The Multi Node Spec</a>. that is a convenience wrapper for starting the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/remote/testconductor/TestConductor$.html" title="org.apache.pekko.remote.testconductor.TestConductor"><code>TestConductor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/ [...]
+  <li><a href="multi-node-testing.html#the-multi-node-spec">The Multi Node Spec</a>. that is a convenience wrapper for starting the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/remote/testconductor/TestConductor$.html" title="org.apache.pekko.remote.testconductor.TestConductor"><code>TestConductor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-144 [...]
   <li><a href="multi-node-testing.html#the-sbtmultijvm-plugin">The SbtMultiJvm Plugin</a>. that starts tests in multiple JVMs possibly on multiple machines.</li>
 </ul>
 <h2><a href="#the-test-conductor" name="the-test-conductor" class="anchor"><span class="anchor-link"></span></a>The Test Conductor</h2>
-<p>The basis for the multi node testing is the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/remote/testconductor/TestConductor$.html" title="org.apache.pekko.remote.testconductor.TestConductor"><code>TestConductor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/remote/testconductor/TestConductor$.html" title="org.apache.pekko.remote.testconducto [...]
+<p>The basis for the multi node testing is the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/remote/testconductor/TestConductor$.html" title="org.apache.pekko.remote.testconductor.TestConductor"><code>TestConductor</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/remote/testconductor/TestConductor$.html" title="org.apac [...]
 <ul>
   <li>Node Address Lookup: Finding out the full path to another test node (No need to share configuration between test nodes)</li>
   <li>Node Barrier Coordination: Waiting for other nodes at named barriers.</li>
@@ -492,9 +492,9 @@ dependencies {
 </ul>
 <p>This is a schematic overview of the test conductor.</p>
 <p><img src="./images/pekko-remote-testconductor.png" alt="pekko-remote-testconductor.png" /></p>
-<p>The test conductor server is responsible for coordinating barriers and sending commands to the test conductor clients that act upon them, e.g. throttling network traffic to/from another client. More information on the possible operations is available in the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/remote/testconductor/Conductor.html" title="org.apache.pekko.remote.testconductor.Conductor"><code>remote.testconductor. [...]
+<p>The test conductor server is responsible for coordinating barriers and sending commands to the test conductor clients that act upon them, e.g. throttling network traffic to/from another client. More information on the possible operations is available in the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/remote/testconductor/Conductor.html" title="org.apache.pekko.remote.testconductor.Conductor"><code>remote. [...]
 <h2><a href="#the-multi-node-spec" name="the-multi-node-spec" class="anchor"><span class="anchor-link"></span></a>The Multi Node Spec</h2>
-<p>The Multi Node Spec consists of two parts. The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/remote/testkit/MultiNodeConfig.html" title="org.apache.pekko.remote.testkit.MultiNodeConfig"><code>MultiNodeConfig</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/remote/testkit/MultiNodeConfig.html" title="org.apache.pekko.remote.testkit.MultiNodeConf [...]
+<p>The Multi Node Spec consists of two parts. The <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/remote/testkit/MultiNodeConfig.html" title="org.apache.pekko.remote.testkit.MultiNodeConfig"><code>MultiNodeConfig</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/remote/testkit/MultiNodeConfig.html" title="org.apache.pekko. [...]
 <p>The setup of the <code>MultiNodeSpec</code> is configured through java system properties that you set on all JVMs that&rsquo;s going to run a node under test. These can be set on the JVM command line with <code>-Dproperty=value</code>.</p>
 <dl>
   <dt>These are the available properties</dt>
@@ -549,8 +549,8 @@ dependencies {
 </code></pre>
 <p>More than one test name can be listed to run multiple specific tests. Tab completion in sbt makes it easy to complete the test names.</p>
 <h2><a href="#a-multi-node-testing-example" name="a-multi-node-testing-example" class="anchor"><span class="anchor-link"></span></a>A Multi Node Testing Example</h2>
-<p>First we need some scaffolding to hook up the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/remote/testkit/MultiNodeSpec.html" title="org.apache.pekko.remote.testkit.MultiNodeSpec"><code>MultiNodeSpec</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/remote/testkit/MultiNodeSpec.html" title="org.apache.pekko.remote.testkit.MultiNodeSpec"><code>M [...]
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/remote-tests/src/test/scala/org/apache/pekko/remote/testkit/STMultiNodeSpec.scala#L15-L36" target="_blank" title="Go to snippet source">source</a><code class="language-scala">package org.apache.pekko.remote.testkit
+<p>First we need some scaffolding to hook up the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/remote/testkit/MultiNodeSpec.html" title="org.apache.pekko.remote.testkit.MultiNodeSpec"><code>MultiNodeSpec</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/remote/testkit/MultiNodeSpec.html" title="org.apache.pekko.remote.te [...]
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/remote-tests/src/test/scala/org/apache/pekko/remote/testkit/STMultiNodeSpec.scala#L15-L36" target="_blank" title="Go to snippet source">source</a><code class="language-scala">package org.apache.pekko.remote.testkit
 
 import scala.language.implicitConversions
 
@@ -573,7 +573,7 @@ trait STMultiNodeSpec extends MultiNodeSpecCallbacks with AnyWordSpecLike with M
     new WordSpecStringWrapper(s&quot;$s (on node &#39;${self.myself.name}&#39;, $getClass)&quot;)
 }</code></pre>
 <p>Then we need to define a configuration. Lets use two nodes <code>&quot;node1</code> and <code>&quot;node2&quot;</code> and call it <code>MultiNodeSampleConfig</code>.</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/remote-tests/src/multi-jvm/scala/org/apache/pekko/remote/sample/MultiNodeSample.scala#L15-L16" target="_blank" title="Go to snippet source">source</a><code class="language-scala">package org.apache.pekko.remote.sample
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/remote-tests/src/multi-jvm/scala/org/apache/pekko/remote/sample/MultiNodeSample.scala#L15-L16" target="_blank" title="Go to snippet source">source</a><code class="language-scala">package org.apache.pekko.remote.sample
 
 import org.apache.pekko.remote.testkit.{ MultiNodeConfig, STMultiNodeSpec }
 
@@ -582,7 +582,7 @@ object MultiNodeSampleConfig extends MultiNodeConfig {
   val node2 = role(&quot;node2&quot;)
 }</code></pre>
 <p>And then finally to the node test code. That starts the two nodes, and demonstrates a barrier, and a remote actor message send/receive.</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/remote-tests/src/multi-jvm/scala/org/apache/pekko/remote/sample/MultiNodeSample.scala#L15-L16" target="_blank" title="Go to snippet source">source</a><code class="language-scala">package org.apache.pekko.remote.sample
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/remote-tests/src/multi-jvm/scala/org/apache/pekko/remote/sample/MultiNodeSample.scala#L15-L16" target="_blank" title="Go to snippet source">source</a><code class="language-scala">package org.apache.pekko.remote.sample
 
 import org.apache.pekko
 import pekko.actor.{ Actor, Props }
@@ -643,7 +643,7 @@ class MultiNodeSample extends MultiNodeSpec(MultiNodeSampleConfig) with STMultiN
 <h2><a href="#configuration" name="configuration" class="anchor"><span class="anchor-link"></span></a>Configuration</h2>
 <p>There are several configuration properties for the Multi-Node Testing module, please refer to the <a href="general/configuration-reference.html#config-pekko-multi-node-testkit">reference configuration</a>.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/multi-node-testing.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/multi-node-testing.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -733,7 +733,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/paradox.json b/content/paradox.json
index f9cccdc..ca6659d 100644
--- a/content/paradox.json
+++ b/content/paradox.json
@@ -1,4 +1,4 @@
 {
   "name" : "Pekko",
-  "version" : "0.0.0+26533-ec68a528-SNAPSHOT"
+  "version" : "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 }
\ No newline at end of file
diff --git a/content/persistence-fsm.html b/content/persistence-fsm.html
index 65a4c4d..a21cf86 100644
--- a/content/persistence-fsm.html
+++ b/content/persistence-fsm.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -420,7 +420,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h1><a href="#classic-persistent-fsm" name="classic-persistent-fsm" class="anchor"><span class="anchor-link"></span></a>Classic Persistent FSM</h1><div class="callout note "><div class="callout-title">Note</div>
 <p>Pekko Classic pertains to the original Actor APIs, which have been improved by more type safe and guided Actor APIs. Pekko Classic is still fully supported and existing applications can continue to use the classic APIs. It is also possible to use the new Actor APIs together with classic actors in the same ActorSystem, see <a href="typed/coexisting.html">coexistence</a>. For new projects we recommend using <a href="typed/actors.html">the new Actor API</a>.</p></div>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>Persistent FSMs are part of Pekko persistence, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>Persistent FSMs are part of Pekko persistence, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-persistence" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -429,7 +429,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-persistence" % PekkoVersion<
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -444,7 +444,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-persistence" % PekkoVersion<
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-persistence_${versions.ScalaBinary}"
 }</code></pre></dd></dl><div class="callout warning "><div class="callout-title">Warning</div>
@@ -455,14 +455,14 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L447-L451" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sealed trait Command
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L447-L451" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sealed trait Command
 case class AddItem(item: Item) extends Command
 case object Buy extends Command
 case object Leave extends Command
 case object GetCurrentCart extends Command</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L123-L145" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static final class AddItem implements Command {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L123-L145" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static final class AddItem implements Command {
   private final Item item;
 
   public AddItem(Item item) {
@@ -491,7 +491,7 @@ public enum GetCurrentCart implements Command {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L414-L426" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sealed trait UserState extends FSMState
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L414-L426" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sealed trait UserState extends FSMState
 case object LookingAround extends UserState {
   override def identifier: String = &quot;Looking Around&quot;
 }
@@ -506,7 +506,7 @@ case object Paid extends UserState {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L37-L53" target="_blank" title="Go to snippet source">source</a><code class="language-java">enum UserState implements PersistentFSM.FSMState {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L37-L53" target="_blank" title="Go to snippet source">source</a><code class="language-java">enum UserState implements PersistentFSM.FSMState {
   LOOKING_AROUND(&quot;Looking Around&quot;),
   SHOPPING(&quot;Shopping&quot;),
   INACTIVE(&quot;Inactive&quot;),
@@ -530,14 +530,14 @@ case object Paid extends UserState {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L455-L459" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sealed trait DomainEvent
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L455-L459" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sealed trait DomainEvent
 case class ItemAdded(item: Item) extends DomainEvent
 case object OrderExecuted extends DomainEvent
 case object OrderDiscarded extends DomainEvent
 case object CustomerInactive extends DomainEvent</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L151-L169" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static final class ItemAdded implements DomainEvent {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L151-L169" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static final class ItemAdded implements DomainEvent {
   private final Item item;
 
   public ItemAdded(Item item) {
@@ -561,7 +561,7 @@ public enum OrderDiscarded implements DomainEvent {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L430-L443" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case class Item(id: String, name: String, price: Float)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L430-L443" target="_blank" title="Go to snippet source">source</a><code class="language-scala">case class Item(id: String, name: String, price: Float)
 
 sealed trait ShoppingCart {
   def addItem(item: Item): ShoppingCart
@@ -577,7 +577,7 @@ case class NonEmptyShoppingCart(items: Seq[Item]) extends ShoppingCart {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L57-L117" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class ShoppingCart {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L57-L117" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class ShoppingCart {
   private final List&lt;Item&gt; items = new ArrayList&lt;&gt;();
 
   public ShoppingCart(Item initialItem) {
@@ -643,7 +643,7 @@ public static class Item implements Serializable {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L498-L548" target="_blank" title="Go to snippet source">source</a><code class="language-scala">startWith(LookingAround, EmptyShoppingCart)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L498-L548" target="_blank" title="Go to snippet source">source</a><code class="language-scala">startWith(LookingAround, EmptyShoppingCart)
 
 when(LookingAround) {
   case Event(AddItem(item), _) =&gt;
@@ -690,7 +690,7 @@ when(Paid) {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L215-L288" target="_blank" title="Go to snippet source">source</a><code class="language-java">startWith(UserState.LOOKING_AROUND, new ShoppingCart());
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L215-L288" target="_blank" title="Go to snippet source">source</a><code class="language-java">startWith(UserState.LOOKING_AROUND, new ShoppingCart());
 
 when(
     UserState.LOOKING_AROUND,
@@ -763,7 +763,7 @@ when(
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L558-L565" target="_blank" title="Go to snippet source">source</a><code class="language-scala">override def applyEvent(event: DomainEvent, cartBeforeEvent: ShoppingCart): ShoppingCart = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L558-L565" target="_blank" title="Go to snippet source">source</a><code class="language-scala">override def applyEvent(event: DomainEvent, cartBeforeEvent: ShoppingCart): ShoppingCart = {
   event match {
     case ItemAdded(item)  =&gt; cartBeforeEvent.addItem(item)
     case OrderExecuted    =&gt; cartBeforeEvent
@@ -773,7 +773,7 @@ when(
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L299-L311" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L299-L311" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public ShoppingCart applyEvent(DomainEvent event, ShoppingCart currentData) {
   if (event instanceof ItemAdded) {
     currentData.addItem(((ItemAdded) event).getItem());
@@ -791,13 +791,13 @@ public ShoppingCart applyEvent(DomainEvent event, ShoppingCart currentData) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L512-L519" target="_blank" title="Go to snippet source">source</a><code class="language-scala">goto(Paid).applying(OrderExecuted).andThen {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L512-L519" target="_blank" title="Go to snippet source">source</a><code class="language-scala">goto(Paid).applying(OrderExecuted).andThen {
   case NonEmptyShoppingCart(items) =&gt;
     reportActor ! PurchaseWasMade(items)
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L236-L246" target="_blank" title="Go to snippet source">source</a><code class="language-java">(event, data) -&gt;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L236-L246" target="_blank" title="Go to snippet source">source</a><code class="language-java">(event, data) -&gt;
     goTo(UserState.PAID)
         .applying(OrderExecuted.INSTANCE)
         .andThen(
@@ -810,14 +810,14 @@ public ShoppingCart applyEvent(DomainEvent event, ShoppingCart currentData) {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L523-L527" target="_blank" title="Go to snippet source">source</a><code class="language-scala">stop().applying(OrderDiscarded).andThen {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/scala/org/apache/pekko/persistence/fsm/PersistentFSMSpec.scala#L523-L527" target="_blank" title="Go to snippet source">source</a><code class="language-scala">stop().applying(OrderDiscarded).andThen {
   case _ =&gt;
     reportActor ! ShoppingCardDiscarded
     saveStateSnapshot()
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L251-L259" target="_blank" title="Go to snippet source">source</a><code class="language-java">(event, data) -&gt;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/test/java/org/apache/pekko/persistence/fsm/AbstractPersistentFSMTest.java#L251-L259" target="_blank" title="Go to snippet source">source</a><code class="language-java">(event, data) -&gt;
     stop()
         .applying(OrderDiscarded.INSTANCE)
         .andThen(
@@ -829,23 +829,23 @@ public ShoppingCart applyEvent(DomainEvent event, ShoppingCart currentData) {
 </dl>
 <p>On recovery state data is initialized according to the latest available snapshot, then the remaining domain events are replayed, triggering the <code>applyEvent</code> method.</p>
 <h2><a href="#migration-to-eventsourcedbehavior" name="migration-to-eventsourcedbehavior" class="anchor"><span class="anchor-link"></span></a>Migration to EventSourcedBehavior</h2>
-<p>Persistent FSMs can be represented using <a href="typed/persistence.html">Persistence Typed</a>. The data stored by Persistence FSM can be read by an <span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/typed/javadsl/EventSourcedBehavior.html" title="org.apache.pekko.persistence.typed.javadsl.EventSourcedBehavior"><code>EventSourcedBehavior</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/a [...]
+<p>Persistent FSMs can be represented using <a href="typed/persistence.html">Persistence Typed</a>. The data stored by Persistence FSM can be read by an <span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/typed/javadsl/EventSourcedBehavior.html" title="org.apache.pekko.persistence.typed.javadsl.EventSourcedBehavior"><code>EventSourcedBehavior</code></a></span><span class="group-scala"><a href="https://doc [...]
 <p>Before reading the migration guide it is advised to understand <a href="typed/persistence.html">Persistence Typed</a>. </p>
 <h3><a href="#migration-steps" name="migration-steps" class="anchor"><span class="anchor-link"></span></a>Migration steps</h3>
 <ol>
-  <li>Modify or create new commands to include <code>replyTo</code> <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRef"><code>ActorRef</code></a> [...]
+  <li>Modify or create new commands to include <code>replyTo</code> <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRef"><code>ActorRef</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/actor/typed/ActorRef.html" title="org.apache.pekko.actor.typed.ActorRe [...]
   <li>Typically persisted events will remain the same</li>
   <li>Create an <code>EventSourcedBehavior</code> that mimics the old <code>PersistentFSM</code></li>
   <li>Replace any state timeouts with <code>Behaviors.withTimers</code> either hard coded or stored in the state</li>
-  <li>Add an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/typed/EventAdapter.html" title="org.apache.pekko.persistence.typed.EventAdapter"><code>EventAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/typed/EventAdapter.html" title="org.apache.pekko.persistence.typed.EventAdapter"><code>EventAdapter</code></a></span> [...]
-  <li>If snapshots are used add a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/typed/SnapshotAdapter.html" title="org.apache.pekko.persistence.typed.SnapshotAdapter"><code>SnapshotAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/typed/SnapshotAdapter.html" title="org.apache.pekko.persistence.typed.SnapshotAdapter"> [...]
+  <li>Add an <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/typed/EventAdapter.html" title="org.apache.pekko.persistence.typed.EventAdapter"><code>EventAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/typed/EventAdapter.html" title="org.apache.pekko.persistence.typed.EventAdapter"><code>Ev [...]
+  <li>If snapshots are used add a <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/typed/SnapshotAdapter.html" title="org.apache.pekko.persistence.typed.SnapshotAdapter"><code>SnapshotAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/typed/SnapshotAdapter.html" title="org.apache.pekko.persist [...]
 </ol>
 <p>The following is the shopping cart example above converted to an <code>EventSourcedBehavior</code>. </p>
 <p>The new commands, note the replyTo field for getting the current cart.</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L65-L70" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sealed trait Command
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L65-L70" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sealed trait Command
 case class AddItem(item: Item) extends Command
 case object Buy extends Command
 case object Leave extends Command
@@ -853,7 +853,7 @@ case class GetCurrentCart(replyTo: ActorRef[ShoppingCart]) extends Command
 private case object Timeout extends Command</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L29-L57" target="_blank" title="Go to snippet source">source</a><code class="language-java">interface Command {}
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L29-L57" target="_blank" title="Go to snippet source">source</a><code class="language-java">interface Command {}
 
 public static class AddItem implements Command {
   public final Item item;
@@ -887,14 +887,14 @@ private enum Timeout implements Command {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L74-L78" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sealed trait State
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L74-L78" target="_blank" title="Go to snippet source">source</a><code class="language-scala">sealed trait State
 case class LookingAround(cart: ShoppingCart) extends State
 case class Shopping(cart: ShoppingCart) extends State
 case class Inactive(cart: ShoppingCart) extends State
 case class Paid(cart: ShoppingCart) extends State</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L61-L91" target="_blank" title="Go to snippet source">source</a><code class="language-java">abstract static class State {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L61-L91" target="_blank" title="Go to snippet source">source</a><code class="language-java">abstract static class State {
   public final ShoppingCart cart;
 
   protected State(ShoppingCart cart) {
@@ -930,7 +930,7 @@ public static class Paid extends State {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L119-L164" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def commandHandler(timers: TimerScheduler[Command])(state: State, command: Command [...]
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L119-L164" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def commandHandler(timers: TimerScheduler[Command])(state: State, com [...]
   state match {
     case LookingAround(cart) =&gt;
       command match {
@@ -978,7 +978,7 @@ public static class Paid extends State {
   }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L144-L164" target="_blank" title="Go to snippet source">source</a><code class="language-java">  CommandHandlerBuilder&lt;Command, DomainEvent, State&gt; builder = newC [...]
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L144-L164" target="_blank" title="Go to snippet source">source</a><code class="language-java">  CommandHandlerBuilder&lt;Command, DomainEvent, State&gt; b [...]
 
   builder.forStateType(LookingAround.class).onCommand(AddItem.class, this::addItem);
 
@@ -1004,7 +1004,7 @@ public static class Paid extends State {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L203-L210" target="_blank" title="Go to snippet source">source</a><code class="language-scala">.receiveSignal {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L203-L210" target="_blank" title="Go to snippet source">source</a><code class="language-scala">.receiveSignal {
   case (state, RecoveryCompleted) =&gt;
     state match {
       case _: Shopping | _: Inactive =&gt;
@@ -1014,7 +1014,7 @@ public static class Paid extends State {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L227-L238" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L227-L238" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public SignalHandler&lt;State&gt; signalHandler() {
   return newSignalHandlerBuilder()
       .onSignal(
@@ -1031,7 +1031,7 @@ public SignalHandler&lt;State&gt; signalHandler() {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L168-L190" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def eventHandler(state: State, event: DomainEvent): State = {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L168-L190" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def eventHandler(state: State, event: DomainEvent): State = {
   state match {
     case la @ LookingAround(cart) =&gt;
       event match {
@@ -1056,7 +1056,7 @@ public SignalHandler&lt;State&gt; signalHandler() {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L195-L218" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L195-L218" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public EventHandler&lt;State, DomainEvent&gt; eventHandler() {
   EventHandlerBuilder&lt;State, DomainEvent&gt; eventHandlerBuilder = newEventHandlerBuilder();
 
@@ -1081,11 +1081,11 @@ public EventHandler&lt;State, DomainEvent&gt; eventHandler() {
   return eventHandlerBuilder.build();
 }</code></pre></dd>
 </dl>
-<p>The last step is the adapters that will allow the new <span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/typed/javadsl/EventSourcedBehavior.html" title="org.apache.pekko.persistence.typed.javadsl.EventSourcedBehavior"><code>EventSourcedBehavior</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/typed/scaladsl/EventSourcedBehavi [...]
+<p>The last step is the adapters that will allow the new <span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/typed/javadsl/EventSourcedBehavior.html" title="org.apache.pekko.persistence.typed.javadsl.EventSourcedBehavior"><code>EventSourcedBehavior</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/typed [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L96-L113" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class PersistentFsmEventAdapter extends EventAdapter[DomainEvent, Any] {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L96-L113" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class PersistentFsmEventAdapter extends EventAdapter[DomainEvent, Any] {
   override def toJournal(e: DomainEvent): Any = e
   override def manifest(event: DomainEvent): String = &quot;&quot;
   override def fromJournal(journalEvent: Any, manifest: String): EventSeq[DomainEvent] = {
@@ -1105,7 +1105,7 @@ public EventHandler&lt;State, DomainEvent&gt; eventHandler() {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L95-L122" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class PersistentFSMEventAdapter extends EventAdapter&lt;Doma [...]
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L95-L122" target="_blank" title="Go to snippet source">source</a><code class="language-java">public static class PersistentFSMEventAdapter extends EventAd [...]
 
   @Override
   public Object toJournal(DomainEvent domainEvent) {
@@ -1134,11 +1134,11 @@ public EventHandler&lt;State, DomainEvent&gt; eventHandler() {
     }
   }</code></pre></dd>
 </dl>
-<p>The snapshot adapter needs to adapt an internal type of PersistentFSM so a helper function is provided to build the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/typed/SnapshotAdapter.html" title="org.apache.pekko.persistence.typed.SnapshotAdapter"><code>SnapshotAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/ty [...]
+<p>The snapshot adapter needs to adapt an internal type of PersistentFSM so a helper function is provided to build the <span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/typed/SnapshotAdapter.html" title="org.apache.pekko.persistence.typed.SnapshotAdapter"><code>SnapshotAdapter</code></a></span><span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org [...]
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L82-L92" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val persistentFSMSnapshotAdapter: SnapshotAdapter[State] = PersistentFSMMigration.sn [...]
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/scala/docs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationSpec.scala#L82-L92" target="_blank" title="Go to snippet source">source</a><code class="language-scala">val persistentFSMSnapshotAdapter: SnapshotAdapter[State] = PersistentFS [...]
   case (stateIdentifier, data, _) =&gt;
     val cart = data.asInstanceOf[ShoppingCart]
     stateIdentifier match {
@@ -1151,7 +1151,7 @@ public EventHandler&lt;State, DomainEvent&gt; eventHandler() {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L242-L260" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence-typed/src/test/java/jdocs/org/apache/pekko/persistence/typed/PersistentFsmToTypedMigrationCompileOnlyTest.java#L242-L260" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public SnapshotAdapter&lt;State&gt; snapshotAdapter() {
   return PersistentFSMMigration.snapshotAdapter(
       (stateIdentifier, snapshot, timeout) -&gt; {
@@ -1171,10 +1171,10 @@ public SnapshotAdapter&lt;State&gt; snapshotAdapter() {
       });
 }</code></pre></dd>
 </dl>
-<p>That concludes all the steps to allow an <span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/typed/javadsl/EventSourcedBehavior.html" title="org.apache.pekko.persistence.typed.javadsl.EventSourcedBehavior"><code>EventSourcedBehavior</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528-SNAPSHOT/org/apache/pekko/persistence/typed/scaladsl/EventSourcedBehavior.html" titl [...]
+<p>That concludes all the steps to allow an <span class="group-java"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/typed/javadsl/EventSourcedBehavior.html" title="org.apache.pekko.persistence.typed.javadsl.EventSourcedBehavior"><code>EventSourcedBehavior</code></a></span><span class="group-scala"><a href="https://doc.akka.io/api/akka/0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT/org/apache/pekko/persistence/typed/scaladsl/Eve [...]
 <p>There is one case where <a href="additional/rolling-updates.html#migrating-from-persistentfsm-to-eventsourcedbehavior">a full shutdown and startup is required</a>.</p></div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/persistence-fsm.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/persistence-fsm.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -1258,7 +1258,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/persistence-journals.html b/content/persistence-journals.html
index 6abcd7a..36f05b0 100644
--- a/content/persistence-journals.html
+++ b/content/persistence-journals.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -422,14 +422,14 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L27-L31" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L27-L31" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.persistence._
 import pekko.persistence.journal._
 import pekko.persistence.snapshot._
 </code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.dispatch.Futures;
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L17-L20" target="_blank" title="Go to snippet source">source</a><code class="language-java">import org.apache.pekko.dispatch.Futures;
 import org.apache.pekko.persistence.*;
 import org.apache.pekko.persistence.journal.japi.*;
 import org.apache.pekko.persistence.snapshot.japi.*;</code></pre></dd>
@@ -440,7 +440,7 @@ import org.apache.pekko.persistence.snapshot.japi.*;</code></pre></dd>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/main/scala/org/apache/pekko/persistence/journal/AsyncWriteJournal.scala#L212-L297" target="_blank" title="Go to snippet source">source</a><code class="language-scala">/**
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/main/scala/org/apache/pekko/persistence/journal/AsyncWriteJournal.scala#L212-L297" target="_blank" title="Go to snippet source">source</a><code class="language-scala">/**
  * Plugin API: asynchronously writes a batch (`Seq`) of persistent messages to the
  * journal.
  *
@@ -528,7 +528,7 @@ def asyncDeleteMessagesTo(persistenceId: String, toSequenceNr: Long): Future[Uni
 def receivePluginInternal: Actor.Receive = Actor.emptyBehavior</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/main/java/org/apache/pekko/persistence/journal/japi/AsyncWritePlugin.java#L24-L85" target="_blank" title="Go to snippet source">source</a><code class="language-java">/**
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/main/java/org/apache/pekko/persistence/journal/japi/AsyncWritePlugin.java#L24-L85" target="_blank" title="Go to snippet source">source</a><code class="language-java">/**
  * Java API, Plugin API: asynchronously writes a batch (`Iterable`) of persistent messages to the
  * journal.
  *
@@ -595,14 +595,14 @@ Future&lt;Void&gt; doAsyncDeleteMessagesTo(String persistenceId, long toSequence
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L167-L171" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def asyncWriteMessages(messages: immutable.Seq[AtomicWrite]): Future[immutable.Seq[Try[Unit]]] =
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L167-L171" target="_blank" title="Go to snippet source">source</a><code class="language-scala">def asyncWriteMessages(messages: immutable.Seq[AtomicWrite]): Future[immutable.Seq[Try[Unit]]] =
   Future.fromTry(Try {
     // blocking call here
     ???
   })</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L107-L118" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L107-L118" target="_blank" title="Go to snippet source">source</a><code class="language-java">@Override
 public Future&lt;Iterable&lt;Optional&lt;Exception&gt;&gt;&gt; doAsyncWriteMessages(
     Iterable&lt;AtomicWrite&gt; messages) {
   try {
@@ -619,7 +619,7 @@ public Future&lt;Iterable&lt;Optional&lt;Exception&gt;&gt;&gt; doAsyncWriteMessa
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/main/scala/org/apache/pekko/persistence/journal/AsyncRecovery.scala#L26-L80" target="_blank" title="Go to snippet source">source</a><code class="language-scala">/**
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/main/scala/org/apache/pekko/persistence/journal/AsyncRecovery.scala#L26-L80" target="_blank" title="Go to snippet source">source</a><code class="language-scala">/**
  * Plugin API: asynchronously replays persistent messages. Implementations replay
  * a message by calling `replayCallback`. The returned future must be completed
  * when all messages (matching the sequence number bounds) have been replayed.
@@ -676,7 +676,7 @@ def asyncReplayMessages(persistenceId: String, fromSequenceNr: Long, toSequenceN
 def asyncReadHighestSequenceNr(persistenceId: String, fromSequenceNr: Long): Future[Long]</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/main/java/org/apache/pekko/persistence/journal/japi/AsyncRecoveryPlugin.java#L24-L60" target="_blank" title="Go to snippet source">source</a><code class="language-java">/**
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/main/java/org/apache/pekko/persistence/journal/japi/AsyncRecoveryPlugin.java#L24-L60" target="_blank" title="Go to snippet source">source</a><code class="language-java">/**
  * Java API, Plugin API: asynchronously replays persistent messages. Implementations replay a
  * message by calling `replayCallback`. The returned future must be completed when all messages
  * (matching the sequence number bounds) have been replayed. The future must be completed with a
@@ -715,7 +715,7 @@ Future&lt;Void&gt; doAsyncReplayMessages(
 Future&lt;Long&gt; doAsyncReadHighestSequenceNr(String persistenceId, long fromSequenceNr);</code></pre></dd>
 </dl>
 <p>A journal plugin can be activated with the following minimal configuration:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L79-L88" target="_blank" title="Go to snippet source">source</a><code class="language-scala"># Path to the journal plugin to be used
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L79-L88" target="_blank" title="Go to snippet source">source</a><code class="language-scala"># Path to the journal plugin to be used
 pekko.persistence.journal.plugin = &quot;my-journal&quot;
 
 # My custom journal plugin
@@ -740,7 +740,7 @@ my-journal {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/main/scala/org/apache/pekko/persistence/snapshot/SnapshotStore.scala#L137-L188" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>/**
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/main/scala/org/apache/pekko/persistence/snapshot/SnapshotStore.scala#L137-L188" target="_blank" title="Go to snippet source">source</a><code class="language-scala"><br/>/**
  * Plugin API: asynchronously loads a snapshot.
  *
  * If the future `Option` is `None` then all events will be replayed,
@@ -793,7 +793,7 @@ def deleteAsync(persistenceId: String, criteria: SnapshotSelectionCriteria): Fut
 def receivePluginInternal: Actor.Receive = Actor.emptyBehavior</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/persistence/src/main/java/org/apache/pekko/persistence/snapshot/japi/SnapshotStorePlugin.java#L25-L55" target="_blank" title="Go to snippet source">source</a><code class="language-java">/**
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/persistence/src/main/java/org/apache/pekko/persistence/snapshot/japi/SnapshotStorePlugin.java#L25-L55" target="_blank" title="Go to snippet source">source</a><code class="language-java">/**
  * Java API, Plugin API: asynchronously loads a snapshot.
  *
  * @param persistenceId id of the persistent actor.
@@ -826,7 +826,7 @@ Future&lt;Void&gt; doDeleteAsync(SnapshotMetadata metadata);
 Future&lt;Void&gt; doDeleteAsync(String persistenceId, SnapshotSelectionCriteria criteria);</code></pre></dd>
 </dl>
 <p>A snapshot store plugin can be activated with the following minimal configuration:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L92-L101" target="_blank" title="Go to snippet source">source</a><code class="language-scala"># Path to the snapshot store plugin to be used
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L92-L101" target="_blank" title="Go to snippet source">source</a><code class="language-scala"># Path to the snapshot store plugin to be used
 pekko.persistence.snapshot-store.plugin = &quot;my-snapshot-store&quot;
 
 # My custom snapshot store plugin
@@ -848,7 +848,7 @@ my-snapshot-store {
 <p>Don&rsquo;t run snapshot store tasks/futures on the system default dispatcher, since that might starve other tasks.</p>
 <h2><a href="#plugin-tck" name="plugin-tck" class="anchor"><span class="anchor-link"></span></a>Plugin TCK</h2>
 <p>In order to help developers build correct and high quality storage plugins, we provide a Technology Compatibility Kit (<a href="https://en.wikipedia.org/wiki/Technology_Compatibility_Kit">TCK</a> for short).</p>
-<p>The TCK is usable from Java as well as Scala projects. To test your implementation (independently of language) you need to include the pekko-persistence-tck dependency:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>The TCK is usable from Java as well as Scala projects. To test your implementation (independently of language) you need to include the pekko-persistence-tck dependency:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-persistence-tck" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -857,7 +857,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-persistence-tck" % PekkoVers
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -872,7 +872,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-persistence-tck" % PekkoVers
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-persistence-tck_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -880,7 +880,7 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L198-L207" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class MyJournalSpec
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L198-L207" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class MyJournalSpec
     extends JournalSpec(
       config = ConfigFactory.parseString(&quot;&quot;&quot;pekko.persistence.journal.plugin = &quot;my.journal.plugin&quot;&quot;&quot;&quot;)) {
 
@@ -892,7 +892,7 @@ dependencies {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L145-L159" target="_blank" title="Go to snippet source">source</a><code class="language-java">@RunWith(JUnitRunner.class)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L145-L159" target="_blank" title="Go to snippet source">source</a><code class="language-java">@RunWith(JUnitRunner.class)
 class MyJournalSpecTest extends JavaJournalSpec {
 
   public MyJournalSpecTest() {
@@ -914,7 +914,7 @@ class MyJournalSpecTest extends JavaJournalSpec {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L214-L222" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class MySnapshotStoreSpec
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L214-L222" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class MySnapshotStoreSpec
     extends SnapshotStoreSpec(
       config = ConfigFactory.parseString(&quot;&quot;&quot;
     pekko.persistence.snapshot-store.plugin = &quot;my.snapshot-store.plugin&quot;
@@ -925,7 +925,7 @@ class MyJournalSpecTest extends JavaJournalSpec {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L166-L175" target="_blank" title="Go to snippet source">source</a><code class="language-java">@RunWith(JUnitRunner.class)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L166-L175" target="_blank" title="Go to snippet source">source</a><code class="language-java">@RunWith(JUnitRunner.class)
 class MySnapshotStoreTest extends JavaSnapshotStoreSpec {
 
   public MySnapshotStoreTest() {
@@ -940,7 +940,7 @@ class MySnapshotStoreTest extends JavaSnapshotStoreSpec {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L232-L254" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class MyJournalSpec
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L232-L254" target="_blank" title="Go to snippet source">source</a><code class="language-scala">class MyJournalSpec
     extends JournalSpec(config = ConfigFactory.parseString(&quot;&quot;&quot;
     pekko.persistence.journal.plugin = &quot;my.journal.plugin&quot;
     &quot;&quot;&quot;)) {
@@ -965,7 +965,7 @@ class MySnapshotStoreTest extends JavaSnapshotStoreSpec {
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L183-L221" target="_blank" title="Go to snippet source">source</a><code class="language-java">@RunWith(JUnitRunner.class)
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L183-L221" target="_blank" title="Go to snippet source">source</a><code class="language-java">@RunWith(JUnitRunner.class)
 class MyJournalSpecTest extends JavaJournalSpec {
 
   List&lt;File&gt; storageLocations = new ArrayList&lt;File&gt;();
@@ -1010,7 +1010,7 @@ class MyJournalSpecTest extends JavaJournalSpec {
 <p>If a journal can&rsquo;t prevent users from running persistent actors with the same <code>persistenceId</code> concurrently it is likely that an event log will be corrupted by having events with the same sequence number.</p>
 <p>It is recommended that journals should still deliver these events during recovery so that a <code>replay-filter</code> can be used to decide what to do about it in a journal agnostic way.</p>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/persistence-journals.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/persistence-journals.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -1096,7 +1096,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/persistence-plugins.html b/content/persistence-plugins.html
index af61aec..1a4e225 100644
--- a/content/persistence-plugins.html
+++ b/content/persistence-plugins.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -468,7 +468,7 @@ pekko.persistence.state.plugin = &quot;&quot;
 <p>The LevelDB plugin cannot be used in an Pekko Cluster since the storage is in a local file system.</p></div>
 <p>The LevelDB journal is deprecated and it is not advised to build new applications with it. As a replacement we recommend using <a href="https://doc.akka.io/docs/akka-persistence-jdbc/current/index.html">Pekko Persistence JDBC</a>.</p>
 <p>The LevelDB journal plugin config entry is <code>pekko.persistence.journal.leveldb</code>. Enable this plugin by defining config property:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L38-L39" target="_blank" title="Go to snippet source">source</a><code class="language-scala"># Path to the journal plugin to be used
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L38-L39" target="_blank" title="Go to snippet source">source</a><code class="language-scala"># Path to the journal plugin to be used
 pekko.persistence.journal.plugin = &quot;pekko.persistence.journal.leveldb&quot;</code></pre>
 <p>LevelDB based plugins will also require the following additional dependency declaration:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">libraryDependencies += "org.fusesource.leveldbjni" % "leveldbjni-all" % "1.8"</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;dependencies&gt
   &lt;dependency&gt;
@@ -480,10 +480,10 @@ pekko.persistence.journal.plugin = &quot;pekko.persistence.journal.leveldb&quot;
   implementation "org.fusesource.leveldbjni:leveldbjni-all:1.8"
 }</code></pre></dd></dl>
 <p>The default location of LevelDB files is a directory named <code>journal</code> in the current working directory. This location can be changed by configuration where the specified path can be relative or absolute:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L51" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.persistence.journal.leveldb.dir = &quot;target/journal&quot;</code></pre>
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L51" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.persistence.journal.leveldb.dir = &quot;target/journal&quot;</code></pre>
 <p>With this plugin, each actor system runs its own private LevelDB instance.</p>
 <p>One peculiarity of LevelDB is that the deletion operation does not remove messages from the journal, but adds a &ldquo;tombstone&rdquo; for each deleted message instead. In the case of heavy journal usage, especially one including frequent deletes, this may be an issue as users may find themselves dealing with continuously increasing journal sizes. To this end, LevelDB offers a special journal compaction function that is exposed via the following configuration:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L61-L69" target="_blank" title="Go to snippet source">source</a><code class="language-scala"># Number of deleted messages per persistence id that will trigger journal compaction
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L61-L69" target="_blank" title="Go to snippet source">source</a><code class="language-scala"># Number of deleted messages per persistence id that will trigger journal compaction
 pekko.persistence.journal.leveldb.compaction-intervals {
   persistence-id-1 = 100
   persistence-id-2 = 200
@@ -499,22 +499,22 @@ pekko.persistence.journal.leveldb.compaction-intervals {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L158-L160" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.persistence.journal.leveldb.SharedLeveldbStore
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L158-L160" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko.persistence.journal.leveldb.SharedLeveldbStore
 
 val store = system.actorOf(Props[SharedLeveldbStore](), &quot;store&quot;)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L49" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef store = system.actorOf(Props.create(SharedLeveldbStore.class), &quot;store&quot;);</code></pre></dd>
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L49" target="_blank" title="Go to snippet source">source</a><code class="language-java">final ActorRef store = system.actorOf(Props.create(SharedLeveldbStore.class), &quot;store&quot;);</code></pre></dd>
 </dl>
 <p>By default, the shared instance writes journaled messages to a local directory named <code>journal</code> in the current working directory. The storage location can be changed by configuration:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L131" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.persistence.journal.leveldb-shared.store.dir = &quot;target/shared&quot;</code></pre>
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L131" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.persistence.journal.leveldb-shared.store.dir = &quot;target/shared&quot;</code></pre>
 <p>Actor systems that use a shared LevelDB store must activate the <code>pekko.persistence.journal.leveldb-shared</code> plugin.</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L125" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.persistence.journal.plugin = &quot;pekko.persistence.journal.leveldb-shared&quot;</code></pre>
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L125" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.persistence.journal.plugin = &quot;pekko.persistence.journal.leveldb-shared&quot;</code></pre>
 <p>This plugin must be initialized by injecting the (remote) <code>SharedLeveldbStore</code> actor reference. Injection is done by calling the <code>SharedLeveldbJournal.setStore</code> method with the actor reference as argument.</p>
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L139-L148" target="_blank" title="Go to snippet source">source</a><code class="language-scala">trait SharedStoreUsage extends Actor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L139-L148" target="_blank" title="Go to snippet source">source</a><code class="language-scala">trait SharedStoreUsage extends Actor {
   override def preStart(): Unit = {
     context.actorSelection(&quot;pekko://example@127.0.0.1:2552/user/store&quot;) ! Identify(1)
   }
@@ -526,7 +526,7 @@ val store = system.actorOf(Props[SharedLeveldbStore](), &quot;store&quot;)</code
 }</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L53-L78" target="_blank" title="Go to snippet source">source</a><code class="language-java">class SharedStorageUsage extends AbstractActor {
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/java/jdocs/persistence/LambdaPersistencePluginDocTest.java#L53-L78" target="_blank" title="Go to snippet source">source</a><code class="language-java">class SharedStorageUsage extends AbstractActor {
   @Override
   public void preStart() throws Exception {
     String path = &quot;pekko://example@127.0.0.1:2552/user/store&quot;;
@@ -558,10 +558,10 @@ val store = system.actorOf(Props[SharedLeveldbStore](), &quot;store&quot;)</code
 <p>This plugin writes snapshot files to the local filesystem.</p><div class="callout warning "><div class="callout-title">Warning</div>
 <p>The local snapshot store plugin cannot be used in an Pekko Cluster since the storage is in a local file system.</p></div>
 <p>The local snapshot store plugin config entry is <code>pekko.persistence.snapshot-store.local</code>. Enable this plugin by defining config property:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L43-L44" target="_blank" title="Go to snippet source">source</a><code class="language-scala"># Path to the snapshot store plugin to be used
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L43-L44" target="_blank" title="Go to snippet source">source</a><code class="language-scala"># Path to the snapshot store plugin to be used
 pekko.persistence.snapshot-store.plugin = &quot;pekko.persistence.snapshot-store.local&quot;</code></pre>
 <p>The default storage location is a directory named <code>snapshots</code> in the current working directory. This can be changed by configuration where the specified path can be relative or absolute:</p>
-<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L54" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.persistence.snapshot-store.local.dir = &quot;target/snapshots&quot;</code></pre>
+<pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/PersistencePluginDocSpec.scala#L54" target="_blank" title="Go to snippet source">source</a><code class="language-scala">pekko.persistence.snapshot-store.local.dir = &quot;target/snapshots&quot;</code></pre>
 <p>Note that it is not mandatory to specify a snapshot store plugin. If you don&rsquo;t use snapshots you don&rsquo;t have to configure it.</p>
 <h3><a href="#persistence-plugin-proxy" name="persistence-plugin-proxy" class="anchor"><span class="anchor-link"></span></a>Persistence Plugin Proxy</h3>
 <p>For testing purposes a persistence plugin proxy allows sharing of a journal and snapshot store on a single node across multiple actor systems (on the same or on different nodes). This, for example, allows persistent actors to failover to a backup node and continue using the shared journal instance from the backup node. The proxy works by forwarding all the journal/snapshot store messages to a single, shared, persistence plugin instance, and therefore supports any use case supported by [...]
@@ -570,7 +570,7 @@ pekko.persistence.snapshot-store.plugin = &quot;pekko.persistence.snapshot-store
 <p>Pekko starts extensions lazily when they are required, and this includes the proxy. This means that in order for the proxy to work, the persistence plugin on the target node must be instantiated. This can be done by instantiating the <code>PersistencePluginProxyExtension</code> <a href="extending-pekko.html">extension</a>, or by calling the <code>PersistencePluginProxy.start</code> method.</p></div><div class="callout note "><div class="callout-title">Note</div>
 <p>The proxied persistence plugin can (and should) be configured using its original configuration keys.</p></div>
 <div class="source-github">
-The source code for this page can be found <a href="https://github.com/akka/akka/tree/main/docs/src/main/paradox/persistence-plugins.md">here</a>.
+The source code for this page can be found <a href="https://github.com/apache/incubator-pekko/tree/main/docs/src/main/paradox/persistence-plugins.md">here</a>.
 </div>
 
 <div class="nav-next">
@@ -654,7 +654,7 @@ The source code for this page can be found <a href="https://github.com/akka/akka
 <script type="text/javascript" src="lib/prettify/prettify.js"></script>
 <script type="text/javascript" src="lib/prettify/lang-scala.js"></script>
 <script type="text/javascript">jQuery(function(){window.prettyPrint && prettyPrint()});</script>
-<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528-SNAPSHOT', 'https://akka.io/')});</script>
+<script type="text/javascript">jQuery(function(jq){initOldVersionWarnings(jq, '0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT', 'https://akka.io/')});</script>
 
 
 </html>
diff --git a/content/persistence-query-leveldb.html b/content/persistence-query-leveldb.html
index 47495bf..051537e 100644
--- a/content/persistence-query-leveldb.html
+++ b/content/persistence-query-leveldb.html
@@ -32,7 +32,7 @@
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -227,7 +227,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <span class="home-icon">⌂</span>Pekko Documentation
 </a>
 <div class="version-number">
-0.0.0+26533-ec68a528*
+0.0.0+26533-ec68a528+20230119-1442*
 </div>
 </div>
 <select class="supergroup" name="Language"><option class="group" value="group-scala">Scala</option><option class="group" value="group-java">Java</option></select>
@@ -419,7 +419,7 @@ C16.952,7,17,6.553,17,6c0-0.553-0.048-1-0.6-1H3.6C3.048,5,3,5.447,3,6C3,6.553,3.
 <h1><a href="#persistence-query-for-leveldb" name="persistence-query-for-leveldb" class="anchor"><span class="anchor-link"></span></a>Persistence Query for LevelDB</h1>
 <p>The LevelDB journal and query plugin is deprecated and it is not advised to build new applications with it. As a replacement we recommend using <a href="https://doc.akka.io/docs/akka-persistence-jdbc/current/index.html">Pekko Persistence JDBC</a>.</p>
 <h2><a href="#dependency" name="dependency" class="anchor"><span class="anchor-link"></span></a>Dependency</h2>
-<p>To use Persistence Query, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528-SNAPSHOT"
+<p>To use Persistence Query, you must add the following dependency in your project:</p><dl class="dependency"><dt>sbt</dt><dd><pre class="prettyprint"><code class="language-scala">val PekkoVersion = "0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT"
 libraryDependencies += "org.apache.pekko" %% "pekko-persistence-query" % PekkoVersion</code></pre></dd><dt>Maven</dt><dd><pre class="prettyprint"><code class="language-xml">&lt;properties&gt;
   &lt;scala.binary.version&gt;2.13&lt;/scala.binary.version&gt;
 &lt;/properties&gt;
@@ -428,7 +428,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-persistence-query" % PekkoVe
     &lt;dependency&gt;
       &lt;groupId&gt;org.apache.pekko&lt;/groupId&gt;
       &lt;artifactId&gt;pekko-bom_${scala.binary.version}&lt;/artifactId&gt;
-      &lt;version&gt;0.0.0+26533-ec68a528-SNAPSHOT&lt;/version&gt;
+      &lt;version&gt;0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT&lt;/version&gt;
       &lt;type&gt;pom&lt;/type&gt;
       &lt;scope&gt;import&lt;/scope&gt;
     &lt;/dependency&gt
@@ -443,7 +443,7 @@ libraryDependencies += "org.apache.pekko" %% "pekko-persistence-query" % PekkoVe
   ScalaBinary: "2.13"
 ]
 dependencies {
-  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528-SNAPSHOT")
+  implementation platform("org.apache.pekko:pekko-bom_${versions.ScalaBinary}:0.0.0+26533-ec68a528+20230119-1442-SNAPSHOT")
 
   implementation "org.apache.pekko:pekko-persistence-query_${versions.ScalaBinary}"
 }</code></pre></dd></dl>
@@ -455,14 +455,14 @@ dependencies {
 <dl>
   <dt>Scala</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/scala/docs/persistence/query/LeveldbPersistenceQueryDocSpec.scala#L51-L55" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
+  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/apache/incubator-pekko/tree/main/docs/src/test/scala/docs/persistence/query/LeveldbPersistenceQueryDocSpec.scala#L51-L55" target="_blank" title="Go to snippet source">source</a><code class="language-scala">import org.apache.pekko
 import pekko.persistence.query.PersistenceQuery
 import pekko.persistence.query.journal.leveldb.scaladsl.LeveldbReadJournal
 
 val queries = PersistenceQuery(system).readJournalFor[LeveldbReadJournal](LeveldbReadJournal.Identifier)</code></pre></dd>
   <dt>Java</dt>
   <dd>
-  <pre class="prettyprint"><button class="snippet-button copy-snippet" title="Copy snippet to clipboard">copy</button><a class="snippet-button go-to-source" href="https://github.com/akka/akka/tree/main/docs/src/test/java/jdocs/persistence/query/LeveldbPersistenceQueryDocTest.java#L35-L37" target="_blank" title="Go to snippet source">source</a><code class="language-java">LeveldbReadJournal queries =
... 35822 lines suppressed ...


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