Skip to content

Commit

Permalink
update more akka refs to use pekko name (apache#200)
Browse files Browse the repository at this point in the history
  • Loading branch information
pjfanning authored Feb 17, 2023
1 parent 79b0189 commit c32fcf1
Show file tree
Hide file tree
Showing 69 changed files with 139 additions and 137 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -27,7 +27,7 @@ import pekko.testkit.TestKit

class DispatcherShutdownSpec extends AnyWordSpec with Matchers {

"akka dispatcher" should {
"pekko dispatcher" should {

"eventually shutdown when used after system terminate" in {

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -73,7 +73,7 @@ object Terminated {
* once. Registration does not need to happen before the Actor terminates, a
* notification is guaranteed to arrive after both registration and termination
* have occurred. This message is also sent when the watched actor is on a node
* that has been removed from the cluster when using Akka Cluster.
* that has been removed from the cluster when using Pekko Cluster.
*
* @param ref Scala API: the `ActorRef` for the terminated actor
*/
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -180,7 +180,7 @@ trait ActorContext[T] extends TypedActorContext[T] with ClassicActorContextProvi
/**
* Register for [[Terminated]] notification once the Actor identified by the
* given [[ActorRef]] terminates. This message is also sent when the watched actor
* is on a node that has been removed from the cluster when using Akka Cluster.
* is on a node that has been removed from the cluster when using Pekko Cluster.
*
* `watch` is idempotent if it is not mixed with `watchWith`.
*
Expand All @@ -195,7 +195,7 @@ trait ActorContext[T] extends TypedActorContext[T] with ClassicActorContextProvi
/**
* Register for termination notification with a custom message once the Actor identified by the
* given [[ActorRef]] terminates. This message is also sent when the watched actor
* is on a node that has been removed from the cluster when using Akka Cluster.
* is on a node that has been removed from the cluster when using Pekko Cluster.
*
* `watchWith` is idempotent if it is called with the same `msg` and not mixed with `watch`.
*
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -163,7 +163,7 @@ trait ActorContext[T] extends TypedActorContext[T] with ClassicActorContextProvi
/**
* Register for [[pekko.actor.typed.Terminated]] notification once the Actor identified by the
* given [[ActorRef]] terminates. This message is also sent when the watched actor
* is on a node that has been removed from the cluster when using Akka Cluster.
* is on a node that has been removed from the cluster when using Pekko Cluster.
*
* `watch` is idempotent if it is not mixed with `watchWith`.
*
Expand All @@ -178,7 +178,7 @@ trait ActorContext[T] extends TypedActorContext[T] with ClassicActorContextProvi
/**
* Register for termination notification with a custom message once the Actor identified by the
* given [[ActorRef]] terminates. This message is also sent when the watched actor
* is on a node that has been removed from the cluster when using using Akka Cluster.
* is on a node that has been removed from the cluster when using using Pekko Cluster.
*
* `watchWith` is idempotent if it is called with the same `msg` and not mixed with `watch`.
*
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -18,8 +18,8 @@
import scala.concurrent.duration.FiniteDuration;

/**
* An Akka scheduler service. This one needs one special behavior: if Closeable, it MUST execute all
* outstanding tasks upon .close() in order to properly shutdown all dispatchers.
* An Apache Pekko scheduler service. This one needs one special behavior: if Closeable, it MUST
* execute all outstanding tasks upon .close() in order to properly shutdown all dispatchers.
*
* <p>Furthermore, this timer service MUST throw IllegalStateException if it cannot schedule a task.
* Once scheduled, the task MUST be executed. If executed upon close(), the task may execute before
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@

/**
* Marks APIs that are designed under an closed-world assumption for and are NOT meant to be
* extended by user-code. It is fine to extend these classes within Akka itself however.
* extended by user-code. It is fine to extend these classes within Apache Pekko itself, however.
*
* <p>This is most useful for binary compatibility purposes when a set of classes and interfaces
* assume a "closed world" between them, and gain the ability to add methods to the interfaces
Expand All @@ -26,7 +26,7 @@
* / artifact, it is impossible to obtain a "old" class with a "new" interface, as they are part of
* the same dependency.
*
* <p>Notable examples of such API include the FlowOps trait in Akka Streams or Akka HTTP model
* <p>Notable examples of such API include the FlowOps trait in Pekko Streams or Pekko HTTP model
* interfaces, which extensively uses inheritance internally, but are not meant for extension by
* user code.
*/
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -16,8 +16,8 @@
import java.lang.annotation.*;

/**
* Marks APIs that are considered internal to Akka and may change at any point in time without any
* warning.
* Marks APIs that are considered internal to Apache Pekko and may change at any point in time
* without any warning.
*
* <p>For example, this annotation should be used when the Scala {@code private[pekko]} access
* restriction is used, as Java has no way of representing this package restricted access and such
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -20,9 +20,9 @@
import java.lang.annotation.Target;

/**
* Marks APIs that are considered internal to Akka and should not be accessed by user code but that
* are used across Akka project boundaries and therefore shouldn't be changed without considering
* possible usage outside of the Akka core modules.
* Marks APIs that are considered internal to Apache Pekko and should not be accessed by user code
* but that are used across Apache Pekko project boundaries and therefore shouldn't be changed
* without considering possible usage outside of the Apache Pekko core modules.
*
* <p>If a method/class annotated with this annotation is part of a public API and has the Scala
* {@code private[pekko]} access restriction, which leads to a public method from Java, there should
Expand Down
2 changes: 1 addition & 1 deletion actor/src/main/scala/org/apache/pekko/NotUsed.scala
Original file line number Diff line number Diff line change
Expand Up @@ -16,7 +16,7 @@ package org.apache.pekko
/**
* This type is used in generic type signatures wherever the actual value is of no importance.
* It is a combination of Scala’s `Unit` and Java’s `Void`, which both have different issues when
* used from the other language. An example use-case is the materialized value of an Akka Stream for cases
* used from the other language. An example use-case is the materialized value of an Pekko Stream for cases
* where no result shall be returned from materialization.
*/
sealed abstract class NotUsed
Expand Down
2 changes: 1 addition & 1 deletion actor/src/main/scala/org/apache/pekko/PekkoException.scala
Original file line number Diff line number Diff line change
Expand Up @@ -36,7 +36,7 @@ trait OnlyCauseStackTrace { self: Throwable =>
}

/**
* This exception is thrown when Akka detects a problem with the provided configuration
* This exception is thrown when Apache Pekko detects a problem with the provided configuration
*/
class ConfigurationException(message: String, cause: Throwable) extends PekkoException(message, cause) {
def this(msg: String) = this(msg, null)
Expand Down
2 changes: 1 addition & 1 deletion actor/src/main/scala/org/apache/pekko/actor/Actor.scala
Original file line number Diff line number Diff line change
Expand Up @@ -384,7 +384,7 @@ trait DiagnosticActorLogging extends Actor {
object Actor {

/**
* Type alias representing a Receive-expression for Akka Actors.
* Type alias representing a Receive-expression for Pekko Actors.
*/
// #receive
type Receive = PartialFunction[Any, Unit]
Expand Down
4 changes: 2 additions & 2 deletions actor/src/main/scala/org/apache/pekko/actor/ActorCell.scala
Original file line number Diff line number Diff line change
Expand Up @@ -367,7 +367,7 @@ private[pekko] trait Cell {
}

/**
* Everything in here is completely Akka PRIVATE. You will not find any
* Everything in here is completely Pekko PRIVATE. You will not find any
* supported APIs in this place. This is not the API you were looking
* for! (waves hand)
*/
Expand Down Expand Up @@ -412,7 +412,7 @@ private[pekko] object ActorCell {
//vars don't need volatile since it's protected with the mailbox status
//Make sure that they are not read/written outside of a message processing (systemInvoke/invoke)
/**
* Everything in here is completely Akka PRIVATE. You will not find any
* Everything in here is completely Pekko PRIVATE. You will not find any
* supported APIs in this place. This is not the API you were looking
* for! (waves hand)
*/
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,11 +26,11 @@ import pekko.event.LogMarker
object ActorLogMarker {

/**
* Marker "akkaDeadLetter" of log event for dead letter messages.
* Marker "pekkoDeadLetter" of log event for dead letter messages.
*
* @param messageClass The message class of the DeadLetter. Included as property "akkaMessageClass".
* @param messageClass The message class of the DeadLetter. Included as property "pekkoMessageClass".
*/
def deadLetter(messageClass: String): LogMarker =
LogMarker("akkaDeadLetter", Map(LogMarker.Properties.MessageClass -> messageClass))
LogMarker("pekkoDeadLetter", Map(LogMarker.Properties.MessageClass -> messageClass))

}
Original file line number Diff line number Diff line change
Expand Up @@ -35,7 +35,7 @@ import pekko.util.OptionVal

/**
* Interface for all ActorRef providers to implement.
* Not intended for extension outside of Akka.
* Not intended for extension outside of Apache Pekko.
*/
@DoNotInherit trait ActorRefProvider {

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -484,7 +484,7 @@ object ActorSystem {

if (ConfigVersion != Version)
throw new pekko.ConfigurationException(
"Akka JAR version [" + Version + "] does not match the provided config version [" + ConfigVersion + "]")
"Pekko JAR version [" + Version + "] does not match the provided config version [" + ConfigVersion + "]")

/**
* Returns the String representation of the Config that this Settings is backed by
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -308,7 +308,7 @@ object SupervisorStrategy extends SupervisorStrategyLowPriorityImplicits {
}

/**
* An Akka SupervisorStrategy is the policy to apply for crashing children.
* A Pekko SupervisorStrategy is the policy to apply for crashing children.
*
* <b>IMPORTANT:</b>
*
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -33,7 +33,7 @@ import pekko.util.JavaDurationConverters
private final case class SchedulerException(msg: String) extends pekko.PekkoException(msg) with NoStackTrace

/**
* An Akka scheduler service.
* An Apache Pekko scheduler service.
*
* For scheduling within actors `with Timers` should be preferred.
*
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -228,7 +228,7 @@ private[pekko] class Mailboxes(
case "unbounded" => UnboundedMailbox()
case "bounded" => new BoundedMailbox(settings, config(id))
case _ if id.startsWith(BoundedCapacityPrefix) =>
// hack to allow programmatic set of capacity through props in akka-typed but still share
// hack to allow programmatic set of capacity through props in pekko-typed but still share
// mailbox configurators for the same size
val capacity = id.split(':')(1).toInt
new BoundedMailbox(capacity, Duration.Zero)
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@ import pekko.event.Logging.simpleName
import pekko.util.Subclassification

/**
* An Akka EventStream is a pub-sub stream of events both system and user generated,
* An Apache Pekko EventStream is a pub-sub stream of events both system and user generated,
* where subscribers are ActorRefs and the channels are Classes and Events are any java.lang.Object.
* EventStreams employ SubchannelClassification, which means that if you listen to a Class,
* you'll receive any message that is of that type or a subtype.
Expand Down
6 changes: 3 additions & 3 deletions actor/src/main/scala/org/apache/pekko/event/Logging.scala
Original file line number Diff line number Diff line change
Expand Up @@ -1731,9 +1731,9 @@ object LogMarker {
* INTERNAL API
*/
@InternalApi private[pekko] object Properties {
val MessageClass = "akkaMessageClass"
val RemoteAddress = "akkaRemoteAddress"
val RemoteAddressUid = "akkaRemoteAddressUid"
val MessageClass = "pekkoMessageClass"
val RemoteAddress = "pekkoRemoteAddress"
val RemoteAddressUid = "pekkoRemoteAddressUid"
}

}
Expand Down
4 changes: 2 additions & 2 deletions actor/src/main/scala/org/apache/pekko/io/DnsProvider.scala
Original file line number Diff line number Diff line change
Expand Up @@ -19,9 +19,9 @@ import pekko.actor.Actor
/**
* Where as it is possible to plug in alternative DNS implementations it is not recommended.
*
* It is expected that this will be deprecated/removed in future Akka versions
* It is expected that this will be deprecated/removed in future Apache Pekko versions
*
* TODO make private and remove deprecated in 2.7.0
* TODO make private and remove deprecated in v1.1.0
*/
@deprecated("Overriding the DNS implementation will be removed in future versions of Akka", "2.6.0")
trait DnsProvider {
Expand Down
2 changes: 1 addition & 1 deletion actor/src/main/scala/org/apache/pekko/japi/JavaAPI.scala
Original file line number Diff line number Diff line change
Expand Up @@ -141,7 +141,7 @@ object JavaPartialFunction {
* }
* }}}
*
* The typical use of partial functions from Akka looks like the following:
* The typical use of partial functions from Apache Pekko looks like the following:
*
* {{{
* if (pf.isDefinedAt(x)) {
Expand Down
16 changes: 8 additions & 8 deletions actor/src/main/scala/org/apache/pekko/pattern/Backoff.scala
Original file line number Diff line number Diff line change
Expand Up @@ -57,8 +57,8 @@ object Backoff {
* be restarted with an exponentially increasing back off until the resource is available again.
*
* '''***
* This supervisor should not be used with `Akka Persistence` child actors.
* `Akka Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* This supervisor should not be used with `Pekko Persistence` child actors.
* `Pekko Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* than throw an exception on a failure like normal actors.
* [[#onStop]] should be used instead for cases where the child actor
* terminates itself as a failure signal instead of the normal behavior of throwing an exception.
Expand Down Expand Up @@ -117,8 +117,8 @@ object Backoff {
* be restarted with an exponentially increasing back off until the resource is available again.
*
* '''***
* This supervisor should not be used with `Akka Persistence` child actors.
* `Akka Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* This supervisor should not be used with `Pekko Persistence` child actors.
* `Pekko Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* than throw an exception on a failure like normal actors.
* [[#onStop]] should be used instead for cases where the child actor
* terminates itself as a failure signal instead of the normal behavior of throwing an exception.
Expand Down Expand Up @@ -172,8 +172,8 @@ object Backoff {
* be restarted with an exponentially increasing back off until the resource is available again.
*
* '''***
* This supervisor should not be used with `Akka Persistence` child actors.
* `Akka Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* This supervisor should not be used with `Pekko Persistence` child actors.
* `Pekko Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* than throw an exception on a failure like normal actors.
* [[#onStop]] should be used instead for cases where the child actor
* terminates itself as a failure signal instead of the normal behavior of throwing an exception.
Expand Down Expand Up @@ -232,8 +232,8 @@ object Backoff {
* be restarted with an exponentially increasing back off until the resource is available again.
*
* '''***
* This supervisor should not be used with `Akka Persistence` child actors.
* `Akka Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* This supervisor should not be used with `Pekko Persistence` child actors.
* `Pekko Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* than throw an exception on a failure like normal actors.
* [[#onStop]] should be used instead for cases where the child actor
* terminates itself as a failure signal instead of the normal behavior of throwing an exception.
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -53,8 +53,8 @@ object BackoffOpts {
* be restarted with an exponentially increasing back off until the resource is available again.
*
* '''***
* This supervisor should not be used with `Akka Persistence` child actors.
* `Akka Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* This supervisor should not be used with `Pekko Persistence` child actors.
* `Pekko Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* than throw an exception on a failure like normal actors.
* [[#onStop]] should be used instead for cases where the child actor
* terminates itself as a failure signal instead of the normal behavior of throwing an exception.
Expand Down Expand Up @@ -107,8 +107,8 @@ object BackoffOpts {
* be restarted with an exponentially increasing back off until the resource is available again.
*
* '''***
* This supervisor should not be used with `Akka Persistence` child actors.
* `Akka Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* This supervisor should not be used with `Pekko Persistence` child actors.
* `Pekko Persistence` actors shutdown unconditionally on `persistFailure()`s rather
* than throw an exception on a failure like normal actors.
* [[#onStop]] should be used instead for cases where the child actor
* terminates itself as a failure signal instead of the normal behavior of throwing an exception.
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@ package org.apache.pekko
package pattern

/**
* == Extended Versions Of Akka Patterns ==
* == Extended Versions Of Pekko Patterns ==
*
* This subpackage contains extended versions of Akka patterns.
*
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -104,7 +104,7 @@ object Serializers {
* For serialization of data that need to evolve over time the `SerializerWithStringManifest` is recommended instead
* of [[Serializer]] because the manifest (type hint) is a `String` instead of a `Class`. That means
* that the class can be moved/removed and the serializer can still deserialize old data by matching
* on the `String`. This is especially useful for Akka Persistence.
* on the `String`. This is especially useful for Pekko Persistence.
*
* The manifest string can also encode a version number that can be used in `fromBinary` to
* deserialize in different ways to migrate old data to new domain objects.
Expand Down Expand Up @@ -179,7 +179,7 @@ abstract class SerializerWithStringManifest extends Serializer {
* Implementations should typically extend [[SerializerWithStringManifest]] and
* in addition to the `ByteBuffer` based `toBinary` and `fromBinary` methods also
* implement the array based `toBinary` and `fromBinary` methods. The array based
* methods will be used when `ByteBuffer` is not used, e.g. in Akka Persistence.
* methods will be used when `ByteBuffer` is not used, e.g. in Pekko Persistence.
*
* Note that the array based methods can for example be implemented by delegation
* like this:
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -31,7 +31,7 @@ import pekko.actor.ExtensionIdProvider
import pekko.event.Logging

/**
* Akka extension that extracts [[ManifestInfo.Version]] information from META-INF/MANIFEST.MF in jar files
* Apache Pekko extension that extracts [[ManifestInfo.Version]] information from META-INF/MANIFEST.MF in jar files
* on the classpath of the `ClassLoader` of the `ActorSystem`.
*/
object ManifestInfo extends ExtensionId[ManifestInfo] with ExtensionIdProvider {
Expand Down
2 changes: 1 addition & 1 deletion bench-jmh/README.md
Original file line number Diff line number Diff line change
@@ -1,4 +1,4 @@
# Akka Microbenchmarks
# Apache Pekko Microbenchmarks

This subproject contains some microbenchmarks excercising key parts of Akka. (Excluding typed which has its
own jmh module)
Expand Down
4 changes: 2 additions & 2 deletions build.sbt
Original file line number Diff line number Diff line change
Expand Up @@ -100,7 +100,7 @@ lazy val root = Project(id = "pekko", base = file("."))
benchJmh,
protobuf,
protobufV3,
akkaScalaNightly,
pekkoScalaNightly,
docs,
serialversionRemoverPlugin))
.settings(
Expand All @@ -126,7 +126,7 @@ lazy val actorTests = pekkoModule("actor-tests")
.enablePlugins(NoPublish)
.disablePlugins(MimaPlugin)

lazy val akkaScalaNightly = pekkoModule("scala-nightly")
lazy val pekkoScalaNightly = pekkoModule("scala-nightly")
.aggregate(aggregatedProjects: _*)
.disablePlugins(MimaPlugin)
.disablePlugins(ValidatePullRequest, MimaPlugin, CopyrightHeaderInPr)
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -47,7 +47,7 @@ object ShardedDaemonProcessSettings {
}

/**
* Not for user constructions, use factory methods to instanciate.
* Not for user constructions, use factory methods to instantiate.
*/
final class ShardedDaemonProcessSettings @InternalApi private[pekko] (
val keepAliveInterval: FiniteDuration,
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -30,7 +30,7 @@ import pekko.persistence.typed.ReplicationId
* INTERNAL API
*
* Used when sharding Replicated Event Sourced entities in multiple instances of sharding, for example one per DC in a Multi DC
* Akka Cluster.
* Pekko Cluster.
*
* This actor should be started once on each node where Replicated Event Sourced entities will run (the same nodes that you start
* sharding on). The entities should be set up with [[pekko.persistence.typed.scaladsl.EventSourcedBehavior.withEventPublishing]]
Expand Down
Loading

0 comments on commit c32fcf1

Please sign in to comment.