Skip to content

Commit

Permalink
=doc akka#17329 Fixed and normalized spellings in ScalaDoc and comments
Browse files Browse the repository at this point in the history
  • Loading branch information
kukido committed Jun 3, 2015
1 parent 10f039f commit bc791eb
Show file tree
Hide file tree
Showing 77 changed files with 100 additions and 100 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -137,7 +137,7 @@ public final boolean isEmpty() {
*/
public final int size() {
//Order of operations is extremely important here
// If no item was dequeued between when we looked at the count of the enqueueing end,
// If no item was dequeued between when we looked at the count of the enqueuing end,
// there should be no out-of-bounds
for(;;) {
final int deqCountBefore = getDeq().count;
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/actor/ActorRef.scala
Original file line number Diff line number Diff line change
Expand Up @@ -465,7 +465,7 @@ private[akka] trait MinimalActorRef extends InternalActorRef with LocalRef {
protected def writeReplace(): AnyRef = SerializedActorRef(this)
}

/** Subscribe to this class to be notified about all DeadLetters (also the supressed ones). */
/** Subscribe to this class to be notified about all DeadLetters (also the suppressed ones). */
sealed trait AllDeadLetters {
def message: Any
def sender: ActorRef
Expand Down
4 changes: 2 additions & 2 deletions akka-actor/src/main/scala/akka/actor/ActorSystem.scala
Original file line number Diff line number Diff line change
Expand Up @@ -133,7 +133,7 @@ object ActorSystem {
* falls back to the ClassLoader associated with the ActorSystem class.
* If an ExecutionContext is given, it will be used as the default executor inside this ActorSystem.
* If no ExecutionContext is given, the system will fallback to the executor configured under "akka.actor.default-dispatcher.default-executor.fallback".
* The system will use the passed in config, or falls back to the deafult reference configuration using the ClassLoader.
* The system will use the passed in config, or falls back to the default reference configuration using the ClassLoader.
*
* @see <a href="http://typesafehub.github.io/config/v1.3.0/" target="_blank">The Typesafe Config Library API Documentation</a>
*/
Expand Down Expand Up @@ -828,7 +828,7 @@ private[akka] class ActorSystemImpl(
private[this] final val done = Promise[T]()
private[this] final val ref = new AtomicReference(done)

// onComplete never fires twice so safe to avoid nullcheck
// onComplete never fires twice so safe to avoid null check
upStreamTerminated onComplete { t ref.getAndSet(null).complete(t) }

/**
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/actor/FSM.scala
Original file line number Diff line number Diff line change
Expand Up @@ -212,7 +212,7 @@ object FSM {
final case class Event[D](event: Any, stateData: D) extends NoSerializationVerificationNeeded

/**
* Case class representing the state of the [[akka.actor.FSM]] whithin the
* Case class representing the state of the [[akka.actor.FSM]] within the
* `onTermination` block.
*/
final case class StopEvent[S, D](reason: Reason, currentState: S, stateData: D) extends NoSerializationVerificationNeeded
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/actor/Scheduler.scala
Original file line number Diff line number Diff line change
Expand Up @@ -213,7 +213,7 @@ class LightArrayRevolverScheduler(config: Config,
try {
((d + TickDuration - oneNs) / TickDuration).toLong * TickDuration
} catch {
case _: IllegalArgumentException d // rouding up Long.MaxValue.nanos overflows
case _: IllegalArgumentException d // rounding up Long.MaxValue.nanos overflows
}

/**
Expand Down
6 changes: 3 additions & 3 deletions akka-actor/src/main/scala/akka/actor/TypedActor.scala
Original file line number Diff line number Diff line change
Expand Up @@ -59,7 +59,7 @@ trait TypedActorFactory {
}

/**
* Returns wether the supplied AnyRef is a TypedActor proxy or not
* Returns whether the supplied AnyRef is a TypedActor proxy or not
*/
def isTypedActor(proxyOrNot: AnyRef): Boolean

Expand Down Expand Up @@ -654,7 +654,7 @@ class TypedActorExtension(val system: ExtendedActorSystem) extends TypedActorFac
}

/**
* Returns wether the supplied AnyRef is a TypedActor proxy or not
* Returns whether the supplied AnyRef is a TypedActor proxy or not
*/
def isTypedActor(proxyOrNot: AnyRef): Boolean = invocationHandlerFor(proxyOrNot) ne null

Expand All @@ -675,7 +675,7 @@ class TypedActorExtension(val system: ExtendedActorSystem) extends TypedActorFac
proxy
} else {
proxyVar set proxy // Chicken and egg situation we needed to solve, set the proxy so that we can set the self-reference inside each receive
actorVar set actorRef //Make sure the InvocationHandler gets ahold of the actor reference, this is not a problem since the proxy hasn't escaped this method yet
actorVar set actorRef //Make sure the InvocationHandler gets a hold of the actor reference, this is not a problem since the proxy hasn't escaped this method yet
proxyVar.get
}
}
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -59,7 +59,7 @@ private[akka] trait BatchingExecutor extends Executor {
protected final def resubmitUnbatched(): Boolean = {
val current = _tasksLocal.get()
_tasksLocal.remove()
if ((current eq this) && !current.isEmpty) { // Resubmit outselves if something bad happened and we still have work to do
if ((current eq this) && !current.isEmpty) { // Resubmit ourselves if something bad happened and we still have work to do
unbatchedExecute(current) //TODO what if this submission fails?
true
} else false
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/dispatch/Future.scala
Original file line number Diff line number Diff line change
Expand Up @@ -88,7 +88,7 @@ object Futures {
*
* The result becomes available once the asynchronous computation is completed.
*
* @param body the asychronous computation
* @param body the asynchronous computation
* @param executor the execution context on which the future is run
* @return the `Future` holding the result of the computation
*/
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/event/EventStream.scala
Original file line number Diff line number Diff line change
Expand Up @@ -126,7 +126,7 @@ class EventStream(sys: ActorSystem, private val debug: Boolean) extends LoggingB
*
* The actual check if the subscriber still has subscriptions is performed by the `EventStreamUnsubscriber`,
* because it's an expensive operation, and we don want to block client-code for that long, the Actor will eventually
* catch up and perform the apropriate operation.
* catch up and perform the appropriate operation.
*/
@tailrec
private def unregisterIfNoMoreSubscribedChannels(subscriber: ActorRef): Unit = {
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/event/Logging.scala
Original file line number Diff line number Diff line change
Expand Up @@ -224,7 +224,7 @@ trait LoggingBus extends ActorEventBus {
* }
*
* class MyClass extends MyType {
* val sys = ActorSyste("sys")
* val sys = ActorSystem("sys")
* val log = Logging(sys, this) // will use "hallo,akka://sys" as logSource
* def name = "hallo"
* }
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/io/SelectionHandler.scala
Original file line number Diff line number Diff line change
Expand Up @@ -52,7 +52,7 @@ private[io] trait ChannelRegistry {
/**
* Implementations of this interface are sent as actor messages back to a channel actor as
* a result of it having called `register` on the `ChannelRegistry`.
* Enables a channel actor to directly schedule interest setting tasks to the selector mgmt. dispatcher.
* Enables a channel actor to directly schedule interest setting tasks to the selector management dispatcher.
*/
private[io] trait ChannelRegistration extends NoSerializationVerificationNeeded {
def enableInterest(op: Int)
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/io/Tcp.scala
Original file line number Diff line number Diff line change
Expand Up @@ -26,7 +26,7 @@ import java.lang.{ Iterable ⇒ JIterable }
* In order to open an outbound connection send a [[Tcp.Connect]] message
* to the [[TcpExt#manager]].
*
* In order to start listening for inbound connetions send a [[Tcp.Bind]]
* In order to start listening for inbound connections send a [[Tcp.Bind]]
* message to the [[TcpExt#manager]].
*
* The Java API for generating TCP commands is available at [[TcpMessage]].
Expand Down
4 changes: 2 additions & 2 deletions akka-actor/src/main/scala/akka/io/TcpManager.scala
Original file line number Diff line number Diff line change
Expand Up @@ -49,11 +49,11 @@ private[io] class TcpManager(tcp: TcpExt)

def receive = workerForCommandHandler {
case c: Connect
val commander = sender() // cache because we create a function that will run asyncly
val commander = sender() // cache because we create a function that will run asynchly
(registry Props(classOf[TcpOutgoingConnection], tcp, registry, commander, c))

case b: Bind
val commander = sender() // cache because we create a function that will run asyncly
val commander = sender() // cache because we create a function that will run asynchly
(registry Props(classOf[TcpListener], selectorPool, tcp, registry, commander, b))
}

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@ private[io] class UdpConnectedManager(udpConn: UdpConnectedExt)

def receive = workerForCommandHandler {
case c: Connect
val commander = sender() // cache because we create a function that will run asyncly
val commander = sender() // cache because we create a function that will run asynchly
registry Props(classOf[UdpConnection], udpConn, registry, commander, c)
}

Expand Down
4 changes: 2 additions & 2 deletions akka-actor/src/main/scala/akka/io/UdpManager.scala
Original file line number Diff line number Diff line change
Expand Up @@ -47,11 +47,11 @@ private[io] class UdpManager(udp: UdpExt) extends SelectionHandler.SelectorBased

def receive = workerForCommandHandler {
case b: Bind
val commander = sender() // cache because we create a function that will run asyncly
val commander = sender() // cache because we create a function that will run asynchly
(registry Props(classOf[UdpListener], udp, registry, commander, b))

case SimpleSender(options)
val commander = sender() // cache because we create a function that will run asyncly
val commander = sender() // cache because we create a function that will run asynchly
(registry Props(classOf[UdpSender], udp, registry, commander, options))
}

Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/routing/Balancing.scala
Original file line number Diff line number Diff line change
Expand Up @@ -126,7 +126,7 @@ final case class BalancingPool(
}

/**
* Uses the supervisor strategy of the given Routerconfig
* Uses the supervisor strategy of the given RouterConfig
* if this RouterConfig doesn't have one.
*/
override def withFallback(other: RouterConfig): RouterConfig =
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/routing/Broadcast.scala
Original file line number Diff line number Diff line change
Expand Up @@ -97,7 +97,7 @@ final case class BroadcastPool(
def withDispatcher(dispatcherId: String): BroadcastPool = copy(routerDispatcher = dispatcherId)

/**
* Uses the resizer and/or the supervisor strategy of the given Routerconfig
* Uses the resizer and/or the supervisor strategy of the given RouterConfig
* if this RouterConfig doesn't have one, i.e. the resizer defined in code is used if
* resizer was not defined in config.
*/
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -314,7 +314,7 @@ final case class ConsistentHashingPool(
copy(hashMapping = ConsistentHashingRouter.hashMappingAdapter(mapper))

/**
* Uses the resizer and/or the supervisor strategy of the given Routerconfig
* Uses the resizer and/or the supervisor strategy of the given RouterConfig
* if this RouterConfig doesn't have one, i.e. the resizer defined in code is used if
* resizer was not defined in config.
* Uses the the `hashMapping` defined in code, since that can't be defined in configuration.
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/routing/Random.scala
Original file line number Diff line number Diff line change
Expand Up @@ -98,7 +98,7 @@ final case class RandomPool(
def withDispatcher(dispatcherId: String): RandomPool = copy(routerDispatcher = dispatcherId)

/**
* Uses the resizer and/or the supervisor strategy of the given Routerconfig
* Uses the resizer and/or the supervisor strategy of the given RouterConfig
* if this RouterConfig doesn't have one, i.e. the resizer defined in code is used if
* resizer was not defined in config.
*/
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/routing/Resizer.scala
Original file line number Diff line number Diff line change
Expand Up @@ -49,7 +49,7 @@ trait Resizer {
* returns true and no other resize is in progress.
*
* Return the number of routees to add or remove. Negative value will remove that number of routees.
* Positive value will add that number of routess. 0 will not change the routees.
* Positive value will add that number of routees. 0 will not change the routees.
*
* This method is invoked only in the context of the Router actor.
*/
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/routing/RoundRobin.scala
Original file line number Diff line number Diff line change
Expand Up @@ -102,7 +102,7 @@ final case class RoundRobinPool(
def withDispatcher(dispatcherId: String): RoundRobinPool = copy(routerDispatcher = dispatcherId)

/**
* Uses the resizer and/or the supervisor strategy of the given Routerconfig
* Uses the resizer and/or the supervisor strategy of the given RouterConfig
* if this RouterConfig doesn't have one, i.e. the resizer defined in code is used if
* resizer was not defined in config.
*/
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -119,7 +119,7 @@ private[akka] class RoutedActorCell(
}

/**
* Called when `router` is initalized but before `super.start()` to
* Called when `router` is initialized but before `super.start()` to
* be able to do extra initialization in subclass.
*/
protected def preSuperStart(): Unit = ()
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/routing/RouterConfig.scala
Original file line number Diff line number Diff line change
Expand Up @@ -54,7 +54,7 @@ trait RouterConfig extends Serializable {
* Possibility to define an actor for controlling the routing
* logic from external stimuli (e.g. monitoring metrics).
* This actor will be a child of the router "head" actor.
* Managment messages not handled by the "head" actor are
* Management messages not handled by the "head" actor are
* delegated to this controller actor.
*/
def routingLogicController(routingLogic: RoutingLogic): Option[Props] = None
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -136,7 +136,7 @@ final case class ScatterGatherFirstCompletedPool(
def withDispatcher(dispatcherId: String): ScatterGatherFirstCompletedPool = copy(routerDispatcher = dispatcherId)

/**
* Uses the resizer and/or the supervisor strategy of the given Routerconfig
* Uses the resizer and/or the supervisor strategy of the given RouterConfig
* if this RouterConfig doesn't have one, i.e. the resizer defined in code is used if
* resizer was not defined in config.
*/
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -213,7 +213,7 @@ final case class SmallestMailboxPool(
def withDispatcher(dispatcherId: String): SmallestMailboxPool = copy(routerDispatcher = dispatcherId)

/**
* Uses the resizer and/or the supervisor strategy of the given Routerconfig
* Uses the resizer and/or the supervisor strategy of the given RouterConfig
* if this RouterConfig doesn't have one, i.e. the resizer defined in code is used if
* resizer was not defined in config.
*/
Expand Down
4 changes: 2 additions & 2 deletions akka-actor/src/main/scala/akka/routing/TailChopping.scala
Original file line number Diff line number Diff line change
Expand Up @@ -83,7 +83,7 @@ private[akka] final case class TailChoppingRoutees(
}

/**
* A router poll thats sends the message to a first, random picked, routee,
* A router poll that sends the message to a first, random picked, routee,
* then wait a specified `interval` and then send to a second, random picked, and so on till one full cycle..
*
* The configuration parameter trumps the constructor arguments. This means that
Expand Down Expand Up @@ -169,7 +169,7 @@ final case class TailChoppingPool(
def withDispatcher(dispatcherId: String): TailChoppingPool = copy(routerDispatcher = dispatcherId)

/**
* Uses the resizer and/or the supervisor strategy of the given Routerconfig
* Uses the resizer and/or the supervisor strategy of the given RouterConfig
* if this RouterConfig doesn't have one, i.e. the resizer defined in code is used if
* resizer was not defined in config.
*/
Expand Down
2 changes: 1 addition & 1 deletion akka-actor/src/main/scala/akka/util/LockUtil.scala
Original file line number Diff line number Diff line change
Expand Up @@ -138,7 +138,7 @@ class Switch(startAsOn: Boolean = false) {
def isOn: Boolean = switch.get

/**
* Returns whether the switch is IMMEDDIATELY off (no locking)
* Returns whether the switch is IMMEDIATELY off (no locking)
*/
def isOff: Boolean = !isOn
}
2 changes: 1 addition & 1 deletion akka-camel/src/main/scala/akka/camel/Camel.scala
Original file line number Diff line number Diff line change
Expand Up @@ -103,7 +103,7 @@ class CamelSettings private[camel] (config: Config, dynamicAccess: DynamicAccess
(s: String, r: RouteDefinition) conversions.get(s).fold(r)(r.convertBodyTo)
}
/**
* Configured setting, determine the class used to load/retrive the instance of the Camel Context
* Configured setting, determine the class used to load/retrieve the instance of the Camel Context
*/
final val ContextProvider: ContextProvider = {
val fqcn = config.getString("akka.camel.context-provider")
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -163,7 +163,7 @@ final case class AdaptiveLoadBalancingPool(
def withDispatcher(dispatcherId: String): AdaptiveLoadBalancingPool = copy(routerDispatcher = dispatcherId)

/**
* Uses the supervisor strategy of the given Routerconfig
* Uses the supervisor strategy of the given RouterConfig
* if this RouterConfig doesn't have one
*/
override def withFallback(other: RouterConfig): RouterConfig =
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -81,7 +81,7 @@ private[metrics] object MetricsCollector {
* Loads JVM and system metrics through JMX monitoring beans.
*
* @param address The [[akka.actor.Address]] of the node being sampled
* @param decay how quickly the exponential weighting of past data is decayed
* @param decayFactor how quickly the exponential weighting of past data is decayed
*/
class JmxMetricsCollector(address: Address, decayFactor: Double) extends MetricsCollector {
import StandardMetrics._
Expand Down Expand Up @@ -184,7 +184,7 @@ class JmxMetricsCollector(address: Address, decayFactor: Double) extends Metrics
* to missing classes or native libraries.
*
* @param address The [[akka.actor.Address]] of the node being sampled
* @param decay how quickly the exponential weighting of past data is decayed
* @param decayFactor how quickly the exponential weighting of past data is decayed
* @param sigar the org.hyperic.Sigar instance
*/
class SigarMetricsCollector(address: Address, decayFactor: Double, sigar: SigarProxy)
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -399,7 +399,7 @@ private[akka] object ClusterShardingGuardian {
}

/**
* INTERNAL API. [[ShardRegion]] and [[ShardCoordinator]] actors are createad as children
* INTERNAL API. [[ShardRegion]] and [[ShardCoordinator]] actors are created as children
* of this actor.
*/
private[akka] class ClusterShardingGuardian extends Actor {
Expand Down Expand Up @@ -1467,7 +1467,7 @@ object ShardCoordinator {
*/
@SerialVersionUID(1L) final case class RegisterProxy(shardRegionProxy: ActorRef) extends CoordinatorCommand
/**
* Acknowledgement from `ShardCoordinator` that [[Register]] or [[RegisterProxy]] was sucessful.
* Acknowledgement from `ShardCoordinator` that [[Register]] or [[RegisterProxy]] was successful.
*/
@SerialVersionUID(1L) final case class RegisterAck(coordinator: ActorRef) extends CoordinatorMessage
/**
Expand All @@ -1484,7 +1484,7 @@ object ShardCoordinator {
*/
@SerialVersionUID(1L) final case class ShardHome(shard: ShardId, ref: ActorRef) extends CoordinatorMessage
/**
* `ShardCoodinator` informs a `ShardRegion` that it is hosting this shard
* `ShardCoordinator` informs a `ShardRegion` that it is hosting this shard
*/
@SerialVersionUID(1L) final case class HostShard(shard: ShardId) extends CoordinatorMessage
/**
Expand All @@ -1505,7 +1505,7 @@ object ShardCoordinator {
*/
@SerialVersionUID(1L) final case class BeginHandOffAck(shard: ShardId) extends CoordinatorCommand
/**
* When all `ShardRegion` actors have acknoledged the `BeginHandOff` the
* When all `ShardRegion` actors have acknowledged the `BeginHandOff` the
* `ShardCoordinator` sends this message to the `ShardRegion` responsible for the
* shard. The `ShardRegion` is supposed to stop all entries in that shard and when
* all entries have terminated reply with `ShardStopped` to the `ShardCoordinator`.
Expand Down Expand Up @@ -1872,7 +1872,7 @@ class ShardCoordinator(handOffTimeout: FiniteDuration, shardStartTimeout: Finite

case ShardHome(_, _)
//On rebalance, we send ourselves a GetShardHome message to reallocate a
// shard. This recieve handles the "response" from that message. i.e. Ingores it.
// shard. This receive handles the "response" from that message. i.e. ignores it.

case ClusterShuttingDown
log.debug("Shutting down ShardCoordinator")
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -88,7 +88,7 @@ object ClusterShardingSpec extends MultiNodeConfig {

override def postStop(): Unit = {
super.postStop()
// Simulate that the passivation takes some time, to verify passivation bufffering
// Simulate that the passivation takes some time, to verify passivation buffering
Thread.sleep(500)
}
//#counter-actor
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -154,7 +154,7 @@ object ClusterSingletonManager {
*/
private object Internal {
/**
* Sent from new oldest to previous oldest to initate the
* Sent from new oldest to previous oldest to initiate the
* hand-over process. `HandOverInProgress` and `HandOverDone`
* are expected replies.
*/
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -70,7 +70,7 @@ object ClusterSingletonManagerSpec extends MultiNodeConfig {
}

/**
* This channel is extremly strict with regards to
* This channel is extremely strict with regards to
* registration and unregistration of consumer to
* be able to detect misbehaviour (e.g. two active
* singleton instances).
Expand Down
Loading

0 comments on commit bc791eb

Please sign in to comment.