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/31 11:43:26 UTC

[incubator-pekko-site] branch asf-site updated (5cbae17e -> a4bd7fe8)

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

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


 discard 5cbae17e Update README.md
 discard eee0d058 javadoc
 discard 60ca72a6 add scala doc
     add b29b4a04 add scala doc
     add 4551a6f7 javadoc
     add 29222c8f Update README.md
     add a4bd7fe8 latest docs

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (5cbae17e)
            \
             N -- N -- N   refs/heads/asf-site (a4bd7fe8)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

No new revisions were added by this update.

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


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