Skip to content

Commit 6872f9c

Browse files
authored
Fix some non-standard comments (apache#939)
* Fix some non-standard comments * revert --------- Co-authored-by: Jiafu Tang <[email protected]>
1 parent 269748d commit 6872f9c

File tree

18 files changed

+22
-22
lines changed

18 files changed

+22
-22
lines changed

actor/src/main/scala-2.12/org/apache/pekko/util/ByteString.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -913,7 +913,7 @@ sealed abstract class ByteString extends IndexedSeq[Byte] with IndexedSeqOptimiz
913913
*/
914914
def decodeString(charset: Charset): String
915915

916-
/*
916+
/**
917917
* Returns a ByteString which is the binary representation of this ByteString
918918
* if this ByteString is Base64-encoded.
919919
*/

actor/src/main/scala-3/org/apache/pekko/util/ByteString.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -960,7 +960,7 @@ sealed abstract class ByteString
960960
*/
961961
def decodeString(charset: Charset): String
962962

963-
/*
963+
/**
964964
* Returns a ByteString which is the binary representation of this ByteString
965965
* if this ByteString is Base64-encoded.
966966
*/

actor/src/main/scala/org/apache/pekko/actor/ActorSystem.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -1128,7 +1128,7 @@ private[pekko] class ActorSystemImpl(
11281128
.get
11291129
// #create-scheduler
11301130

1131-
/*
1131+
/**
11321132
* This is called after the last actor has signaled its termination, i.e.
11331133
* after the last dispatcher has had its chance to schedule its shutdown
11341134
* action.

actor/src/main/scala/org/apache/pekko/actor/dungeon/Children.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -145,7 +145,7 @@ private[pekko] trait Children { this: ActorCell =>
145145
_nextNameDoNotCallMeDirectly
146146
}
147147

148-
/*
148+
/**
149149
* low level CAS helpers
150150
*/
151151
private final def swapChildrenRefs(oldChildren: ChildrenContainer, newChildren: ChildrenContainer): Boolean =

actor/src/main/scala/org/apache/pekko/dispatch/AbstractDispatcher.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -282,7 +282,7 @@ abstract class MessageDispatcher(val configurator: MessageDispatcherConfigurator
282282
mbox.suspend()
283283
}
284284

285-
/*
285+
/**
286286
* After the call to this method, the dispatcher must begin any new message processing for the specified reference
287287
*/
288288
protected[pekko] def resume(actor: ActorCell): Unit = {

actor/src/main/scala/org/apache/pekko/routing/RouterConfig.scala

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -84,7 +84,7 @@ trait RouterConfig extends Serializable {
8484
case _ => false
8585
}
8686

87-
/*
87+
/**
8888
* Specify that this router should stop itself when all routees have terminated (been removed).
8989
* By Default it is `true`, unless a `resizer` is used.
9090
*/
@@ -244,7 +244,7 @@ trait Pool extends RouterConfig {
244244
*/
245245
def props(routeeProps: Props): Props = routeeProps.withRouter(this)
246246

247-
/*
247+
/**
248248
* Specify that this router should stop itself when all routees have terminated (been removed).
249249
* By Default it is `true`, unless a `resizer` is used.
250250
*/

bench-jmh/src/main/scala/org/apache/pekko/stream/io/FileSourcesBenchmark.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -104,7 +104,7 @@ class FileSourcesBenchmark {
104104
Await.result(h, 30.seconds)
105105
}
106106

107-
/*
107+
/**
108108
* The previous status quo was very slow:
109109
* Benchmark Mode Cnt Score Error Units
110110
* FileSourcesBenchmark.naive_ioSourceLinesIterator avgt 20 7067.944 ± 1341.847 ms/op

cluster-sharding/src/main/scala/org/apache/pekko/cluster/sharding/ShardRegion.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -209,7 +209,7 @@ object ShardRegion {
209209
*/
210210
@SerialVersionUID(1L) final case class Passivate(stopMessage: Any) extends ShardRegionCommand
211211

212-
/*
212+
/**
213213
* Send this message to the `ShardRegion` actor to handoff all shards that are hosted by
214214
* the `ShardRegion` and then the `ShardRegion` actor will be stopped. You can `watch`
215215
* it to know when it is completed.

cluster/src/main/scala/org/apache/pekko/cluster/ClusterJmx.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -45,7 +45,7 @@ trait ClusterNodeMBean {
4545
*/
4646
def getUnreachable: String
4747

48-
/*
48+
/**
4949
* JSON format of the status of all nodes in the cluster as follows:
5050
* {{{
5151
* {

distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/protobuf/ReplicatedDataSerializer.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -661,7 +661,7 @@ class ReplicatedDataSerializer(val system: ExtendedActorSystem)
661661
decrements = gcounterFromProto(pncounter.getDecrements))
662662
}
663663

664-
/*
664+
/**
665665
* Convert a Map[A, B] to an Iterable[Entry] where Entry is the protobuf map entry.
666666
*/
667667
private def getEntries[

multi-node-testkit/src/main/scala/org/apache/pekko/remote/testconductor/Conductor.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -444,7 +444,7 @@ private[pekko] class Controller(private var initialParticipants: Int, controller
444444
settings.ServerSocketWorkerPoolSize,
445445
new ConductorHandler(settings.QueryTimeout, self, Logging(context.system, classOf[ConductorHandler])))
446446

447-
/*
447+
/**
448448
* Supervision of the BarrierCoordinator means to catch all his bad emotions
449449
* and sometimes console him (BarrierEmpty, BarrierTimeout), sometimes tell
450450
* him to hate the world (WrongBarrier, DuplicateNode, ClientLost). The latter shall help

osgi/src/main/scala/org/apache/pekko/osgi/BundleDelegatingClassLoader.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -31,7 +31,7 @@ import org.apache.pekko.util.ccompat.JavaConverters._
3131
*/
3232
object BundleDelegatingClassLoader {
3333

34-
/*
34+
/**
3535
* Create a bundle delegating ClassLoader for the bundle context's bundle
3636
*/
3737
def apply(context: BundleContext): BundleDelegatingClassLoader =

remote/src/main/scala/org/apache/pekko/remote/RemoteActorRefProvider.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -108,7 +108,7 @@ private[pekko] object RemoteActorRefProvider {
108108

109109
}
110110

111-
/*
111+
/**
112112
* Remoting wraps messages destined to a remote host in a remoting specific envelope: EndpointManager.Send
113113
* As these wrapped messages might arrive to the dead letters of an EndpointWriter, they need to be unwrapped
114114
* and handled as dead letters to the original (remote) destination. Without this special case, DeathWatch related

remote/src/main/scala/org/apache/pekko/remote/transport/PekkoProtocolTransport.scala

Lines changed: 3 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -243,21 +243,21 @@ private[remote] class PekkoProtocolHandle(
243243
private[remote] object ProtocolStateActor {
244244
sealed trait AssociationState
245245

246-
/*
246+
/**
247247
* State when the underlying transport is not yet initialized
248248
* State data can be OutboundUnassociated
249249
*/
250250
case object Closed extends AssociationState
251251

252-
/*
252+
/**
253253
* State when the underlying transport is initialized, there is an association present, and we are waiting
254254
* for the first message (has to be CONNECT if inbound).
255255
* State data can be OutboundUnderlyingAssociated (for outbound associations) or InboundUnassociated (for inbound
256256
* when upper layer is not notified yet)
257257
*/
258258
case object WaitHandshake extends AssociationState
259259

260-
/*
260+
/**
261261
* State when the underlying transport is initialized and the handshake succeeded.
262262
* If the upper layer did not yet provided a handler for incoming messages, state data is AssociatedWaitHandler.
263263
* If everything is initialized, the state data is HandlerReady

stream/src/main/scala/org/apache/pekko/stream/impl/Sinks.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -85,7 +85,7 @@ import pekko.util.ccompat._
8585
@InternalApi private[pekko] class PublisherSink[In](val attributes: Attributes, shape: SinkShape[In])
8686
extends SinkModule[In, Publisher[In]](shape) {
8787

88-
/*
88+
/**
8989
* This method is the reason why SinkModule.create may return something that is
9090
* not a Subscriber: a VirtualPublisher is used in order to avoid the immediate
9191
* subscription a VirtualProcessor would perform (and it also saves overhead).

stream/src/main/scala/org/apache/pekko/stream/javadsl/Source.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -704,7 +704,7 @@ object Source {
704704
new Source(scaladsl.Source.zipN(seq).map(_.asJava))
705705
}
706706

707-
/*
707+
/**
708708
* Combine the elements of multiple streams into a stream of lists using a combiner function.
709709
*/
710710
def zipWithN[T, O](

stream/src/main/scala/org/apache/pekko/stream/scaladsl/Source.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -815,7 +815,7 @@ object Source {
815815
def zipN[T](sources: immutable.Seq[Source[T, _]]): Source[immutable.Seq[T], NotUsed] =
816816
zipWithN(ConstantFun.scalaIdentityFunction[immutable.Seq[T]])(sources).addAttributes(DefaultAttributes.zipN)
817817

818-
/*
818+
/**
819819
* Combine the elements of multiple streams into a stream of sequences using a combiner function.
820820
*/
821821
def zipWithN[T, O](zipper: immutable.Seq[T] => O)(sources: immutable.Seq[Source[T, _]]): Source[O, NotUsed] = {

testkit/src/main/scala/org/apache/pekko/testkit/CallingThreadDispatcher.scala

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -110,7 +110,7 @@ private[testkit] class CallingThreadDispatcherQueues extends Extension {
110110
queues -= mbox
111111
}
112112

113-
/*
113+
/**
114114
* This method must be called with "own" being this thread's queue for the
115115
* given mailbox. When this method returns, the queue will be entered
116116
* (active).
@@ -248,7 +248,7 @@ class CallingThreadDispatcher(_configurator: MessageDispatcherConfigurator) exte
248248

249249
protected[pekko] override def executeTask(invocation: TaskInvocation): Unit = { invocation.run() }
250250

251-
/*
251+
/**
252252
* This method must be called with this thread's queue.
253253
*
254254
* If the catch block is executed, then a non-empty mailbox may be stalled as

0 commit comments

Comments
 (0)