You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pekko.apache.org by he...@apache.org on 2023/01/12 02:59:35 UTC

[incubator-pekko] branch main updated (e365e44aea -> 4ac0f00a47)

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

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


    from e365e44aea add link to CLA page (#97)
     new 3323ff6eb3 !sbt Use Apache header for new files.
     new 4ac0f00a47 Update headers with The Apache header annotated.

The 2 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .../actor/testkit/typed/CapturedLogEvent.scala     |  9 +++
 .../apache/pekko/actor/testkit/typed/Effect.scala  |  9 +++
 .../pekko/actor/testkit/typed/FishingOutcome.scala |  9 +++
 .../pekko/actor/testkit/typed/LoggingEvent.scala   |  9 +++
 .../pekko/actor/testkit/typed/TestException.scala  |  9 +++
 .../actor/testkit/typed/TestKitSettings.scala      |  9 +++
 .../testkit/typed/internal/ActorSystemStub.scala   |  9 +++
 .../typed/internal/BehaviorTestKitImpl.scala       |  9 +++
 .../testkit/typed/internal/CapturingAppender.scala |  9 +++
 .../typed/internal/ControlledExecutor.scala        |  9 +++
 .../actor/testkit/typed/internal/DebugRef.scala    |  9 +++
 .../typed/internal/EffectfulActorContext.scala     |  9 +++
 .../actor/testkit/typed/internal/LogbackUtil.scala |  9 +++
 .../typed/internal/LoggingTestKitImpl.scala        |  9 +++
 .../typed/internal/StubbedActorContext.scala       |  9 +++
 .../testkit/typed/internal/TestAppender.scala      |  9 +++
 .../testkit/typed/internal/TestInboxImpl.scala     |  9 +++
 .../testkit/typed/internal/TestKitUtils.scala      |  9 +++
 .../testkit/typed/internal/TestProbeImpl.scala     |  9 +++
 .../actor/testkit/typed/javadsl/ActorTestKit.scala |  9 +++
 .../testkit/typed/javadsl/BehaviorTestKit.scala    |  9 +++
 .../actor/testkit/typed/javadsl/Effects.scala      |  9 +++
 .../actor/testkit/typed/javadsl/LogCapturing.scala |  9 +++
 .../testkit/typed/javadsl/LoggingTestKit.scala     |  9 +++
 .../actor/testkit/typed/javadsl/ManualTime.scala   |  9 +++
 .../typed/javadsl/SerializationTestKit.scala       |  9 +++
 .../actor/testkit/typed/javadsl/TestInbox.scala    |  9 +++
 .../typed/javadsl/TestKitJunitResource.scala       |  9 +++
 .../actor/testkit/typed/javadsl/TestProbe.scala    |  9 +++
 .../testkit/typed/scaladsl/ActorTestKit.scala      |  9 +++
 .../testkit/typed/scaladsl/ActorTestKitBase.scala  |  9 +++
 .../testkit/typed/scaladsl/BehaviorTestKit.scala   |  9 +++
 .../actor/testkit/typed/scaladsl/Effects.scala     |  9 +++
 .../testkit/typed/scaladsl/LogCapturing.scala      |  9 +++
 .../testkit/typed/scaladsl/LoggingTestKit.scala    |  9 +++
 .../actor/testkit/typed/scaladsl/ManualTime.scala  |  9 +++
 .../typed/scaladsl/ScalaTestWithActorTestKit.scala |  9 +++
 .../typed/scaladsl/SerializationTestKit.scala      |  9 +++
 .../actor/testkit/typed/scaladsl/TestInbox.scala   |  9 +++
 .../actor/testkit/typed/scaladsl/TestProbe.scala   |  9 +++
 .../actor/testkit/typed/scaladsl/package.scala     |  9 +++
 .../typed/javadsl/AsyncTestingExampleTest.java     |  9 +++
 .../typed/javadsl/JunitIntegrationExampleTest.java |  9 +++
 .../typed/javadsl/LogCapturingExampleTest.java     |  9 +++
 .../typed/javadsl/ManualTimerExampleTest.java      |  9 +++
 .../typed/javadsl/SyncTestingExampleTest.java      |  9 +++
 .../testkit/typed/javadsl/TestConfigExample.java   |  9 +++
 .../testkit/typed/javadsl/ActorTestKitApiTest.java |  9 +++
 .../testkit/typed/javadsl/ActorTestKitTest.java    |  9 +++
 .../testkit/typed/javadsl/BehaviorTestKitTest.java |  9 +++
 .../testkit/typed/javadsl/LoggingTestKitTest.java  |  9 +++
 .../actor/testkit/typed/javadsl/TestProbeTest.java |  9 +++
 .../typed/scaladsl/AsyncTestingExampleSpec.scala   |  9 +++
 .../typed/scaladsl/ManualTimerExampleSpec.scala    |  9 +++
 .../scaladsl/ScalaTestIntegrationExampleSpec.scala |  9 +++
 .../typed/scaladsl/SyncTestingExampleSpec.scala    |  9 +++
 .../testkit/typed/scaladsl/TestConfigExample.scala |  9 +++
 .../testkit/typed/scaladsl/ActorTestKitSpec.scala  |  9 +++
 .../typed/scaladsl/BehaviorTestKitSpec.scala       |  9 +++
 .../typed/scaladsl/LoggingEventFilterSpec.scala    |  9 +++
 .../testkit/typed/scaladsl/TestAppenderSpec.scala  |  9 +++
 .../testkit/typed/scaladsl/TestProbeSpec.scala     |  9 +++
 .../apache/pekko/actor/AbstractFSMActorTest.java   |  9 +++
 .../org/apache/pekko/actor/ActorCreationTest.java  |  9 +++
 .../org/apache/pekko/actor/ActorSelectionTest.java |  9 +++
 .../org/apache/pekko/actor/ActorSystemTest.java    |  9 +++
 .../java/org/apache/pekko/actor/AddressTest.java   |  9 +++
 .../test/java/org/apache/pekko/actor/JavaAPI.java  |  9 +++
 .../org/apache/pekko/actor/JavaAPITestActor.java   |  9 +++
 .../java/org/apache/pekko/actor/JavaExtension.java |  9 +++
 .../org/apache/pekko/actor/NonPublicClass.java     |  9 +++
 .../org/apache/pekko/actor/NonStaticCreator.java   |  9 +++
 .../java/org/apache/pekko/actor/StashJavaAPI.java  |  9 +++
 .../apache/pekko/actor/StashJavaAPITestActors.java |  9 +++
 .../org/apache/pekko/actor/TestAnnotation.java     |  9 +++
 .../pekko/actor/setup/ActorSystemSetupTest.java    |  9 +++
 .../org/apache/pekko/dispatch/JavaFutureTests.java |  9 +++
 .../java/org/apache/pekko/event/ActorWithMDC.java  |  9 +++
 .../org/apache/pekko/event/LoggingAdapterTest.java |  9 +++
 .../org/apache/pekko/japi/JavaAPITestBase.java     |  9 +++
 .../org/apache/pekko/japi/MatchBuilderTest.java    |  9 +++
 .../java/org/apache/pekko/japi/ThrowablesTest.java |  9 +++
 .../org/apache/pekko/japi/pf/PFBuilderTest.java    |  9 +++
 .../apache/pekko/japi/pf/ReceiveBuilderTest.java   |  9 +++
 .../apache/pekko/pattern/CircuitBreakerTest.java   |  9 +++
 .../org/apache/pekko/pattern/PatternsTest.java     |  9 +++
 .../org/apache/pekko/pattern/StatusReplyTest.java  |  9 +++
 .../java/org/apache/pekko/util/ByteStringTest.java |  9 +++
 .../java/org/apache/pekko/util/JavaDuration.java   |  9 +++
 .../pekko/util/LineNumberSpecCodeForJava.java      |  9 +++
 .../org/apache/pekko/util/LineNumberSpec.scala     | 23 ++++--
 .../org/apache/pekko/util/TypedMultiMapSpec.scala  |  9 +++
 .../src/test/scala/org/apache/pekko/Messages.scala |  9 +++
 .../org/apache/pekko/PekkoExceptionSpec.scala      |  9 +++
 .../scala/org/apache/pekko/PekkoVersionSpec.scala  |  9 +++
 .../actor/ActorConfigurationVerificationSpec.scala |  9 +++
 .../apache/pekko/actor/ActorCreationPerfSpec.scala |  9 +++
 .../apache/pekko/actor/ActorLifeCycleSpec.scala    |  9 +++
 .../org/apache/pekko/actor/ActorMailboxSpec.scala  |  9 +++
 .../org/apache/pekko/actor/ActorPathSpec.scala     |  9 +++
 .../org/apache/pekko/actor/ActorRefSpec.scala      |  9 +++
 .../apache/pekko/actor/ActorSelectionSpec.scala    |  9 +++
 .../pekko/actor/ActorSystemDispatcherSpec.scala    |  9 +++
 .../org/apache/pekko/actor/ActorSystemSpec.scala   |  9 +++
 .../org/apache/pekko/actor/ActorTimeoutSpec.scala  |  9 +++
 .../pekko/actor/ActorWithBoundedStashSpec.scala    |  9 +++
 .../apache/pekko/actor/ActorWithStashSpec.scala    |  9 +++
 .../org/apache/pekko/actor/ConsistencySpec.scala   |  9 +++
 .../pekko/actor/CoordinatedShutdownSpec.scala      |  9 +++
 .../pekko/actor/DeadLetterSupressionSpec.scala     |  9 +++
 .../pekko/actor/DeadLetterSuspensionSpec.scala     |  9 +++
 .../org/apache/pekko/actor/DeathWatchSpec.scala    |  9 +++
 .../org/apache/pekko/actor/DeployerSpec.scala      |  9 +++
 .../org/apache/pekko/actor/DynamicAccessSpec.scala |  9 +++
 .../org/apache/pekko/actor/ExtensionSpec.scala     |  9 +++
 .../org/apache/pekko/actor/FSMActorSpec.scala      |  9 +++
 .../org/apache/pekko/actor/FSMTimingSpec.scala     |  9 +++
 .../org/apache/pekko/actor/FSMTransitionSpec.scala |  9 +++
 .../org/apache/pekko/actor/ForwardActorSpec.scala  |  9 +++
 .../org/apache/pekko/actor/FunctionRefSpec.scala   |  9 +++
 .../scala/org/apache/pekko/actor/HotSwapSpec.scala |  9 +++
 .../pekko/actor/LocalActorRefProviderSpec.scala    |  9 +++
 .../org/apache/pekko/actor/PropsCreationSpec.scala |  9 +++
 .../apache/pekko/actor/ProviderSelectionSpec.scala |  9 +++
 .../apache/pekko/actor/ReceiveTimeoutSpec.scala    |  9 +++
 .../apache/pekko/actor/RelativeActorPathSpec.scala |  9 +++
 .../apache/pekko/actor/RestartStrategySpec.scala   |  9 +++
 .../org/apache/pekko/actor/SchedulerSpec.scala     |  9 +++
 .../scala/org/apache/pekko/actor/Supervisor.scala  |  9 +++
 .../pekko/actor/SupervisorHierarchySpec.scala      |  9 +++
 .../apache/pekko/actor/SupervisorMiscSpec.scala    |  9 +++
 .../org/apache/pekko/actor/SupervisorSpec.scala    |  9 +++
 .../apache/pekko/actor/SupervisorTreeSpec.scala    |  9 +++
 .../org/apache/pekko/actor/Ticket669Spec.scala     |  9 +++
 .../scala/org/apache/pekko/actor/TimerSpec.scala   |  9 +++
 .../org/apache/pekko/actor/TypedActorSpec.scala    |  9 +++
 .../org/apache/pekko/actor/UidClashTest.scala      |  9 +++
 .../pekko/actor/dispatch/ActorModelSpec.scala      |  9 +++
 .../actor/dispatch/BalancingDispatcherSpec.scala   |  9 +++
 .../pekko/actor/dispatch/DispatcherActorSpec.scala |  9 +++
 .../actor/dispatch/DispatcherActorsSpec.scala      |  9 +++
 .../pekko/actor/dispatch/DispatchersSpec.scala     |  9 +++
 .../pekko/actor/dispatch/PinnedActorSpec.scala     |  9 +++
 .../apache/pekko/actor/dungeon/DispatchSpec.scala  |  9 +++
 .../apache/pekko/actor/routing/ListenerSpec.scala  |  9 +++
 .../pekko/actor/setup/ActorSystemSetupSpec.scala   |  9 +++
 .../scala/org/apache/pekko/config/ConfigSpec.scala |  9 +++
 .../org/apache/pekko/dataflow/Future2Actor.scala   |  9 +++
 .../dispatch/ControlAwareDispatcherSpec.scala      |  9 +++
 .../pekko/dispatch/DispatcherShutdownSpec.scala    |  9 +++
 .../pekko/dispatch/ExecutionContextSpec.scala      |  9 +++
 .../dispatch/ForkJoinPoolStarvationSpec.scala      |  9 +++
 .../apache/pekko/dispatch/MailboxConfigSpec.scala  |  9 +++
 .../pekko/dispatch/PriorityDispatcherSpec.scala    |  9 +++
 .../dispatch/SameThreadExecutionContextSpec.scala  |  9 +++
 .../dispatch/StablePriorityDispatcherSpec.scala    |  9 +++
 .../dispatch/sysmsg/SystemMessageListSpec.scala    |  9 +++
 .../event/AddressTerminatedTopicBenchSpec.scala    |  9 +++
 .../org/apache/pekko/event/EventBusSpec.scala      |  9 +++
 .../org/apache/pekko/event/EventStreamSpec.scala   |  9 +++
 .../scala/org/apache/pekko/event/LoggerSpec.scala  |  9 +++
 .../apache/pekko/event/LoggingReceiveSpec.scala    |  9 +++
 .../org/apache/pekko/event/MarkerLoggingSpec.scala |  9 +++
 .../apache/pekko/event/jul/JavaLoggerSpec.scala    |  9 +++
 .../org/apache/pekko/io/CapacityLimitSpec.scala    |  9 +++
 .../pekko/io/InetAddressDnsResolverSpec.scala      |  9 +++
 .../org/apache/pekko/io/SimpleDnsCacheSpec.scala   |  9 +++
 .../org/apache/pekko/io/TcpConnectionSpec.scala    |  9 +++
 .../org/apache/pekko/io/TcpIntegrationSpec.scala   |  9 +++
 .../pekko/io/TcpIntegrationSpecSupport.scala       |  9 +++
 .../org/apache/pekko/io/TcpListenerSpec.scala      |  9 +++
 .../pekko/io/UdpConnectedIntegrationSpec.scala     |  9 +++
 .../org/apache/pekko/io/UdpIntegrationSpec.scala   |  9 +++
 .../io/dns/AsyncDnsResolverIntegrationSpec.scala   |  9 +++
 .../org/apache/pekko/io/dns/DnsSettingsSpec.scala  |  9 +++
 .../apache/pekko/io/dns/DockerBindDnsService.scala |  9 +++
 .../pekko/io/dns/NameserverAddressParserSpec.scala |  9 +++
 .../io/dns/internal/AsyncDnsManagerSpec.scala      |  9 +++
 .../io/dns/internal/AsyncDnsResolverSpec.scala     |  9 +++
 .../pekko/io/dns/internal/DnsClientSpec.scala      |  9 +++
 .../apache/pekko/io/dns/internal/MessageSpec.scala |  9 +++
 .../io/dns/internal/ResolvConfParserSpec.scala     |  9 +++
 .../pekko/io/dns/internal/TcpDnsClientSpec.scala   |  9 +++
 .../scala/org/apache/pekko/pattern/AskSpec.scala   |  9 +++
 .../pattern/BackoffOnRestartSupervisorSpec.scala   |  9 +++
 .../pekko/pattern/BackoffSupervisorSpec.scala      |  9 +++
 .../pekko/pattern/CircuitBreakerMTSpec.scala       |  9 +++
 .../apache/pekko/pattern/CircuitBreakerSpec.scala  |  9 +++
 .../pekko/pattern/CircuitBreakerStressSpec.scala   |  9 +++
 .../org/apache/pekko/pattern/PatternSpec.scala     |  9 +++
 .../org/apache/pekko/pattern/PipeToSpec.scala      |  9 +++
 .../org/apache/pekko/pattern/PromiseRefSpec.scala  |  9 +++
 .../scala/org/apache/pekko/pattern/RetrySpec.scala |  9 +++
 .../org/apache/pekko/pattern/StatusReplySpec.scala |  9 +++
 .../pekko/pattern/extended/ExplicitAskSpec.scala   |  9 +++
 .../org/apache/pekko/routing/BalancingSpec.scala   |  9 +++
 .../org/apache/pekko/routing/BroadcastSpec.scala   |  9 +++
 .../pekko/routing/ConfiguredLocalRoutingSpec.scala |  9 +++
 .../routing/ConsistentHashingRouterSpec.scala      |  9 +++
 .../pekko/routing/MetricsBasedResizerSpec.scala    |  9 +++
 .../org/apache/pekko/routing/RandomSpec.scala      |  9 +++
 .../org/apache/pekko/routing/ResizerSpec.scala     |  9 +++
 .../org/apache/pekko/routing/RoundRobinSpec.scala  |  9 +++
 .../apache/pekko/routing/RouteeCreationSpec.scala  |  9 +++
 .../org/apache/pekko/routing/RoutingSpec.scala     |  9 +++
 .../routing/ScatterGatherFirstCompletedSpec.scala  |  9 +++
 .../apache/pekko/routing/SmallestMailboxSpec.scala |  9 +++
 .../apache/pekko/routing/TailChoppingSpec.scala    |  9 +++
 .../pekko/serialization/AsyncSerializeSpec.scala   |  9 +++
 .../DisabledJavaSerializerWarningSpec.scala        |  9 +++
 .../pekko/serialization/NoVerification.scala       |  9 +++
 .../PrimitivesSerializationSpec.scala              |  9 +++
 .../serialization/SerializationSetupSpec.scala     |  9 +++
 .../apache/pekko/serialization/SerializeSpec.scala |  9 +++
 .../testkit/CallingThreadDispatcherModelSpec.scala |  9 +++
 .../apache/pekko/util/AsciiStringCopySpec.scala    |  9 +++
 .../pekko/util/BoundedBlockingQueueSpec.scala      |  9 +++
 .../org/apache/pekko/util/ByteIteratorSpec.scala   |  9 +++
 .../pekko/util/ByteStringInitializationSpec.scala  |  9 +++
 .../org/apache/pekko/util/ByteStringSpec.scala     |  9 +++
 .../apache/pekko/util/DoubleLinkedListSpec.scala   |  9 +++
 .../scala/org/apache/pekko/util/DurationSpec.scala |  9 +++
 .../org/apache/pekko/util/FrequencyListSpec.scala  |  9 +++
 .../apache/pekko/util/FrequencySketchSpec.scala    |  9 +++
 .../apache/pekko/util/ImmutableIntMapSpec.scala    |  9 +++
 .../scala/org/apache/pekko/util/IndexSpec.scala    |  9 +++
 .../pekko/util/LineNumberSpecCodeForScala.scala    |  9 +++
 .../org/apache/pekko/util/ManifestInfoSpec.scala   |  9 +++
 .../org/apache/pekko/util/MessageBufferSpec.scala  |  9 +++
 .../org/apache/pekko/util/PrettyDurationSpec.scala |  9 +++
 .../org/apache/pekko/util/RecencyListSpec.scala    |  9 +++
 .../scala/org/apache/pekko/util/ReflectSpec.scala  |  9 +++
 .../pekko/util/SegmentedRecencyListSpec.scala      |  9 +++
 .../scala/org/apache/pekko/util/SwitchSpec.scala   |  9 +++
 .../org/apache/pekko/util/TokenBucketSpec.scala    |  9 +++
 .../scala/org/apache/pekko/util/VersionSpec.scala  |  9 +++
 .../org/apache/pekko/util/WildcardIndexSpec.scala  |  9 +++
 .../org/apache/pekko/util/ZipfianGenerator.scala   |  9 +++
 .../other/SerializerOutsidePekkoPackage.scala      |  9 +++
 .../jdocs/org/apache/pekko/typed/Aggregator.java   |  9 +++
 .../org/apache/pekko/typed/AggregatorTest.java     |  9 +++
 .../org/apache/pekko/typed/BubblingSample.java     |  9 +++
 .../org/apache/pekko/typed/BubblingSampleTest.java |  9 +++
 .../org/apache/pekko/typed/DispatchersDocTest.java |  9 +++
 .../jdocs/org/apache/pekko/typed/FSMDocTest.java   |  9 +++
 .../apache/pekko/typed/GracefulStopDocTest.java    |  9 +++
 .../InteractionPatternsAskWithStatusTest.java      |  9 +++
 .../pekko/typed/InteractionPatternsTest.java       |  9 +++
 .../jdocs/org/apache/pekko/typed/IntroTest.java    |  9 +++
 .../org/apache/pekko/typed/LoggingDocExamples.java |  9 +++
 .../org/apache/pekko/typed/MailboxDocTest.java     |  9 +++
 .../jdocs/org/apache/pekko/typed/OOIntroTest.java  |  9 +++
 .../jdocs/org/apache/pekko/typed/RouterTest.java   |  9 +++
 .../apache/pekko/typed/SpawnProtocolDocTest.java   |  9 +++
 .../org/apache/pekko/typed/StashDocSample.java     |  9 +++
 .../jdocs/org/apache/pekko/typed/StashDocTest.java |  9 +++
 .../apache/pekko/typed/StyleGuideDocExamples.java  |  9 +++
 .../jdocs/org/apache/pekko/typed/TailChopping.java |  9 +++
 .../coexistence/ClassicWatchingTypedTest.java      |  9 +++
 .../coexistence/TypedWatchingClassicTest.java      |  9 +++
 .../pekko/typed/extensions/ExtensionDocTest.java   |  9 +++
 .../pekko/typed/fromclassic/ClassicSample.java     |  9 +++
 .../pekko/typed/fromclassic/TypedSample.java       |  9 +++
 .../apache/pekko/typed/pubsub/PubSubExample.java   |  9 +++
 .../supervision/SupervisionCompileOnlyTest.java    |  9 +++
 .../apache/pekko/actor/typed/ActorSystemTest.java  |  9 +++
 .../pekko/actor/typed/DispatcherSelectorTest.java  |  9 +++
 .../apache/pekko/actor/typed/ExtensionsTest.java   |  9 +++
 .../pekko/actor/typed/MailboxSelectorTest.java     |  9 +++
 .../apache/pekko/actor/typed/SchedulerTest.java    |  9 +++
 .../actor/typed/eventstream/EventStreamTest.java   |  9 +++
 .../pekko/actor/typed/javadsl/ActorCompile.java    |  9 +++
 .../actor/typed/javadsl/ActorContextAskTest.java   |  9 +++
 .../typed/javadsl/ActorContextPipeToSelfTest.java  |  9 +++
 .../actor/typed/javadsl/ActorLoggingTest.java      |  9 +++
 .../pekko/actor/typed/javadsl/AdapterTest.java     |  9 +++
 .../actor/typed/javadsl/BehaviorBuilderTest.java   |  9 +++
 .../pekko/actor/typed/javadsl/InterceptTest.java   |  9 +++
 .../actor/typed/javadsl/ReceiveBuilderTest.java    |  9 +++
 .../pekko/actor/typed/javadsl/RoutersTest.java     |  9 +++
 .../pekko/actor/typed/javadsl/StashBufferTest.java |  9 +++
 .../pekko/actor/typed/javadsl/WatchTest.java       |  9 +++
 .../typed/receptionist/ReceptionistApiTest.java    |  9 +++
 .../docs/org/apache/pekko/typed/Aggregator.scala   |  9 +++
 .../org/apache/pekko/typed/AggregatorSpec.scala    |  9 +++
 .../apache/pekko/typed/DispatchersDocSpec.scala    |  9 +++
 .../docs/org/apache/pekko/typed/FSMDocSpec.scala   |  9 +++
 .../apache/pekko/typed/FaultToleranceDocSpec.scala |  9 +++
 .../apache/pekko/typed/GracefulStopDocSpec.scala   |  9 +++
 .../pekko/typed/InteractionPatternsSpec.scala      |  9 +++
 .../docs/org/apache/pekko/typed/IntroSpec.scala    |  9 +++
 .../apache/pekko/typed/LoggingDocExamples.scala    |  9 +++
 .../org/apache/pekko/typed/MailboxDocSpec.scala    |  9 +++
 .../docs/org/apache/pekko/typed/OOIntroSpec.scala  |  9 +++
 .../docs/org/apache/pekko/typed/RouterSpec.scala   |  9 +++
 .../apache/pekko/typed/SpawnProtocolDocSpec.scala  |  9 +++
 .../docs/org/apache/pekko/typed/StashDocSpec.scala |  9 +++
 .../apache/pekko/typed/StyleGuideDocExamples.scala |  9 +++
 .../docs/org/apache/pekko/typed/TailChopping.scala |  9 +++
 .../coexistence/ClassicWatchingTypedSpec.scala     |  9 +++
 .../coexistence/TypedWatchingClassicSpec.scala     |  9 +++
 .../pekko/typed/extensions/ExtensionDocSpec.scala  |  9 +++
 .../pekko/typed/fromclassic/ClassicSample.scala    |  9 +++
 .../pekko/typed/fromclassic/TypedSample.scala      |  9 +++
 .../org/apache/pekko/typed/myapp/package.scala     |  9 +++
 .../apache/pekko/typed/pubsub/PubSubExample.scala  |  9 +++
 .../typed/supervision/SupervisionCompileOnly.scala |  9 +++
 .../pekko/actor/typed/ActorContextSpec.scala       |  9 +++
 .../pekko/actor/typed/ActorRefIgnoreSpec.scala     |  9 +++
 .../pekko/actor/typed/ActorRefResolverSpec.scala   |  9 +++
 .../org/apache/pekko/actor/typed/AskSpec.scala     |  9 +++
 .../apache/pekko/actor/typed/BehaviorSpec.scala    |  9 +++
 .../apache/pekko/actor/typed/DeferredSpec.scala    |  9 +++
 .../apache/pekko/actor/typed/ExtensionsSpec.scala  |  9 +++
 .../apache/pekko/actor/typed/InterceptSpec.scala   |  9 +++
 .../LocalActorRefProviderLogMessagesSpec.scala     |  9 +++
 .../apache/pekko/actor/typed/LogMessagesSpec.scala |  9 +++
 .../pekko/actor/typed/MailboxSelectorSpec.scala    |  9 +++
 .../org/apache/pekko/actor/typed/MonitorSpec.scala |  9 +++
 .../org/apache/pekko/actor/typed/OrElseSpec.scala  |  9 +++
 .../org/apache/pekko/actor/typed/PropsSpec.scala   |  9 +++
 .../apache/pekko/actor/typed/SchedulerSpec.scala   |  9 +++
 .../pekko/actor/typed/SpawnProtocolSpec.scala      |  9 +++
 .../apache/pekko/actor/typed/SupervisionSpec.scala |  9 +++
 .../apache/pekko/actor/typed/TerminatedSpec.scala  |  9 +++
 .../org/apache/pekko/actor/typed/TimerSpec.scala   |  9 +++
 .../pekko/actor/typed/TransformMessagesSpec.scala  |  9 +++
 .../org/apache/pekko/actor/typed/WatchSpec.scala   |  9 +++
 .../coexistence/ClassicSupervisingTypedSpec.scala  |  9 +++
 .../coexistence/TypedSupervisingClassicSpec.scala  |  9 +++
 .../typed/delivery/ConsumerControllerSpec.scala    |  9 +++
 .../delivery/DurableProducerControllerSpec.scala   |  9 +++
 .../typed/delivery/DurableProducerQueueSpec.scala  |  9 +++
 .../typed/delivery/DurableWorkPullingSpec.scala    |  9 +++
 .../typed/delivery/ProducerControllerSpec.scala    |  9 +++
 .../delivery/ReliableDeliveryRandomSpec.scala      |  9 +++
 .../typed/delivery/ReliableDeliverySpec.scala      |  9 +++
 .../pekko/actor/typed/delivery/TestConsumer.scala  |  9 +++
 .../typed/delivery/TestDurableProducerQueue.scala  |  9 +++
 .../pekko/actor/typed/delivery/TestProducer.scala  |  9 +++
 .../actor/typed/delivery/TestProducerWithAsk.scala |  9 +++
 .../typed/delivery/TestProducerWorkPulling.scala   |  9 +++
 .../actor/typed/delivery/WorkPullingSpec.scala     |  9 +++
 .../actor/typed/eventstream/EventStreamSpec.scala  |  9 +++
 .../typed/internal/ActorRefSerializationSpec.scala |  9 +++
 .../actor/typed/internal/ActorSystemSpec.scala     |  9 +++
 .../typed/internal/adpater/PropsAdapterSpec.scala  |  9 +++
 .../receptionist/LocalReceptionistSpec.scala       |  9 +++
 .../receptionist/ServiceKeySerializationSpec.scala |  9 +++
 .../typed/internal/routing/PoolRouterSpec.scala    |  9 +++
 .../typed/internal/routing/RoutingLogicSpec.scala  |  9 +++
 .../typed/javadsl/AdaptationFailureSpec.scala      |  9 +++
 .../pekko/actor/typed/pubsub/LocalPubSubSpec.scala |  9 +++
 .../typed/receptionist/ReceptionistApiSpec.scala   |  9 +++
 .../actor/typed/scaladsl/ActorContextAskSpec.scala |  9 +++
 .../typed/scaladsl/ActorContextDelegateSpec.scala  |  9 +++
 .../scaladsl/ActorContextPipeToSelfSpec.scala      |  9 +++
 .../actor/typed/scaladsl/ActorLoggingSpec.scala    |  9 +++
 .../actor/typed/scaladsl/ActorThreadSpec.scala     |  9 +++
 .../typed/scaladsl/AdaptationFailureSpec.scala     |  9 +++
 .../typed/scaladsl/DispatcherSelectorSpec.scala    |  9 +++
 .../actor/typed/scaladsl/GracefulStopSpec.scala    |  9 +++
 .../pekko/actor/typed/scaladsl/LoggerOpsSpec.scala |  9 +++
 .../actor/typed/scaladsl/MessageAdapterSpec.scala  |  9 +++
 .../pekko/actor/typed/scaladsl/OnSignalSpec.scala  |  9 +++
 .../actor/typed/scaladsl/ReceivePartialSpec.scala  |  9 +++
 .../pekko/actor/typed/scaladsl/RoutersSpec.scala   |  9 +++
 .../actor/typed/scaladsl/StashBufferSpec.scala     |  9 +++
 .../pekko/actor/typed/scaladsl/StashSpec.scala     |  9 +++
 .../pekko/actor/typed/scaladsl/StopSpec.scala      |  9 +++
 .../actor/typed/scaladsl/adapter/AdapterSpec.scala |  9 +++
 .../scaladsl/adapter/GuardianStartupSpec.scala     |  9 +++
 .../typed/internal/receptionist/Platform.scala     |  9 +++
 .../pekko/actor/typed/internal/jfr/Events.scala    |  9 +++
 .../internal/jfr/JFRActorFlightRecorder.scala      |  9 +++
 .../org/apache/pekko/actor/typed/ActorRef.scala    |  9 +++
 .../pekko/actor/typed/ActorRefResolver.scala       |  9 +++
 .../org/apache/pekko/actor/typed/ActorSystem.scala |  9 +++
 .../org/apache/pekko/actor/typed/Behavior.scala    |  9 +++
 .../pekko/actor/typed/BehaviorInterceptor.scala    |  9 +++
 .../org/apache/pekko/actor/typed/Dispatchers.scala |  9 +++
 .../org/apache/pekko/actor/typed/Extensions.scala  |  9 +++
 .../org/apache/pekko/actor/typed/LogOptions.scala  |  9 +++
 .../pekko/actor/typed/MessageAndSignals.scala      |  9 +++
 .../scala/org/apache/pekko/actor/typed/Props.scala |  9 +++
 .../org/apache/pekko/actor/typed/Scheduler.scala   |  9 +++
 .../apache/pekko/actor/typed/SpawnProtocol.scala   |  9 +++
 .../pekko/actor/typed/SupervisorStrategy.scala     |  9 +++
 .../pekko/actor/typed/TypedActorContext.scala      |  9 +++
 .../actor/typed/delivery/ConsumerController.scala  |  9 +++
 .../typed/delivery/DurableProducerQueue.scala      |  9 +++
 .../actor/typed/delivery/ProducerController.scala  |  9 +++
 .../delivery/WorkPullingProducerController.scala   |  9 +++
 .../typed/delivery/internal/ChunkedMessage.scala   |  9 +++
 .../delivery/internal/ConsumerControllerImpl.scala |  9 +++
 .../delivery/internal/DeliverySerializable.scala   |  9 +++
 .../delivery/internal/ProducerControllerImpl.scala |  9 +++
 .../WorkPullingProducerControllerImpl.scala        |  9 +++
 .../actor/typed/eventstream/EventStream.scala      |  9 +++
 .../actor/typed/internal/ActorContextImpl.scala    |  9 +++
 .../actor/typed/internal/ActorFlightRecorder.scala |  9 +++
 .../pekko/actor/typed/internal/ActorMdc.scala      |  9 +++
 .../pekko/actor/typed/internal/ActorRefImpl.scala  |  9 +++
 .../pekko/actor/typed/internal/BehaviorImpl.scala  |  9 +++
 .../typed/internal/EventStreamExtension.scala      |  9 +++
 .../actor/typed/internal/ExtensionsImpl.scala      |  9 +++
 .../actor/typed/internal/InterceptorImpl.scala     |  9 +++
 .../actor/typed/internal/InternalMessage.scala     |  9 +++
 .../typed/internal/InternalRecipientRef.scala      |  9 +++
 .../pekko/actor/typed/internal/LoggerClass.scala   |  9 +++
 .../typed/internal/MiscMessageSerializer.scala     |  9 +++
 .../pekko/actor/typed/internal/PoisonPill.scala    |  9 +++
 .../pekko/actor/typed/internal/PropsImpl.scala     |  9 +++
 .../actor/typed/internal/StashBufferImpl.scala     |  9 +++
 .../pekko/actor/typed/internal/Supervision.scala   |  9 +++
 .../pekko/actor/typed/internal/SystemMessage.scala |  9 +++
 .../actor/typed/internal/TimerSchedulerImpl.scala  |  9 +++
 .../internal/WithMdcBehaviorInterceptor.scala      |  9 +++
 .../typed/internal/adapter/ActorAdapter.scala      |  9 +++
 .../internal/adapter/ActorContextAdapter.scala     |  9 +++
 .../typed/internal/adapter/ActorRefAdapter.scala   |  9 +++
 .../internal/adapter/ActorRefFactoryAdapter.scala  |  9 +++
 .../internal/adapter/ActorSystemAdapter.scala      |  9 +++
 .../typed/internal/adapter/AdapterExtension.scala  |  9 +++
 .../internal/adapter/EventStreamAdapter.scala      |  9 +++
 .../internal/adapter/GuardianStartupBehavior.scala |  9 +++
 .../typed/internal/adapter/PropsAdapter.scala      |  9 +++
 .../typed/internal/adapter/SchedulerAdapter.scala  |  9 +++
 .../actor/typed/internal/pubsub/TopicImpl.scala    |  9 +++
 .../internal/receptionist/LocalReceptionist.scala  |  9 +++
 .../internal/receptionist/ReceptionistImpl.scala   |  9 +++
 .../receptionist/ReceptionistMessages.scala        |  9 +++
 .../typed/internal/receptionist/ServiceKey.scala   |  9 +++
 .../receptionist/ServiceKeySerializer.scala        |  9 +++
 .../typed/internal/routing/GroupRouterImpl.scala   |  9 +++
 .../typed/internal/routing/PoolRouterImpl.scala    |  9 +++
 .../typed/internal/routing/RoutingLogic.scala      |  9 +++
 .../actor/typed/javadsl/AbstractBehavior.scala     |  9 +++
 .../pekko/actor/typed/javadsl/ActorContext.scala   |  9 +++
 .../apache/pekko/actor/typed/javadsl/Adapter.scala |  9 +++
 .../pekko/actor/typed/javadsl/AskPattern.scala     |  9 +++
 .../actor/typed/javadsl/BehaviorBuilder.scala      |  9 +++
 .../pekko/actor/typed/javadsl/Behaviors.scala      |  9 +++
 .../apache/pekko/actor/typed/javadsl/Receive.scala |  9 +++
 .../pekko/actor/typed/javadsl/ReceiveBuilder.scala |  9 +++
 .../apache/pekko/actor/typed/javadsl/Routers.scala |  9 +++
 .../pekko/actor/typed/javadsl/StashBuffer.scala    |  9 +++
 .../pekko/actor/typed/javadsl/TimerScheduler.scala |  9 +++
 .../apache/pekko/actor/typed/pubsub/Topic.scala    |  9 +++
 .../actor/typed/receptionist/Receptionist.scala    |  9 +++
 .../actor/typed/scaladsl/AbstractBehavior.scala    |  9 +++
 .../pekko/actor/typed/scaladsl/ActorContext.scala  |  9 +++
 .../pekko/actor/typed/scaladsl/AskPattern.scala    |  9 +++
 .../pekko/actor/typed/scaladsl/Behaviors.scala     |  9 +++
 .../pekko/actor/typed/scaladsl/Routers.scala       |  9 +++
 .../pekko/actor/typed/scaladsl/StashBuffer.scala   |  9 +++
 .../actor/typed/scaladsl/TimerScheduler.scala      |  9 +++
 .../typed/scaladsl/adapter/PropsAdapter.scala      |  9 +++
 .../actor/typed/scaladsl/adapter/package.scala     |  9 +++
 .../pekko/actor/typed/scaladsl/package.scala       |  9 +++
 .../pekko/japi/function/Functions.scala.template   |  9 +++
 .../apache/pekko/japi/tuple/Tuples.scala.template  |  9 +++
 .../org/apache/pekko/actor/AbstractActorRef.java   |  9 +++
 .../org/apache/pekko/actor/AbstractScheduler.java  |  9 +++
 .../pekko/actor/dungeon/AbstractActorCell.java     |  9 +++
 .../org/apache/pekko/annotation/ApiMayChange.java  |  9 +++
 .../org/apache/pekko/annotation/DoNotInherit.java  |  9 +++
 .../org/apache/pekko/annotation/InternalApi.java   |  9 +++
 .../apache/pekko/annotation/InternalStableApi.java |  9 +++
 .../pekko/dispatch/AbstractBoundedNodeQueue.java   |  9 +++
 .../org/apache/pekko/dispatch/AbstractMailbox.java |  9 +++
 .../pekko/dispatch/AbstractMessageDispatcher.java  |  9 +++
 .../apache/pekko/dispatch/AbstractNodeQueue.java   |  9 +++
 .../apache/pekko/dispatch/affinity/OnSpinWait.java |  9 +++
 .../src/main/java/org/apache/pekko/japi/JAPI.java  |  9 +++
 .../org/apache/pekko/japi/pf/AbstractMatch.java    |  9 +++
 .../apache/pekko/japi/pf/AbstractPFBuilder.java    |  9 +++
 .../org/apache/pekko/japi/pf/DeciderBuilder.java   |  9 +++
 .../src/main/java/org/apache/pekko/japi/pf/FI.java |  9 +++
 .../pekko/japi/pf/FSMStateFunctionBuilder.java     |  9 +++
 .../org/apache/pekko/japi/pf/FSMStopBuilder.java   |  9 +++
 .../pekko/japi/pf/FSMTransitionHandlerBuilder.java |  9 +++
 .../main/java/org/apache/pekko/japi/pf/Match.java  |  9 +++
 .../java/org/apache/pekko/japi/pf/PFBuilder.java   |  9 +++
 .../org/apache/pekko/japi/pf/ReceiveBuilder.java   |  9 +++
 .../java/org/apache/pekko/japi/pf/UnitMatch.java   |  9 +++
 .../org/apache/pekko/japi/pf/UnitPFBuilder.java    |  9 +++
 .../pekko/pattern/AbstractCircuitBreaker.java      |  9 +++
 .../pekko/pattern/AbstractPromiseActorRef.java     |  9 +++
 .../main/java/org/apache/pekko/util/Unsafe.java    |  9 +++
 .../org/apache/pekko/compat/Future.scala           |  9 +++
 .../org/apache/pekko/compat/PartialFunction.scala  |  9 +++
 .../internal/SameThreadExecutionContext.scala      |  9 +++
 .../pekko/util/ccompat/ccompatUsedUntil213.scala   |  9 +++
 .../org/apache/pekko/util/ccompat/package.scala    |  9 +++
 .../pekko/dispatch/internal/ScalaBatchable.scala   |  9 +++
 .../org/apache/pekko/util/ByteIterator.scala       |  9 +++
 .../org/apache/pekko/util/ByteString.scala         |  9 +++
 actor/src/main/scala/org/apache/pekko/Done.scala   |  9 +++
 actor/src/main/scala/org/apache/pekko/Main.scala   |  9 +++
 .../src/main/scala/org/apache/pekko/NotUsed.scala  |  9 +++
 .../scala/org/apache/pekko/PekkoException.scala    |  9 +++
 .../main/scala/org/apache/pekko/PekkoVersion.scala |  9 +++
 .../org/apache/pekko/actor/AbstractActor.scala     |  9 +++
 .../scala/org/apache/pekko/actor/AbstractFSM.scala |  9 +++
 .../org/apache/pekko/actor/AbstractProps.scala     |  9 +++
 .../main/scala/org/apache/pekko/actor/Actor.scala  |  9 +++
 .../scala/org/apache/pekko/actor/ActorCell.scala   |  9 +++
 .../org/apache/pekko/actor/ActorLogMarker.scala    |  9 +++
 .../scala/org/apache/pekko/actor/ActorPath.scala   |  9 +++
 .../scala/org/apache/pekko/actor/ActorRef.scala    |  9 +++
 .../org/apache/pekko/actor/ActorRefProvider.scala  |  9 +++
 .../org/apache/pekko/actor/ActorSelection.scala    |  9 +++
 .../scala/org/apache/pekko/actor/ActorSystem.scala |  9 +++
 .../scala/org/apache/pekko/actor/Address.scala     |  9 +++
 .../pekko/actor/ClassicActorSystemProvider.scala   |  9 +++
 .../apache/pekko/actor/CoordinatedShutdown.scala   |  9 +++
 .../scala/org/apache/pekko/actor/Deployer.scala    |  9 +++
 .../org/apache/pekko/actor/DynamicAccess.scala     |  9 +++
 .../scala/org/apache/pekko/actor/Extension.scala   |  9 +++
 .../main/scala/org/apache/pekko/actor/FSM.scala    |  9 +++
 .../org/apache/pekko/actor/FaultHandling.scala     |  9 +++
 .../apache/pekko/actor/IndirectActorProducer.scala |  9 +++
 .../pekko/actor/LightArrayRevolverScheduler.scala  |  9 +++
 .../main/scala/org/apache/pekko/actor/Props.scala  |  9 +++
 .../pekko/actor/ReflectiveDynamicAccess.scala      |  9 +++
 .../apache/pekko/actor/RepointableActorRef.scala   |  9 +++
 .../scala/org/apache/pekko/actor/Scheduler.scala   |  9 +++
 .../main/scala/org/apache/pekko/actor/Stash.scala  |  9 +++
 .../main/scala/org/apache/pekko/actor/Timers.scala |  9 +++
 .../scala/org/apache/pekko/actor/TypedActor.scala  |  9 +++
 .../org/apache/pekko/actor/dungeon/Children.scala  |  9 +++
 .../pekko/actor/dungeon/ChildrenContainer.scala    |  9 +++
 .../apache/pekko/actor/dungeon/DeathWatch.scala    |  9 +++
 .../org/apache/pekko/actor/dungeon/Dispatch.scala  |  9 +++
 .../apache/pekko/actor/dungeon/FaultHandling.scala |  9 +++
 .../pekko/actor/dungeon/ReceiveTimeout.scala       |  9 +++
 .../pekko/actor/dungeon/TimerSchedulerImpl.scala   |  9 +++
 .../scala/org/apache/pekko/actor/package.scala     |  9 +++
 .../pekko/actor/setup/ActorSystemSetup.scala       |  9 +++
 .../apache/pekko/dispatch/AbstractDispatcher.scala |  9 +++
 .../pekko/dispatch/BalancingDispatcher.scala       |  9 +++
 .../apache/pekko/dispatch/BatchingExecutor.scala   |  9 +++
 .../org/apache/pekko/dispatch/CachingConfig.scala  |  9 +++
 .../org/apache/pekko/dispatch/Dispatcher.scala     |  9 +++
 .../org/apache/pekko/dispatch/Dispatchers.scala    |  9 +++
 .../dispatch/ForkJoinExecutorConfigurator.scala    |  9 +++
 .../scala/org/apache/pekko/dispatch/Future.scala   |  9 +++
 .../scala/org/apache/pekko/dispatch/Mailbox.scala  |  9 +++
 .../org/apache/pekko/dispatch/Mailboxes.scala      |  9 +++
 .../apache/pekko/dispatch/PinnedDispatcher.scala   |  9 +++
 .../apache/pekko/dispatch/ThreadPoolBuilder.scala  |  9 +++
 .../pekko/dispatch/affinity/AffinityPool.scala     |  9 +++
 .../pekko/dispatch/sysmsg/SystemMessage.scala      |  9 +++
 .../event/ActorClassificationUnsubscriber.scala    |  9 +++
 .../pekko/event/AddressTerminatedTopic.scala       |  9 +++
 .../apache/pekko/event/DeadLetterListener.scala    |  9 +++
 .../scala/org/apache/pekko/event/EventBus.scala    |  9 +++
 .../scala/org/apache/pekko/event/EventStream.scala |  9 +++
 .../pekko/event/EventStreamUnsubscriber.scala      |  9 +++
 .../org/apache/pekko/event/LoggerMailbox.scala     |  9 +++
 .../scala/org/apache/pekko/event/Logging.scala     |  9 +++
 .../org/apache/pekko/event/LoggingReceive.scala    |  9 +++
 .../apache/pekko/event/japi/EventBusJavaAPI.scala  |  9 +++
 .../org/apache/pekko/event/jul/JavaLogger.scala    |  9 +++
 .../org/apache/pekko/io/DirectByteBufferPool.scala |  9 +++
 actor/src/main/scala/org/apache/pekko/io/Dns.scala |  9 +++
 .../scala/org/apache/pekko/io/DnsProvider.scala    |  9 +++
 actor/src/main/scala/org/apache/pekko/io/IO.scala  |  9 +++
 .../src/main/scala/org/apache/pekko/io/Inet.scala  |  9 +++
 .../apache/pekko/io/InetAddressDnsProvider.scala   |  9 +++
 .../apache/pekko/io/InetAddressDnsResolver.scala   |  9 +++
 .../org/apache/pekko/io/SelectionHandler.scala     |  9 +++
 .../scala/org/apache/pekko/io/SimpleDnsCache.scala |  9 +++
 .../org/apache/pekko/io/SimpleDnsManager.scala     |  9 +++
 actor/src/main/scala/org/apache/pekko/io/Tcp.scala |  9 +++
 .../scala/org/apache/pekko/io/TcpConnection.scala  |  9 +++
 .../apache/pekko/io/TcpIncomingConnection.scala    |  9 +++
 .../scala/org/apache/pekko/io/TcpListener.scala    |  9 +++
 .../scala/org/apache/pekko/io/TcpManager.scala     |  9 +++
 .../apache/pekko/io/TcpOutgoingConnection.scala    |  9 +++
 actor/src/main/scala/org/apache/pekko/io/Udp.scala |  9 +++
 .../scala/org/apache/pekko/io/UdpConnected.scala   |  9 +++
 .../org/apache/pekko/io/UdpConnectedManager.scala  |  9 +++
 .../scala/org/apache/pekko/io/UdpConnection.scala  |  9 +++
 .../scala/org/apache/pekko/io/UdpListener.scala    |  9 +++
 .../scala/org/apache/pekko/io/UdpManager.scala     |  9 +++
 .../main/scala/org/apache/pekko/io/UdpSender.scala |  9 +++
 .../scala/org/apache/pekko/io/WithUdpSend.scala    |  9 +++
 .../org/apache/pekko/io/dns/CachePolicy.scala      |  9 +++
 .../org/apache/pekko/io/dns/DnsProtocol.scala      |  9 +++
 .../apache/pekko/io/dns/DnsResourceRecords.scala   |  9 +++
 .../org/apache/pekko/io/dns/DnsSettings.scala      |  9 +++
 .../org/apache/pekko/io/dns/RecordClass.scala      |  9 +++
 .../scala/org/apache/pekko/io/dns/RecordType.scala |  9 +++
 .../pekko/io/dns/internal/AsyncDnsManager.scala    |  9 +++
 .../pekko/io/dns/internal/AsyncDnsProvider.scala   |  9 +++
 .../pekko/io/dns/internal/AsyncDnsResolver.scala   |  9 +++
 .../apache/pekko/io/dns/internal/DnsClient.scala   |  9 +++
 .../apache/pekko/io/dns/internal/DnsMessage.scala  |  9 +++
 .../apache/pekko/io/dns/internal/DomainName.scala  |  9 +++
 .../apache/pekko/io/dns/internal/Question.scala    |  9 +++
 .../io/dns/internal/RecordClassSerializer.scala    |  9 +++
 .../io/dns/internal/RecordTypeSerializer.scala     |  9 +++
 .../pekko/io/dns/internal/ResolvConfParser.scala   |  9 +++
 .../pekko/io/dns/internal/TcpDnsClient.scala       |  9 +++
 .../org/apache/pekko/io/dns/internal/package.scala |  9 +++
 .../main/scala/org/apache/pekko/japi/JavaAPI.scala |  9 +++
 .../scala/org/apache/pekko/japi/Throwables.scala   |  9 +++
 .../org/apache/pekko/japi/function/Function.scala  |  9 +++
 .../org/apache/pekko/japi/pf/CaseStatements.scala  |  9 +++
 .../org/apache/pekko/pattern/AskSupport.scala      |  9 +++
 .../scala/org/apache/pekko/pattern/Backoff.scala   |  9 +++
 .../org/apache/pekko/pattern/BackoffOptions.scala  |  9 +++
 .../apache/pekko/pattern/BackoffSupervisor.scala   |  9 +++
 .../org/apache/pekko/pattern/CircuitBreaker.scala  |  9 +++
 .../pekko/pattern/CircuitBreakersRegistry.scala    |  9 +++
 .../pekko/pattern/FutureTimeoutSupport.scala       |  9 +++
 .../apache/pekko/pattern/GracefulStopSupport.scala |  9 +++
 .../org/apache/pekko/pattern/HandleBackoff.scala   |  9 +++
 .../scala/org/apache/pekko/pattern/Patterns.scala  |  9 +++
 .../org/apache/pekko/pattern/PipeToSupport.scala   |  9 +++
 .../org/apache/pekko/pattern/PromiseRef.scala      |  9 +++
 .../org/apache/pekko/pattern/RetrySupport.scala    |  9 +++
 .../org/apache/pekko/pattern/StatusReply.scala     |  9 +++
 .../apache/pekko/pattern/extended/package.scala    |  9 +++
 .../internal/BackoffOnRestartSupervisor.scala      |  9 +++
 .../pattern/internal/BackoffOnStopSupervisor.scala |  9 +++
 .../pattern/internal/CircuitBreakerTelemetry.scala |  9 +++
 .../scala/org/apache/pekko/pattern/package.scala   |  9 +++
 .../scala/org/apache/pekko/routing/Balancing.scala |  9 +++
 .../scala/org/apache/pekko/routing/Broadcast.scala |  9 +++
 .../org/apache/pekko/routing/ConsistentHash.scala  |  9 +++
 .../apache/pekko/routing/ConsistentHashing.scala   |  9 +++
 .../scala/org/apache/pekko/routing/Listeners.scala |  9 +++
 .../routing/OptimalSizeExploringResizer.scala      |  9 +++
 .../scala/org/apache/pekko/routing/Random.scala    |  9 +++
 .../scala/org/apache/pekko/routing/Resizer.scala   |  9 +++
 .../org/apache/pekko/routing/RoundRobin.scala      |  9 +++
 .../org/apache/pekko/routing/RoutedActorCell.scala |  9 +++
 .../org/apache/pekko/routing/RoutedActorRef.scala  |  9 +++
 .../scala/org/apache/pekko/routing/Router.scala    |  9 +++
 .../org/apache/pekko/routing/RouterConfig.scala    |  9 +++
 .../routing/ScatterGatherFirstCompleted.scala      |  9 +++
 .../org/apache/pekko/routing/SmallestMailbox.scala |  9 +++
 .../org/apache/pekko/routing/TailChopping.scala    |  9 +++
 .../pekko/serialization/AsyncSerializer.scala      |  9 +++
 .../pekko/serialization/PrimitiveSerializers.scala |  9 +++
 .../apache/pekko/serialization/Serialization.scala |  9 +++
 .../serialization/SerializationExtension.scala     |  9 +++
 .../pekko/serialization/SerializationSetup.scala   |  9 +++
 .../apache/pekko/serialization/Serializer.scala    |  9 +++
 .../apache/pekko/util/BoundedBlockingQueue.scala   |  9 +++
 .../scala/org/apache/pekko/util/BoxedType.scala    |  9 +++
 .../pekko/util/ClassLoaderObjectInputStream.scala  |  9 +++
 .../scala/org/apache/pekko/util/Collections.scala  |  9 +++
 .../scala/org/apache/pekko/util/ConstantFun.scala  |  9 +++
 .../org/apache/pekko/util/DoubleLinkedList.scala   |  9 +++
 .../org/apache/pekko/util/ErrorMessages.scala      |  9 +++
 .../apache/pekko/util/FlightRecorderLoader.scala   |  9 +++
 .../org/apache/pekko/util/FrequencyList.scala      |  9 +++
 .../org/apache/pekko/util/FrequencySketch.scala    |  9 +++
 .../scala/org/apache/pekko/util/HashCode.scala     |  9 +++
 .../main/scala/org/apache/pekko/util/Helpers.scala |  9 +++
 .../org/apache/pekko/util/ImmutableIntMap.scala    |  9 +++
 .../main/scala/org/apache/pekko/util/Index.scala   |  9 +++
 .../apache/pekko/util/JavaDurationConverters.scala |  9 +++
 .../scala/org/apache/pekko/util/JavaVersion.scala  |  9 +++
 .../scala/org/apache/pekko/util/LineNumbers.scala  |  9 +++
 .../scala/org/apache/pekko/util/LockUtil.scala     |  9 +++
 .../scala/org/apache/pekko/util/ManifestInfo.scala |  9 +++
 .../org/apache/pekko/util/MessageBuffer.scala      |  9 +++
 .../scala/org/apache/pekko/util/OptionVal.scala    |  9 +++
 .../org/apache/pekko/util/PrettyByteString.scala   |  9 +++
 .../org/apache/pekko/util/PrettyDuration.scala     |  9 +++
 .../scala/org/apache/pekko/util/RecencyList.scala  |  9 +++
 .../main/scala/org/apache/pekko/util/Reflect.scala |  9 +++
 .../apache/pekko/util/SegmentedRecencyList.scala   |  9 +++
 .../SerializedSuspendableExecutionContext.scala    |  9 +++
 .../apache/pekko/util/StablePriorityQueue.scala    |  9 +++
 .../org/apache/pekko/util/SubclassifiedIndex.scala |  9 +++
 .../main/scala/org/apache/pekko/util/Timeout.scala |  9 +++
 .../scala/org/apache/pekko/util/TokenBucket.scala  |  9 +++
 .../org/apache/pekko/util/TypedMultiMap.scala      |  9 +++
 .../org/apache/pekko/util/UUIDComparator.scala     |  9 +++
 .../main/scala/org/apache/pekko/util/Unused.scala  |  9 +++
 .../main/scala/org/apache/pekko/util/Version.scala |  9 +++
 .../scala/org/apache/pekko/util/WallClock.scala    |  9 +++
 .../org/apache/pekko/util/WildcardIndex.scala      |  9 +++
 .../akka/serialization/jackson/JavaMessages.java   |  9 +++
 .../main/scala/org/apache/pekko/BenchRunner.scala  |  9 +++
 .../org/apache/pekko/actor/ActorBenchmark.scala    |  9 +++
 .../pekko/actor/ActorCreationBenchmark.scala       |  9 +++
 .../pekko/actor/ActorPathValidationBenchmark.scala |  9 +++
 .../actor/AffinityPoolComparativeBenchmark.scala   |  9 +++
 .../actor/AffinityPoolIdleCPULevelBenchmark.scala  |  9 +++
 .../AffinityPoolRequestResponseBenchmark.scala     |  9 +++
 .../org/apache/pekko/actor/BenchmarkActors.scala   |  9 +++
 .../actor/DirectByteBufferPoolBenchmark.scala      |  9 +++
 .../pekko/actor/ForkJoinActorBenchmark.scala       |  9 +++
 .../org/apache/pekko/actor/JCToolsMailbox.scala    |  9 +++
 .../apache/pekko/actor/ManyToOneArrayMailbox.scala |  9 +++
 .../apache/pekko/actor/RequestResponseActors.scala |  9 +++
 .../pekko/actor/RouterPoolCreationBenchmark.scala  |  9 +++
 .../org/apache/pekko/actor/ScheduleBenchmark.scala |  9 +++
 .../pekko/actor/StashCreationBenchmark.scala       |  9 +++
 .../org/apache/pekko/actor/TellOnlyBenchmark.scala |  9 +++
 .../pekko/actor/typed/TypedActorBenchmark.scala    |  9 +++
 .../pekko/actor/typed/TypedBenchmarkActors.scala   |  9 +++
 .../actor/typed/TypedForkJoinActorBenchmark.scala  |  9 +++
 .../typed/delivery/ReliableDeliveryBenchmark.scala |  9 +++
 .../pekko/cluster/ddata/ORSetMergeBenchmark.scala  |  9 +++
 .../ddata/ORSetSerializationBenchmark.scala        |  9 +++
 .../cluster/ddata/VersionVectorBenchmark.scala     |  9 +++
 .../pekko/dispatch/CachingConfigBenchmark.scala    |  9 +++
 .../apache/pekko/dispatch/NodeQueueBenchmark.scala |  9 +++
 .../pekko/event/LogLevelAccessBenchmark.scala      |  9 +++
 .../org/apache/pekko/persistence/Common.scala      |  9 +++
 .../persistence/LevelDbBatchingBenchmark.scala     |  9 +++
 .../PersistenceActorDeferBenchmark.scala           |  9 +++
 .../persistence/PersistentActorBenchmark.scala     |  9 +++
 ...tentActorWithAtLeastOnceDeliveryBenchmark.scala |  9 +++
 .../pekko/remote/artery/BenchTestSource.scala      |  9 +++
 .../pekko/remote/artery/CodecBenchmark.scala       |  9 +++
 .../org/apache/pekko/remote/artery/LatchSink.scala |  9 +++
 .../remote/artery/LiteralEncodingBenchmark.scala   |  9 +++
 .../pekko/remote/artery/SendQueueBenchmark.scala   |  9 +++
 .../artery/compress/CountMinSketchBenchmark.scala  |  9 +++
 .../compress/InvertCompressionTableBenchmark.scala |  9 +++
 .../SerializationFormatCacheBenchmark.scala        |  9 +++
 .../remote/compress/HeavyHittersBenchmark.scala    |  9 +++
 .../jackson/JacksonSerializationBench.scala        |  9 +++
 .../org/apache/pekko/stream/AskBenchmark.scala     |  9 +++
 .../apache/pekko/stream/EmptySourceBenchmark.scala |  9 +++
 .../pekko/stream/FlatMapConcatBenchmark.scala      |  9 +++
 .../pekko/stream/FlatMapMergeBenchmark.scala       |  9 +++
 .../org/apache/pekko/stream/FlowMapBenchmark.scala |  9 +++
 .../org/apache/pekko/stream/FramingBenchmark.scala |  9 +++
 .../apache/pekko/stream/FusedGraphsBenchmark.scala |  9 +++
 .../pekko/stream/GraphBuilderBenchmark.scala       |  9 +++
 .../apache/pekko/stream/InterpreterBenchmark.scala |  9 +++
 .../pekko/stream/InvokeWithFeedbackBenchmark.scala |  9 +++
 .../apache/pekko/stream/JsonFramingBenchmark.scala |  9 +++
 .../apache/pekko/stream/MapAsyncBenchmark.scala    |  9 +++
 .../pekko/stream/MaterializationBenchmark.scala    |  9 +++
 .../pekko/stream/PartitionHubBenchmark.scala       |  9 +++
 .../apache/pekko/stream/SourceRefBenchmark.scala   |  9 +++
 .../impl/OutputStreamSourceStageBenchmark.scala    |  9 +++
 .../pekko/stream/io/FileSourcesBenchmark.scala     |  9 +++
 .../stream/io/FileSourcesScaleBenchmark.scala      |  9 +++
 .../pekko/util/ByteString_append_Benchmark.scala   |  9 +++
 .../pekko/util/ByteString_apply_Benchmark.scala    |  9 +++
 .../util/ByteString_copyToBuffer_Benchmark.scala   |  9 +++
 .../pekko/util/ByteString_decode_Benchmark.scala   |  9 +++
 .../util/ByteString_dropRight_Benchmark.scala      |  9 +++
 .../util/ByteString_dropSliceTake_Benchmark.scala  |  9 +++
 .../pekko/util/ByteString_drop_Benchmark.scala     |  9 +++
 .../pekko/util/ByteString_grouped_Benchmark.scala  |  9 +++
 .../pekko/util/ByteString_indexOf_Benchmark.scala  |  9 +++
 .../pekko/util/ByteString_take_Benchmark.scala     |  9 +++
 .../pekko/util/ByteString_toArray_Benchmark.scala  |  9 +++
 .../pekko/util/FastFrequencySketchBenchmark.scala  |  9 +++
 .../pekko/util/FrequencySketchBenchmark.scala      |  9 +++
 .../apache/pekko/util/ImmutableIntMapBench.scala   |  9 +++
 .../apache/pekko/util/LruBoundedCacheBench.scala   |  9 +++
 .../scala/org/apache/pekko/util/StackBench.scala   |  9 +++
 .../protobuf/msg/ClusterMetricsMessages.java       |  9 +++
 .../src/main/protobuf/ClusterMetricsMessages.proto |  9 +++
 .../cluster/metrics/ClusterMetricsCollector.scala  |  9 +++
 .../cluster/metrics/ClusterMetricsExtension.scala  |  9 +++
 .../cluster/metrics/ClusterMetricsRouting.scala    |  9 +++
 .../cluster/metrics/ClusterMetricsSettings.scala   |  9 +++
 .../cluster/metrics/ClusterMetricsStrategy.scala   |  9 +++
 .../org/apache/pekko/cluster/metrics/EWMA.scala    |  9 +++
 .../org/apache/pekko/cluster/metrics/Metric.scala  |  9 +++
 .../pekko/cluster/metrics/MetricsCollector.scala   |  9 +++
 .../apache/pekko/cluster/metrics/Provision.scala   |  9 +++
 .../metrics/protobuf/MessageSerializer.scala       |  9 +++
 .../metrics/ClusterMetricsExtensionSpec.scala      |  9 +++
 .../metrics/ClusterMetricsRoutingSpec.scala        |  9 +++
 .../cluster/metrics/sample/StatsMessages.scala     |  9 +++
 .../cluster/metrics/sample/StatsSampleSpec.scala   |  9 +++
 .../cluster/metrics/sample/StatsService.scala      |  9 +++
 .../pekko/cluster/metrics/sample/StatsWorker.scala |  9 +++
 .../metrics/ClusterMetricsExtensionSpec.scala      |  9 +++
 .../metrics/ClusterMetricsRoutingSpec.scala        |  9 +++
 .../metrics/ClusterMetricsSettingsSpec.scala       |  9 +++
 .../apache/pekko/cluster/metrics/EWMASpec.scala    |  9 +++
 .../apache/pekko/cluster/metrics/MetricSpec.scala  |  9 +++
 .../cluster/metrics/MetricsCollectorSpec.scala     |  9 +++
 .../apache/pekko/cluster/metrics/TestUtil.scala    |  9 +++
 .../cluster/metrics/WeightedRouteesSpec.scala      |  9 +++
 .../metrics/protobuf/MessageSerializerSpec.scala   |  9 +++
 .../typed/internal/protobuf/ShardingMessages.java  |  9 +++
 .../src/main/protobuf/ShardingMessages.proto       |  9 +++
 .../sharding/typed/ClusterShardingQuery.scala      |  9 +++
 .../sharding/typed/ClusterShardingSettings.scala   |  9 +++
 .../sharding/typed/Murmur2MessageExtractor.scala   |  9 +++
 .../sharding/typed/ReplicatedEntityProvider.scala  |  9 +++
 .../typed/ReplicatedShardingExtension.scala        |  9 +++
 .../typed/ShardedDaemonProcessSettings.scala       |  9 +++
 .../sharding/typed/ShardingDirectReplication.scala |  9 +++
 .../sharding/typed/ShardingMessageExtractor.scala  |  9 +++
 .../delivery/ShardingConsumerController.scala      |  9 +++
 .../delivery/ShardingProducerController.scala      |  9 +++
 .../internal/ShardingConsumerControllerImpl.scala  |  9 +++
 .../internal/ShardingProducerControllerImpl.scala  |  9 +++
 .../typed/internal/ClusterShardingImpl.scala       |  9 +++
 .../JoinConfigCompatCheckerClusterSharding.scala   |  9 +++
 .../internal/ReplicatedShardingExtensionImpl.scala |  9 +++
 .../typed/internal/ShardedDaemonProcessImpl.scala  |  9 +++
 .../typed/internal/ShardingSerializer.scala        |  9 +++
 .../sharding/typed/internal/ShardingState.scala    |  9 +++
 .../typed/internal/testkit/TestEntityRefImpl.scala |  9 +++
 .../sharding/typed/javadsl/ClusterSharding.scala   |  9 +++
 .../typed/javadsl/ShardedDaemonProcess.scala       |  9 +++
 .../sharding/typed/scaladsl/ClusterSharding.scala  |  9 +++
 .../typed/scaladsl/ShardedDaemonProcess.scala      |  9 +++
 .../sharding/typed/testkit/javadsl/EntityRef.scala |  9 +++
 .../typed/testkit/scaladsl/EntityRef.scala         |  9 +++
 .../ClusterShardingRememberEntitiesPerfSpec.scala  |  9 +++
 .../ClusterShardingPreparingForShutdownSpec.scala  |  9 +++
 .../sharding/typed/ClusterShardingStatsSpec.scala  |  9 +++
 .../typed/MultiDcClusterShardingSpec.scala         |  9 +++
 .../sharding/typed/ReplicatedShardingSpec.scala    |  9 +++
 .../sharding/typed/ShardedDaemonProcessSpec.scala  |  9 +++
 .../typed/delivery/DeliveryThroughputSpec.scala    |  9 +++
 .../jdocs/delivery/PointToPointDocExample.java     |  9 +++
 .../java/jdocs/delivery/ShardingDocExample.java    |  9 +++
 .../java/jdocs/delivery/WorkPullingDocExample.java |  9 +++
 .../sharding/typed/AccountExampleDocTest.java      |  9 +++
 .../cluster/sharding/typed/AccountExampleTest.java |  9 +++
 .../AccountExampleWithEventHandlersInState.java    |  9 +++
 .../typed/AccountExampleWithMutableState.java      |  9 +++
 .../typed/AccountExampleWithNullDurableState.java  |  9 +++
 .../typed/AccountExampleWithNullState.java         |  9 +++
 ...DurableStateStoreQueryUsageCompileOnlyTest.java |  9 +++
 .../ExternalShardAllocationCompileOnlyTest.java    |  9 +++
 .../HelloWorldEventSourcedEntityExampleTest.java   |  9 +++
 .../typed/HelloWorldPersistentEntityExample.java   |  9 +++
 .../typed/ReplicatedShardingCompileOnlySpec.java   |  9 +++
 .../sharding/typed/ShardingCompileOnlyTest.java    |  9 +++
 .../typed/ShardingReplyCompileOnlyTest.java        |  9 +++
 .../sharding/typed/ReplicatedShardingTest.java     |  9 +++
 .../javadsl/ClusterShardingPersistenceTest.java    |  9 +++
 .../ClusterShardingSettingsCompileOnly.java        |  9 +++
 .../ShardedDaemonProcessCompileOnlyTest.java       |  9 +++
 ...edEntityWithEnforcedRepliesCompileOnlyTest.java |  9 +++
 .../docs/delivery/PointToPointDocExample.scala     |  9 +++
 .../scala/docs/delivery/ShardingDocExample.scala   |  9 +++
 .../docs/delivery/WorkPullingDocExample.scala      |  9 +++
 .../sharding/typed/AccountExampleDocSpec.scala     |  9 +++
 .../sharding/typed/AccountExampleSpec.scala        |  9 +++
 ...tExampleWithCommandHandlersInDurableState.scala |  9 +++
 .../AccountExampleWithCommandHandlersInState.scala |  9 +++
 .../AccountExampleWithEventHandlersInState.scala   |  9 +++
 .../AccountExampleWithOptionDurableState.scala     |  9 +++
 .../typed/AccountExampleWithOptionState.scala      |  9 +++
 ...urableStateStoreQueryUsageCompileOnlySpec.scala |  9 +++
 .../ExternalShardAllocationCompileOnlySpec.scala   |  9 +++
 .../HelloWorldEventSourcedEntityExampleSpec.scala  |  9 +++
 .../typed/HelloWorldPersistentEntityExample.scala  |  9 +++
 .../typed/ReplicatedShardingCompileOnlySpec.scala  |  9 +++
 .../sharding/typed/ShardingCompileOnlySpec.scala   |  9 +++
 .../pekko/cluster/sharding/FlightRecording.scala   |  9 +++
 ...oinConfigCompatCheckerClusterShardingSpec.scala |  9 +++
 .../ReplicatedShardingDirectReplicationSpec.scala  |  9 +++
 .../sharding/typed/ReplicatedShardingSpec.scala    |  9 +++
 .../sharding/typed/ShardingSerializerSpec.scala    |  9 +++
 .../typed/delivery/DurableShardingSpec.scala       |  9 +++
 .../delivery/ReliableDeliveryShardingSpec.scala    |  9 +++
 .../sharding/typed/internal/Murmur2Spec.scala      |  9 +++
 .../scaladsl/ClusterShardingPersistenceSpec.scala  |  9 +++
 .../typed/scaladsl/ClusterShardingSpec.scala       |  9 +++
 .../typed/scaladsl/ClusterShardingStateSpec.scala  |  9 +++
 .../typed/scaladsl/ClusterShardingStatsSpec.scala  |  9 +++
 .../typed/scaladsl/ShardedDaemonProcessSpec.scala  |  9 +++
 .../typed/testkit/scaladsl/TestEntityRefSpec.scala |  9 +++
 .../protobuf/msg/ClusterShardingMessages.java      |  9 +++
 .../main/protobuf/ClusterShardingMessages.proto    |  9 +++
 .../cluster/sharding/internal/jfr/Events.scala     |  9 +++
 .../internal/jfr/JFRShardingFlightRecorder.scala   |  9 +++
 .../pekko/cluster/sharding/ClusterSharding.scala   |  9 +++
 .../sharding/ClusterShardingHealthCheck.scala      |  9 +++
 .../sharding/ClusterShardingSerializable.scala     |  9 +++
 .../cluster/sharding/ClusterShardingSettings.scala |  9 +++
 .../sharding/JoinConfigCompatCheckSharding.scala   |  9 +++
 .../OldCoordinatorStateMigrationEventAdapter.scala |  9 +++
 .../RemoveInternalClusterShardingData.scala        |  9 +++
 .../org/apache/pekko/cluster/sharding/Shard.scala  |  9 +++
 .../pekko/cluster/sharding/ShardCoordinator.scala  |  9 +++
 .../pekko/cluster/sharding/ShardRegion.scala       |  9 +++
 .../cluster/sharding/ShardingFlightRecorder.scala  |  9 +++
 .../pekko/cluster/sharding/ShardingLogMarker.scala |  9 +++
 .../pekko/cluster/sharding/ShardingQueries.scala   |  9 +++
 .../sharding/external/ClientTimeoutException.scala |  9 +++
 .../external/ExternalShardAllocation.scala         |  9 +++
 .../external/ExternalShardAllocationStrategy.scala |  9 +++
 .../cluster/sharding/external/ShardLocations.scala |  9 +++
 .../ExternalShardAllocationClientImpl.scala        |  9 +++
 .../javadsl/ExternalShardAllocationClient.scala    |  9 +++
 .../scaladsl/ExternalShardAllocationClient.scala   |  9 +++
 .../AbstractLeastShardAllocationStrategy.scala     |  9 +++
 .../internal/CustomStateStoreModeProvider.scala    |  9 +++
 .../DDataRememberEntitiesCoordinatorStore.scala    |  9 +++
 .../internal/DDataRememberEntitiesProvider.scala   |  9 +++
 .../internal/DDataRememberEntitiesShardStore.scala |  9 +++
 .../internal/EntityPassivationStrategy.scala       |  9 +++
 ...ntSourcedRememberEntitiesCoordinatorStore.scala |  9 +++
 .../EventSourcedRememberEntitiesProvider.scala     |  9 +++
 .../EventSourcedRememberEntitiesShardStore.scala   |  9 +++
 .../internal/LeastShardAllocationStrategy.scala    |  9 +++
 .../sharding/internal/RememberEntitiesStore.scala  |  9 +++
 .../sharding/internal/RememberEntityStarter.scala  |  9 +++
 .../ClusterShardingMessageSerializer.scala         |  9 +++
 .../apache/pekko/cluster/sbr/GlobalRegistry.scala  |  9 +++
 .../pekko/cluster/sbr/GremlinController.scala      |  9 +++
 .../RandomizedBrainResolverIntegrationSpec.scala   |  9 +++
 .../pekko/cluster/sbr/SbrTestLeaseActor.scala      |  9 +++
 .../sbr/SplitBrainResolverIntegrationSpec.scala    |  9 +++
 .../ClusterShardCoordinatorDowning2Spec.scala      |  9 +++
 .../ClusterShardCoordinatorDowningSpec.scala       |  9 +++
 .../ClusterShardingCustomShardAllocationSpec.scala |  9 +++
 .../sharding/ClusterShardingFailureSpec.scala      |  9 +++
 .../sharding/ClusterShardingGetStateSpec.scala     |  9 +++
 .../sharding/ClusterShardingGetStatsSpec.scala     |  9 +++
 ...ClusterShardingGracefulShutdownOldestSpec.scala |  9 +++
 .../ClusterShardingGracefulShutdownSpec.scala      |  9 +++
 .../ClusterShardingIncorrectSetupSpec.scala        |  9 +++
 .../sharding/ClusterShardingLeavingSpec.scala      |  9 +++
 .../sharding/ClusterShardingMinMembersSpec.scala   |  9 +++
 .../sharding/ClusterShardingQueriesSpec.scala      |  9 +++
 ...ardingRegistrationCoordinatedShutdownSpec.scala |  9 +++
 ...rShardingRememberEntitiesNewExtractorSpec.scala |  9 +++
 .../ClusterShardingRememberEntitiesSpec.scala      |  9 +++
 .../ClusterShardingRolePartitioningSpec.scala      |  9 +++
 .../ClusterShardingSingleShardPerEntitySpec.scala  |  9 +++
 .../cluster/sharding/ClusterShardingSpec.scala     |  9 +++
 .../sharding/ExternalShardAllocationSpec.scala     |  9 +++
 .../sharding/MultiDcClusterShardingSpec.scala      |  9 +++
 .../sharding/MultiNodeClusterShardingConfig.scala  |  9 +++
 .../sharding/MultiNodeClusterShardingSpec.scala    |  9 +++
 .../RollingUpdateShardAllocationSpec.scala         |  9 +++
 .../sharding/ClusterShardingHealthCheckSpec.scala  |  9 +++
 .../sharding/ClusterShardingInternalsSpec.scala    |  9 +++
 .../sharding/ClusterShardingLeaseSpec.scala        |  9 +++
 .../sharding/ClusterShardingSettingsSpec.scala     |  9 +++
 .../sharding/ConcurrentStartupShardingSpec.scala   |  9 +++
 .../sharding/CoordinatedShutdownShardingSpec.scala |  9 +++
 ...eprecatedLeastShardAllocationStrategySpec.scala |  9 +++
 .../pekko/cluster/sharding/EntitiesSpec.scala      |  9 +++
 .../cluster/sharding/EntityTerminationSpec.scala   |  9 +++
 .../cluster/sharding/GetShardTypeNamesSpec.scala   |  9 +++
 .../JoinConfigCompatCheckShardingSpec.scala        |  9 +++
 ...eastShardAllocationStrategyRandomizedSpec.scala |  9 +++
 .../LeastShardAllocationStrategySpec.scala         |  9 +++
 .../sharding/PersistentShardingMigrationSpec.scala |  9 +++
 .../pekko/cluster/sharding/ProxyShardingSpec.scala |  9 +++
 .../RememberEntitiesAndStartEntitySpec.scala       |  9 +++
 .../RememberEntitiesBatchedUpdatesSpec.scala       |  9 +++
 .../sharding/RememberEntitiesFailureSpec.scala     |  9 +++
 ...ememberEntitiesShardIdExtractorChangeSpec.scala |  9 +++
 .../RemoveInternalClusterShardingDataSpec.scala    |  9 +++
 .../pekko/cluster/sharding/ShardRegionSpec.scala   |  9 +++
 .../cluster/sharding/ShardWithLeaseSpec.scala      |  9 +++
 .../cluster/sharding/ShardingQueriesSpec.scala     |  9 +++
 .../pekko/cluster/sharding/StartEntitySpec.scala   |  9 +++
 .../pekko/cluster/sharding/SupervisionSpec.scala   |  9 +++
 .../ExternalShardAllocationStrategySpec.scala      |  9 +++
 .../internal/RememberEntitiesShardStoreSpec.scala  |  9 +++
 .../internal/RememberEntitiesStarterSpec.scala     |  9 +++
 .../sharding/passivation/CompositeSpec.scala       |  9 +++
 .../passivation/EntityPassivationSpec.scala        |  9 +++
 .../HillClimbingAdmissionOptimizerSpec.scala       |  9 +++
 .../cluster/sharding/passivation/IdleSpec.scala    |  9 +++
 .../passivation/LeastFrequentlyUsedSpec.scala      |  9 +++
 .../passivation/LeastRecentlyUsedSpec.scala        |  9 +++
 .../passivation/MostRecentlyUsedSpec.scala         |  9 +++
 .../passivation/simulator/AccessPattern.scala      |  9 +++
 .../sharding/passivation/simulator/Simulator.scala |  9 +++
 .../passivation/simulator/SimulatorSettings.scala  |  9 +++
 .../passivation/simulator/SimulatorStats.scala     |  9 +++
 .../ClusterShardingMessageSerializerSpec.scala     |  9 +++
 .../client/protobuf/msg/ClusterClientMessages.java |  9 +++
 .../protobuf/msg/DistributedPubSubMessages.java    |  9 +++
 .../src/main/protobuf/ClusterClientMessages.proto  |  9 +++
 .../main/protobuf/DistributedPubSubMessages.proto  |  9 +++
 .../pekko/cluster/client/ClusterClient.scala       |  9 +++
 .../protobuf/ClusterClientMessageSerializer.scala  |  9 +++
 .../cluster/pubsub/DistributedPubSubMediator.scala |  9 +++
 .../pekko/cluster/pubsub/PerGroupingBuffer.scala   |  9 +++
 .../DistributedPubSubMessageSerializer.scala       |  9 +++
 .../singleton/ClusterSingletonManager.scala        |  9 +++
 .../cluster/singleton/ClusterSingletonProxy.scala  |  9 +++
 .../ClusterSingletonMessageSerializer.scala        |  9 +++
 .../cluster/client/ClusterClientHandoverSpec.scala |  9 +++
 .../pekko/cluster/client/ClusterClientSpec.scala   |  9 +++
 .../cluster/client/ClusterClientStopSpec.scala     |  9 +++
 .../pubsub/DistributedPubSubMediatorSpec.scala     |  9 +++
 .../pubsub/DistributedPubSubRestartSpec.scala      |  9 +++
 .../ClusterSingletonManagerChaosSpec.scala         |  9 +++
 .../ClusterSingletonManagerDownedSpec.scala        |  9 +++
 .../ClusterSingletonManagerLeaseSpec.scala         |  9 +++
 .../ClusterSingletonManagerLeave2Spec.scala        |  9 +++
 .../ClusterSingletonManagerLeaveSpec.scala         |  9 +++
 ...rSingletonManagerPreparingForShutdownSpec.scala |  9 +++
 .../singleton/ClusterSingletonManagerSpec.scala    |  9 +++
 .../ClusterSingletonManagerStartupSpec.scala       |  9 +++
 .../singleton/MultiDcSingletonManagerSpec.scala    |  9 +++
 .../pekko/cluster/client/ClusterClientTest.java    |  9 +++
 .../pubsub/DistributedPubSubMediatorTest.java      |  9 +++
 .../singleton/ClusterSingletonManagerTest.java     |  9 +++
 .../apache/pekko/cluster/singleton/Consumer.java   |  9 +++
 .../cluster/singleton/TestSingletonMessages.java   |  9 +++
 .../ClusterClientMessageSerializerSpec.scala       |  9 +++
 .../DistributedPubSubMediatorDeadLettersSpec.scala |  9 +++
 .../DistributedPubSubMediatorRouterSpec.scala      |  9 +++
 .../DistributedPubSubMessageSerializerSpec.scala   |  9 +++
 .../singleton/ClusterSingletonLeaseSpec.scala      |  9 +++
 .../ClusterSingletonLeavingSpeedSpec.scala         |  9 +++
 .../singleton/ClusterSingletonProxySpec.scala      |  9 +++
 .../singleton/ClusterSingletonRestart2Spec.scala   |  9 +++
 .../singleton/ClusterSingletonRestartSpec.scala    |  9 +++
 .../ClusterSingletonMessageSerializerSpec.scala    |  9 +++
 .../typed/internal/protobuf/ClusterMessages.java   |  9 +++
 .../typed/internal/protobuf/ReliableDelivery.java  |  9 +++
 .../src/main/protobuf/ClusterMessages.proto        |  9 +++
 .../src/main/protobuf/ReliableDelivery.proto       |  9 +++
 .../receptionist/ClusterReceptionistProtocol.scala |  9 +++
 .../ddata/typed/internal/ReplicatorBehavior.scala  |  9 +++
 .../ddata/typed/javadsl/DistributedData.scala      |  9 +++
 .../cluster/ddata/typed/javadsl/Replicator.scala   |  9 +++
 .../typed/javadsl/ReplicatorMessageAdapter.scala   |  9 +++
 .../ddata/typed/javadsl/ReplicatorSettings.scala   |  9 +++
 .../ddata/typed/scaladsl/DistributedData.scala     |  9 +++
 .../cluster/ddata/typed/scaladsl/Replicator.scala  |  9 +++
 .../typed/scaladsl/ReplicatorMessageAdapter.scala  |  9 +++
 .../ddata/typed/scaladsl/ReplicatorSettings.scala  |  9 +++
 .../cluster/ddata/typed/scaladsl/package.scala     |  9 +++
 .../org/apache/pekko/cluster/typed/Cluster.scala   |  9 +++
 .../pekko/cluster/typed/ClusterSingleton.scala     |  9 +++
 .../typed/internal/AdaptedClusterImpl.scala        |  9 +++
 .../internal/AdaptedClusterSingletonImpl.scala     |  9 +++
 .../internal/PekkoClusterTypedSerializer.scala     |  9 +++
 .../delivery/ReliableDeliverySerializer.scala      |  9 +++
 .../receptionist/ClusterReceptionist.scala         |  9 +++
 .../ClusterReceptionistConfigCompatChecker.scala   |  9 +++
 .../receptionist/ClusterReceptionistSettings.scala |  9 +++
 .../typed/internal/receptionist/Registry.scala     |  9 +++
 .../cluster/typed/ChunkLargeMessageSpec.scala      |  9 +++
 .../typed/MultiDcClusterSingletonSpec.scala        |  9 +++
 .../apache/pekko/cluster/typed/MultiDcPinger.scala |  9 +++
 .../cluster/typed/MultiNodeTypedClusterSpec.scala  |  9 +++
 .../apache/pekko/cluster/typed/PubSubSpec.scala    |  9 +++
 .../ClusterReceptionistUnreachabilitySpec.scala    |  9 +++
 .../ddata/typed/javadsl/ReplicatorDocSample.java   |  9 +++
 .../ddata/typed/javadsl/ReplicatorDocTest.java     |  9 +++
 .../cluster/typed/BasicClusterExampleTest.java     |  9 +++
 .../cluster/typed/PingSerializerExampleTest.java   |  9 +++
 .../pekko/cluster/typed/ReceptionistExample.java   |  9 +++
 .../cluster/typed/SingletonCompileOnlyTest.java    |  9 +++
 .../apache/pekko/cluster/typed/ClusterApiTest.java |  9 +++
 .../ddata/typed/scaladsl/ReplicatorDocSpec.scala   |  9 +++
 .../cluster/typed/BasicClusterExampleSpec.scala    |  9 +++
 .../cluster/typed/DistributedPubSubExample.scala   |  9 +++
 .../pekko/cluster/typed/PingSerializer.scala       |  9 +++
 .../pekko/cluster/typed/ReceptionistExample.scala  |  9 +++
 .../cluster/typed/SingletonCompileOnlySpec.scala   |  9 +++
 .../typed/scaladsl/ReplicatorCompileOnlyTest.scala |  9 +++
 .../ddata/typed/scaladsl/ReplicatorSpec.scala      |  9 +++
 .../typed/ActorRefIgnoreSerializationSpec.scala    |  9 +++
 .../pekko/cluster/typed/ActorSystemSpec.scala      |  9 +++
 .../cluster/typed/ClusterActorLoggingSpec.scala    |  9 +++
 .../pekko/cluster/typed/ClusterApiSpec.scala       |  9 +++
 .../typed/ClusterDispatcherSelectorSpec.scala      |  9 +++
 .../cluster/typed/ClusterSingletonApiSpec.scala    |  9 +++
 .../typed/ClusterSingletonPoisonPillSpec.scala     |  9 +++
 .../pekko/cluster/typed/GroupRouterSpec.scala      |  9 +++
 .../pekko/cluster/typed/RemoteContextAskSpec.scala |  9 +++
 .../cluster/typed/RemoteDeployNotAllowedSpec.scala |  9 +++
 .../pekko/cluster/typed/RemoteMessageSpec.scala    |  9 +++
 .../internal/PekkoClusterTypedSerializerSpec.scala |  9 +++
 .../delivery/ReliableDeliverySerializerSpec.scala  |  9 +++
 .../receptionist/ClusterReceptionistSpec.scala     |  9 +++
 .../ClusterReceptionistStateSpec.scala             |  9 +++
 .../cluster/protobuf/msg/ClusterMessages.java      |  9 +++
 cluster/src/main/protobuf/ClusterMessages.proto    |  9 +++
 .../scala/org/apache/pekko/cluster/Cluster.scala   |  9 +++
 .../pekko/cluster/ClusterActorRefProvider.scala    |  9 +++
 .../org/apache/pekko/cluster/ClusterDaemon.scala   |  9 +++
 .../org/apache/pekko/cluster/ClusterEvent.scala    |  9 +++
 .../apache/pekko/cluster/ClusterHeartbeat.scala    |  9 +++
 .../org/apache/pekko/cluster/ClusterJmx.scala      |  9 +++
 .../org/apache/pekko/cluster/ClusterLogClass.scala |  9 +++
 .../apache/pekko/cluster/ClusterLogMarker.scala    |  9 +++
 .../org/apache/pekko/cluster/ClusterReadView.scala |  9 +++
 .../pekko/cluster/ClusterRemoteWatcher.scala       |  9 +++
 .../org/apache/pekko/cluster/ClusterSettings.scala |  9 +++
 .../pekko/cluster/CoordinatedShutdownLeave.scala   |  9 +++
 .../pekko/cluster/CrossDcClusterHeartbeat.scala    |  9 +++
 .../org/apache/pekko/cluster/DowningProvider.scala |  9 +++
 .../scala/org/apache/pekko/cluster/Gossip.scala    |  9 +++
 .../cluster/JoinConfigCompatCheckCluster.scala     |  9 +++
 .../pekko/cluster/JoinConfigCompatChecker.scala    |  9 +++
 .../scala/org/apache/pekko/cluster/Member.scala    |  9 +++
 .../org/apache/pekko/cluster/MembershipState.scala |  9 +++
 .../org/apache/pekko/cluster/Reachability.scala    |  9 +++
 .../org/apache/pekko/cluster/SeedNodeProcess.scala |  9 +++
 .../org/apache/pekko/cluster/VectorClock.scala     |  9 +++
 .../protobuf/ClusterMessageSerializer.scala        |  9 +++
 .../cluster/routing/ClusterRouterConfig.scala      |  9 +++
 .../apache/pekko/cluster/sbr/DowningStrategy.scala |  9 +++
 .../pekko/cluster/sbr/SplitBrainResolver.scala     |  9 +++
 .../cluster/sbr/SplitBrainResolverProvider.scala   |  9 +++
 .../cluster/sbr/SplitBrainResolverSettings.scala   |  9 +++
 .../cluster/AttemptSysMsgRedeliverySpec.scala      |  9 +++
 .../ClientDowningNodeThatIsUnreachableSpec.scala   |  9 +++
 .../cluster/ClientDowningNodeThatIsUpSpec.scala    |  9 +++
 .../ClusterAccrualFailureDetectorSpec.scala        |  9 +++
 .../pekko/cluster/ClusterDeathWatchSpec.scala      |  9 +++
 .../apache/pekko/cluster/ClusterShutdownSpec.scala |  9 +++
 .../ClusterWatcherNoClusterWatcheeSpec.scala       |  9 +++
 .../org/apache/pekko/cluster/ConvergenceSpec.scala |  9 +++
 .../DeterministicOldestWhenJoiningSpec.scala       |  9 +++
 .../cluster/DisallowJoinOfTwoClustersSpec.scala    |  9 +++
 ...henOtherHasQuarantinedThisActorSystemSpec.scala |  9 +++
 .../pekko/cluster/InitialHeartbeatSpec.scala       |  9 +++
 .../pekko/cluster/InitialMembersOfNewDcSpec.scala  |  9 +++
 .../apache/pekko/cluster/JoinInProgressSpec.scala  |  9 +++
 .../apache/pekko/cluster/JoinSeedNodeSpec.scala    |  9 +++
 .../pekko/cluster/LargeMessageClusterSpec.scala    |  9 +++
 .../cluster/LeaderDowningAllOtherNodesSpec.scala   |  9 +++
 .../LeaderDowningNodeThatIsUnreachableSpec.scala   |  9 +++
 .../apache/pekko/cluster/LeaderElectionSpec.scala  |  9 +++
 .../apache/pekko/cluster/LeaderLeavingSpec.scala   |  9 +++
 .../scala/org/apache/pekko/cluster/MBeanSpec.scala |  9 +++
 .../apache/pekko/cluster/MemberWeaklyUpSpec.scala  |  9 +++
 .../MembershipChangeListenerExitingSpec.scala      |  9 +++
 .../cluster/MembershipChangeListenerUpSpec.scala   |  9 +++
 .../pekko/cluster/MinMembersBeforeUpSpec.scala     |  9 +++
 .../apache/pekko/cluster/MultiDcClusterSpec.scala  |  9 +++
 .../cluster/MultiDcHeartbeatTakingOverSpec.scala   |  9 +++
 .../apache/pekko/cluster/MultiDcJoin2Spec.scala    |  9 +++
 .../org/apache/pekko/cluster/MultiDcJoinSpec.scala |  9 +++
 .../apache/pekko/cluster/MultiDcLastNodeSpec.scala |  9 +++
 .../pekko/cluster/MultiDcSplitBrainSpec.scala      |  9 +++
 .../pekko/cluster/MultiDcSunnyWeatherSpec.scala    |  9 +++
 .../pekko/cluster/MultiNodeClusterSpec.scala       |  9 +++
 .../org/apache/pekko/cluster/NodeChurnSpec.scala   |  9 +++
 .../cluster/NodeDowningAndBeingRemovedSpec.scala   |  9 +++
 .../NodeLeavingAndExitingAndBeingRemovedSpec.scala |  9 +++
 .../pekko/cluster/NodeLeavingAndExitingSpec.scala  |  9 +++
 .../apache/pekko/cluster/NodeMembershipSpec.scala  |  9 +++
 .../org/apache/pekko/cluster/NodeUpSpec.scala      |  9 +++
 .../apache/pekko/cluster/QuickRestartSpec.scala    |  9 +++
 .../cluster/RemoteFeaturesWithClusterSpec.scala    |  9 +++
 .../pekko/cluster/RestartFirstSeedNodeSpec.scala   |  9 +++
 .../apache/pekko/cluster/RestartNode2Spec.scala    |  9 +++
 .../apache/pekko/cluster/RestartNode3Spec.scala    |  9 +++
 .../org/apache/pekko/cluster/RestartNodeSpec.scala |  9 +++
 .../pekko/cluster/SharedMediaDriverSupport.scala   |  9 +++
 .../pekko/cluster/SingletonClusterSpec.scala       |  9 +++
 .../pekko/cluster/SplitBrainQuarantineSpec.scala   |  9 +++
 .../org/apache/pekko/cluster/SplitBrainSpec.scala  |  9 +++
 .../org/apache/pekko/cluster/StreamRefSpec.scala   |  9 +++
 .../org/apache/pekko/cluster/StressSpec.scala      |  9 +++
 .../apache/pekko/cluster/SunnyWeatherSpec.scala    |  9 +++
 .../cluster/SurviveNetworkInstabilitySpec.scala    |  9 +++
 .../org/apache/pekko/cluster/TransitionSpec.scala  |  9 +++
 .../cluster/UnreachableNodeJoinsAgainSpec.scala    |  9 +++
 .../ClusterConsistentHashingGroupSpec.scala        |  9 +++
 .../ClusterConsistentHashingRouterSpec.scala       |  9 +++
 .../cluster/routing/ClusterRoundRobinSpec.scala    |  9 +++
 .../pekko/cluster/routing/UseRoleIgnoredSpec.scala |  9 +++
 .../sbr/DownAllIndirectlyConnected5NodeSpec.scala  |  9 +++
 .../cluster/sbr/DownAllUnstable5NodeSpec.scala     |  9 +++
 .../cluster/sbr/IndirectlyConnected3NodeSpec.scala |  9 +++
 .../cluster/sbr/IndirectlyConnected5NodeSpec.scala |  9 +++
 .../pekko/cluster/sbr/LeaseMajority5NodeSpec.scala |  9 +++
 .../pekko/cluster/ClusterJavaCompileTest.java      |  9 +++
 .../apache/pekko/cluster/ClusterConfigSpec.scala   |  9 +++
 .../ClusterDeathWatchNotificationSpec.scala        |  9 +++
 .../apache/pekko/cluster/ClusterDeployerSpec.scala |  9 +++
 .../cluster/ClusterDomainEventPublisherSpec.scala  |  9 +++
 .../pekko/cluster/ClusterDomainEventSpec.scala     |  9 +++
 .../cluster/ClusterHeartbeatReceiverSpec.scala     |  9 +++
 .../pekko/cluster/ClusterHeartbeatSenderSpec.scala |  9 +++
 .../cluster/ClusterHeartbeatSenderStateSpec.scala  |  9 +++
 .../org/apache/pekko/cluster/ClusterLogSpec.scala  |  9 +++
 .../org/apache/pekko/cluster/ClusterSpec.scala     |  9 +++
 .../org/apache/pekko/cluster/ClusterTestKit.scala  |  9 +++
 .../pekko/cluster/CrossDcHeartbeatSenderSpec.scala |  9 +++
 .../apache/pekko/cluster/DowningProviderSpec.scala |  9 +++
 .../pekko/cluster/FailureDetectorPuppet.scala      |  9 +++
 .../org/apache/pekko/cluster/GossipSpec.scala      |  9 +++
 .../pekko/cluster/GossipTargetSelectorSpec.scala   |  9 +++
 .../pekko/cluster/HeartbeatNodeRingPerfSpec.scala  |  9 +++
 .../pekko/cluster/HeartbeatNodeRingSpec.scala      |  9 +++
 .../cluster/JoinConfigCompatCheckClusterSpec.scala |  9 +++
 .../JoinConfigCompatCheckerRollingUpdateSpec.scala |  9 +++
 .../cluster/JoinConfigCompatCheckerSpec.scala      |  9 +++
 .../JoinConfigCompatPreDefinedChecksSpec.scala     |  9 +++
 .../apache/pekko/cluster/MemberOrderingSpec.scala  |  9 +++
 .../apache/pekko/cluster/MembershipStateSpec.scala |  9 +++
 .../pekko/cluster/ReachabilityPerfSpec.scala       |  9 +++
 .../apache/pekko/cluster/ReachabilitySpec.scala    |  9 +++
 .../cluster/ResetSystemMessageSeqNrSpec.scala      |  9 +++
 .../cluster/ShutdownAfterJoinSeedNodesSpec.scala   |  9 +++
 .../pekko/cluster/StartupWithOneThreadSpec.scala   |  9 +++
 .../org/apache/pekko/cluster/TestMember.scala      |  9 +++
 .../apache/pekko/cluster/VectorClockPerfSpec.scala |  9 +++
 .../org/apache/pekko/cluster/VectorClockSpec.scala |  9 +++
 .../protobuf/ClusterMessageSerializerSpec.scala    |  9 +++
 .../routing/ClusterRouterSupervisorSpec.scala      |  9 +++
 .../pekko/cluster/sbr/LeaseMajoritySpec.scala      |  9 +++
 .../pekko/cluster/sbr/SplitBrainResolverSpec.scala |  9 +++
 .../apache/pekko/cluster/sbr/TestAddresses.scala   |  9 +++
 .../apache/pekko/cluster/testkit/AutoDown.scala    |  9 +++
 .../pekko/cluster/testkit/AutoDownSpec.scala       |  9 +++
 .../pekko/coordination/lease/LeaseException.scala  |  9 +++
 .../pekko/coordination/lease/LeaseSettings.scala   |  9 +++
 .../coordination/lease/LeaseUsageSettings.scala    |  9 +++
 .../pekko/coordination/lease/TimeoutSettings.scala |  9 +++
 .../coordination/lease/internal/LeaseAdapter.scala |  9 +++
 .../pekko/coordination/lease/javadsl/Lease.scala   |  9 +++
 .../coordination/lease/javadsl/LeaseProvider.scala |  9 +++
 .../pekko/coordination/lease/scaladsl/Lease.scala  |  9 +++
 .../lease/scaladsl/LeaseProvider.scala             |  9 +++
 .../lease/javadsl/LeaseProviderTest.java           |  9 +++
 .../pekko/coordination/lease/TestLease.scala       |  9 +++
 .../pekko/coordination/lease/TestLeaseActor.scala  |  9 +++
 .../coordination/lease/TimeoutSettingsSpec.scala   |  9 +++
 .../lease/scaladsl/LeaseProviderSpec.scala         |  9 +++
 .../org/apache/pekko/discovery/Discovery.scala     |  9 +++
 .../apache/pekko/discovery/ServiceDiscovery.scala  |  9 +++
 .../aggregate/AggregateServiceDiscovery.scala      |  9 +++
 .../discovery/config/ConfigServiceDiscovery.scala  |  9 +++
 .../pekko/discovery/dns/DnsServiceDiscovery.scala  |  9 +++
 .../apache/pekko/discovery/CompileOnlyTest.java    |  9 +++
 .../apache/pekko/discovery/CompileOnlySpec.scala   |  9 +++
 .../discovery/DiscoveryConfigurationSpec.scala     |  9 +++
 .../org/apache/pekko/discovery/LookupSpec.scala    |  9 +++
 .../aggregate/AggregateServiceDiscoverySpec.scala  |  9 +++
 .../config/ConfigServiceDiscoverySpec.scala        |  9 +++
 .../config/ConfigServicesParserSpec.scala          |  9 +++
 .../pekko/discovery/dns/DnsDiscoverySpec.scala     |  9 +++
 .../discovery/dns/DnsServiceDiscoverySpec.scala    |  9 +++
 .../ddata/protobuf/msg/ReplicatedDataMessages.java |  9 +++
 .../ddata/protobuf/msg/ReplicatorMessages.java     |  9 +++
 .../src/main/protobuf/ReplicatedDataMessages.proto |  9 +++
 .../src/main/protobuf/ReplicatorMessages.proto     |  9 +++
 .../org/apache/pekko/cluster/ddata/GSet.scala      |  9 +++
 .../cluster/ddata/DeltaPropagationSelector.scala   |  9 +++
 .../pekko/cluster/ddata/DistributedData.scala      |  9 +++
 .../apache/pekko/cluster/ddata/DurableStore.scala  |  9 +++
 .../apache/pekko/cluster/ddata/EstimatedSize.scala |  9 +++
 .../org/apache/pekko/cluster/ddata/FastMerge.scala |  9 +++
 .../org/apache/pekko/cluster/ddata/Flag.scala      |  9 +++
 .../org/apache/pekko/cluster/ddata/GCounter.scala  |  9 +++
 .../scala/org/apache/pekko/cluster/ddata/Key.scala |  9 +++
 .../org/apache/pekko/cluster/ddata/LWWMap.scala    |  9 +++
 .../apache/pekko/cluster/ddata/LWWRegister.scala   |  9 +++
 .../org/apache/pekko/cluster/ddata/ORMap.scala     |  9 +++
 .../apache/pekko/cluster/ddata/ORMultiMap.scala    |  9 +++
 .../org/apache/pekko/cluster/ddata/ORSet.scala     |  9 +++
 .../org/apache/pekko/cluster/ddata/PNCounter.scala |  9 +++
 .../apache/pekko/cluster/ddata/PNCounterMap.scala  |  9 +++
 .../cluster/ddata/PayloadSizeAggregator.scala      |  9 +++
 .../apache/pekko/cluster/ddata/PruningState.scala  |  9 +++
 .../pekko/cluster/ddata/ReplicatedData.scala       |  9 +++
 .../apache/pekko/cluster/ddata/Replicator.scala    |  9 +++
 .../apache/pekko/cluster/ddata/VersionVector.scala |  9 +++
 .../ddata/protobuf/ReplicatedDataSerializer.scala  |  9 +++
 .../protobuf/ReplicatorMessageSerializer.scala     |  9 +++
 .../ddata/protobuf/SerializationSupport.scala      |  9 +++
 .../pekko/cluster/ddata/DurableDataSpec.scala      |  9 +++
 .../pekko/cluster/ddata/DurablePruningSpec.scala   |  9 +++
 .../cluster/ddata/JepsenInspiredInsertSpec.scala   |  9 +++
 .../pekko/cluster/ddata/PerformanceSpec.scala      |  9 +++
 .../pekko/cluster/ddata/ReplicatorChaosSpec.scala  |  9 +++
 .../pekko/cluster/ddata/ReplicatorDeltaSpec.scala  |  9 +++
 .../pekko/cluster/ddata/ReplicatorGossipSpec.scala |  9 +++
 .../cluster/ddata/ReplicatorMapDeltaSpec.scala     |  9 +++
 .../cluster/ddata/ReplicatorORSetDeltaSpec.scala   |  9 +++
 .../cluster/ddata/ReplicatorPruningSpec.scala      |  9 +++
 .../pekko/cluster/ddata/ReplicatorSpec.scala       |  9 +++
 .../pekko/cluster/ddata/STMultiNodeSpec.scala      |  9 +++
 .../ddata/JavaImplOfDeltaReplicatedData.java       |  9 +++
 .../ddata/JavaImplOfDeltaReplicatedData2.java      |  9 +++
 .../cluster/ddata/JavaImplOfReplicatedData.java    |  9 +++
 .../org/apache/pekko/cluster/ddata/ORMapTest.java  |  9 +++
 .../apache/pekko/cluster/ddata/ORMultiMapTest.java |  9 +++
 .../apache/pekko/cluster/ddata/PNCounterTest.java  |  9 +++
 .../pekko/cluster/ddata/DataEnvelopeSpec.scala     |  9 +++
 .../ddata/DeltaPropagationSelectorSpec.scala       |  9 +++
 .../org/apache/pekko/cluster/ddata/FlagSpec.scala  |  9 +++
 .../apache/pekko/cluster/ddata/GCounterSpec.scala  |  9 +++
 .../org/apache/pekko/cluster/ddata/GSetSpec.scala  |  9 +++
 .../apache/pekko/cluster/ddata/LWWMapSpec.scala    |  9 +++
 .../pekko/cluster/ddata/LWWRegisterSpec.scala      |  9 +++
 .../pekko/cluster/ddata/LocalConcurrencySpec.scala |  9 +++
 .../apache/pekko/cluster/ddata/LotsOfDataBot.scala |  9 +++
 .../org/apache/pekko/cluster/ddata/ORMapSpec.scala |  9 +++
 .../pekko/cluster/ddata/ORMultiMapSpec.scala       |  9 +++
 .../org/apache/pekko/cluster/ddata/ORSetSpec.scala |  9 +++
 .../pekko/cluster/ddata/PNCounterMapSpec.scala     |  9 +++
 .../apache/pekko/cluster/ddata/PNCounterSpec.scala |  9 +++
 .../pekko/cluster/ddata/PruningStateSpec.scala     |  9 +++
 .../cluster/ddata/ReplicatorSettingsSpec.scala     |  9 +++
 .../pekko/cluster/ddata/VersionVectorSpec.scala    |  9 +++
 .../pekko/cluster/ddata/WriteAggregatorSpec.scala  |  9 +++
 .../protobuf/ReplicatedDataSerializerSpec.scala    |  9 +++
 .../protobuf/ReplicatorMessageSerializerSpec.scala |  9 +++
 .../ddata/protobuf/msg/TwoPhaseSetMessages.java    |  9 +++
 .../docs/persistence/proto/FlightAppModels.java    |  9 +++
 docs/src/main/protobuf/FlightAppModels.proto       |  9 +++
 docs/src/main/protobuf/TwoPhaseSetMessages.proto   |  9 +++
 .../stream/operators/source/AsSubscriber.java      |  9 +++
 .../stream/operators/source/FromPublisher.java     |  9 +++
 docs/src/test/java/jdocs/AbstractJavaTest.java     |  9 +++
 docs/src/test/java/jdocs/actor/ActorDocTest.java   |  9 +++
 .../jdocs/actor/ByteBufferSerializerDocTest.java   |  9 +++
 .../jdocs/actor/DependencyInjectionDocTest.java    |  9 +++
 .../java/jdocs/actor/FaultHandlingDocSample.java   |  9 +++
 .../test/java/jdocs/actor/FaultHandlingTest.java   |  9 +++
 .../test/java/jdocs/actor/GraduallyBuiltActor.java |  9 +++
 .../test/java/jdocs/actor/ImmutableMessage.java    |  9 +++
 .../java/jdocs/actor/InitializationDocTest.java    |  9 +++
 docs/src/test/java/jdocs/actor/Messages.java       |  9 +++
 docs/src/test/java/jdocs/actor/MyActor.java        |  9 +++
 docs/src/test/java/jdocs/actor/MyBoundedActor.java |  9 +++
 .../src/test/java/jdocs/actor/MyStoppingActor.java |  9 +++
 docs/src/test/java/jdocs/actor/SampleActor.java    |  9 +++
 .../src/test/java/jdocs/actor/SampleActorTest.java |  9 +++
 .../test/java/jdocs/actor/SchedulerDocTest.java    |  9 +++
 docs/src/test/java/jdocs/actor/TimerDocTest.java   |  9 +++
 docs/src/test/java/jdocs/actor/fsm/Buncher.java    |  9 +++
 .../src/test/java/jdocs/actor/fsm/BuncherTest.java |  9 +++
 docs/src/test/java/jdocs/actor/fsm/Events.java     |  9 +++
 docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java |  9 +++
 .../jdocs/actor/io/dns/DnsCompileOnlyDocTest.java  |  9 +++
 .../test/java/jdocs/actor/typed/BlockingActor.java |  9 +++
 .../jdocs/actor/typed/BlockingDispatcherTest.java  |  9 +++
 .../actor/typed/CoordinatedActorShutdownTest.java  |  9 +++
 .../java/jdocs/actor/typed/DispatcherDocTest.java  |  9 +++
 .../test/java/jdocs/actor/typed/PrintActor.java    |  9 +++
 .../SeparateDispatcherCompletionStageActor.java    |  9 +++
 .../actor/typed/SharedMutableStateDocTest.java     |  9 +++
 .../jdocs/circuitbreaker/DangerousJavaActor.java   |  9 +++
 .../circuitbreaker/EvenNoFailureJavaExample.java   |  9 +++
 .../jdocs/circuitbreaker/TellPatternJavaActor.java |  9 +++
 .../test/java/jdocs/cluster/ClusterDocTest.java    |  9 +++
 .../test/java/jdocs/cluster/FactorialBackend.java  |  9 +++
 .../test/java/jdocs/cluster/FactorialFrontend.java |  9 +++
 .../java/jdocs/cluster/FactorialFrontendMain.java  |  9 +++
 .../test/java/jdocs/cluster/FactorialResult.java   |  9 +++
 .../test/java/jdocs/cluster/MetricsListener.java   |  9 +++
 .../java/jdocs/cluster/SimpleClusterListener.java  |  9 +++
 .../java/jdocs/cluster/SimpleClusterListener2.java |  9 +++
 .../test/java/jdocs/cluster/StatsAggregator.java   |  9 +++
 .../src/test/java/jdocs/cluster/StatsMessages.java |  9 +++
 .../test/java/jdocs/cluster/StatsSampleClient.java |  9 +++
 .../cluster/StatsSampleOneMasterClientMain.java    |  9 +++
 .../jdocs/cluster/StatsSampleOneMasterMain.java    |  9 +++
 docs/src/test/java/jdocs/cluster/StatsService.java |  9 +++
 docs/src/test/java/jdocs/cluster/StatsWorker.java  |  9 +++
 .../java/jdocs/cluster/TransformationBackend.java  |  9 +++
 .../java/jdocs/cluster/TransformationFrontend.java |  9 +++
 .../java/jdocs/cluster/TransformationMessages.java |  9 +++
 .../singleton/ClusterSingletonSupervision.java     |  9 +++
 .../jdocs/cluster/singleton/SupervisorActor.java   |  9 +++
 docs/src/test/java/jdocs/config/ConfigDocTest.java |  9 +++
 .../test/java/jdocs/coordination/LeaseDocTest.java |  9 +++
 docs/src/test/java/jdocs/ddata/DataBot.java        |  9 +++
 .../java/jdocs/ddata/DistributedDataDocTest.java   |  9 +++
 docs/src/test/java/jdocs/ddata/ShoppingCart.java   |  9 +++
 docs/src/test/java/jdocs/ddata/TwoPhaseSet.java    |  9 +++
 .../ddata/protobuf/TwoPhaseSetSerializer.java      |  9 +++
 .../ddata/protobuf/TwoPhaseSetSerializer2.java     |  9 +++
 .../TwoPhaseSetSerializerWithCompression.java      |  9 +++
 .../java/jdocs/discovery/DnsDiscoveryDocTest.java  |  9 +++
 .../java/jdocs/dispatcher/DispatcherDocTest.java   |  9 +++
 .../java/jdocs/dispatcher/MyUnboundedMailbox.java  |  9 +++
 .../MyUnboundedMessageQueueSemantics.java          |  9 +++
 docs/src/test/java/jdocs/duration/Java.java        |  9 +++
 .../src/test/java/jdocs/event/EventBusDocTest.java |  9 +++
 docs/src/test/java/jdocs/event/LoggingDocTest.java |  9 +++
 .../java/jdocs/extension/ExtensionDocTest.java     |  9 +++
 .../jdocs/extension/SettingsExtensionDocTest.java  |  9 +++
 .../test/java/jdocs/future/ActorWithFuture.java    |  9 +++
 docs/src/test/java/jdocs/future/FutureDocTest.java |  9 +++
 docs/src/test/java/jdocs/io/IODocTest.java         |  9 +++
 .../test/java/jdocs/io/JavaReadBackPressure.java   |  9 +++
 docs/src/test/java/jdocs/io/JavaUdpMulticast.java  |  9 +++
 .../test/java/jdocs/io/JavaUdpMulticastTest.java   |  9 +++
 .../test/java/jdocs/io/UdpConnectedDocTest.java    |  9 +++
 docs/src/test/java/jdocs/io/UdpDocTest.java        |  9 +++
 docs/src/test/java/jdocs/io/japi/EchoHandler.java  |  9 +++
 docs/src/test/java/jdocs/io/japi/EchoManager.java  |  9 +++
 docs/src/test/java/jdocs/io/japi/EchoServer.java   |  9 +++
 docs/src/test/java/jdocs/io/japi/IODocTest.java    |  9 +++
 docs/src/test/java/jdocs/io/japi/Message.java      |  9 +++
 .../test/java/jdocs/io/japi/SimpleEchoHandler.java |  9 +++
 docs/src/test/java/jdocs/io/japi/Watcher.java      |  9 +++
 .../jdocs/pattern/BackoffSupervisorDocTest.java    |  9 +++
 .../src/test/java/jdocs/pattern/SupervisedAsk.java |  9 +++
 .../test/java/jdocs/pattern/SupervisedAskSpec.java |  9 +++
 .../persistence/LambdaPersistenceDocTest.java      |  9 +++
 .../LambdaPersistencePluginDocTest.java            |  9 +++
 .../PersistenceEventAdapterDocTest.java            |  9 +++
 .../jdocs/persistence/PersistenceMultiDocTest.java |  9 +++
 .../jdocs/persistence/PersistenceQueryDocTest.java |  9 +++
 .../PersistenceSchemaEvolutionDocTest.java         |  9 +++
 .../jdocs/persistence/PersistentActorExample.java  |  9 +++
 .../query/LeveldbPersistenceQueryDocTest.java      |  9 +++
 .../persistence/query/MyEventsByTagSource.java     |  9 +++
 .../jdocs/persistence/testkit/Configuration.java   |  9 +++
 .../persistence/testkit/PersistenceInitTest.java   |  9 +++
 .../PersistenceTestKitPolicySampleTest.java        |  9 +++
 .../testkit/PersistenceTestKitSampleTest.java      |  9 +++
 .../jdocs/persistence/testkit/TestKitExamples.java |  9 +++
 .../jdocs/remoting/RemoteDeploymentDocTest.java    |  9 +++
 .../routing/ConsistentHashingRouterDocTest.java    |  9 +++
 .../java/jdocs/routing/CustomRouterDocTest.java    |  9 +++
 .../test/java/jdocs/routing/RedundancyGroup.java   |  9 +++
 .../src/test/java/jdocs/routing/RouterDocTest.java |  9 +++
 .../jdocs/serialization/SerializationDocTest.java  |  9 +++
 .../java/jdocs/sharding/ClusterShardingTest.java   |  9 +++
 .../test/java/jdocs/stream/BidiFlowDocTest.java    |  9 +++
 .../test/java/jdocs/stream/CompositionDocTest.java |  9 +++
 docs/src/test/java/jdocs/stream/FlowDocTest.java   |  9 +++
 .../test/java/jdocs/stream/FlowErrorDocTest.java   |  9 +++
 .../java/jdocs/stream/FlowParallelismDocTest.java  |  9 +++
 .../java/jdocs/stream/FlowStreamRefsDocTest.java   |  9 +++
 .../test/java/jdocs/stream/GraphCyclesDocTest.java |  9 +++
 .../test/java/jdocs/stream/GraphStageDocTest.java  |  9 +++
 .../jdocs/stream/GraphStageLoggingDocTest.java     |  9 +++
 docs/src/test/java/jdocs/stream/HubDocTest.java    |  9 +++
 .../test/java/jdocs/stream/IntegrationDocTest.java |  9 +++
 .../test/java/jdocs/stream/KillSwitchDocTest.java  |  9 +++
 docs/src/test/java/jdocs/stream/Main.java          |  9 +++
 .../src/test/java/jdocs/stream/MigrationsJava.java |  9 +++
 .../test/java/jdocs/stream/QuickStartDocTest.java  |  9 +++
 .../jdocs/stream/RateTransformationDocTest.java    |  9 +++
 .../java/jdocs/stream/ReactiveStreamsDocTest.java  |  9 +++
 .../src/test/java/jdocs/stream/RestartDocTest.java |  9 +++
 .../test/java/jdocs/stream/SilenceSystemOut.java   |  9 +++
 .../test/java/jdocs/stream/SinkRecipeDocTest.java  |  9 +++
 .../jdocs/stream/StreamBuffersRateDocTest.java     |  9 +++
 .../jdocs/stream/StreamPartialGraphDSLDocTest.java |  9 +++
 .../java/jdocs/stream/StreamTestKitDocTest.java    |  9 +++
 .../test/java/jdocs/stream/SubstreamDocTest.java   |  9 +++
 .../stream/TwitterStreamQuickstartDocTest.java     |  9 +++
 .../java/jdocs/stream/io/StreamFileDocTest.java    |  9 +++
 .../java/jdocs/stream/io/StreamTcpDocTest.java     |  9 +++
 .../javadsl/cookbook/RecipeAdhocSourceTest.java    |  9 +++
 .../stream/javadsl/cookbook/RecipeByteStrings.java |  9 +++
 .../stream/javadsl/cookbook/RecipeDecompress.java  |  9 +++
 .../stream/javadsl/cookbook/RecipeDigest.java      |  9 +++
 .../javadsl/cookbook/RecipeDroppyBroadcast.java    |  9 +++
 .../stream/javadsl/cookbook/RecipeFlattenList.java |  9 +++
 .../javadsl/cookbook/RecipeGlobalRateLimit.java    |  9 +++
 .../jdocs/stream/javadsl/cookbook/RecipeHold.java  |  9 +++
 .../stream/javadsl/cookbook/RecipeKeepAlive.java   |  9 +++
 .../javadsl/cookbook/RecipeLoggingElements.java    |  9 +++
 .../javadsl/cookbook/RecipeManualTrigger.java      |  9 +++
 .../stream/javadsl/cookbook/RecipeMissedTicks.java |  9 +++
 .../javadsl/cookbook/RecipeMultiGroupByTest.java   |  9 +++
 .../stream/javadsl/cookbook/RecipeParseLines.java  |  9 +++
 .../javadsl/cookbook/RecipeReduceByKeyTest.java    |  9 +++
 .../jdocs/stream/javadsl/cookbook/RecipeSeq.java   |  9 +++
 .../stream/javadsl/cookbook/RecipeSimpleDrop.java  |  9 +++
 .../javadsl/cookbook/RecipeSourceFromFunction.java |  9 +++
 .../stream/javadsl/cookbook/RecipeSplitter.java    |  9 +++
 .../jdocs/stream/javadsl/cookbook/RecipeTest.java  |  9 +++
 .../stream/javadsl/cookbook/RecipeWorkerPool.java  |  9 +++
 .../stream/operators/BroadcastDocExample.java      |  9 +++
 .../stream/operators/MergeSequenceDocExample.java  |  9 +++
 .../stream/operators/PartitionDocExample.java      |  9 +++
 .../jdocs/stream/operators/SinkDocExamples.java    |  9 +++
 .../jdocs/stream/operators/SourceDocExamples.java  |  9 +++
 .../java/jdocs/stream/operators/SourceOrFlow.java  |  9 +++
 .../jdocs/stream/operators/WithContextTest.java    |  9 +++
 .../converters/StreamConvertersToJava.java         |  9 +++
 .../operators/converters/ToFromJavaIOStreams.java  |  9 +++
 .../stream/operators/flow/FromSinkAndSource.java   |  9 +++
 .../jdocs/stream/operators/flow/FutureFlow.java    |  9 +++
 .../java/jdocs/stream/operators/flow/Lazy.java     |  9 +++
 .../jdocs/stream/operators/flow/StatefulMap.java   |  9 +++
 .../stream/operators/flow/StatefulMapConcat.java   |  9 +++
 .../java/jdocs/stream/operators/sink/Lazy.java     |  9 +++
 .../jdocs/stream/operators/source/Combine.java     |  9 +++
 .../operators/source/CompletionStageSource.java    |  9 +++
 .../java/jdocs/stream/operators/source/From.java   |  9 +++
 .../operators/source/FromCompletionStage.java      |  9 +++
 .../java/jdocs/stream/operators/source/Lazy.java   |  9 +++
 .../jdocs/stream/operators/source/Restart.java     |  9 +++
 .../java/jdocs/stream/operators/source/Tick.java   |  9 +++
 .../java/jdocs/stream/operators/source/Unfold.java |  9 +++
 .../jdocs/stream/operators/source/UnfoldAsync.java |  9 +++
 .../stream/operators/source/UnfoldResource.java    |  9 +++
 .../operators/source/UnfoldResourceAsync.java      |  9 +++
 .../java/jdocs/stream/operators/source/Zip.java    |  9 +++
 .../sourceorflow/ExtrapolateAndExpand.java         |  9 +++
 .../operators/sourceorflow/FlatMapConcat.java      |  9 +++
 .../operators/sourceorflow/FlatMapMerge.java       |  9 +++
 .../stream/operators/sourceorflow/Intersperse.java |  9 +++
 .../jdocs/stream/operators/sourceorflow/Limit.java |  9 +++
 .../operators/sourceorflow/LimitWeighted.java      |  9 +++
 .../stream/operators/sourceorflow/MapAsyncs.java   |  9 +++
 .../stream/operators/sourceorflow/MapConcat.java   |  9 +++
 .../stream/operators/sourceorflow/MapError.java    |  9 +++
 .../stream/operators/sourceorflow/MergeLatest.java |  9 +++
 .../stream/operators/sourceorflow/Monitor.java     |  9 +++
 .../stream/operators/sourceorflow/Sliding.java     |  9 +++
 .../jdocs/stream/operators/sourceorflow/Split.java |  9 +++
 .../stream/operators/sourceorflow/Throttle.java    |  9 +++
 .../test/java/jdocs/testkit/ParentChildTest.java   |  9 +++
 .../test/java/jdocs/testkit/TestKitDocTest.java    |  9 +++
 .../test/java/jdocs/testkit/TestKitSampleTest.java |  9 +++
 .../tutorial_1/ActorHierarchyExperiments.java      |  9 +++
 .../test/java/jdocs/typed/tutorial_2/IotMain.java  |  9 +++
 .../java/jdocs/typed/tutorial_2/IotSupervisor.java |  9 +++
 .../test/java/jdocs/typed/tutorial_3/Device.java   |  9 +++
 .../java/jdocs/typed/tutorial_3/DeviceTest.java    |  9 +++
 .../jdocs/typed/tutorial_3/inprogress1/Device.java |  9 +++
 .../jdocs/typed/tutorial_3/inprogress2/Device.java |  9 +++
 .../jdocs/typed/tutorial_3/inprogress3/Device.java |  9 +++
 .../test/java/jdocs/typed/tutorial_4/Device.java   |  9 +++
 .../java/jdocs/typed/tutorial_4/DeviceGroup.java   |  9 +++
 .../jdocs/typed/tutorial_4/DeviceGroupTest.java    |  9 +++
 .../java/jdocs/typed/tutorial_4/DeviceManager.java |  9 +++
 .../jdocs/typed/tutorial_4/DeviceManagerTest.java  |  9 +++
 .../java/jdocs/typed/tutorial_4/DeviceTest.java    |  9 +++
 .../test/java/jdocs/typed/tutorial_5/Device.java   |  9 +++
 .../java/jdocs/typed/tutorial_5/DeviceGroup.java   |  9 +++
 .../jdocs/typed/tutorial_5/DeviceGroupQuery.java   |  9 +++
 .../typed/tutorial_5/DeviceGroupQueryTest.java     |  9 +++
 .../jdocs/typed/tutorial_5/DeviceGroupTest.java    |  9 +++
 .../java/jdocs/typed/tutorial_5/DeviceManager.java |  9 +++
 .../jdocs/typed/tutorial_5/DeviceManagerTest.java  |  9 +++
 .../java/jdocs/typed/tutorial_5/DeviceTest.java    |  9 +++
 .../stream/operators/source/AsSubscriber.scala     |  9 +++
 .../stream/operators/source/FromPublisher.scala    |  9 +++
 docs/src/test/scala/docs/CompileOnlySpec.scala     |  9 +++
 docs/src/test/scala/docs/actor/ActorDocSpec.scala  |  9 +++
 .../docs/actor/ByteBufferSerializerDocSpec.scala   |  9 +++
 docs/src/test/scala/docs/actor/FSMDocSpec.scala    |  9 +++
 .../scala/docs/actor/FaultHandlingDocSample.scala  |  9 +++
 .../scala/docs/actor/FaultHandlingDocSpec.scala    |  9 +++
 .../scala/docs/actor/InitializationDocSpec.scala   |  9 +++
 .../test/scala/docs/actor/PropsEdgeCaseSpec.scala  |  9 +++
 .../test/scala/docs/actor/SchedulerDocSpec.scala   |  9 +++
 .../docs/actor/SharedMutableStateDocSpec.scala     |  9 +++
 docs/src/test/scala/docs/actor/TimerDocSpec.scala  |  9 +++
 .../test/scala/docs/actor/UnnestedReceives.scala   |  9 +++
 .../docs/actor/io/dns/DnsCompileOnlyDocSpec.scala  |  9 +++
 .../scala/docs/actor/typed/BlockingActor.scala     |  9 +++
 .../actor/typed/BlockingDispatcherSample.scala     |  9 +++
 .../actor/typed/CoordinatedActorShutdownSpec.scala |  9 +++
 .../scala/docs/actor/typed/DispatcherDocSpec.scala |  9 +++
 .../test/scala/docs/actor/typed/PrintActor.scala   |  9 +++
 .../actor/typed/SharedMutableStateDocSpec.scala    |  9 +++
 .../circuitbreaker/CircuitBreakerDocSpec.scala     |  9 +++
 .../test/scala/docs/cluster/ClusterDocSpec.scala   |  9 +++
 .../test/scala/docs/cluster/FactorialBackend.scala |  9 +++
 .../scala/docs/cluster/FactorialFrontend.scala     |  9 +++
 .../test/scala/docs/cluster/MetricsListener.scala  |  9 +++
 .../scala/docs/cluster/SimpleClusterListener.scala |  9 +++
 .../docs/cluster/SimpleClusterListener2.scala      |  9 +++
 .../scala/docs/cluster/TransformationBackend.scala |  9 +++
 .../docs/cluster/TransformationFrontend.scala      |  9 +++
 .../docs/cluster/TransformationMessages.scala      |  9 +++
 .../singleton/ClusterSingletonSupervision.scala    |  9 +++
 .../src/test/scala/docs/config/ConfigDocSpec.scala |  9 +++
 .../scala/docs/coordination/LeaseDocSpec.scala     |  9 +++
 .../scala/docs/ddata/DistributedDataDocSpec.scala  |  9 +++
 docs/src/test/scala/docs/ddata/ShoppingCart.scala  |  9 +++
 docs/src/test/scala/docs/ddata/TwoPhaseSet.scala   |  9 +++
 .../ddata/protobuf/TwoPhaseSetSerializer.scala     |  9 +++
 .../ddata/protobuf/TwoPhaseSetSerializer2.scala    |  9 +++
 .../scala/docs/discovery/DnsDiscoveryDocSpec.scala |  9 +++
 .../scala/docs/dispatcher/DispatcherDocSpec.scala  |  9 +++
 .../scala/docs/dispatcher/MyUnboundedMailbox.scala |  9 +++
 docs/src/test/scala/docs/duration/Sample.scala     |  9 +++
 .../test/scala/docs/event/EventBusDocSpec.scala    |  9 +++
 .../src/test/scala/docs/event/LoggingDocSpec.scala |  9 +++
 .../scala/docs/extension/ExtensionDocSpec.scala    |  9 +++
 .../docs/extension/SettingsExtensionDocSpec.scala  |  9 +++
 docs/src/test/scala/docs/faq/Faq.scala             |  9 +++
 .../src/test/scala/docs/future/FutureDocSpec.scala |  9 +++
 docs/src/test/scala/docs/io/EchoServer.scala       |  9 +++
 docs/src/test/scala/docs/io/IODocSpec.scala        |  9 +++
 docs/src/test/scala/docs/io/ReadBackPressure.scala |  9 +++
 .../src/test/scala/docs/io/ScalaUdpMulticast.scala |  9 +++
 .../test/scala/docs/io/ScalaUdpMulticastSpec.scala |  9 +++
 docs/src/test/scala/docs/io/UdpDocSpec.scala       |  9 +++
 .../docs/pattern/BackoffSupervisorDocSpec.scala    |  9 +++
 .../docs/persistence/PersistenceDocSpec.scala      |  9 +++
 .../PersistenceEventAdapterDocSpec.scala           |  9 +++
 .../docs/persistence/PersistenceMultiDocSpec.scala |  9 +++
 .../persistence/PersistencePluginDocSpec.scala     |  9 +++
 .../PersistenceSchemaEvolutionDocSpec.scala        |  9 +++
 .../persistence/PersistenceSerializerDocSpec.scala |  9 +++
 .../docs/persistence/PersistentActorExample.scala  |  9 +++
 .../query/LeveldbPersistenceQueryDocSpec.scala     |  9 +++
 .../persistence/query/MyEventsByTagSource.scala    |  9 +++
 .../query/PersistenceQueryDocSpec.scala            |  9 +++
 .../docs/persistence/testkit/Configuration.scala   |  9 +++
 .../persistence/testkit/PersistenceInitSpec.scala  |  9 +++
 .../docs/persistence/testkit/TestKitExamples.scala |  9 +++
 .../docs/remoting/RemoteDeploymentDocSpec.scala    |  9 +++
 .../routing/ConsistentHashingRouterDocSpec.scala   |  9 +++
 .../scala/docs/routing/CustomRouterDocSpec.scala   |  9 +++
 .../test/scala/docs/routing/RouterDocSpec.scala    |  9 +++
 .../docs/serialization/SerializationDocSpec.scala  |  9 +++
 .../test/scala/docs/stream/BidiFlowDocSpec.scala   |  9 +++
 .../scala/docs/stream/CompositionDocSpec.scala     |  9 +++
 docs/src/test/scala/docs/stream/FlowDocSpec.scala  |  9 +++
 .../test/scala/docs/stream/FlowErrorDocSpec.scala  |  9 +++
 .../scala/docs/stream/FlowParallelismDocSpec.scala |  9 +++
 .../scala/docs/stream/FlowStreamRefsDocSpec.scala  |  9 +++
 .../test/scala/docs/stream/GraphCyclesSpec.scala   |  9 +++
 .../test/scala/docs/stream/GraphDSLDocSpec.scala   |  9 +++
 .../test/scala/docs/stream/GraphStageDocSpec.scala |  9 +++
 .../docs/stream/GraphStageLoggingDocSpec.scala     |  9 +++
 docs/src/test/scala/docs/stream/HubsDocSpec.scala  |  9 +++
 .../scala/docs/stream/IntegrationDocSpec.scala     |  9 +++
 .../test/scala/docs/stream/KillSwitchDocSpec.scala |  9 +++
 .../test/scala/docs/stream/MigrationsScala.scala   |  9 +++
 .../test/scala/docs/stream/QuickStartDocSpec.scala |  9 +++
 .../docs/stream/RateTransformationDocSpec.scala    |  9 +++
 .../scala/docs/stream/ReactiveStreamsDocSpec.scala |  9 +++
 .../test/scala/docs/stream/RestartDocSpec.scala    |  9 +++
 .../test/scala/docs/stream/SinkRecipeDocSpec.scala |  9 +++
 .../scala/docs/stream/StreamBuffersRateSpec.scala  |  9 +++
 .../docs/stream/StreamPartialGraphDSLDocSpec.scala |  9 +++
 .../scala/docs/stream/StreamTestKitDocSpec.scala   |  9 +++
 .../test/scala/docs/stream/SubstreamDocSpec.scala  |  9 +++
 .../stream/TwitterStreamQuickstartDocSpec.scala    |  9 +++
 .../docs/stream/cookbook/RecipeAdhocSource.scala   |  9 +++
 .../docs/stream/cookbook/RecipeByteStrings.scala   |  9 +++
 .../stream/cookbook/RecipeCollectingMetrics.scala  |  9 +++
 .../docs/stream/cookbook/RecipeDecompress.scala    |  9 +++
 .../scala/docs/stream/cookbook/RecipeDigest.scala  |  9 +++
 .../stream/cookbook/RecipeDroppyBroadcast.scala    |  9 +++
 .../docs/stream/cookbook/RecipeFlattenSeq.scala    |  9 +++
 .../stream/cookbook/RecipeGlobalRateLimit.scala    |  9 +++
 .../scala/docs/stream/cookbook/RecipeHold.scala    |  9 +++
 .../docs/stream/cookbook/RecipeKeepAlive.scala     |  9 +++
 .../stream/cookbook/RecipeLoggingElements.scala    |  9 +++
 .../docs/stream/cookbook/RecipeManualTrigger.scala |  9 +++
 .../docs/stream/cookbook/RecipeMissedTicks.scala   |  9 +++
 .../docs/stream/cookbook/RecipeMultiGroupBy.scala  |  9 +++
 .../docs/stream/cookbook/RecipeParseLines.scala    |  9 +++
 .../docs/stream/cookbook/RecipeReduceByKey.scala   |  9 +++
 .../scala/docs/stream/cookbook/RecipeSeq.scala     |  9 +++
 .../docs/stream/cookbook/RecipeSimpleDrop.scala    |  9 +++
 .../stream/cookbook/RecipeSourceFromFunction.scala |  9 +++
 .../scala/docs/stream/cookbook/RecipeSpec.scala    |  9 +++
 .../docs/stream/cookbook/RecipeSplitter.scala      |  9 +++
 .../docs/stream/cookbook/RecipeWorkerPool.scala    |  9 +++
 .../scala/docs/stream/io/StreamFileDocSpec.scala   |  9 +++
 .../scala/docs/stream/io/StreamTcpDocSpec.scala    |  9 +++
 .../stream/operators/BroadcastDocExample.scala     |  9 +++
 .../src/test/scala/docs/stream/operators/Map.scala |  9 +++
 .../stream/operators/MergeSequenceDocExample.scala |  9 +++
 .../stream/operators/PartitionDocExample.scala     |  9 +++
 .../docs/stream/operators/SourceOperators.scala    |  9 +++
 .../docs/stream/operators/WithContextSpec.scala    |  9 +++
 .../converters/StreamConvertersToJava.scala        |  9 +++
 .../operators/converters/ToFromJavaIOStreams.scala |  9 +++
 .../stream/operators/flow/FromSinkAndSource.scala  |  9 +++
 .../docs/stream/operators/flow/FutureFlow.scala    |  9 +++
 .../scala/docs/stream/operators/flow/Lazy.scala    |  9 +++
 .../docs/stream/operators/flow/StatefulMap.scala   |  9 +++
 .../stream/operators/flow/StatefulMapConcat.scala  |  9 +++
 .../docs/stream/operators/sink/AsPublisher.scala   |  9 +++
 .../docs/stream/operators/sink/Cancelled.scala     |  9 +++
 .../docs/stream/operators/sink/Collection.scala    |  9 +++
 .../scala/docs/stream/operators/sink/Fold.scala    |  9 +++
 .../docs/stream/operators/sink/HeadOption.scala    |  9 +++
 .../scala/docs/stream/operators/sink/Ignore.scala  |  9 +++
 .../scala/docs/stream/operators/sink/Lazy.scala    |  9 +++
 .../docs/stream/operators/source/Combine.scala     |  9 +++
 .../scala/docs/stream/operators/source/From.scala  |  9 +++
 .../stream/operators/source/FutureSource.scala     |  9 +++
 .../scala/docs/stream/operators/source/Lazy.scala  |  9 +++
 .../docs/stream/operators/source/Restart.scala     |  9 +++
 .../scala/docs/stream/operators/source/Tick.scala  |  9 +++
 .../docs/stream/operators/source/Unfold.scala      |  9 +++
 .../docs/stream/operators/source/UnfoldAsync.scala |  9 +++
 .../stream/operators/source/UnfoldResource.scala   |  9 +++
 .../operators/source/UnfoldResourceAsync.scala     |  9 +++
 .../scala/docs/stream/operators/source/Zip.scala   |  9 +++
 .../stream/operators/sourceorflow/Collect.scala    |  9 +++
 .../operators/sourceorflow/CompletionTimeout.scala |  9 +++
 .../stream/operators/sourceorflow/Conflate.scala   |  9 +++
 .../docs/stream/operators/sourceorflow/Drop.scala  |  9 +++
 .../sourceorflow/ExtrapolateAndExpand.scala        |  9 +++
 .../stream/operators/sourceorflow/Filter.scala     |  9 +++
 .../operators/sourceorflow/FlatMapConcat.scala     |  9 +++
 .../operators/sourceorflow/FlatMapMerge.scala      |  9 +++
 .../docs/stream/operators/sourceorflow/Fold.scala  |  9 +++
 .../stream/operators/sourceorflow/FoldAsync.scala  |  9 +++
 .../stream/operators/sourceorflow/GroupBy.scala    |  9 +++
 .../stream/operators/sourceorflow/Grouped.scala    |  9 +++
 .../operators/sourceorflow/GroupedWeighted.scala   |  9 +++
 .../operators/sourceorflow/Intersperse.scala       |  9 +++
 .../docs/stream/operators/sourceorflow/Limit.scala |  9 +++
 .../operators/sourceorflow/LimitWeighted.scala     |  9 +++
 .../docs/stream/operators/sourceorflow/Log.scala   |  9 +++
 .../operators/sourceorflow/LogWithMarker.scala     |  9 +++
 .../stream/operators/sourceorflow/MapAsyncs.scala  |  9 +++
 .../stream/operators/sourceorflow/MapConcat.scala  |  9 +++
 .../stream/operators/sourceorflow/MapError.scala   |  9 +++
 .../operators/sourceorflow/MergeLatest.scala       |  9 +++
 .../stream/operators/sourceorflow/Monitor.scala    |  9 +++
 .../stream/operators/sourceorflow/Reduce.scala     |  9 +++
 .../docs/stream/operators/sourceorflow/Scan.scala  |  9 +++
 .../stream/operators/sourceorflow/ScanAsync.scala  |  9 +++
 .../stream/operators/sourceorflow/Sliding.scala    |  9 +++
 .../docs/stream/operators/sourceorflow/Split.scala |  9 +++
 .../docs/stream/operators/sourceorflow/Take.scala  |  9 +++
 .../stream/operators/sourceorflow/TakeWhile.scala  |  9 +++
 .../stream/operators/sourceorflow/Throttle.scala   |  9 +++
 .../docs/stream/operators/sourceorflow/Watch.scala |  9 +++
 .../operators/sourceorflow/WatchTermination.scala  |  9 +++
 .../test/scala/docs/testkit/ParentChildSpec.scala  |  9 +++
 .../test/scala/docs/testkit/PlainWordSpec.scala    |  9 +++
 .../test/scala/docs/testkit/TestKitUsageSpec.scala |  9 +++
 .../test/scala/docs/testkit/TestkitDocSpec.scala   |  9 +++
 .../tutorial_1/ActorHierarchyExperiments.scala     |  9 +++
 docs/src/test/scala/typed/tutorial_2/IotApp.scala  |  9 +++
 .../scala/typed/tutorial_2/IotSupervisor.scala     |  9 +++
 docs/src/test/scala/typed/tutorial_3/Device.scala  |  9 +++
 .../scala/typed/tutorial_3/DeviceInProgress.scala  |  9 +++
 .../test/scala/typed/tutorial_3/DeviceSpec.scala   |  9 +++
 docs/src/test/scala/typed/tutorial_4/Device.scala  |  9 +++
 .../test/scala/typed/tutorial_4/DeviceGroup.scala  |  9 +++
 .../scala/typed/tutorial_4/DeviceGroupSpec.scala   |  9 +++
 .../scala/typed/tutorial_4/DeviceManager.scala     |  9 +++
 .../scala/typed/tutorial_4/DeviceManagerSpec.scala |  9 +++
 .../test/scala/typed/tutorial_4/DeviceSpec.scala   |  9 +++
 docs/src/test/scala/typed/tutorial_5/Device.scala  |  9 +++
 .../test/scala/typed/tutorial_5/DeviceGroup.scala  |  9 +++
 .../scala/typed/tutorial_5/DeviceGroupQuery.scala  |  9 +++
 .../typed/tutorial_5/DeviceGroupQuerySpec.scala    |  9 +++
 .../scala/typed/tutorial_5/DeviceGroupSpec.scala   |  9 +++
 .../scala/typed/tutorial_5/DeviceManager.scala     |  9 +++
 .../scala/typed/tutorial_5/DeviceManagerSpec.scala |  9 +++
 .../test/scala/typed/tutorial_5/DeviceSpec.scala   |  9 +++
 .../testconductor/TestConductorProtocol.java       |  9 +++
 .../src/main/protobuf/TestConductorProtocol.proto  |  9 +++
 .../pekko/remote/testconductor/Conductor.scala     |  9 +++
 .../pekko/remote/testconductor/DataTypes.scala     |  9 +++
 .../pekko/remote/testconductor/Extension.scala     |  9 +++
 .../apache/pekko/remote/testconductor/Player.scala |  9 +++
 .../remote/testconductor/RemoteConnection.scala    |  9 +++
 .../pekko/remote/testkit/MultiNodeSpec.scala       |  9 +++
 .../pekko/remote/testkit/PerfFlamesSupport.scala   |  9 +++
 .../apache/pekko/osgi/ActorSystemActivator.scala   |  9 +++
 .../pekko/osgi/BundleDelegatingClassLoader.scala   |  9 +++
 .../org/apache/pekko/osgi/DefaultOSGiLogger.scala  |  9 +++
 .../apache/pekko/osgi/OsgiActorSystemFactory.scala |  9 +++
 osgi/src/test/scala/docs/osgi/Activator.scala      |  9 +++
 .../pekko/osgi/ActorSystemActivatorTest.scala      |  9 +++
 .../org/apache/pekko/osgi/PojoSRTestSupport.scala  |  9 +++
 .../org/apache/pekko/osgi/test/PingPong.scala      |  9 +++
 .../apache/pekko/osgi/test/TestActivators.scala    |  9 +++
 .../query/internal/protobuf/QueryMessages.java     |  9 +++
 .../src/main/protobuf/QueryMessages.proto          |  9 +++
 .../persistence/query/DurableStateChange.scala     |  9 +++
 .../pekko/persistence/query/EventEnvelope.scala    |  9 +++
 .../apache/pekko/persistence/query/Offset.scala    |  9 +++
 .../pekko/persistence/query/PersistenceQuery.scala |  9 +++
 .../persistence/query/ReadJournalProvider.scala    |  9 +++
 .../query/internal/QuerySerializer.scala           |  9 +++
 .../CurrentEventsByPersistenceIdQuery.scala        |  9 +++
 .../query/javadsl/CurrentEventsByTagQuery.scala    |  9 +++
 .../query/javadsl/CurrentPersistenceIdsQuery.scala |  9 +++
 ...DurableStateStorePagedPersistenceIdsQuery.scala |  9 +++
 .../query/javadsl/DurableStateStoreQuery.scala     |  9 +++
 .../query/javadsl/EventsByPersistenceIdQuery.scala |  9 +++
 .../query/javadsl/EventsByTagQuery.scala           |  9 +++
 .../query/javadsl/PagedPersistenceIdsQuery.scala   |  9 +++
 .../query/javadsl/PersistenceIdsQuery.scala        |  9 +++
 .../persistence/query/javadsl/ReadJournal.scala    |  9 +++
 .../journal/leveldb/AllPersistenceIdsStage.scala   |  9 +++
 .../persistence/query/journal/leveldb/Buffer.scala |  9 +++
 .../leveldb/EventsByPersistenceIdStage.scala       |  9 +++
 .../query/journal/leveldb/EventsByTagStage.scala   |  9 +++
 .../leveldb/LeveldbReadJournalProvider.scala       |  9 +++
 .../leveldb/javadsl/LeveldbReadJournal.scala       |  9 +++
 .../leveldb/scaladsl/LeveldbReadJournal.scala      |  9 +++
 .../CurrentEventsByPersistenceIdQuery.scala        |  9 +++
 .../query/scaladsl/CurrentEventsByTagQuery.scala   |  9 +++
 .../scaladsl/CurrentPersistenceIdsQuery.scala      |  9 +++
 ...DurableStateStorePagedPersistenceIdsQuery.scala |  9 +++
 .../query/scaladsl/DurableStateStoreQuery.scala    |  9 +++
 .../scaladsl/EventsByPersistenceIdQuery.scala      |  9 +++
 .../query/scaladsl/EventsByTagQuery.scala          |  9 +++
 .../query/scaladsl/PagedPersistenceIdsQuery.scala  |  9 +++
 .../query/scaladsl/PersistenceIdsQuery.scala       |  9 +++
 .../persistence/query/scaladsl/ReadJournal.scala   |  9 +++
 .../persistence/query/typed/EventEnvelope.scala    |  9 +++
 .../typed/javadsl/CurrentEventsBySliceQuery.scala  |  9 +++
 .../javadsl/DurableStateStoreBySliceQuery.scala    |  9 +++
 .../query/typed/javadsl/EventTimestampQuery.scala  |  9 +++
 .../query/typed/javadsl/EventsBySliceQuery.scala   |  9 +++
 .../query/typed/javadsl/LoadEventQuery.scala       |  9 +++
 .../typed/scaladsl/CurrentEventsBySliceQuery.scala |  9 +++
 .../scaladsl/DurableStateStoreBySliceQuery.scala   |  9 +++
 .../query/typed/scaladsl/EventTimestampQuery.scala |  9 +++
 .../query/typed/scaladsl/EventsBySliceQuery.scala  |  9 +++
 .../query/typed/scaladsl/LoadEventQuery.scala      |  9 +++
 .../persistence/query/DummyJavaReadJournal.java    |  9 +++
 .../query/DummyJavaReadJournalForScala.java        |  9 +++
 .../query/DummyJavaReadJournalProvider.java        |  9 +++
 .../persistence/query/PersistenceQueryTest.java    |  9 +++
 .../pekko/persistence/query/DummyReadJournal.scala |  9 +++
 .../pekko/persistence/query/OffsetSpec.scala       |  9 +++
 .../persistence/query/PersistenceQuerySpec.scala   |  9 +++
 .../query/internal/QuerySerializerSpec.scala       |  9 +++
 .../journal/leveldb/AllPersistenceIdsSpec.scala    |  9 +++
 .../query/journal/leveldb/Cleanup.scala            |  9 +++
 .../leveldb/EventsByPersistenceIdSpec.scala        |  9 +++
 .../query/journal/leveldb/EventsByTagSpec.scala    |  9 +++
 .../query/journal/leveldb/TestActor.scala          |  9 +++
 .../leveldb/PersistencePluginProxySpec.scala       |  9 +++
 .../journal/leveldb/SharedLeveldbJournalSpec.scala |  9 +++
 .../persistence/serialization/SerializerSpec.scala |  9 +++
 .../apache/pekko/persistence/CapabilityFlags.scala |  9 +++
 .../org/apache/pekko/persistence/PluginSpec.scala  |  9 +++
 .../apache/pekko/persistence/TestSerializer.scala  |  9 +++
 .../japi/journal/JavaJournalPerfSpec.scala         |  9 +++
 .../persistence/japi/journal/JavaJournalSpec.scala |  9 +++
 .../japi/snapshot/JavaSnapshotStoreSpec.scala      |  9 +++
 .../persistence/journal/JournalPerfSpec.scala      |  9 +++
 .../pekko/persistence/journal/JournalSpec.scala    |  9 +++
 .../pekko/persistence/scalatest/MayVerb.scala      |  9 +++
 .../persistence/scalatest/OptionalTests.scala      |  9 +++
 .../persistence/snapshot/SnapshotStoreSpec.scala   |  9 +++
 .../apache/pekko/persistence/PluginCleanup.scala   |  9 +++
 .../persistence/japi/JavaJournalSpecSpec.scala     |  9 +++
 .../journal/inmem/InmemJournalSpec.scala           |  9 +++
 .../journal/leveldb/LeveldbJournalJavaSpec.scala   |  9 +++
 .../journal/leveldb/LeveldbJournalNativeSpec.scala |  9 +++
 ...bJournalNoAtomicPersistMultipleEventsSpec.scala |  9 +++
 .../snapshot/local/LocalSnapshotStoreSpec.scala    |  9 +++
 .../pekko/persistence/testkit/EventStorage.scala   |  9 +++
 .../testkit/PersistenceTestKitPlugin.scala         |  9 +++
 .../persistence/testkit/ProcessingPolicy.scala     |  9 +++
 .../persistence/testkit/SnapshotStorage.scala      |  9 +++
 .../persistence/testkit/internal/CurrentTime.scala |  9 +++
 .../internal/EventSourcedBehaviorTestKitImpl.scala |  9 +++
 .../testkit/internal/InMemStorageExtension.scala   |  9 +++
 .../testkit/internal/PersistenceInitImpl.scala     |  9 +++
 .../internal/SerializedEventStorageImpl.scala      |  9 +++
 .../internal/SerializedSnapshotStorageImpl.scala   |  9 +++
 .../testkit/internal/SimpleEventStorageImpl.scala  |  9 +++
 .../internal/SimpleSnapshotStorageImpl.scala       |  9 +++
 .../SnapshotStorageEmulatorExtension.scala         |  9 +++
 .../testkit/internal/TestKitStorage.scala          |  9 +++
 .../javadsl/EventSourcedBehaviorTestKit.scala      |  9 +++
 .../testkit/javadsl/PersistenceInit.scala          |  9 +++
 .../testkit/javadsl/PersistenceTestKit.scala       |  9 +++
 .../testkit/javadsl/SnapshotTestKit.scala          |  9 +++
 .../PersistenceTestKitReadJournalProvider.scala    |  9 +++
 .../internal/EventsByPersistenceIdStage.scala      |  9 +++
 .../javadsl/PersistenceTestKitReadJournal.scala    |  9 +++
 .../scaladsl/PersistenceTestKitReadJournal.scala   |  9 +++
 .../scaladsl/EventSourcedBehaviorTestKit.scala     |  9 +++
 .../testkit/scaladsl/PersistenceInit.scala         |  9 +++
 .../testkit/scaladsl/PersistenceTestKit.scala      |  9 +++
 .../persistence/testkit/scaladsl/TestOps.scala     |  9 +++
 ...rsistenceTestKitDurableStateStoreProvider.scala |  9 +++
 .../PersistenceTestKitDurableStateStore.scala      |  9 +++
 .../PersistenceTestKitDurableStateStore.scala      |  9 +++
 .../pekko/persistence/testkit/CommonUtils.scala    |  9 +++
 .../testkit/javadsl/CommonSnapshotTests.scala      |  9 +++
 .../testkit/javadsl/CommonTestKitTests.scala       |  9 +++
 .../persistence/testkit/javadsl/JavaDslUtils.scala |  9 +++
 .../testkit/javadsl/SnapshotNotSerializeSpec.scala |  9 +++
 .../testkit/javadsl/SnapshotSerializeSpec.scala    |  9 +++
 .../testkit/javadsl/TestKitNotSerializeSpec.scala  |  9 +++
 .../testkit/javadsl/TestKitSerializeSpec.scala     |  9 +++
 .../testkit/query/CurrentEventsBySlicesSpec.scala  |  9 +++
 .../testkit/query/CurrentEventsByTagSpec.scala     |  9 +++
 .../testkit/query/EventsByPersistenceIdSpec.scala  |  9 +++
 .../testkit/scaladsl/CommonSnapshotTests.scala     |  9 +++
 .../testkit/scaladsl/CommonTestKitTests.scala      |  9 +++
 ...EventSourcedBehaviorNoSnapshotTestKitSpec.scala |  9 +++
 .../scaladsl/EventSourcedBehaviorTestKitSpec.scala |  9 +++
 .../testkit/scaladsl/MultipleJournalsSpec.scala    |  9 +++
 .../PersistenceTestKitJournalCompatSpec.scala      |  9 +++
 .../testkit/scaladsl/ScalaDslUtils.scala           |  9 +++
 .../scaladsl/SnapshotNotSerializeSpec.scala        |  9 +++
 .../testkit/scaladsl/SnapshotSerializeSpec.scala   |  9 +++
 .../testkit/scaladsl/TestKitNotSerializeSpec.scala |  9 +++
 .../testkit/scaladsl/TestKitSerializeSpec.scala    |  9 +++
 .../PersistenceTestKitDurableStateStoreSpec.scala  |  9 +++
 .../persistence/typed/MyReplicatedBehavior.java    |  9 +++
 .../typed/ReplicatedAuctionExampleTest.java        |  9 +++
 .../persistence/typed/ReplicatedBlogExample.java   |  9 +++
 .../persistence/typed/ReplicatedMovieExample.java  |  9 +++
 .../typed/ReplicatedShoppingCartExample.java       |  9 +++
 .../persistence/typed/ReplicatedStringSet.java     |  9 +++
 .../typed/ReplicatedEventSourcingTest.java         |  9 +++
 .../javadsl/EventSourcedActorFailureTest.java      |  9 +++
 .../javadsl/EventSourcedBehaviorJavaDslTest.java   |  9 +++
 .../typed/ReplicatedAuctionExampleSpec.scala       |  9 +++
 .../typed/ReplicatedBlogExampleSpec.scala          |  9 +++
 .../ReplicatedEventSourcingCompileOnlySpec.scala   |  9 +++
 .../ReplicatedMovieWatchListExampleSpec.scala      |  9 +++
 .../typed/ReplicatedShoppingCartExampleSpec.scala  |  9 +++
 .../persistence/typed/EventPublishingSpec.scala    |  9 +++
 .../typed/EventSourcedBehaviorLoggingSpec.scala    |  9 +++
 .../typed/MultiJournalReplicationSpec.scala        |  9 +++
 .../typed/ReplicatedEventPublishingSpec.scala      |  9 +++
 .../typed/ReplicatedEventSourcingSpec.scala        |  9 +++
 .../typed/ReplicatedEventSourcingTaggingSpec.scala |  9 +++
 .../persistence/typed/ReplicationBaseSpec.scala    |  9 +++
 .../typed/ReplicationIllegalAccessSpec.scala       |  9 +++
 .../typed/ReplicationSnapshotSpec.scala            |  9 +++
 .../pekko/persistence/typed/crdt/CounterSpec.scala |  9 +++
 .../pekko/persistence/typed/crdt/LwwSpec.scala     |  9 +++
 .../pekko/persistence/typed/crdt/ORSetSpec.scala   |  9 +++
 .../ReplicatedEventSourcingJacksonSpec.scala       |  9 +++
 .../scaladsl/EventSourcedBehaviorFailureSpec.scala |  9 +++
 .../EventSourcedBehaviorInterceptorSpec.scala      |  9 +++
 .../EventSourcedBehaviorRecoveryTimeoutSpec.scala  |  9 +++
 .../scaladsl/EventSourcedBehaviorReplySpec.scala   |  9 +++
 .../EventSourcedBehaviorRetentionSpec.scala        |  9 +++
 .../typed/scaladsl/EventSourcedBehaviorSpec.scala  |  9 +++
 .../scaladsl/EventSourcedBehaviorStashSpec.scala   |  9 +++
 .../scaladsl/EventSourcedBehaviorTimersSpec.scala  |  9 +++
 .../scaladsl/EventSourcedBehaviorWatchSpec.scala   |  9 +++
 .../scaladsl/EventSourcedEventAdapterSpec.scala    |  9 +++
 .../scaladsl/EventSourcedSequenceNumberSpec.scala  |  9 +++
 .../scaladsl/EventSourcedSnapshotAdapterSpec.scala |  9 +++
 .../scaladsl/EventSourcedStashOverflowSpec.scala   |  9 +++
 .../typed/scaladsl/LoggerSourceSpec.scala          |  9 +++
 .../typed/scaladsl/NullEmptyStateSpec.scala        |  9 +++
 .../typed/scaladsl/OptionalSnapshotStoreSpec.scala |  9 +++
 .../typed/scaladsl/PerformanceSpec.scala           |  9 +++
 .../typed/scaladsl/PrimitiveStateSpec.scala        |  9 +++
 .../typed/scaladsl/SlowInMemorySnapshotStore.scala |  9 +++
 .../typed/scaladsl/SnapshotMutableStateSpec.scala  |  9 +++
 .../SnapshotRecoveryWithEmptyJournalSpec.scala     |  9 +++
 .../DurableStateBehaviorInterceptorSpec.scala      |  9 +++
 .../scaladsl/DurableStateBehaviorReplySpec.scala   |  9 +++
 .../scaladsl/DurableStateBehaviorTimersSpec.scala  |  9 +++
 .../state/scaladsl/DurableStateRevisionSpec.scala  |  9 +++
 .../typed/state/scaladsl/NullEmptyStateSpec.scala  |  9 +++
 .../typed/state/scaladsl/PrimitiveStateSpec.scala  |  9 +++
 .../serialization/ReplicatedEventSourcing.java     |  9 +++
 .../main/protobuf/ReplicatedEventSourcing.proto    |  9 +++
 .../pekko/persistence/typed/EventAdapter.scala     |  9 +++
 .../persistence/typed/EventRejectedException.scala |  9 +++
 .../persistence/typed/EventSourcedSignal.scala     |  9 +++
 .../pekko/persistence/typed/PersistenceId.scala    |  9 +++
 .../pekko/persistence/typed/PublishedEvent.scala   |  9 +++
 .../apache/pekko/persistence/typed/ReplicaId.scala |  9 +++
 .../pekko/persistence/typed/ReplicationId.scala    |  9 +++
 .../pekko/persistence/typed/SnapshotAdapter.scala  |  9 +++
 .../typed/SnapshotSelectionCriteria.scala          |  9 +++
 .../pekko/persistence/typed/crdt/Counter.scala     |  9 +++
 .../pekko/persistence/typed/crdt/LwwTime.scala     |  9 +++
 .../pekko/persistence/typed/crdt/ORSet.scala       |  9 +++
 .../pekko/persistence/typed/crdt/OpCrdt.scala      |  9 +++
 .../typed/delivery/EventSourcedProducerQueue.scala |  9 +++
 .../persistence/typed/internal/BehaviorSetup.scala |  9 +++
 .../persistence/typed/internal/EffectImpl.scala    |  9 +++
 .../typed/internal/EventSourcedBehaviorImpl.scala  |  9 +++
 .../typed/internal/EventSourcedSettings.scala      |  9 +++
 .../typed/internal/ExternalInteractions.scala      |  9 +++
 .../typed/internal/FastForwardingFilter.scala      |  9 +++
 .../typed/internal/JournalFailureException.scala   |  9 +++
 .../typed/internal/NoOpSnapshotAdapter.scala       |  9 +++
 .../persistence/typed/internal/RecoveryImpl.scala  |  9 +++
 .../typed/internal/ReplayingEvents.scala           |  9 +++
 .../typed/internal/ReplayingSnapshot.scala         |  9 +++
 .../typed/internal/ReplicationSetup.scala          |  9 +++
 .../typed/internal/RequestingRecoveryPermit.scala  |  9 +++
 .../typed/internal/RetentionCriteriaImpl.scala     |  9 +++
 .../pekko/persistence/typed/internal/Running.scala |  9 +++
 .../persistence/typed/internal/SideEffect.scala    |  9 +++
 .../typed/internal/StashManagement.scala           |  9 +++
 .../persistence/typed/internal/VersionVector.scala |  9 +++
 .../persistence/typed/javadsl/CommandHandler.scala |  9 +++
 .../typed/javadsl/CommandHandlerWithReply.scala    |  9 +++
 .../pekko/persistence/typed/javadsl/Effect.scala   |  9 +++
 .../persistence/typed/javadsl/EventHandler.scala   |  9 +++
 .../typed/javadsl/EventSourcedBehavior.scala       |  9 +++
 .../typed/javadsl/PersistentFSMMigration.scala     |  9 +++
 .../pekko/persistence/typed/javadsl/Recovery.scala |  9 +++
 .../javadsl/ReplicatedEventSourcedBehavior.scala   |  9 +++
 .../typed/javadsl/ReplicatedEventSourcing.scala    |  9 +++
 .../typed/javadsl/RetentionCriteria.scala          |  9 +++
 .../persistence/typed/javadsl/SignalHandler.scala  |  9 +++
 .../pekko/persistence/typed/scaladsl/Effect.scala  |  9 +++
 .../typed/scaladsl/EventSourcedBehavior.scala      |  9 +++
 .../typed/scaladsl/PersistentFSMMigration.scala    |  9 +++
 .../persistence/typed/scaladsl/Recovery.scala      |  9 +++
 .../typed/scaladsl/ReplicatedEventSourcing.scala   |  9 +++
 .../typed/scaladsl/RetentionCriteria.scala         |  9 +++
 .../ReplicatedEventSourcingSerializer.scala        |  9 +++
 .../typed/state/DurableStateSignal.scala           |  9 +++
 .../typed/state/internal/BehaviorSetup.scala       |  9 +++
 .../state/internal/DurableStateBehaviorImpl.scala  |  9 +++
 .../state/internal/DurableStateSettings.scala      |  9 +++
 .../internal/DurableStateStoreException.scala      |  9 +++
 .../internal/DurableStateStoreInteractions.scala   |  9 +++
 .../typed/state/internal/EffectImpl.scala          |  9 +++
 .../typed/state/internal/NoOpSnapshotAdapter.scala |  9 +++
 .../typed/state/internal/Recovering.scala          |  9 +++
 .../state/internal/RequestingRecoveryPermit.scala  |  9 +++
 .../persistence/typed/state/internal/Running.scala |  9 +++
 .../typed/state/internal/SideEffect.scala          |  9 +++
 .../typed/state/internal/StashManagement.scala     |  9 +++
 .../typed/state/javadsl/CommandHandler.scala       |  9 +++
 .../state/javadsl/CommandHandlerWithReply.scala    |  9 +++
 .../typed/state/javadsl/DurableStateBehavior.scala |  9 +++
 .../persistence/typed/state/javadsl/Effect.scala   |  9 +++
 .../typed/state/javadsl/SignalHandler.scala        |  9 +++
 .../state/scaladsl/DurableStateBehavior.scala      |  9 +++
 .../persistence/typed/state/scaladsl/Effect.scala  |  9 +++
 .../typed/BasicPersistentBehaviorTest.java         |  9 +++
 .../pekko/persistence/typed/BlogPostEntity.java    |  9 +++
 .../typed/BlogPostEntityDurableState.java          |  9 +++
 .../typed/DurableStatePersistentBehaviorTest.java  |  9 +++
 .../pekko/persistence/typed/MovieWatchList.java    |  9 +++
 .../pekko/persistence/typed/NullBlogState.java     |  9 +++
 .../pekko/persistence/typed/OptionalBlogState.java |  9 +++
 ...rsistentFsmToTypedMigrationCompileOnlyTest.java |  9 +++
 .../pekko/persistence/typed/StashingExample.java   |  9 +++
 .../persistence/typed/WebStoreCustomerFSM.java     |  9 +++
 .../pekko/persistence/typed/auction/Auction.java   |  9 +++
 .../persistence/typed/auction/AuctionCommand.java  |  9 +++
 .../persistence/typed/auction/AuctionEntity.java   |  9 +++
 .../persistence/typed/auction/AuctionEvent.java    |  9 +++
 .../persistence/typed/auction/AuctionState.java    |  9 +++
 .../persistence/typed/auction/AuctionStatus.java   |  9 +++
 .../pekko/persistence/typed/auction/Bid.java       |  9 +++
 .../persistence/typed/auction/BidResultStatus.java |  9 +++
 .../typed/javadsl/LoggerSourceTest.java            |  9 +++
 .../typed/javadsl/NullEmptyStateTest.java          |  9 +++
 .../javadsl/PersistentActorCompileOnlyTest.java    |  9 +++
 .../typed/javadsl/PrimitiveStateTest.java          |  9 +++
 .../typed/BasicPersistentBehaviorCompileOnly.scala |  9 +++
 .../pekko/persistence/typed/BlogPostEntity.scala   |  9 +++
 .../typed/BlogPostEntityDurableState.scala         |  9 +++
 ...DurableStatePersistentBehaviorCompileOnly.scala |  9 +++
 .../pekko/persistence/typed/MovieWatchList.scala   |  9 +++
 .../typed/PersistentFsmToTypedMigrationSpec.scala  |  9 +++
 .../pekko/persistence/typed/StashingExample.scala  |  9 +++
 .../typed/ClusterSingletonPersistenceSpec.scala    |  9 +++
 .../persistence/typed/ManyRecoveriesSpec.scala     |  9 +++
 .../persistence/typed/PersistenceIdSpec.scala      |  9 +++
 .../ReplicatedEventSourcingSerializationSpec.scala |  9 +++
 .../typed/StashingWhenSnapshottingSpec.scala       |  9 +++
 .../delivery/EventSourcedProducerQueueSpec.scala   |  9 +++
 ...DeliveryWithEventSourcedProducerQueueSpec.scala |  9 +++
 ...kPullingWithEventSourcedProducerQueueSpec.scala |  9 +++
 .../typed/internal/RecoveryPermitterSpec.scala     |  9 +++
 .../typed/internal/RetentionCriteriaSpec.scala     |  9 +++
 .../typed/internal/StashStateSpec.scala            |  9 +++
 .../scaladsl/PersistentActorCompileOnlyTest.scala  |  9 +++
 .../typed/scaladsl/SnapshotIsOptionalSpec.scala    |  9 +++
 .../ReplicatedEventSourcingSerializerSpec.scala    |  9 +++
 .../fsm/japi/pf/FSMStateFunctionBuilder.java       |  9 +++
 .../persistence/fsm/japi/pf/FSMStopBuilder.java    |  9 +++
 .../journal/japi/AsyncRecoveryPlugin.java          |  9 +++
 .../persistence/journal/japi/AsyncWritePlugin.java |  9 +++
 .../persistence/serialization/MessageFormats.java  |  9 +++
 .../snapshot/japi/SnapshotStorePlugin.java         |  9 +++
 persistence/src/main/protobuf/MessageFormats.proto |  9 +++
 .../org/apache/pekko/persistence/TraitOrder.scala  |  9 +++
 .../pekko/persistence/AtLeastOnceDelivery.scala    |  9 +++
 .../apache/pekko/persistence/Eventsourced.scala    |  9 +++
 .../apache/pekko/persistence/JournalProtocol.scala |  9 +++
 .../org/apache/pekko/persistence/Persistence.scala |  9 +++
 .../pekko/persistence/PersistencePlugin.scala      |  9 +++
 .../org/apache/pekko/persistence/Persistent.scala  |  9 +++
 .../apache/pekko/persistence/PersistentActor.scala |  9 +++
 .../org/apache/pekko/persistence/Protocol.scala    |  9 +++
 .../pekko/persistence/RecoveryPermitter.scala      |  9 +++
 .../pekko/persistence/SnapshotProtocol.scala       |  9 +++
 .../org/apache/pekko/persistence/Snapshotter.scala |  9 +++
 .../pekko/persistence/fsm/PersistentFSM.scala      |  9 +++
 .../pekko/persistence/fsm/PersistentFSMBase.scala  |  9 +++
 .../pekko/persistence/journal/AsyncRecovery.scala  |  9 +++
 .../persistence/journal/AsyncWriteJournal.scala    |  9 +++
 .../persistence/journal/AsyncWriteProxy.scala      |  9 +++
 .../pekko/persistence/journal/EventAdapter.scala   |  9 +++
 .../pekko/persistence/journal/EventAdapters.scala  |  9 +++
 .../journal/PersistencePluginProxy.scala           |  9 +++
 .../pekko/persistence/journal/ReplayFilter.scala   |  9 +++
 .../apache/pekko/persistence/journal/Tagged.scala  |  9 +++
 .../persistence/journal/WriteJournalBase.scala     |  9 +++
 .../persistence/journal/inmem/InmemJournal.scala   |  9 +++
 .../persistence/journal/japi/AsyncRecovery.scala   |  9 +++
 .../journal/japi/AsyncWriteJournal.scala           |  9 +++
 .../journal/leveldb/LeveldbCompaction.scala        |  9 +++
 .../journal/leveldb/LeveldbIdMapping.scala         |  9 +++
 .../journal/leveldb/LeveldbJournal.scala           |  9 +++
 .../persistence/journal/leveldb/LeveldbKey.scala   |  9 +++
 .../journal/leveldb/LeveldbRecovery.scala          |  9 +++
 .../persistence/journal/leveldb/LeveldbStore.scala |  9 +++
 .../journal/leveldb/SharedLeveldbStore.scala       |  9 +++
 .../serialization/MessageSerializer.scala          |  9 +++
 .../serialization/SnapshotSerializer.scala         |  9 +++
 .../pekko/persistence/serialization/package.scala  |  9 +++
 .../persistence/snapshot/NoSnapshotStore.scala     |  9 +++
 .../pekko/persistence/snapshot/SnapshotStore.scala |  9 +++
 .../persistence/snapshot/japi/SnapshotStore.scala  |  9 +++
 .../snapshot/local/LocalSnapshotStore.scala        |  9 +++
 .../state/DurableStateStoreProvider.scala          |  9 +++
 .../state/DurableStateStoreRegistry.scala          |  9 +++
 .../state/javadsl/DurableStateStore.scala          |  9 +++
 .../state/javadsl/DurableStateUpdateStore.scala    |  9 +++
 .../state/scaladsl/DurableStateStore.scala         |  9 +++
 .../state/scaladsl/DurableStateUpdateStore.scala   |  9 +++
 .../persistence/fsm/AbstractPersistentFSMTest.java |  9 +++
 .../persistence/AtLeastOnceDeliveryCrashSpec.scala |  9 +++
 .../AtLeastOnceDeliveryFailureSpec.scala           |  9 +++
 .../persistence/AtLeastOnceDeliverySpec.scala      |  9 +++
 .../apache/pekko/persistence/AtomicWriteSpec.scala |  9 +++
 .../persistence/EndToEndEventAdapterSpec.scala     |  9 +++
 .../pekko/persistence/EventAdapterSpec.scala       |  9 +++
 .../EventSourcedActorDeleteFailureSpec.scala       |  9 +++
 .../persistence/EventSourcedActorFailureSpec.scala |  9 +++
 .../apache/pekko/persistence/LoadPluginSpec.scala  |  9 +++
 .../pekko/persistence/ManyRecoveriesSpec.scala     |  9 +++
 .../pekko/persistence/OptimizedRecoverySpec.scala  |  9 +++
 .../persistence/OptionalSnapshotStoreSpec.scala    |  9 +++
 .../apache/pekko/persistence/PerformanceSpec.scala |  9 +++
 .../apache/pekko/persistence/PersistenceSpec.scala |  9 +++
 .../PersistentActorBoundedStashingSpec.scala       |  9 +++
 .../PersistentActorJournalProtocolSpec.scala       |  9 +++
 .../PersistentActorRecoveryTimeoutSpec.scala       |  9 +++
 .../pekko/persistence/PersistentActorSpec.scala    |  9 +++
 .../persistence/PersistentActorStashingSpec.scala  |  9 +++
 .../pekko/persistence/RecoveryPermitterSpec.scala  |  9 +++
 .../apache/pekko/persistence/SliceRangesSpec.scala |  9 +++
 .../persistence/SnapshotDecodeFailureSpec.scala    |  9 +++
 .../persistence/SnapshotDirectoryFailureSpec.scala |  9 +++
 .../SnapshotFailureRobustnessSpec.scala            |  9 +++
 .../SnapshotRecoveryLocalStoreSpec.scala           |  9 +++
 .../SnapshotRecoveryWithEmptyJournalSpec.scala     |  9 +++
 .../persistence/SnapshotSerializationSpec.scala    |  9 +++
 .../apache/pekko/persistence/SnapshotSpec.scala    |  9 +++
 .../persistence/TimerPersistentActorSpec.scala     |  9 +++
 .../pekko/persistence/fsm/PersistentFSMSpec.scala  |  9 +++
 .../journal/InmemEventAdaptersSpec.scala           |  9 +++
 .../persistence/journal/ReplayFilterSpec.scala     |  9 +++
 .../persistence/journal/SteppingInmemJournal.scala |  9 +++
 .../persistence/journal/chaos/ChaosJournal.scala   |  9 +++
 .../journal/inmem/InmemJournalSpec.scala           |  9 +++
 .../leveldb/CompactionSegmentManagementSpec.scala  |  9 +++
 .../journal/leveldb/JournalCompactionSpec.scala    |  9 +++
 .../serialization/MessageSerializerSpec.scala      |  9 +++
 .../apache/pekko/pki/pem/DERPrivateKeyLoader.scala |  9 +++
 .../org/apache/pekko/pki/pem/PEMDecoder.scala      |  9 +++
 .../pekko/pki/pem/DERPrivateKeyLoaderSpec.scala    |  9 +++
 .../org/apache/pekko/pki/pem/PEMDecoderSpec.scala  |  9 +++
 project/AddLogTimestamps.scala                     |  9 +++
 project/AutomaticModuleName.scala                  |  9 +++
 project/CliOptions.scala                           |  9 +++
 project/CopyrightHeader.scala                      | 92 ++++++++++++----------
 project/CopyrightHeaderForBoilerplate.scala        |  9 +++
 project/CopyrightHeaderForBuild.scala              |  9 +++
 project/CopyrightHeaderForJdk9.scala               |  9 +++
 project/CopyrightHeaderForProtobuf.scala           |  9 +++
 project/Dependencies.scala                         |  9 +++
 project/Doc.scala                                  |  9 +++
 project/GitHub.scala                               |  9 +++
 project/JavaFormatter.scala                        |  9 +++
 project/Jdk9.scala                                 |  9 +++
 project/JdkOptions.scala                           |  9 +++
 project/Jvm.scala                                  |  9 +++
 project/MiMa.scala                                 |  9 +++
 project/MultiNode.scala                            |  9 +++
 project/OSGi.scala                                 |  9 +++
 project/Paradox.scala                              |  9 +++
 project/ParadoxBrowse.scala                        |  9 +++
 project/PekkoBuild.scala                           |  9 +++
 project/PekkoDisciplinePlugin.scala                |  9 +++
 project/ProjectFileIgnoreSupport.scala             |  9 +++
 project/Protobuf.scala                             |  9 +++
 project/Publish.scala                              |  9 +++
 project/SbtMultiJvm.scala                          |  9 +++
 project/ScalaFixExtraRulesPlugin.scala             |  9 +++
 project/ScalaFixForJdk9Plugin.scala                |  9 +++
 project/ScalafixForMultiNodePlugin.scala           |  9 +++
 project/ScalafixIgnoreFilePlugin.scala             |  9 +++
 project/ScalafixSupport.scala                      |  9 +++
 project/SigarLoader.scala                          |  9 +++
 project/StreamOperatorsIndexGenerator.scala        |  9 +++
 project/TestExtras.scala                           |  9 +++
 project/ValidatePullRequest.scala                  |  9 +++
 project/VersionGenerator.scala                     |  9 +++
 .../org/apache/pekko/protobuf/AbstractMessage.java |  9 +++
 .../apache/pekko/protobuf/AbstractMessageLite.java |  9 +++
 .../org/apache/pekko/protobuf/AbstractParser.java  |  9 +++
 .../apache/pekko/protobuf/BlockingRpcChannel.java  |  9 +++
 .../org/apache/pekko/protobuf/BlockingService.java |  9 +++
 .../apache/pekko/protobuf/BoundedByteString.java   |  9 +++
 .../java/org/apache/pekko/protobuf/ByteString.java |  9 +++
 .../apache/pekko/protobuf/CodedInputStream.java    |  9 +++
 .../apache/pekko/protobuf/CodedOutputStream.java   |  9 +++
 .../apache/pekko/protobuf/DescriptorProtos.java    |  9 +++
 .../org/apache/pekko/protobuf/Descriptors.java     |  9 +++
 .../org/apache/pekko/protobuf/DynamicMessage.java  |  9 +++
 .../apache/pekko/protobuf/ExtensionRegistry.java   |  9 +++
 .../pekko/protobuf/ExtensionRegistryLite.java      |  9 +++
 .../java/org/apache/pekko/protobuf/FieldSet.java   |  9 +++
 .../apache/pekko/protobuf/GeneratedMessage.java    |  9 +++
 .../pekko/protobuf/GeneratedMessageLite.java       |  9 +++
 .../java/org/apache/pekko/protobuf/Internal.java   |  9 +++
 .../protobuf/InvalidProtocolBufferException.java   |  9 +++
 .../java/org/apache/pekko/protobuf/LazyField.java  |  9 +++
 .../apache/pekko/protobuf/LazyStringArrayList.java |  9 +++
 .../org/apache/pekko/protobuf/LazyStringList.java  |  9 +++
 .../apache/pekko/protobuf/LiteralByteString.java   |  9 +++
 .../java/org/apache/pekko/protobuf/Message.java    |  9 +++
 .../org/apache/pekko/protobuf/MessageLite.java     |  9 +++
 .../pekko/protobuf/MessageLiteOrBuilder.java       |  9 +++
 .../apache/pekko/protobuf/MessageOrBuilder.java    |  9 +++
 .../java/org/apache/pekko/protobuf/Parser.java     |  9 +++
 .../apache/pekko/protobuf/ProtocolMessageEnum.java |  9 +++
 .../pekko/protobuf/RepeatedFieldBuilder.java       |  9 +++
 .../org/apache/pekko/protobuf/RopeByteString.java  |  9 +++
 .../org/apache/pekko/protobuf/RpcCallback.java     |  9 +++
 .../java/org/apache/pekko/protobuf/RpcChannel.java |  9 +++
 .../org/apache/pekko/protobuf/RpcController.java   |  9 +++
 .../java/org/apache/pekko/protobuf/RpcUtil.java    |  9 +++
 .../java/org/apache/pekko/protobuf/Service.java    |  9 +++
 .../apache/pekko/protobuf/ServiceException.java    |  9 +++
 .../apache/pekko/protobuf/SingleFieldBuilder.java  |  9 +++
 .../org/apache/pekko/protobuf/SmallSortedMap.java  |  9 +++
 .../java/org/apache/pekko/protobuf/TextFormat.java |  9 +++
 .../protobuf/UninitializedMessageException.java    |  9 +++
 .../org/apache/pekko/protobuf/UnknownFieldSet.java |  9 +++
 .../pekko/protobuf/UnmodifiableLazyStringList.java |  9 +++
 .../main/java/org/apache/pekko/protobuf/Utf8.java  |  9 +++
 .../java/org/apache/pekko/protobuf/WireFormat.java |  9 +++
 .../scala/org/apache/pekko/io/DnsSpec.scala        |  9 +++
 .../pekko/remote/AttemptSysMsgRedeliverySpec.scala |  9 +++
 .../pekko/remote/LookupRemoteActorSpec.scala       |  9 +++
 .../apache/pekko/remote/NewRemoteActorSpec.scala   |  9 +++
 .../remote/PiercingShouldKeepQuarantineSpec.scala  |  9 +++
 .../apache/pekko/remote/RemoteDeliverySpec.scala   |  9 +++
 .../remote/RemoteDeploymentDeathWatchSpec.scala    |  9 +++
 .../apache/pekko/remote/RemoteFeaturesSpec.scala   |  9 +++
 .../pekko/remote/RemoteNodeDeathWatchSpec.scala    |  9 +++
 .../remote/RemoteNodeRestartDeathWatchSpec.scala   |  9 +++
 .../remote/RemoteQuarantinePiercingSpec.scala      |  9 +++
 .../pekko/remote/RemoteReDeploymentSpec.scala      |  9 +++
 .../pekko/remote/RemotingMultiNodeSpec.scala       |  9 +++
 .../apache/pekko/remote/TransportFailSpec.scala    |  9 +++
 .../remote/artery/BenchmarkFileReporter.scala      |  9 +++
 .../pekko/remote/artery/DirectMemorySpec.scala     |  9 +++
 .../pekko/remote/artery/FanInThrougputSpec.scala   |  9 +++
 .../pekko/remote/artery/FanOutThrougputSpec.scala  |  9 +++
 .../artery/HandshakeRestartReceiverSpec.scala      |  9 +++
 .../apache/pekko/remote/artery/LatencySpec.scala   |  9 +++
 .../pekko/remote/artery/MaxThroughputSpec.scala    |  9 +++
 .../apache/pekko/remote/artery/PlotResult.scala    |  9 +++
 .../artery/RemoteRestartedQuarantinedSpec.scala    |  9 +++
 ...dStreamRestartWithCompressionInFlightSpec.scala |  9 +++
 .../artery/SurviveNetworkPartitionSpec.scala       |  9 +++
 .../apache/pekko/remote/artery/TestMessage.scala   |  9 +++
 .../pekko/remote/artery/TestRateReporter.scala     |  9 +++
 .../apache/pekko/remote/artery/UdpPortActor.scala  |  9 +++
 .../artery/aeron/AeronStreamConcistencySpec.scala  |  9 +++
 .../artery/aeron/AeronStreamLatencySpec.scala      |  9 +++
 .../aeron/AeronStreamMaxThroughputSpec.scala       |  9 +++
 .../artery/aeron/AeronStreamMultiNodeSpec.scala    |  9 +++
 .../remote/classic/RemoteGatePiercingSpec.scala    |  9 +++
 .../remote/classic/RemoteNodeRestartGateSpec.scala |  9 +++
 .../RemoteNodeShutdownAndComesBackSpec.scala       |  9 +++
 .../pekko/remote/classic/Ticket15109Spec.scala     |  9 +++
 .../pekko/remote/routing/RemoteRandomSpec.scala    |  9 +++
 .../remote/routing/RemoteRoundRobinSpec.scala      |  9 +++
 .../remote/routing/RemoteScatterGatherSpec.scala   |  9 +++
 .../pekko/remote/sample/MultiNodeSample.scala      |  9 +++
 .../remote/testconductor/TestConductorSpec.scala   |  9 +++
 .../pekko/remote/testkit/MultiNodeSpecSpec.scala   |  9 +++
 .../pekko/remote/artery/protobuf/TestMessages.java |  9 +++
 remote-tests/src/test/protobuf/TestMessages.proto  |  9 +++
 .../remote/artery/ArteryFailedToBindSpec.scala     |  9 +++
 .../remote/classic/RemotingFailedToBindSpec.scala  |  9 +++
 .../pekko/remote/testconductor/BarrierSpec.scala   |  9 +++
 .../remote/testconductor/ControllerSpec.scala      |  9 +++
 .../pekko/remote/testkit/LogRoleReplace.scala      |  9 +++
 .../pekko/remote/testkit/STMultiNodeSpec.scala     |  9 +++
 .../scala/org/scalatest/extra/QuietReporter.scala  |  9 +++
 .../apache/pekko/remote/ArteryControlFormats.java  |  9 +++
 .../org/apache/pekko/remote/ContainerFormats.java  |  9 +++
 .../apache/pekko/remote/SystemMessageFormats.java  |  9 +++
 .../java/org/apache/pekko/remote/WireFormats.java  |  9 +++
 .../pekko/remote/artery/AbstractAssociation.java   |  9 +++
 .../remote/artery/compress/CountMinSketch.java     |  9 +++
 .../src/main/protobuf/ArteryControlFormats.proto   |  9 +++
 remote/src/main/protobuf/ContainerFormats.proto    |  9 +++
 .../src/main/protobuf/SystemMessageFormats.proto   |  9 +++
 remote/src/main/protobuf/WireFormats.proto         |  9 +++
 .../apache/pekko/remote/artery/jfr/Events.scala    |  9 +++
 .../artery/jfr/JFRRemotingFlightRecorder.scala     |  9 +++
 .../org/apache/pekko/remote/AckedDelivery.scala    |  9 +++
 .../apache/pekko/remote/AddressUidExtension.scala  |  9 +++
 .../pekko/remote/BoundAddressesExtension.scala     |  9 +++
 .../org/apache/pekko/remote/ByteStringUtils.scala  |  9 +++
 .../pekko/remote/DeadlineFailureDetector.scala     |  9 +++
 .../remote/DefaultFailureDetectorRegistry.scala    |  9 +++
 .../scala/org/apache/pekko/remote/Endpoint.scala   |  9 +++
 .../org/apache/pekko/remote/FailureDetector.scala  |  9 +++
 .../pekko/remote/FailureDetectorRegistry.scala     |  9 +++
 .../apache/pekko/remote/MessageSerializer.scala    |  9 +++
 .../pekko/remote/PhiAccrualFailureDetector.scala   |  9 +++
 .../pekko/remote/RemoteActorRefProvider.scala      |  9 +++
 .../org/apache/pekko/remote/RemoteDaemon.scala     |  9 +++
 .../org/apache/pekko/remote/RemoteDeployer.scala   |  9 +++
 .../pekko/remote/RemoteDeploymentWatcher.scala     |  9 +++
 .../org/apache/pekko/remote/RemoteLogMarker.scala  |  9 +++
 .../pekko/remote/RemoteMetricsExtension.scala      |  9 +++
 .../org/apache/pekko/remote/RemoteSettings.scala   |  9 +++
 .../org/apache/pekko/remote/RemoteTransport.scala  |  9 +++
 .../org/apache/pekko/remote/RemoteWatcher.scala    |  9 +++
 .../scala/org/apache/pekko/remote/Remoting.scala   |  9 +++
 .../pekko/remote/RemotingLifecycleEvent.scala      |  9 +++
 .../org/apache/pekko/remote/UniqueAddress.scala    |  9 +++
 .../pekko/remote/artery/ArterySettings.scala       |  9 +++
 .../pekko/remote/artery/ArteryTransport.scala      |  9 +++
 .../apache/pekko/remote/artery/Association.scala   |  9 +++
 .../org/apache/pekko/remote/artery/Codecs.scala    |  9 +++
 .../org/apache/pekko/remote/artery/Control.scala   |  9 +++
 .../pekko/remote/artery/EnvelopeBufferPool.scala   |  9 +++
 .../remote/artery/FixedSizePartitionHub.scala      |  9 +++
 .../artery/FlushBeforeDeathWatchNotification.scala |  9 +++
 .../pekko/remote/artery/FlushOnShutdown.scala      |  9 +++
 .../org/apache/pekko/remote/artery/Handshake.scala |  9 +++
 .../pekko/remote/artery/ImmutableLongMap.scala     |  9 +++
 .../pekko/remote/artery/InboundEnvelope.scala      |  9 +++
 .../remote/artery/InboundQuarantineCheck.scala     |  9 +++
 .../pekko/remote/artery/LruBoundedCache.scala      |  9 +++
 .../pekko/remote/artery/MessageDispatcher.scala    |  9 +++
 .../apache/pekko/remote/artery/ObjectPool.scala    |  9 +++
 .../pekko/remote/artery/OutboundEnvelope.scala     |  9 +++
 .../pekko/remote/artery/QuarantinedEvent.scala     |  9 +++
 .../pekko/remote/artery/RemoteInstrument.scala     |  9 +++
 .../remote/artery/RemotingFlightRecorder.scala     |  9 +++
 .../pekko/remote/artery/RestartCounter.scala       |  9 +++
 .../org/apache/pekko/remote/artery/SendQueue.scala |  9 +++
 .../remote/artery/SystemMessageDelivery.scala      |  9 +++
 .../org/apache/pekko/remote/artery/TestStage.scala |  9 +++
 .../pekko/remote/artery/aeron/AeronSink.scala      |  9 +++
 .../pekko/remote/artery/aeron/AeronSource.scala    |  9 +++
 .../artery/aeron/ArteryAeronUdpTransport.scala     |  9 +++
 .../pekko/remote/artery/aeron/TaskRunner.scala     |  9 +++
 .../artery/compress/CompressionProtocol.scala      |  9 +++
 .../remote/artery/compress/CompressionTable.scala  |  9 +++
 .../artery/compress/DecompressionTable.scala       |  9 +++
 .../artery/compress/InboundCompressions.scala      |  9 +++
 .../remote/artery/compress/TopHeavyHitters.scala   |  9 +++
 .../remote/artery/tcp/ArteryTcpTransport.scala     |  9 +++
 .../artery/tcp/ConfigSSLEngineProvider.scala       |  9 +++
 .../remote/artery/tcp/SSLEngineProvider.scala      |  9 +++
 .../remote/artery/tcp/SecureRandomFactory.scala    |  9 +++
 .../pekko/remote/artery/tcp/TcpFraming.scala       |  9 +++
 .../artery/tcp/ssl/PemManagersProvider.scala       |  9 +++
 .../tcp/ssl/RotatingKeysSSLEngineProvider.scala    |  9 +++
 .../remote/artery/tcp/ssl/SSLEngineConfig.scala    |  9 +++
 .../remote/artery/tcp/ssl/SessionVerifier.scala    |  9 +++
 .../pekko/remote/artery/tcp/ssl/X509Readers.scala  |  9 +++
 .../pekko/remote/routing/RemoteRouterConfig.scala  |  9 +++
 .../pekko/remote/security/provider/SeedSize.scala  |  9 +++
 .../serialization/ActorRefResolveCache.scala       |  9 +++
 .../serialization/ArteryMessageSerializer.scala    |  9 +++
 .../serialization/DaemonMsgCreateSerializer.scala  |  9 +++
 .../serialization/MessageContainerSerializer.scala |  9 +++
 .../serialization/MiscMessageSerializer.scala      |  9 +++
 .../serialization/PrimitiveSerializers.scala       |  9 +++
 .../remote/serialization/ProtobufSerializer.scala  |  9 +++
 .../serialization/SystemMessageSerializer.scala    |  9 +++
 .../ThrowableNotSerializableException.scala        |  9 +++
 .../remote/serialization/ThrowableSupport.scala    |  9 +++
 .../serialization/WrappedPayloadSupport.scala      |  9 +++
 .../transport/AbstractTransportAdapter.scala       |  9 +++
 .../FailureInjectorTransportAdapter.scala          |  9 +++
 .../pekko/remote/transport/PekkoPduCodec.scala     |  9 +++
 .../remote/transport/PekkoProtocolTransport.scala  |  9 +++
 .../pekko/remote/transport/TestTransport.scala     |  9 +++
 .../transport/ThrottlerTransportAdapter.scala      |  9 +++
 .../apache/pekko/remote/transport/Transport.scala  |  9 +++
 .../remote/transport/netty/NettyHelpers.scala      |  9 +++
 .../remote/transport/netty/NettySSLSupport.scala   |  9 +++
 .../remote/transport/netty/NettyTransport.scala    |  9 +++
 .../remote/transport/netty/SSLEngineProvider.scala |  9 +++
 .../pekko/remote/transport/netty/TcpSupport.scala  |  9 +++
 .../org/apache/pekko/remote/ProtobufProtocol.java  |  9 +++
 .../remote/protobuf/v3/ProtobufProtocolV3.java     |  9 +++
 .../transport/ThrottlerTransportAdapterTest.java   |  9 +++
 remote/src/test/protobuf/ProtobufProtocol.proto    |  9 +++
 remote/src/test/protobuf/ProtobufProtocolV3.proto  |  9 +++
 .../artery/jfr/JFRRemotingFlightRecorderSpec.scala |  9 +++
 .../pekko/remote/AccrualFailureDetectorSpec.scala  |  9 +++
 .../apache/pekko/remote/AckedDeliverySpec.scala    |  9 +++
 .../org/apache/pekko/remote/DaemonicSpec.scala     |  9 +++
 .../pekko/remote/DeadlineFailureDetectorSpec.scala |  9 +++
 .../apache/pekko/remote/EndpointRegistrySpec.scala |  9 +++
 .../pekko/remote/FailureDetectorRegistrySpec.scala |  9 +++
 .../org/apache/pekko/remote/LogSourceSpec.scala    |  9 +++
 .../apache/pekko/remote/MessageLoggingSpec.scala   |  9 +++
 .../apache/pekko/remote/NetworkFailureSpec.scala   |  9 +++
 .../pekko/remote/RemoteActorMailboxSpec.scala      |  9 +++
 .../org/apache/pekko/remote/RemoteConfigSpec.scala |  9 +++
 .../remote/RemoteConsistentHashingRouterSpec.scala |  9 +++
 .../apache/pekko/remote/RemoteDeployerSpec.scala   |  9 +++
 .../apache/pekko/remote/RemoteFeaturesSpec.scala   |  9 +++
 .../org/apache/pekko/remote/RemoteRouterSpec.scala |  9 +++
 .../pekko/remote/Ticket1978CommunicationSpec.scala |  9 +++
 .../apache/pekko/remote/Ticket1978ConfigSpec.scala |  9 +++
 .../remote/TransientSerializationErrorSpec.scala   |  9 +++
 .../pekko/remote/TypedActorRemoteDeploySpec.scala  |  9 +++
 .../ActorRefResolveCacheQuarantineSpec.scala       |  9 +++
 .../pekko/remote/artery/ArteryMultiNodeSpec.scala  |  9 +++
 .../pekko/remote/artery/ArterySpecSupport.scala    |  9 +++
 .../remote/artery/BindCanonicalAddressSpec.scala   |  9 +++
 .../pekko/remote/artery/DuplicateFlushSpec.scala   |  9 +++
 .../remote/artery/DuplicateHandshakeSpec.scala     |  9 +++
 .../pekko/remote/artery/EnvelopeBufferSpec.scala   |  9 +++
 .../pekko/remote/artery/FlushOnShutdownSpec.scala  |  9 +++
 .../pekko/remote/artery/HandshakeDenySpec.scala    |  9 +++
 .../pekko/remote/artery/HandshakeFailureSpec.scala |  9 +++
 .../pekko/remote/artery/HandshakeRetrySpec.scala   |  9 +++
 .../pekko/remote/artery/ImmutableLongMapSpec.scala |  9 +++
 .../remote/artery/InboundControlJunctionSpec.scala |  9 +++
 .../pekko/remote/artery/InboundHandshakeSpec.scala |  9 +++
 .../remote/artery/LargeMessagesStreamSpec.scala    |  9 +++
 .../pekko/remote/artery/LateConnectSpec.scala      |  9 +++
 .../pekko/remote/artery/LruBoundedCacheSpec.scala  |  9 +++
 .../pekko/remote/artery/MetadataCarryingSpec.scala |  9 +++
 .../artery/OutboundControlJunctionSpec.scala       |  9 +++
 .../remote/artery/OutboundHandshakeSpec.scala      |  9 +++
 .../remote/artery/OutboundIdleShutdownSpec.scala   |  9 +++
 .../remote/artery/RemoteActorRefProviderSpec.scala |  9 +++
 .../remote/artery/RemoteActorSelectionSpec.scala   |  9 +++
 .../pekko/remote/artery/RemoteConnectionSpec.scala |  9 +++
 .../pekko/remote/artery/RemoteDeathWatchSpec.scala |  9 +++
 .../pekko/remote/artery/RemoteDeployerSpec.scala   |  9 +++
 .../pekko/remote/artery/RemoteDeploymentSpec.scala |  9 +++
 .../pekko/remote/artery/RemoteFailureSpec.scala    |  9 +++
 .../RemoteInstrumentsSerializationSpec.scala       |  9 +++
 .../remote/artery/RemoteInstrumentsSpec.scala      |  9 +++
 .../artery/RemoteMessageSerializationSpec.scala    |  9 +++
 .../pekko/remote/artery/RemoteRouterSpec.scala     |  9 +++
 .../remote/artery/RemoteSendConsistencySpec.scala  |  9 +++
 .../pekko/remote/artery/RemoteWatcherSpec.scala    |  9 +++
 .../remote/artery/RemotingFlightRecorderSpec.scala |  9 +++
 .../pekko/remote/artery/RestartCounterSpec.scala   |  9 +++
 .../artery/RollingEventLogSimulationSpec.scala     |  9 +++
 .../apache/pekko/remote/artery/SendQueueSpec.scala |  9 +++
 .../remote/artery/SerializationErrorSpec.scala     |  9 +++
 .../SerializationTransportInformationSpec.scala    |  9 +++
 .../remote/artery/SystemMessageAckerSpec.scala     |  9 +++
 .../remote/artery/SystemMessageDeliverySpec.scala  |  9 +++
 .../apache/pekko/remote/artery/TestContext.scala   |  9 +++
 .../artery/TransientSerializationErrorSpec.scala   |  9 +++
 .../apache/pekko/remote/artery/UntrustedSpec.scala |  9 +++
 .../pekko/remote/artery/aeron/AeronSinkSpec.scala  |  9 +++
 .../compress/CompressionIntegrationSpec.scala      |  9 +++
 .../artery/compress/CompressionTableSpec.scala     |  9 +++
 .../artery/compress/CompressionTestUtils.scala     |  9 +++
 .../HandshakeShouldDropCompressionTableSpec.scala  |  9 +++
 .../remote/artery/compress/HeavyHittersSpec.scala  |  9 +++
 .../artery/compress/OutboundCompressionSpec.scala  |  9 +++
 .../artery/tcp/SecureRandomFactorySpec.scala       |  9 +++
 .../pekko/remote/artery/tcp/TcpFramingSpec.scala   |  9 +++
 .../pekko/remote/artery/tcp/TlsTcpSpec.scala       |  9 +++
 .../artery/tcp/ssl/CipherSuiteSupportCheck.scala   |  9 +++
 .../artery/tcp/ssl/PeerSubjectVerifierSpec.scala   |  9 +++
 .../artery/tcp/ssl/PemManagersProviderSpec.scala   |  9 +++
 .../ssl/RotatingKeysSSLEngineProviderSpec.scala    |  9 +++
 .../remote/artery/tcp/ssl/TlsResourcesSpec.scala   |  9 +++
 .../remote/artery/tcp/ssl/X509ReadersSpec.scala    |  9 +++
 .../pekko/remote/classic/ActorsLeakSpec.scala      |  9 +++
 .../remote/classic/RemoteDeathWatchSpec.scala      |  9 +++
 .../classic/RemoteDeploymentAllowListSpec.scala    |  9 +++
 .../pekko/remote/classic/RemoteInitErrorSpec.scala |  9 +++
 .../pekko/remote/classic/RemoteSettingsSpec.scala  |  9 +++
 .../pekko/remote/classic/RemoteWatcherSpec.scala   |  9 +++
 .../apache/pekko/remote/classic/RemotingSpec.scala |  9 +++
 .../pekko/remote/classic/UntrustedSpec.scala       |  9 +++
 .../classic/transport/GenericTransportSpec.scala   |  9 +++
 .../classic/transport/PekkoProtocolSpec.scala      |  9 +++
 .../transport/PekkoProtocolStressTest.scala        |  9 +++
 .../transport/SwitchableLoggedBehaviorSpec.scala   |  9 +++
 .../SystemMessageDeliveryStressTest.scala          |  9 +++
 .../classic/transport/TestTransportSpec.scala      |  9 +++
 .../classic/transport/ThrottleModeSpec.scala       |  9 +++
 .../transport/ThrottlerTransportAdapterSpec.scala  |  9 +++
 .../transport/netty/NettyTransportSpec.scala       |  9 +++
 .../AllowJavaSerializationOffSpec.scala            |  9 +++
 .../ArteryMessageSerializerSpec.scala              |  9 +++
 ...reateSerializerAllowJavaSerializationSpec.scala |  9 +++
 .../MessageContainerSerializerSpec.scala           |  9 +++
 .../serialization/MiscMessageSerializerSpec.scala  |  9 +++
 .../PrimitivesSerializationSpec.scala              |  9 +++
 .../serialization/ProtobufSerializerSpec.scala     |  9 +++
 .../SerializationTransportInformationSpec.scala    |  9 +++
 .../SystemMessageSerializationSpec.scala           |  9 +++
 .../serialization/jackson/ActorRefModule.scala     |  9 +++
 .../serialization/jackson/ActorSystemAccess.scala  |  9 +++
 .../serialization/jackson/AddressModule.scala      |  9 +++
 .../jackson/AkkaSerializationModule.scala          |  9 +++
 .../jackson/FiniteDurationModule.scala             |  9 +++
 .../serialization/jackson/JacksonMigration.scala   |  9 +++
 .../serialization/jackson/JacksonModule.scala      |  9 +++
 .../jackson/JacksonObjectMapperProvider.scala      |  9 +++
 .../serialization/jackson/JacksonSerializer.scala  |  9 +++
 .../serialization/jackson/PekkoJacksonModule.scala |  9 +++
 .../serialization/jackson/StreamRefModule.scala    |  9 +++
 .../jackson/TypedActorRefModule.scala              |  9 +++
 .../serialization/jackson/MySerializable.java      |  9 +++
 .../jackson/SerializationDocTest.java              |  9 +++
 .../pekko/serialization/jackson/v1/Customer.java   |  9 +++
 .../pekko/serialization/jackson/v1/ItemAdded.java  |  9 +++
 .../pekko/serialization/jackson/v1/OrderAdded.java |  9 +++
 .../jackson/v1withv2/ItemAddedMigration.java       |  9 +++
 .../pekko/serialization/jackson/v2a/Address.java   |  9 +++
 .../pekko/serialization/jackson/v2a/Customer.java  |  9 +++
 .../jackson/v2a/CustomerMigration.java             |  9 +++
 .../pekko/serialization/jackson/v2a/ItemAdded.java |  9 +++
 .../serialization/jackson/v2a/OrderPlaced.java     |  9 +++
 .../jackson/v2a/OrderPlacedMigration.java          |  9 +++
 .../pekko/serialization/jackson/v2b/ItemAdded.java |  9 +++
 .../jackson/v2b/ItemAddedMigration.java            |  9 +++
 .../pekko/serialization/jackson/v2c/ItemAdded.java |  9 +++
 .../jackson/v2c/ItemAddedMigration.java            |  9 +++
 .../jackson/JavaTestEventMigrationV2.java          |  9 +++
 .../jackson/JavaTestEventMigrationV2WithV3.java    |  9 +++
 .../jackson/JavaTestEventMigrationV3.java          |  9 +++
 .../serialization/jackson/JavaTestMessages.java    |  9 +++
 .../jackson/CustomAdtSerializer.scala              |  9 +++
 .../jackson/SerializationDocSpec.scala             |  9 +++
 .../pekko/serialization/jackson/v1/Customer.scala  |  9 +++
 .../pekko/serialization/jackson/v1/ItemAdded.scala |  9 +++
 .../serialization/jackson/v1/OrderAdded.scala      |  9 +++
 .../jackson/v1withv2/ItemAddedMigration.scala      |  9 +++
 .../pekko/serialization/jackson/v2a/Address.scala  |  9 +++
 .../pekko/serialization/jackson/v2a/Customer.scala |  9 +++
 .../jackson/v2a/CustomerMigration.scala            |  9 +++
 .../serialization/jackson/v2a/ItemAdded.scala      |  9 +++
 .../serialization/jackson/v2a/OrderPlaced.scala    |  9 +++
 .../jackson/v2a/OrderPlacedMigration.scala         |  9 +++
 .../serialization/jackson/v2b/ItemAdded.scala      |  9 +++
 .../jackson/v2b/ItemAddedMigration.scala           |  9 +++
 .../serialization/jackson/v2c/ItemAdded.scala      |  9 +++
 .../jackson/v2c/ItemAddedMigration.scala           |  9 +++
 .../serialization/jackson/CborSerializable.scala   |  9 +++
 .../jackson/JacksonSerializerSpec.scala            |  9 +++
 .../serialization/jackson/JsonSerializable.scala   |  9 +++
 .../jackson/ScalaTestEventMigration.scala          |  9 +++
 .../org/apache/pekko/event/slf4j/Slf4jLogger.scala |  9 +++
 .../apache/pekko/event/slf4j/Slf4jLoggerSpec.scala |  9 +++
 .../pekko/event/slf4j/Slf4jLoggingFilterSpec.scala |  9 +++
 .../pekko/stream/testkit/StreamTestKit.scala       |  9 +++
 .../pekko/stream/testkit/TestGraphStage.scala      |  9 +++
 .../stream/testkit/javadsl/StreamTestKit.scala     |  9 +++
 .../pekko/stream/testkit/javadsl/TestSink.scala    |  9 +++
 .../pekko/stream/testkit/javadsl/TestSource.scala  |  9 +++
 .../stream/testkit/scaladsl/StreamTestKit.scala    |  9 +++
 .../pekko/stream/testkit/scaladsl/TestSink.scala   |  9 +++
 .../pekko/stream/testkit/scaladsl/TestSource.scala |  9 +++
 .../impl/fusing/GraphInterpreterSpecKit.scala      |  9 +++
 .../pekko/stream/testkit/BaseTwoStreamsSetup.scala |  9 +++
 .../apache/pekko/stream/testkit/ChainSetup.scala   |  9 +++
 .../apache/pekko/stream/testkit/ScriptedTest.scala |  9 +++
 .../apache/pekko/stream/testkit/StreamSpec.scala   |  9 +++
 .../stream/testkit/StreamTestDefaultMailbox.scala  |  9 +++
 .../pekko/stream/testkit/StreamTestKitSpec.scala   |  9 +++
 .../testkit/TestPublisherSubscriberSpec.scala      |  9 +++
 .../pekko/stream/testkit/TwoStreamsSetup.scala     |  9 +++
 .../org/apache/pekko/stream/testkit/Utils.scala    |  9 +++
 ...IterablePublisherViaJavaFlowPublisherTest.scala |  9 +++
 .../pekko/stream/tck/ActorSystemLifecycle.scala    |  9 +++
 .../stream/tck/AkkaSubscriberVerification.scala    |  9 +++
 .../stream/tck/CancelledSinkSubscriberTest.scala   |  9 +++
 .../org/apache/pekko/stream/tck/ConcatTest.scala   |  9 +++
 .../pekko/stream/tck/EmptyPublisherTest.scala      |  9 +++
 .../pekko/stream/tck/FanoutPublisherTest.scala     |  9 +++
 .../pekko/stream/tck/FilePublisherTest.scala       |  9 +++
 .../tck/FlatMapConcatDoubleSubscriberTest.scala    |  9 +++
 .../pekko/stream/tck/FlatMapPrefixTest.scala       |  9 +++
 .../org/apache/pekko/stream/tck/FlattenTest.scala  |  9 +++
 .../pekko/stream/tck/FoldSinkSubscriberTest.scala  |  9 +++
 .../stream/tck/ForeachSinkSubscriberTest.scala     |  9 +++
 .../pekko/stream/tck/FusableProcessorTest.scala    |  9 +++
 .../pekko/stream/tck/FuturePublisherTest.scala     |  9 +++
 .../org/apache/pekko/stream/tck/GroupByTest.scala  |  9 +++
 .../pekko/stream/tck/InputStreamSourceTest.scala   |  9 +++
 .../pekko/stream/tck/IterablePublisherTest.scala   |  9 +++
 .../org/apache/pekko/stream/tck/MapTest.scala      |  9 +++
 .../apache/pekko/stream/tck/MaybeSourceTest.scala  |  9 +++
 .../tck/PekkoIdentityProcessorVerification.scala   |  9 +++
 .../stream/tck/PekkoPublisherVerification.scala    |  9 +++
 .../pekko/stream/tck/PrefixAndTailTest.scala       |  9 +++
 .../pekko/stream/tck/SingleElementSourceTest.scala |  9 +++
 .../pekko/stream/tck/SinkholeSubscriberTest.scala  |  9 +++
 .../apache/pekko/stream/tck/SplitWhenTest.scala    |  9 +++
 .../org/apache/pekko/stream/tck/Timeouts.scala     |  9 +++
 .../pekko/stream/tck/TransformProcessorTest.scala  |  9 +++
 .../pekko/stream/tck/VirtualPublisherTest.scala    |  9 +++
 .../stream/javadsl/JavaFlowSupportCompileTest.java |  9 +++
 .../pekko/stream/StreamAttributeDocTest.java       |  9 +++
 .../java/org/apache/pekko/stream/StreamTest.java   |  9 +++
 .../pekko/stream/io/InputStreamSinkTest.java       |  9 +++
 .../pekko/stream/io/OutputStreamSinkTest.java      |  9 +++
 .../pekko/stream/io/OutputStreamSourceTest.java    |  9 +++
 .../pekko/stream/io/SinkAsJavaSourceTest.java      |  9 +++
 .../pekko/stream/javadsl/AttributesTest.java       |  9 +++
 .../stream/javadsl/FlowLogWithMarkerTest.java      |  9 +++
 .../org/apache/pekko/stream/javadsl/FlowTest.java  |  9 +++
 .../pekko/stream/javadsl/FlowThrottleTest.java     |  9 +++
 .../pekko/stream/javadsl/FlowWithContextTest.java  |  9 +++
 .../javadsl/FlowWithContextThrottleTest.java       |  9 +++
 .../apache/pekko/stream/javadsl/FramingTest.java   |  9 +++
 .../apache/pekko/stream/javadsl/GraphDslTest.java  |  9 +++
 .../pekko/stream/javadsl/JsonFramingTest.java      |  9 +++
 .../pekko/stream/javadsl/KillSwitchTest.java       |  9 +++
 .../stream/javadsl/LazyAndFutureFlowTest.java      |  9 +++
 .../stream/javadsl/LazyAndFutureSourcesTest.java   |  9 +++
 .../apache/pekko/stream/javadsl/RetryFlowTest.java |  9 +++
 .../pekko/stream/javadsl/RunnableGraphTest.java    |  9 +++
 .../org/apache/pekko/stream/javadsl/SetupTest.java |  9 +++
 .../org/apache/pekko/stream/javadsl/SinkTest.java  |  9 +++
 .../pekko/stream/javadsl/SourceRunWithTest.java    |  9 +++
 .../apache/pekko/stream/javadsl/SourceTest.java    |  9 +++
 .../pekko/stream/javadsl/SourceUnfoldTest.java     |  9 +++
 .../javadsl/SourceWithContextThrottleTest.java     |  9 +++
 .../org/apache/pekko/stream/javadsl/TcpTest.java   |  9 +++
 .../pekko/stream/stage/JavaIdentityStage.java      |  9 +++
 .../org/apache/pekko/stream/stage/StageTest.java   |  9 +++
 .../stream/scaladsl/FlowPublisherSinkSpec.scala    |  9 +++
 .../pekko/stream/ActorMaterializerSpec.scala       |  9 +++
 .../apache/pekko/stream/DslConsistencySpec.scala   |  9 +++
 .../pekko/stream/DslFactoriesConsistencySpec.scala |  9 +++
 .../scala/org/apache/pekko/stream/FusingSpec.scala |  9 +++
 .../pekko/stream/SourceLocationAttributeSpec.scala |  9 +++
 .../pekko/stream/StreamAttributeDocSpec.scala      |  9 +++
 .../apache/pekko/stream/StreamDispatcherSpec.scala |  9 +++
 .../pekko/stream/SystemMaterializerSpec.scala      |  9 +++
 .../pekko/stream/impl/FanoutProcessorSpec.scala    |  9 +++
 .../apache/pekko/stream/impl/FixedBufferSpec.scala |  9 +++
 .../pekko/stream/impl/GraphStageLogicSpec.scala    |  9 +++
 .../stream/impl/LinearTraversalBuilderSpec.scala   |  9 +++
 .../impl/ResizableMultiReaderRingBufferSpec.scala  |  9 +++
 .../pekko/stream/impl/SubInletOutletSpec.scala     |  9 +++
 .../apache/pekko/stream/impl/TimeoutsSpec.scala    |  9 +++
 .../pekko/stream/impl/TraversalBuilderSpec.scala   |  9 +++
 .../pekko/stream/impl/TraversalTestUtils.scala     |  9 +++
 .../impl/fusing/ActorGraphInterpreterSpec.scala    |  9 +++
 .../stream/impl/fusing/AsyncCallbackSpec.scala     |  9 +++
 .../stream/impl/fusing/ChasingEventsSpec.scala     |  9 +++
 .../fusing/GraphInterpreterFailureModesSpec.scala  |  9 +++
 .../impl/fusing/GraphInterpreterPortsSpec.scala    |  9 +++
 .../stream/impl/fusing/GraphInterpreterSpec.scala  |  9 +++
 .../pekko/stream/impl/fusing/InterpreterSpec.scala |  9 +++
 .../stream/impl/fusing/InterpreterStressSpec.scala |  9 +++
 .../impl/fusing/InterpreterSupervisionSpec.scala   |  9 +++
 .../stream/impl/fusing/KeepGoingStageSpec.scala    |  9 +++
 .../impl/fusing/LifecycleInterpreterSpec.scala     |  9 +++
 .../apache/pekko/stream/impl/io/TLSUtilsSpec.scala |  9 +++
 .../pekko/stream/io/ByteStringParserSpec.scala     |  9 +++
 .../apache/pekko/stream/io/DeprecatedTlsSpec.scala |  9 +++
 .../org/apache/pekko/stream/io/FileSinkSpec.scala  |  9 +++
 .../apache/pekko/stream/io/FileSourceSpec.scala    |  9 +++
 .../pekko/stream/io/InputStreamSinkSpec.scala      |  9 +++
 .../pekko/stream/io/InputStreamSourceSpec.scala    |  9 +++
 .../pekko/stream/io/OutputStreamSinkSpec.scala     |  9 +++
 .../pekko/stream/io/OutputStreamSourceSpec.scala   |  9 +++
 .../org/apache/pekko/stream/io/TcpHelper.scala     |  9 +++
 .../scala/org/apache/pekko/stream/io/TcpSpec.scala |  9 +++
 .../scala/org/apache/pekko/stream/io/TlsSpec.scala |  9 +++
 .../stream/io/compression/CodecSpecSupport.scala   |  9 +++
 .../pekko/stream/io/compression/CoderSpec.scala    |  9 +++
 .../io/compression/CompressionTestingTools.scala   |  9 +++
 .../pekko/stream/io/compression/DeflateSpec.scala  |  9 +++
 .../pekko/stream/io/compression/GzipSpec.scala     |  9 +++
 .../GzipWithCustomCompressionLevelSpec.scala       |  9 +++
 .../scaladsl/ActorRefBackpressureSinkSpec.scala    |  9 +++
 .../scaladsl/ActorRefBackpressureSourceSpec.scala  |  9 +++
 .../pekko/stream/scaladsl/ActorRefSinkSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/ActorRefSourceSpec.scala |  9 +++
 .../scaladsl/AggregateWithBoundarySpec.scala       |  9 +++
 .../pekko/stream/scaladsl/AttributesSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/BidiFlowSpec.scala       |  9 +++
 .../stream/scaladsl/BoundedSourceQueueSpec.scala   |  9 +++
 .../stream/scaladsl/CancellationStrategySpec.scala |  9 +++
 .../pekko/stream/scaladsl/CollectionSinkSpec.scala |  9 +++
 .../pekko/stream/scaladsl/CompressionSpec.scala    |  9 +++
 .../scaladsl/CoupledTerminationFlowSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/FailedSourceSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/FlowAlsoToAllSpec.scala  |  9 +++
 .../pekko/stream/scaladsl/FlowAppendSpec.scala     |  9 +++
 .../apache/pekko/stream/scaladsl/FlowAskSpec.scala |  9 +++
 .../pekko/stream/scaladsl/FlowBatchSpec.scala      |  9 +++
 .../stream/scaladsl/FlowBatchWeightedSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowBufferSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/FlowCollectSpec.scala    |  9 +++
 .../stream/scaladsl/FlowCollectTypeSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/FlowCompileSpec.scala    |  9 +++
 .../stream/scaladsl/FlowConcatAllLazySpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowConcatAllSpec.scala  |  9 +++
 .../pekko/stream/scaladsl/FlowConcatSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/FlowConflateSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/FlowDelaySpec.scala      |  9 +++
 .../pekko/stream/scaladsl/FlowDetacherSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/FlowDispatcherSpec.scala |  9 +++
 .../pekko/stream/scaladsl/FlowDropSpec.scala       |  9 +++
 .../pekko/stream/scaladsl/FlowDropWhileSpec.scala  |  9 +++
 .../pekko/stream/scaladsl/FlowDropWithinSpec.scala |  9 +++
 .../pekko/stream/scaladsl/FlowExpandSpec.scala     |  9 +++
 .../stream/scaladsl/FlowExtrapolateSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/FlowFilterSpec.scala     |  9 +++
 .../stream/scaladsl/FlowFlatMapPrefixSpec.scala    |  9 +++
 .../stream/scaladsl/FlowFlattenMergeSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/FlowFoldAsyncSpec.scala  |  9 +++
 .../pekko/stream/scaladsl/FlowFoldSpec.scala       |  9 +++
 .../pekko/stream/scaladsl/FlowForeachSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowFromFutureSpec.scala |  9 +++
 .../pekko/stream/scaladsl/FlowFutureFlowSpec.scala |  9 +++
 .../pekko/stream/scaladsl/FlowGroupBySpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowGroupedSpec.scala    |  9 +++
 .../stream/scaladsl/FlowGroupedWeightedSpec.scala  |  9 +++
 .../stream/scaladsl/FlowGroupedWithinSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowIdleInjectSpec.scala |  9 +++
 .../stream/scaladsl/FlowInitialDelaySpec.scala     |  9 +++
 .../stream/scaladsl/FlowInterleaveAllSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowInterleaveSpec.scala |  9 +++
 .../stream/scaladsl/FlowIntersperseSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/FlowIteratorSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/FlowJoinSpec.scala       |  9 +++
 .../pekko/stream/scaladsl/FlowKillSwitchSpec.scala |  9 +++
 .../pekko/stream/scaladsl/FlowLimitSpec.scala      |  9 +++
 .../stream/scaladsl/FlowLimitWeightedSpec.scala    |  9 +++
 .../apache/pekko/stream/scaladsl/FlowLogSpec.scala |  9 +++
 .../stream/scaladsl/FlowLogWithMarkerSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowMapAsyncSpec.scala   |  9 +++
 .../scaladsl/FlowMapAsyncUnorderedSpec.scala       |  9 +++
 .../pekko/stream/scaladsl/FlowMapConcatSpec.scala  |  9 +++
 .../pekko/stream/scaladsl/FlowMapErrorSpec.scala   |  9 +++
 .../apache/pekko/stream/scaladsl/FlowMapSpec.scala |  9 +++
 .../pekko/stream/scaladsl/FlowMergeAllSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/FlowMergeSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/FlowMonitorSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowOnCompleteSpec.scala |  9 +++
 .../pekko/stream/scaladsl/FlowOrElseSpec.scala     |  9 +++
 .../stream/scaladsl/FlowPrefixAndTailSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowPrependSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowRecoverSpec.scala    |  9 +++
 .../stream/scaladsl/FlowRecoverWithSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/FlowReduceSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/FlowScanAsyncSpec.scala  |  9 +++
 .../pekko/stream/scaladsl/FlowScanSpec.scala       |  9 +++
 .../pekko/stream/scaladsl/FlowSectionSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowSlidingSpec.scala    |  9 +++
 .../apache/pekko/stream/scaladsl/FlowSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowSplitAfterSpec.scala |  9 +++
 .../pekko/stream/scaladsl/FlowSplitWhenSpec.scala  |  9 +++
 .../scaladsl/FlowStatefulMapConcatSpec.scala       |  9 +++
 .../stream/scaladsl/FlowStatefulMapSpec.scala      |  9 +++
 .../stream/scaladsl/FlowSupervisionSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/FlowTakeSpec.scala       |  9 +++
 .../pekko/stream/scaladsl/FlowTakeWhileSpec.scala  |  9 +++
 .../pekko/stream/scaladsl/FlowTakeWithinSpec.scala |  9 +++
 .../pekko/stream/scaladsl/FlowThrottleSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/FlowWatchSpec.scala      |  9 +++
 .../stream/scaladsl/FlowWatchTerminationSpec.scala |  9 +++
 .../pekko/stream/scaladsl/FlowWireTapSpec.scala    |  9 +++
 .../stream/scaladsl/FlowWithContextLogSpec.scala   |  9 +++
 .../stream/scaladsl/FlowWithContextSpec.scala      |  9 +++
 .../scaladsl/FlowWithContextThrottleSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/FlowZipAllSpec.scala     |  9 +++
 .../apache/pekko/stream/scaladsl/FlowZipSpec.scala |  9 +++
 .../stream/scaladsl/FlowZipWithIndexSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/FlowZipWithSpec.scala    |  9 +++
 .../apache/pekko/stream/scaladsl/FramingSpec.scala |  9 +++
 .../stream/scaladsl/FromMaterializationSpec.scala  |  9 +++
 .../stream/scaladsl/GraphBackedFlowSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/GraphBalanceSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/GraphBroadcastSpec.scala |  9 +++
 .../pekko/stream/scaladsl/GraphConcatSpec.scala    |  9 +++
 .../stream/scaladsl/GraphDSLCompileSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/GraphMatValueSpec.scala  |  9 +++
 .../stream/scaladsl/GraphMergeLatestSpec.scala     |  9 +++
 .../stream/scaladsl/GraphMergePreferredSpec.scala  |  9 +++
 .../scaladsl/GraphMergePrioritizedNSpec.scala      |  9 +++
 .../scaladsl/GraphMergePrioritizedSpec.scala       |  9 +++
 .../stream/scaladsl/GraphMergeSequenceSpec.scala   |  9 +++
 .../stream/scaladsl/GraphMergeSortedSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/GraphMergeSpec.scala     |  9 +++
 .../stream/scaladsl/GraphOpsIntegrationSpec.scala  |  9 +++
 .../pekko/stream/scaladsl/GraphPartialSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/GraphPartitionSpec.scala |  9 +++
 .../stream/scaladsl/GraphStageTimersSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/GraphUnzipSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/GraphUnzipWithSpec.scala |  9 +++
 .../pekko/stream/scaladsl/GraphWireTapSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/GraphZipLatestSpec.scala |  9 +++
 .../stream/scaladsl/GraphZipLatestWithSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/GraphZipNSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/GraphZipSpec.scala       |  9 +++
 .../pekko/stream/scaladsl/GraphZipWithNSpec.scala  |  9 +++
 .../pekko/stream/scaladsl/GraphZipWithSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/HeadSinkSpec.scala       |  9 +++
 .../org/apache/pekko/stream/scaladsl/HubSpec.scala |  9 +++
 .../pekko/stream/scaladsl/JsonFramingSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/LastSinkSpec.scala       |  9 +++
 .../pekko/stream/scaladsl/LazilyAsyncSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/LazyFlowSpec.scala       |  9 +++
 .../pekko/stream/scaladsl/LazySinkSpec.scala       |  9 +++
 .../pekko/stream/scaladsl/LazySourceSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/MaybeSourceSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/NeverSourceSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/PublisherSinkSpec.scala  |  9 +++
 .../pekko/stream/scaladsl/QueueSinkSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/QueueSourceSpec.scala    |  9 +++
 .../apache/pekko/stream/scaladsl/RestartSpec.scala |  9 +++
 .../pekko/stream/scaladsl/RetryFlowSpec.scala      |  9 +++
 .../pekko/stream/scaladsl/ReverseArrowSpec.scala   |  9 +++
 .../pekko/stream/scaladsl/RunnableGraphSpec.scala  |  9 +++
 .../apache/pekko/stream/scaladsl/SeqSinkSpec.scala |  9 +++
 .../apache/pekko/stream/scaladsl/SetupSpec.scala   |  9 +++
 .../stream/scaladsl/SinkAsJavaStreamSpec.scala     |  9 +++
 .../stream/scaladsl/SinkForeachAsyncSpec.scala     |  9 +++
 .../stream/scaladsl/SinkForeachParallelSpec.scala  |  9 +++
 .../apache/pekko/stream/scaladsl/SinkSpec.scala    |  9 +++
 .../stream/scaladsl/SourceFromPublisherSpec.scala  |  9 +++
 .../apache/pekko/stream/scaladsl/SourceSpec.scala  |  9 +++
 .../stream/scaladsl/SourceWithContextSpec.scala    |  9 +++
 .../pekko/stream/scaladsl/StageActorRefSpec.scala  |  9 +++
 .../stream/scaladsl/StreamConvertersSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/StreamRefsSpec.scala     |  9 +++
 .../pekko/stream/scaladsl/SubscriberSinkSpec.scala |  9 +++
 .../stream/scaladsl/SubscriberSourceSpec.scala     |  9 +++
 .../SubstreamSubscriptionTimeoutSpec.scala         |  9 +++
 .../pekko/stream/scaladsl/TakeLastSinkSpec.scala   |  9 +++
 .../apache/pekko/stream/scaladsl/TestConfig.scala  |  9 +++
 .../pekko/stream/scaladsl/TickSourceSpec.scala     |  9 +++
 .../scaladsl/UnfoldResourceAsyncSourceSpec.scala   |  9 +++
 .../stream/scaladsl/UnfoldResourceSourceSpec.scala |  9 +++
 .../stream/scaladsl/WithContextUsageSpec.scala     |  9 +++
 .../stream/snapshot/MaterializerStateSpec.scala    |  9 +++
 .../pekko/stream/typed/javadsl/ActorFlow.scala     |  9 +++
 .../pekko/stream/typed/javadsl/ActorSink.scala     |  9 +++
 .../pekko/stream/typed/javadsl/ActorSource.scala   |  9 +++
 .../apache/pekko/stream/typed/javadsl/PubSub.scala |  9 +++
 .../pekko/stream/typed/scaladsl/ActorFlow.scala    |  9 +++
 .../pekko/stream/typed/scaladsl/ActorSink.scala    |  9 +++
 .../pekko/stream/typed/scaladsl/ActorSource.scala  |  9 +++
 .../pekko/stream/typed/scaladsl/PubSub.scala       |  9 +++
 .../java/docs/javadsl/ActorFlowCompileTest.java    |  9 +++
 .../pekko/stream/typed/ActorSinkExample.java       |  9 +++
 .../stream/typed/ActorSinkWithAckExample.java      |  9 +++
 .../pekko/stream/typed/ActorSourceExample.java     |  9 +++
 .../typed/ActorSourceWithBackpressureExample.java  |  9 +++
 .../typed/javadsl/ActorSourceSinkCompileTest.java  |  9 +++
 .../javadsl/CustomGuardianAndMaterializerTest.java |  9 +++
 .../stream/typed/ActorSourceSinkExample.scala      |  9 +++
 .../test/scala/docs/scaladsl/ActorFlowSpec.scala   |  9 +++
 .../typed/scaladsl/ActorSourceSinkSpec.scala       |  9 +++
 .../typed/scaladsl/MaterializerForTypedSpec.scala  |  9 +++
 .../pekko/stream/typed/scaladsl/PubSubSpec.scala   |  9 +++
 .../akka/stream/FanInShapeN.scala.template         |  9 +++
 .../akka/stream/FanOutShapeN.scala.template        |  9 +++
 .../akka/stream/javadsl/GraphCreate.scala.template |  9 +++
 .../akka/stream/javadsl/UnzipWith.scala.template   |  9 +++
 .../stream/javadsl/ZipLatestWith.scala.template    |  9 +++
 .../akka/stream/javadsl/ZipWith.scala.template     |  9 +++
 .../akka/stream/scaladsl/GraphApply.scala.template |  9 +++
 .../stream/scaladsl/UnzipWithApply.scala.template  |  9 +++
 .../scaladsl/ZipLatestWithApply.scala.template     |  9 +++
 .../stream/scaladsl/ZipWithApply.scala.template    |  9 +++
 .../pekko/stream/javadsl/JavaFlowSupport.java      |  9 +++
 .../org/apache/pekko/stream/StreamRefMessages.java |  9 +++
 .../apache/pekko/stream/javadsl/AsPublisher.java   |  9 +++
 .../pekko/stream/javadsl/FramingTruncation.java    |  9 +++
 stream/src/main/protobuf/StreamRefMessages.proto   |  9 +++
 .../akka/stream/impl/JavaFlowAndRsConverters.scala |  9 +++
 .../akka/stream/scaladsl/JavaFlowSupport.scala     |  9 +++
 .../typesafe/sslconfig/pekko/PekkoSSLConfig.scala  |  9 +++
 .../sslconfig/pekko/SSLEngineConfigurator.scala    |  9 +++
 .../sslconfig/pekko/util/PekkoLoggerBridge.scala   |  9 +++
 .../apache/pekko/stream/ActorMaterializer.scala    |  9 +++
 .../scala/org/apache/pekko/stream/Attributes.scala |  9 +++
 .../apache/pekko/stream/BoundedSourceQueue.scala   |  9 +++
 .../apache/pekko/stream/CompletionStrategy.scala   |  9 +++
 .../scala/org/apache/pekko/stream/FanInShape.scala |  9 +++
 .../org/apache/pekko/stream/FanInShape1N.scala     |  9 +++
 .../org/apache/pekko/stream/FanOutShape.scala      |  9 +++
 .../org/apache/pekko/stream/FlowMonitor.scala      |  9 +++
 .../main/scala/org/apache/pekko/stream/Graph.scala |  9 +++
 .../scala/org/apache/pekko/stream/IOResult.scala   |  9 +++
 .../scala/org/apache/pekko/stream/KillSwitch.scala |  9 +++
 .../org/apache/pekko/stream/Materializer.scala     |  9 +++
 .../pekko/stream/MaterializerLoggingProvider.scala |  9 +++
 .../pekko/stream/NeverMaterializedException.scala  |  9 +++
 .../org/apache/pekko/stream/OverflowStrategy.scala |  9 +++
 .../org/apache/pekko/stream/QueueOfferResult.scala |  9 +++
 .../org/apache/pekko/stream/RestartSettings.scala  |  9 +++
 .../main/scala/org/apache/pekko/stream/Shape.scala |  9 +++
 .../org/apache/pekko/stream/SslTlsOptions.scala    |  9 +++
 .../pekko/stream/StreamDetachedException.scala     |  9 +++
 .../pekko/stream/StreamLimitReachedException.scala |  9 +++
 .../apache/pekko/stream/StreamRefSettings.scala    |  9 +++
 .../scala/org/apache/pekko/stream/StreamRefs.scala |  9 +++
 .../apache/pekko/stream/StreamTcpException.scala   |  9 +++
 .../stream/SubscriptionWithCancelException.scala   |  9 +++
 .../pekko/stream/SubstreamCancelStrategy.scala     |  9 +++
 .../org/apache/pekko/stream/Supervision.scala      |  9 +++
 .../apache/pekko/stream/SystemMaterializer.scala   |  9 +++
 .../org/apache/pekko/stream/ThrottleMode.scala     |  9 +++
 .../stream/TooManySubstreamsOpenException.scala    |  9 +++
 .../apache/pekko/stream/UniformFanInShape.scala    |  9 +++
 .../apache/pekko/stream/UniformFanOutShape.scala   |  9 +++
 .../stream/WatchedActorTerminatedException.scala   |  9 +++
 .../pekko/stream/impl/ActorMaterializerImpl.scala  |  9 +++
 .../apache/pekko/stream/impl/ActorProcessor.scala  |  9 +++
 .../apache/pekko/stream/impl/ActorPublisher.scala  |  9 +++
 .../impl/ActorRefBackpressureSinkStage.scala       |  9 +++
 .../stream/impl/ActorRefBackpressureSource.scala   |  9 +++
 .../pekko/stream/impl/ActorRefSinkStage.scala      |  9 +++
 .../apache/pekko/stream/impl/ActorRefSource.scala  |  9 +++
 .../pekko/stream/impl/ActorSubscriberMessage.scala |  9 +++
 .../pekko/stream/impl/BoundedSourceQueue.scala     |  9 +++
 .../org/apache/pekko/stream/impl/Buffers.scala     |  9 +++
 .../pekko/stream/impl/CompletedPublishers.scala    |  9 +++
 .../org/apache/pekko/stream/impl/ConstantFun.scala |  9 +++
 .../pekko/stream/impl/ContextPropagation.scala     |  9 +++
 .../org/apache/pekko/stream/impl/EmptySource.scala |  9 +++
 .../stream/impl/ExposedPublisherReceive.scala      |  9 +++
 .../apache/pekko/stream/impl/FailedSource.scala    |  9 +++
 .../scala/org/apache/pekko/stream/impl/FanIn.scala |  9 +++
 .../org/apache/pekko/stream/impl/FanOut.scala      |  9 +++
 .../apache/pekko/stream/impl/FanoutProcessor.scala |  9 +++
 .../pekko/stream/impl/JavaStreamSource.scala       |  9 +++
 .../pekko/stream/impl/JsonObjectParser.scala       |  9 +++
 .../org/apache/pekko/stream/impl/LazySource.scala  |  9 +++
 .../pekko/stream/impl/MaterializerGuardian.scala   |  9 +++
 .../org/apache/pekko/stream/impl/MaybeSource.scala |  9 +++
 .../org/apache/pekko/stream/impl/Messages.scala    |  9 +++
 .../org/apache/pekko/stream/impl/Modules.scala     |  9 +++
 .../impl/PhasedFusingActorMaterializer.scala       |  9 +++
 .../org/apache/pekko/stream/impl/QueueSource.scala |  9 +++
 .../stream/impl/ReactiveStreamsCompliance.scala    |  9 +++
 .../impl/ResizableMultiReaderRingBuffer.scala      |  9 +++
 .../pekko/stream/impl/RetryFlowCoordinator.scala   |  9 +++
 .../apache/pekko/stream/impl/SeqActorName.scala    |  9 +++
 .../org/apache/pekko/stream/impl/SetupStage.scala  |  9 +++
 .../apache/pekko/stream/impl/SingleConcat.scala    |  9 +++
 .../pekko/stream/impl/SinkholeSubscriber.scala     |  9 +++
 .../scala/org/apache/pekko/stream/impl/Sinks.scala |  9 +++
 .../org/apache/pekko/stream/impl/Stages.scala      |  9 +++
 .../apache/pekko/stream/impl/StreamLayout.scala    |  9 +++
 .../stream/impl/StreamSubscriptionTimeout.scala    |  9 +++
 .../org/apache/pekko/stream/impl/SubFlowImpl.scala |  9 +++
 .../pekko/stream/impl/SubscriberManagement.scala   |  9 +++
 .../org/apache/pekko/stream/impl/Throttle.scala    |  9 +++
 .../org/apache/pekko/stream/impl/Timers.scala      |  9 +++
 .../org/apache/pekko/stream/impl/Transfer.scala    |  9 +++
 .../pekko/stream/impl/TraversalBuilder.scala       |  9 +++
 .../org/apache/pekko/stream/impl/Unfold.scala      |  9 +++
 .../pekko/stream/impl/UnfoldResourceSource.scala   |  9 +++
 .../stream/impl/UnfoldResourceSourceAsync.scala    |  9 +++
 .../stream/impl/fusing/ActorGraphInterpreter.scala |  9 +++
 .../stream/impl/fusing/AggregateWithBoundary.scala |  9 +++
 .../pekko/stream/impl/fusing/FlatMapPrefix.scala   |  9 +++
 .../pekko/stream/impl/fusing/FutureFlow.scala      |  9 +++
 .../stream/impl/fusing/GraphInterpreter.scala      |  9 +++
 .../pekko/stream/impl/fusing/GraphStages.scala     |  9 +++
 .../org/apache/pekko/stream/impl/fusing/Ops.scala  |  9 +++
 .../pekko/stream/impl/fusing/StreamOfStreams.scala |  9 +++
 .../pekko/stream/impl/io/ByteStringParser.scala    |  9 +++
 .../pekko/stream/impl/io/FileOutputStage.scala     |  9 +++
 .../apache/pekko/stream/impl/io/IOSources.scala    |  9 +++
 .../stream/impl/io/InputStreamSinkStage.scala      |  9 +++
 .../pekko/stream/impl/io/InputStreamSource.scala   |  9 +++
 .../stream/impl/io/OutputStreamGraphStage.scala    |  9 +++
 .../stream/impl/io/OutputStreamSourceStage.scala   |  9 +++
 .../org/apache/pekko/stream/impl/io/TLSActor.scala |  9 +++
 .../apache/pekko/stream/impl/io/TcpStages.scala    |  9 +++
 .../apache/pekko/stream/impl/io/TlsModule.scala    |  9 +++
 .../impl/io/compression/CompressionUtils.scala     |  9 +++
 .../stream/impl/io/compression/Compressor.scala    |  9 +++
 .../impl/io/compression/DeflateCompressor.scala    |  9 +++
 .../impl/io/compression/DeflateDecompressor.scala  |  9 +++
 .../io/compression/DeflateDecompressorBase.scala   |  9 +++
 .../impl/io/compression/GzipCompressor.scala       |  9 +++
 .../impl/io/compression/GzipDecompressor.scala     |  9 +++
 .../org/apache/pekko/stream/impl/package.scala     |  9 +++
 .../pekko/stream/impl/streamref/SinkRefImpl.scala  |  9 +++
 .../stream/impl/streamref/SourceRefImpl.scala      |  9 +++
 .../impl/streamref/StreamRefResolverImpl.scala     |  9 +++
 .../impl/streamref/StreamRefSettingsImpl.scala     |  9 +++
 .../stream/impl/streamref/StreamRefsMaster.scala   |  9 +++
 .../stream/impl/streamref/StreamRefsProtocol.scala |  9 +++
 .../org/apache/pekko/stream/javadsl/BidiFlow.scala |  9 +++
 .../apache/pekko/stream/javadsl/Compression.scala  |  9 +++
 .../stream/javadsl/CoupledTerminationFlow.scala    |  9 +++
 .../pekko/stream/javadsl/DelayStrategy.scala       |  9 +++
 .../org/apache/pekko/stream/javadsl/FileIO.scala   |  9 +++
 .../org/apache/pekko/stream/javadsl/Flow.scala     |  9 +++
 .../pekko/stream/javadsl/FlowWithContext.scala     |  9 +++
 .../org/apache/pekko/stream/javadsl/Framing.scala  |  9 +++
 .../org/apache/pekko/stream/javadsl/Graph.scala    |  9 +++
 .../org/apache/pekko/stream/javadsl/Hub.scala      |  9 +++
 .../apache/pekko/stream/javadsl/JsonFraming.scala  |  9 +++
 .../org/apache/pekko/stream/javadsl/Keep.scala     |  9 +++
 .../apache/pekko/stream/javadsl/MergeLatest.scala  |  9 +++
 .../org/apache/pekko/stream/javadsl/Queue.scala    |  9 +++
 .../apache/pekko/stream/javadsl/RestartFlow.scala  |  9 +++
 .../apache/pekko/stream/javadsl/RestartSink.scala  |  9 +++
 .../pekko/stream/javadsl/RestartSource.scala       |  9 +++
 .../apache/pekko/stream/javadsl/RetryFlow.scala    |  9 +++
 .../org/apache/pekko/stream/javadsl/Sink.scala     |  9 +++
 .../org/apache/pekko/stream/javadsl/Source.scala   |  9 +++
 .../pekko/stream/javadsl/SourceWithContext.scala   |  9 +++
 .../pekko/stream/javadsl/StreamConverters.scala    |  9 +++
 .../apache/pekko/stream/javadsl/StreamRefs.scala   |  9 +++
 .../org/apache/pekko/stream/javadsl/SubFlow.scala  |  9 +++
 .../apache/pekko/stream/javadsl/SubSource.scala    |  9 +++
 .../org/apache/pekko/stream/javadsl/TLS.scala      |  9 +++
 .../org/apache/pekko/stream/javadsl/Tcp.scala      |  9 +++
 .../org/apache/pekko/stream/javadsl/package.scala  |  9 +++
 .../apache/pekko/stream/scaladsl/BidiFlow.scala    |  9 +++
 .../apache/pekko/stream/scaladsl/Compression.scala |  9 +++
 .../stream/scaladsl/CoupledTerminationFlow.scala   |  9 +++
 .../pekko/stream/scaladsl/DelayStrategy.scala      |  9 +++
 .../org/apache/pekko/stream/scaladsl/FileIO.scala  |  9 +++
 .../org/apache/pekko/stream/scaladsl/Flow.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowWithContext.scala    |  9 +++
 .../pekko/stream/scaladsl/FlowWithContextOps.scala |  9 +++
 .../org/apache/pekko/stream/scaladsl/Framing.scala |  9 +++
 .../org/apache/pekko/stream/scaladsl/Graph.scala   |  9 +++
 .../org/apache/pekko/stream/scaladsl/Hub.scala     |  9 +++
 .../apache/pekko/stream/scaladsl/JsonFraming.scala |  9 +++
 .../pekko/stream/scaladsl/Materialization.scala    |  9 +++
 .../apache/pekko/stream/scaladsl/MergeLatest.scala |  9 +++
 .../org/apache/pekko/stream/scaladsl/Queue.scala   |  9 +++
 .../apache/pekko/stream/scaladsl/RestartFlow.scala |  9 +++
 .../apache/pekko/stream/scaladsl/RestartSink.scala |  9 +++
 .../pekko/stream/scaladsl/RestartSource.scala      |  9 +++
 .../apache/pekko/stream/scaladsl/RetryFlow.scala   |  9 +++
 .../org/apache/pekko/stream/scaladsl/Sink.scala    |  9 +++
 .../org/apache/pekko/stream/scaladsl/Source.scala  |  9 +++
 .../pekko/stream/scaladsl/SourceWithContext.scala  |  9 +++
 .../pekko/stream/scaladsl/StreamConverters.scala   |  9 +++
 .../apache/pekko/stream/scaladsl/StreamRefs.scala  |  9 +++
 .../org/apache/pekko/stream/scaladsl/SubFlow.scala |  9 +++
 .../org/apache/pekko/stream/scaladsl/TLS.scala     |  9 +++
 .../org/apache/pekko/stream/scaladsl/Tcp.scala     |  9 +++
 .../org/apache/pekko/stream/scaladsl/package.scala |  9 +++
 .../stream/serialization/StreamRefSerializer.scala |  9 +++
 .../pekko/stream/snapshot/MaterializerState.scala  |  9 +++
 .../org/apache/pekko/stream/stage/GraphStage.scala |  9 +++
 .../apache/pekko/stream/stage/StageLogging.scala   |  9 +++
 .../pekko/testkit/CallingThreadDispatcher.scala    |  9 +++
 .../testkit/ExplicitlyTriggeredScheduler.scala     |  9 +++
 .../apache/pekko/testkit/JavaSerializable.scala    |  9 +++
 .../org/apache/pekko/testkit/SocketUtil.scala      |  9 +++
 .../org/apache/pekko/testkit/TestActorRef.scala    |  9 +++
 .../org/apache/pekko/testkit/TestActors.scala      |  9 +++
 .../org/apache/pekko/testkit/TestBarrier.scala     |  9 +++
 .../apache/pekko/testkit/TestEventListener.scala   |  9 +++
 .../org/apache/pekko/testkit/TestException.scala   |  9 +++
 .../org/apache/pekko/testkit/TestFSMRef.scala      |  9 +++
 .../apache/pekko/testkit/TestJavaSerializer.scala  |  9 +++
 .../scala/org/apache/pekko/testkit/TestKit.scala   |  9 +++
 .../apache/pekko/testkit/TestKitExtension.scala    |  9 +++
 .../org/apache/pekko/testkit/TestKitUtils.scala    |  9 +++
 .../scala/org/apache/pekko/testkit/TestLatch.scala |  9 +++
 .../apache/pekko/testkit/javadsl/EventFilter.scala |  9 +++
 .../org/apache/pekko/testkit/javadsl/TestKit.scala |  9 +++
 .../scala/org/apache/pekko/testkit/package.scala   |  9 +++
 .../testkit/PekkoJUnitActorSystemResource.java     |  9 +++
 .../pekko/testkit/TestActorRefJavaCompile.java     |  9 +++
 .../pekko/testkit/javadsl/TestKitApiTest.java      |  9 +++
 .../org/apache/pekko/testkit/AbstractSpec.scala    |  9 +++
 .../scala/org/apache/pekko/testkit/Coroner.scala   |  9 +++
 .../org/apache/pekko/testkit/CoronerSpec.scala     |  9 +++
 .../apache/pekko/testkit/DefaultTimeoutSpec.scala  |  9 +++
 .../testkit/ExplicitlyTriggeredSchedulerSpec.scala |  9 +++
 .../apache/pekko/testkit/ImplicitSenderSpec.scala  |  9 +++
 .../scala/org/apache/pekko/testkit/PekkoSpec.scala |  9 +++
 .../org/apache/pekko/testkit/PekkoSpecSpec.scala   |  9 +++
 .../apache/pekko/testkit/TestActorRefSpec.scala    |  9 +++
 .../org/apache/pekko/testkit/TestActorsSpec.scala  |  9 +++
 .../pekko/testkit/TestEventListenerSpec.scala      |  9 +++
 .../org/apache/pekko/testkit/TestFSMRefSpec.scala  |  9 +++
 .../org/apache/pekko/testkit/TestProbeSpec.scala   |  9 +++
 .../scala/org/apache/pekko/testkit/TestTags.scala  |  9 +++
 .../org/apache/pekko/testkit/TestTimeSpec.scala    |  9 +++
 .../apache/pekko/testkit/WithLogCapturing.scala    |  9 +++
 .../pekko/testkit/metrics/AveragingGauge.scala     |  9 +++
 .../testkit/metrics/FileDescriptorMetricSet.scala  |  9 +++
 .../pekko/testkit/metrics/HdrHistogram.scala       |  9 +++
 .../testkit/metrics/KnownOpsInTimespanTimer.scala  |  9 +++
 .../testkit/metrics/MemoryUsageSnapshotting.scala  |  9 +++
 .../pekko/testkit/metrics/MetricKeyDSL.scala       |  9 +++
 .../apache/pekko/testkit/metrics/MetricsKit.scala  |  9 +++
 .../pekko/testkit/metrics/MetricsKitOps.scala      |  9 +++
 .../pekko/testkit/metrics/MetricsKitSpec.scala     |  9 +++
 .../metrics/reporter/PekkoConsoleReporter.scala    |  9 +++
 3117 files changed, 28100 insertions(+), 50 deletions(-)


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


[incubator-pekko] 02/02: Update headers with The Apache header annotated.

Posted by he...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit 4ac0f00a477873965ee7d52e16faefb1de91fe3a
Author: He-Pin <he...@gmail.com>
AuthorDate: Sun Jan 8 17:13:31 2023 +0800

    Update headers with The Apache header annotated.
---
 .../actor/testkit/typed/CapturedLogEvent.scala     |  9 +++++++++
 .../apache/pekko/actor/testkit/typed/Effect.scala  |  9 +++++++++
 .../pekko/actor/testkit/typed/FishingOutcome.scala |  9 +++++++++
 .../pekko/actor/testkit/typed/LoggingEvent.scala   |  9 +++++++++
 .../pekko/actor/testkit/typed/TestException.scala  |  9 +++++++++
 .../actor/testkit/typed/TestKitSettings.scala      |  9 +++++++++
 .../testkit/typed/internal/ActorSystemStub.scala   |  9 +++++++++
 .../typed/internal/BehaviorTestKitImpl.scala       |  9 +++++++++
 .../testkit/typed/internal/CapturingAppender.scala |  9 +++++++++
 .../typed/internal/ControlledExecutor.scala        |  9 +++++++++
 .../actor/testkit/typed/internal/DebugRef.scala    |  9 +++++++++
 .../typed/internal/EffectfulActorContext.scala     |  9 +++++++++
 .../actor/testkit/typed/internal/LogbackUtil.scala |  9 +++++++++
 .../typed/internal/LoggingTestKitImpl.scala        |  9 +++++++++
 .../typed/internal/StubbedActorContext.scala       |  9 +++++++++
 .../testkit/typed/internal/TestAppender.scala      |  9 +++++++++
 .../testkit/typed/internal/TestInboxImpl.scala     |  9 +++++++++
 .../testkit/typed/internal/TestKitUtils.scala      |  9 +++++++++
 .../testkit/typed/internal/TestProbeImpl.scala     |  9 +++++++++
 .../actor/testkit/typed/javadsl/ActorTestKit.scala |  9 +++++++++
 .../testkit/typed/javadsl/BehaviorTestKit.scala    |  9 +++++++++
 .../actor/testkit/typed/javadsl/Effects.scala      |  9 +++++++++
 .../actor/testkit/typed/javadsl/LogCapturing.scala |  9 +++++++++
 .../testkit/typed/javadsl/LoggingTestKit.scala     |  9 +++++++++
 .../actor/testkit/typed/javadsl/ManualTime.scala   |  9 +++++++++
 .../typed/javadsl/SerializationTestKit.scala       |  9 +++++++++
 .../actor/testkit/typed/javadsl/TestInbox.scala    |  9 +++++++++
 .../typed/javadsl/TestKitJunitResource.scala       |  9 +++++++++
 .../actor/testkit/typed/javadsl/TestProbe.scala    |  9 +++++++++
 .../testkit/typed/scaladsl/ActorTestKit.scala      |  9 +++++++++
 .../testkit/typed/scaladsl/ActorTestKitBase.scala  |  9 +++++++++
 .../testkit/typed/scaladsl/BehaviorTestKit.scala   |  9 +++++++++
 .../actor/testkit/typed/scaladsl/Effects.scala     |  9 +++++++++
 .../testkit/typed/scaladsl/LogCapturing.scala      |  9 +++++++++
 .../testkit/typed/scaladsl/LoggingTestKit.scala    |  9 +++++++++
 .../actor/testkit/typed/scaladsl/ManualTime.scala  |  9 +++++++++
 .../typed/scaladsl/ScalaTestWithActorTestKit.scala |  9 +++++++++
 .../typed/scaladsl/SerializationTestKit.scala      |  9 +++++++++
 .../actor/testkit/typed/scaladsl/TestInbox.scala   |  9 +++++++++
 .../actor/testkit/typed/scaladsl/TestProbe.scala   |  9 +++++++++
 .../actor/testkit/typed/scaladsl/package.scala     |  9 +++++++++
 .../typed/javadsl/AsyncTestingExampleTest.java     |  9 +++++++++
 .../typed/javadsl/JunitIntegrationExampleTest.java |  9 +++++++++
 .../typed/javadsl/LogCapturingExampleTest.java     |  9 +++++++++
 .../typed/javadsl/ManualTimerExampleTest.java      |  9 +++++++++
 .../typed/javadsl/SyncTestingExampleTest.java      |  9 +++++++++
 .../testkit/typed/javadsl/TestConfigExample.java   |  9 +++++++++
 .../testkit/typed/javadsl/ActorTestKitApiTest.java |  9 +++++++++
 .../testkit/typed/javadsl/ActorTestKitTest.java    |  9 +++++++++
 .../testkit/typed/javadsl/BehaviorTestKitTest.java |  9 +++++++++
 .../testkit/typed/javadsl/LoggingTestKitTest.java  |  9 +++++++++
 .../actor/testkit/typed/javadsl/TestProbeTest.java |  9 +++++++++
 .../typed/scaladsl/AsyncTestingExampleSpec.scala   |  9 +++++++++
 .../typed/scaladsl/ManualTimerExampleSpec.scala    |  9 +++++++++
 .../scaladsl/ScalaTestIntegrationExampleSpec.scala |  9 +++++++++
 .../typed/scaladsl/SyncTestingExampleSpec.scala    |  9 +++++++++
 .../testkit/typed/scaladsl/TestConfigExample.scala |  9 +++++++++
 .../testkit/typed/scaladsl/ActorTestKitSpec.scala  |  9 +++++++++
 .../typed/scaladsl/BehaviorTestKitSpec.scala       |  9 +++++++++
 .../typed/scaladsl/LoggingEventFilterSpec.scala    |  9 +++++++++
 .../testkit/typed/scaladsl/TestAppenderSpec.scala  |  9 +++++++++
 .../testkit/typed/scaladsl/TestProbeSpec.scala     |  9 +++++++++
 .../apache/pekko/actor/AbstractFSMActorTest.java   |  9 +++++++++
 .../org/apache/pekko/actor/ActorCreationTest.java  |  9 +++++++++
 .../org/apache/pekko/actor/ActorSelectionTest.java |  9 +++++++++
 .../org/apache/pekko/actor/ActorSystemTest.java    |  9 +++++++++
 .../java/org/apache/pekko/actor/AddressTest.java   |  9 +++++++++
 .../test/java/org/apache/pekko/actor/JavaAPI.java  |  9 +++++++++
 .../org/apache/pekko/actor/JavaAPITestActor.java   |  9 +++++++++
 .../java/org/apache/pekko/actor/JavaExtension.java |  9 +++++++++
 .../org/apache/pekko/actor/NonPublicClass.java     |  9 +++++++++
 .../org/apache/pekko/actor/NonStaticCreator.java   |  9 +++++++++
 .../java/org/apache/pekko/actor/StashJavaAPI.java  |  9 +++++++++
 .../apache/pekko/actor/StashJavaAPITestActors.java |  9 +++++++++
 .../org/apache/pekko/actor/TestAnnotation.java     |  9 +++++++++
 .../pekko/actor/setup/ActorSystemSetupTest.java    |  9 +++++++++
 .../org/apache/pekko/dispatch/JavaFutureTests.java |  9 +++++++++
 .../java/org/apache/pekko/event/ActorWithMDC.java  |  9 +++++++++
 .../org/apache/pekko/event/LoggingAdapterTest.java |  9 +++++++++
 .../org/apache/pekko/japi/JavaAPITestBase.java     |  9 +++++++++
 .../org/apache/pekko/japi/MatchBuilderTest.java    |  9 +++++++++
 .../java/org/apache/pekko/japi/ThrowablesTest.java |  9 +++++++++
 .../org/apache/pekko/japi/pf/PFBuilderTest.java    |  9 +++++++++
 .../apache/pekko/japi/pf/ReceiveBuilderTest.java   |  9 +++++++++
 .../apache/pekko/pattern/CircuitBreakerTest.java   |  9 +++++++++
 .../org/apache/pekko/pattern/PatternsTest.java     |  9 +++++++++
 .../org/apache/pekko/pattern/StatusReplyTest.java  |  9 +++++++++
 .../java/org/apache/pekko/util/ByteStringTest.java |  9 +++++++++
 .../java/org/apache/pekko/util/JavaDuration.java   |  9 +++++++++
 .../pekko/util/LineNumberSpecCodeForJava.java      |  9 +++++++++
 .../org/apache/pekko/util/LineNumberSpec.scala     | 23 +++++++++++++++-------
 .../org/apache/pekko/util/TypedMultiMapSpec.scala  |  9 +++++++++
 .../src/test/scala/org/apache/pekko/Messages.scala |  9 +++++++++
 .../org/apache/pekko/PekkoExceptionSpec.scala      |  9 +++++++++
 .../scala/org/apache/pekko/PekkoVersionSpec.scala  |  9 +++++++++
 .../actor/ActorConfigurationVerificationSpec.scala |  9 +++++++++
 .../apache/pekko/actor/ActorCreationPerfSpec.scala |  9 +++++++++
 .../apache/pekko/actor/ActorLifeCycleSpec.scala    |  9 +++++++++
 .../org/apache/pekko/actor/ActorMailboxSpec.scala  |  9 +++++++++
 .../org/apache/pekko/actor/ActorPathSpec.scala     |  9 +++++++++
 .../org/apache/pekko/actor/ActorRefSpec.scala      |  9 +++++++++
 .../apache/pekko/actor/ActorSelectionSpec.scala    |  9 +++++++++
 .../pekko/actor/ActorSystemDispatcherSpec.scala    |  9 +++++++++
 .../org/apache/pekko/actor/ActorSystemSpec.scala   |  9 +++++++++
 .../org/apache/pekko/actor/ActorTimeoutSpec.scala  |  9 +++++++++
 .../pekko/actor/ActorWithBoundedStashSpec.scala    |  9 +++++++++
 .../apache/pekko/actor/ActorWithStashSpec.scala    |  9 +++++++++
 .../org/apache/pekko/actor/ConsistencySpec.scala   |  9 +++++++++
 .../pekko/actor/CoordinatedShutdownSpec.scala      |  9 +++++++++
 .../pekko/actor/DeadLetterSupressionSpec.scala     |  9 +++++++++
 .../pekko/actor/DeadLetterSuspensionSpec.scala     |  9 +++++++++
 .../org/apache/pekko/actor/DeathWatchSpec.scala    |  9 +++++++++
 .../org/apache/pekko/actor/DeployerSpec.scala      |  9 +++++++++
 .../org/apache/pekko/actor/DynamicAccessSpec.scala |  9 +++++++++
 .../org/apache/pekko/actor/ExtensionSpec.scala     |  9 +++++++++
 .../org/apache/pekko/actor/FSMActorSpec.scala      |  9 +++++++++
 .../org/apache/pekko/actor/FSMTimingSpec.scala     |  9 +++++++++
 .../org/apache/pekko/actor/FSMTransitionSpec.scala |  9 +++++++++
 .../org/apache/pekko/actor/ForwardActorSpec.scala  |  9 +++++++++
 .../org/apache/pekko/actor/FunctionRefSpec.scala   |  9 +++++++++
 .../scala/org/apache/pekko/actor/HotSwapSpec.scala |  9 +++++++++
 .../pekko/actor/LocalActorRefProviderSpec.scala    |  9 +++++++++
 .../org/apache/pekko/actor/PropsCreationSpec.scala |  9 +++++++++
 .../apache/pekko/actor/ProviderSelectionSpec.scala |  9 +++++++++
 .../apache/pekko/actor/ReceiveTimeoutSpec.scala    |  9 +++++++++
 .../apache/pekko/actor/RelativeActorPathSpec.scala |  9 +++++++++
 .../apache/pekko/actor/RestartStrategySpec.scala   |  9 +++++++++
 .../org/apache/pekko/actor/SchedulerSpec.scala     |  9 +++++++++
 .../scala/org/apache/pekko/actor/Supervisor.scala  |  9 +++++++++
 .../pekko/actor/SupervisorHierarchySpec.scala      |  9 +++++++++
 .../apache/pekko/actor/SupervisorMiscSpec.scala    |  9 +++++++++
 .../org/apache/pekko/actor/SupervisorSpec.scala    |  9 +++++++++
 .../apache/pekko/actor/SupervisorTreeSpec.scala    |  9 +++++++++
 .../org/apache/pekko/actor/Ticket669Spec.scala     |  9 +++++++++
 .../scala/org/apache/pekko/actor/TimerSpec.scala   |  9 +++++++++
 .../org/apache/pekko/actor/TypedActorSpec.scala    |  9 +++++++++
 .../org/apache/pekko/actor/UidClashTest.scala      |  9 +++++++++
 .../pekko/actor/dispatch/ActorModelSpec.scala      |  9 +++++++++
 .../actor/dispatch/BalancingDispatcherSpec.scala   |  9 +++++++++
 .../pekko/actor/dispatch/DispatcherActorSpec.scala |  9 +++++++++
 .../actor/dispatch/DispatcherActorsSpec.scala      |  9 +++++++++
 .../pekko/actor/dispatch/DispatchersSpec.scala     |  9 +++++++++
 .../pekko/actor/dispatch/PinnedActorSpec.scala     |  9 +++++++++
 .../apache/pekko/actor/dungeon/DispatchSpec.scala  |  9 +++++++++
 .../apache/pekko/actor/routing/ListenerSpec.scala  |  9 +++++++++
 .../pekko/actor/setup/ActorSystemSetupSpec.scala   |  9 +++++++++
 .../scala/org/apache/pekko/config/ConfigSpec.scala |  9 +++++++++
 .../org/apache/pekko/dataflow/Future2Actor.scala   |  9 +++++++++
 .../dispatch/ControlAwareDispatcherSpec.scala      |  9 +++++++++
 .../pekko/dispatch/DispatcherShutdownSpec.scala    |  9 +++++++++
 .../pekko/dispatch/ExecutionContextSpec.scala      |  9 +++++++++
 .../dispatch/ForkJoinPoolStarvationSpec.scala      |  9 +++++++++
 .../apache/pekko/dispatch/MailboxConfigSpec.scala  |  9 +++++++++
 .../pekko/dispatch/PriorityDispatcherSpec.scala    |  9 +++++++++
 .../dispatch/SameThreadExecutionContextSpec.scala  |  9 +++++++++
 .../dispatch/StablePriorityDispatcherSpec.scala    |  9 +++++++++
 .../dispatch/sysmsg/SystemMessageListSpec.scala    |  9 +++++++++
 .../event/AddressTerminatedTopicBenchSpec.scala    |  9 +++++++++
 .../org/apache/pekko/event/EventBusSpec.scala      |  9 +++++++++
 .../org/apache/pekko/event/EventStreamSpec.scala   |  9 +++++++++
 .../scala/org/apache/pekko/event/LoggerSpec.scala  |  9 +++++++++
 .../apache/pekko/event/LoggingReceiveSpec.scala    |  9 +++++++++
 .../org/apache/pekko/event/MarkerLoggingSpec.scala |  9 +++++++++
 .../apache/pekko/event/jul/JavaLoggerSpec.scala    |  9 +++++++++
 .../org/apache/pekko/io/CapacityLimitSpec.scala    |  9 +++++++++
 .../pekko/io/InetAddressDnsResolverSpec.scala      |  9 +++++++++
 .../org/apache/pekko/io/SimpleDnsCacheSpec.scala   |  9 +++++++++
 .../org/apache/pekko/io/TcpConnectionSpec.scala    |  9 +++++++++
 .../org/apache/pekko/io/TcpIntegrationSpec.scala   |  9 +++++++++
 .../pekko/io/TcpIntegrationSpecSupport.scala       |  9 +++++++++
 .../org/apache/pekko/io/TcpListenerSpec.scala      |  9 +++++++++
 .../pekko/io/UdpConnectedIntegrationSpec.scala     |  9 +++++++++
 .../org/apache/pekko/io/UdpIntegrationSpec.scala   |  9 +++++++++
 .../io/dns/AsyncDnsResolverIntegrationSpec.scala   |  9 +++++++++
 .../org/apache/pekko/io/dns/DnsSettingsSpec.scala  |  9 +++++++++
 .../apache/pekko/io/dns/DockerBindDnsService.scala |  9 +++++++++
 .../pekko/io/dns/NameserverAddressParserSpec.scala |  9 +++++++++
 .../io/dns/internal/AsyncDnsManagerSpec.scala      |  9 +++++++++
 .../io/dns/internal/AsyncDnsResolverSpec.scala     |  9 +++++++++
 .../pekko/io/dns/internal/DnsClientSpec.scala      |  9 +++++++++
 .../apache/pekko/io/dns/internal/MessageSpec.scala |  9 +++++++++
 .../io/dns/internal/ResolvConfParserSpec.scala     |  9 +++++++++
 .../pekko/io/dns/internal/TcpDnsClientSpec.scala   |  9 +++++++++
 .../scala/org/apache/pekko/pattern/AskSpec.scala   |  9 +++++++++
 .../pattern/BackoffOnRestartSupervisorSpec.scala   |  9 +++++++++
 .../pekko/pattern/BackoffSupervisorSpec.scala      |  9 +++++++++
 .../pekko/pattern/CircuitBreakerMTSpec.scala       |  9 +++++++++
 .../apache/pekko/pattern/CircuitBreakerSpec.scala  |  9 +++++++++
 .../pekko/pattern/CircuitBreakerStressSpec.scala   |  9 +++++++++
 .../org/apache/pekko/pattern/PatternSpec.scala     |  9 +++++++++
 .../org/apache/pekko/pattern/PipeToSpec.scala      |  9 +++++++++
 .../org/apache/pekko/pattern/PromiseRefSpec.scala  |  9 +++++++++
 .../scala/org/apache/pekko/pattern/RetrySpec.scala |  9 +++++++++
 .../org/apache/pekko/pattern/StatusReplySpec.scala |  9 +++++++++
 .../pekko/pattern/extended/ExplicitAskSpec.scala   |  9 +++++++++
 .../org/apache/pekko/routing/BalancingSpec.scala   |  9 +++++++++
 .../org/apache/pekko/routing/BroadcastSpec.scala   |  9 +++++++++
 .../pekko/routing/ConfiguredLocalRoutingSpec.scala |  9 +++++++++
 .../routing/ConsistentHashingRouterSpec.scala      |  9 +++++++++
 .../pekko/routing/MetricsBasedResizerSpec.scala    |  9 +++++++++
 .../org/apache/pekko/routing/RandomSpec.scala      |  9 +++++++++
 .../org/apache/pekko/routing/ResizerSpec.scala     |  9 +++++++++
 .../org/apache/pekko/routing/RoundRobinSpec.scala  |  9 +++++++++
 .../apache/pekko/routing/RouteeCreationSpec.scala  |  9 +++++++++
 .../org/apache/pekko/routing/RoutingSpec.scala     |  9 +++++++++
 .../routing/ScatterGatherFirstCompletedSpec.scala  |  9 +++++++++
 .../apache/pekko/routing/SmallestMailboxSpec.scala |  9 +++++++++
 .../apache/pekko/routing/TailChoppingSpec.scala    |  9 +++++++++
 .../pekko/serialization/AsyncSerializeSpec.scala   |  9 +++++++++
 .../DisabledJavaSerializerWarningSpec.scala        |  9 +++++++++
 .../pekko/serialization/NoVerification.scala       |  9 +++++++++
 .../PrimitivesSerializationSpec.scala              |  9 +++++++++
 .../serialization/SerializationSetupSpec.scala     |  9 +++++++++
 .../apache/pekko/serialization/SerializeSpec.scala |  9 +++++++++
 .../testkit/CallingThreadDispatcherModelSpec.scala |  9 +++++++++
 .../apache/pekko/util/AsciiStringCopySpec.scala    |  9 +++++++++
 .../pekko/util/BoundedBlockingQueueSpec.scala      |  9 +++++++++
 .../org/apache/pekko/util/ByteIteratorSpec.scala   |  9 +++++++++
 .../pekko/util/ByteStringInitializationSpec.scala  |  9 +++++++++
 .../org/apache/pekko/util/ByteStringSpec.scala     |  9 +++++++++
 .../apache/pekko/util/DoubleLinkedListSpec.scala   |  9 +++++++++
 .../scala/org/apache/pekko/util/DurationSpec.scala |  9 +++++++++
 .../org/apache/pekko/util/FrequencyListSpec.scala  |  9 +++++++++
 .../apache/pekko/util/FrequencySketchSpec.scala    |  9 +++++++++
 .../apache/pekko/util/ImmutableIntMapSpec.scala    |  9 +++++++++
 .../scala/org/apache/pekko/util/IndexSpec.scala    |  9 +++++++++
 .../pekko/util/LineNumberSpecCodeForScala.scala    |  9 +++++++++
 .../org/apache/pekko/util/ManifestInfoSpec.scala   |  9 +++++++++
 .../org/apache/pekko/util/MessageBufferSpec.scala  |  9 +++++++++
 .../org/apache/pekko/util/PrettyDurationSpec.scala |  9 +++++++++
 .../org/apache/pekko/util/RecencyListSpec.scala    |  9 +++++++++
 .../scala/org/apache/pekko/util/ReflectSpec.scala  |  9 +++++++++
 .../pekko/util/SegmentedRecencyListSpec.scala      |  9 +++++++++
 .../scala/org/apache/pekko/util/SwitchSpec.scala   |  9 +++++++++
 .../org/apache/pekko/util/TokenBucketSpec.scala    |  9 +++++++++
 .../scala/org/apache/pekko/util/VersionSpec.scala  |  9 +++++++++
 .../org/apache/pekko/util/WildcardIndexSpec.scala  |  9 +++++++++
 .../org/apache/pekko/util/ZipfianGenerator.scala   |  9 +++++++++
 .../other/SerializerOutsidePekkoPackage.scala      |  9 +++++++++
 .../jdocs/org/apache/pekko/typed/Aggregator.java   |  9 +++++++++
 .../org/apache/pekko/typed/AggregatorTest.java     |  9 +++++++++
 .../org/apache/pekko/typed/BubblingSample.java     |  9 +++++++++
 .../org/apache/pekko/typed/BubblingSampleTest.java |  9 +++++++++
 .../org/apache/pekko/typed/DispatchersDocTest.java |  9 +++++++++
 .../jdocs/org/apache/pekko/typed/FSMDocTest.java   |  9 +++++++++
 .../apache/pekko/typed/GracefulStopDocTest.java    |  9 +++++++++
 .../InteractionPatternsAskWithStatusTest.java      |  9 +++++++++
 .../pekko/typed/InteractionPatternsTest.java       |  9 +++++++++
 .../jdocs/org/apache/pekko/typed/IntroTest.java    |  9 +++++++++
 .../org/apache/pekko/typed/LoggingDocExamples.java |  9 +++++++++
 .../org/apache/pekko/typed/MailboxDocTest.java     |  9 +++++++++
 .../jdocs/org/apache/pekko/typed/OOIntroTest.java  |  9 +++++++++
 .../jdocs/org/apache/pekko/typed/RouterTest.java   |  9 +++++++++
 .../apache/pekko/typed/SpawnProtocolDocTest.java   |  9 +++++++++
 .../org/apache/pekko/typed/StashDocSample.java     |  9 +++++++++
 .../jdocs/org/apache/pekko/typed/StashDocTest.java |  9 +++++++++
 .../apache/pekko/typed/StyleGuideDocExamples.java  |  9 +++++++++
 .../jdocs/org/apache/pekko/typed/TailChopping.java |  9 +++++++++
 .../coexistence/ClassicWatchingTypedTest.java      |  9 +++++++++
 .../coexistence/TypedWatchingClassicTest.java      |  9 +++++++++
 .../pekko/typed/extensions/ExtensionDocTest.java   |  9 +++++++++
 .../pekko/typed/fromclassic/ClassicSample.java     |  9 +++++++++
 .../pekko/typed/fromclassic/TypedSample.java       |  9 +++++++++
 .../apache/pekko/typed/pubsub/PubSubExample.java   |  9 +++++++++
 .../supervision/SupervisionCompileOnlyTest.java    |  9 +++++++++
 .../apache/pekko/actor/typed/ActorSystemTest.java  |  9 +++++++++
 .../pekko/actor/typed/DispatcherSelectorTest.java  |  9 +++++++++
 .../apache/pekko/actor/typed/ExtensionsTest.java   |  9 +++++++++
 .../pekko/actor/typed/MailboxSelectorTest.java     |  9 +++++++++
 .../apache/pekko/actor/typed/SchedulerTest.java    |  9 +++++++++
 .../actor/typed/eventstream/EventStreamTest.java   |  9 +++++++++
 .../pekko/actor/typed/javadsl/ActorCompile.java    |  9 +++++++++
 .../actor/typed/javadsl/ActorContextAskTest.java   |  9 +++++++++
 .../typed/javadsl/ActorContextPipeToSelfTest.java  |  9 +++++++++
 .../actor/typed/javadsl/ActorLoggingTest.java      |  9 +++++++++
 .../pekko/actor/typed/javadsl/AdapterTest.java     |  9 +++++++++
 .../actor/typed/javadsl/BehaviorBuilderTest.java   |  9 +++++++++
 .../pekko/actor/typed/javadsl/InterceptTest.java   |  9 +++++++++
 .../actor/typed/javadsl/ReceiveBuilderTest.java    |  9 +++++++++
 .../pekko/actor/typed/javadsl/RoutersTest.java     |  9 +++++++++
 .../pekko/actor/typed/javadsl/StashBufferTest.java |  9 +++++++++
 .../pekko/actor/typed/javadsl/WatchTest.java       |  9 +++++++++
 .../typed/receptionist/ReceptionistApiTest.java    |  9 +++++++++
 .../docs/org/apache/pekko/typed/Aggregator.scala   |  9 +++++++++
 .../org/apache/pekko/typed/AggregatorSpec.scala    |  9 +++++++++
 .../apache/pekko/typed/DispatchersDocSpec.scala    |  9 +++++++++
 .../docs/org/apache/pekko/typed/FSMDocSpec.scala   |  9 +++++++++
 .../apache/pekko/typed/FaultToleranceDocSpec.scala |  9 +++++++++
 .../apache/pekko/typed/GracefulStopDocSpec.scala   |  9 +++++++++
 .../pekko/typed/InteractionPatternsSpec.scala      |  9 +++++++++
 .../docs/org/apache/pekko/typed/IntroSpec.scala    |  9 +++++++++
 .../apache/pekko/typed/LoggingDocExamples.scala    |  9 +++++++++
 .../org/apache/pekko/typed/MailboxDocSpec.scala    |  9 +++++++++
 .../docs/org/apache/pekko/typed/OOIntroSpec.scala  |  9 +++++++++
 .../docs/org/apache/pekko/typed/RouterSpec.scala   |  9 +++++++++
 .../apache/pekko/typed/SpawnProtocolDocSpec.scala  |  9 +++++++++
 .../docs/org/apache/pekko/typed/StashDocSpec.scala |  9 +++++++++
 .../apache/pekko/typed/StyleGuideDocExamples.scala |  9 +++++++++
 .../docs/org/apache/pekko/typed/TailChopping.scala |  9 +++++++++
 .../coexistence/ClassicWatchingTypedSpec.scala     |  9 +++++++++
 .../coexistence/TypedWatchingClassicSpec.scala     |  9 +++++++++
 .../pekko/typed/extensions/ExtensionDocSpec.scala  |  9 +++++++++
 .../pekko/typed/fromclassic/ClassicSample.scala    |  9 +++++++++
 .../pekko/typed/fromclassic/TypedSample.scala      |  9 +++++++++
 .../org/apache/pekko/typed/myapp/package.scala     |  9 +++++++++
 .../apache/pekko/typed/pubsub/PubSubExample.scala  |  9 +++++++++
 .../typed/supervision/SupervisionCompileOnly.scala |  9 +++++++++
 .../pekko/actor/typed/ActorContextSpec.scala       |  9 +++++++++
 .../pekko/actor/typed/ActorRefIgnoreSpec.scala     |  9 +++++++++
 .../pekko/actor/typed/ActorRefResolverSpec.scala   |  9 +++++++++
 .../org/apache/pekko/actor/typed/AskSpec.scala     |  9 +++++++++
 .../apache/pekko/actor/typed/BehaviorSpec.scala    |  9 +++++++++
 .../apache/pekko/actor/typed/DeferredSpec.scala    |  9 +++++++++
 .../apache/pekko/actor/typed/ExtensionsSpec.scala  |  9 +++++++++
 .../apache/pekko/actor/typed/InterceptSpec.scala   |  9 +++++++++
 .../LocalActorRefProviderLogMessagesSpec.scala     |  9 +++++++++
 .../apache/pekko/actor/typed/LogMessagesSpec.scala |  9 +++++++++
 .../pekko/actor/typed/MailboxSelectorSpec.scala    |  9 +++++++++
 .../org/apache/pekko/actor/typed/MonitorSpec.scala |  9 +++++++++
 .../org/apache/pekko/actor/typed/OrElseSpec.scala  |  9 +++++++++
 .../org/apache/pekko/actor/typed/PropsSpec.scala   |  9 +++++++++
 .../apache/pekko/actor/typed/SchedulerSpec.scala   |  9 +++++++++
 .../pekko/actor/typed/SpawnProtocolSpec.scala      |  9 +++++++++
 .../apache/pekko/actor/typed/SupervisionSpec.scala |  9 +++++++++
 .../apache/pekko/actor/typed/TerminatedSpec.scala  |  9 +++++++++
 .../org/apache/pekko/actor/typed/TimerSpec.scala   |  9 +++++++++
 .../pekko/actor/typed/TransformMessagesSpec.scala  |  9 +++++++++
 .../org/apache/pekko/actor/typed/WatchSpec.scala   |  9 +++++++++
 .../coexistence/ClassicSupervisingTypedSpec.scala  |  9 +++++++++
 .../coexistence/TypedSupervisingClassicSpec.scala  |  9 +++++++++
 .../typed/delivery/ConsumerControllerSpec.scala    |  9 +++++++++
 .../delivery/DurableProducerControllerSpec.scala   |  9 +++++++++
 .../typed/delivery/DurableProducerQueueSpec.scala  |  9 +++++++++
 .../typed/delivery/DurableWorkPullingSpec.scala    |  9 +++++++++
 .../typed/delivery/ProducerControllerSpec.scala    |  9 +++++++++
 .../delivery/ReliableDeliveryRandomSpec.scala      |  9 +++++++++
 .../typed/delivery/ReliableDeliverySpec.scala      |  9 +++++++++
 .../pekko/actor/typed/delivery/TestConsumer.scala  |  9 +++++++++
 .../typed/delivery/TestDurableProducerQueue.scala  |  9 +++++++++
 .../pekko/actor/typed/delivery/TestProducer.scala  |  9 +++++++++
 .../actor/typed/delivery/TestProducerWithAsk.scala |  9 +++++++++
 .../typed/delivery/TestProducerWorkPulling.scala   |  9 +++++++++
 .../actor/typed/delivery/WorkPullingSpec.scala     |  9 +++++++++
 .../actor/typed/eventstream/EventStreamSpec.scala  |  9 +++++++++
 .../typed/internal/ActorRefSerializationSpec.scala |  9 +++++++++
 .../actor/typed/internal/ActorSystemSpec.scala     |  9 +++++++++
 .../typed/internal/adpater/PropsAdapterSpec.scala  |  9 +++++++++
 .../receptionist/LocalReceptionistSpec.scala       |  9 +++++++++
 .../receptionist/ServiceKeySerializationSpec.scala |  9 +++++++++
 .../typed/internal/routing/PoolRouterSpec.scala    |  9 +++++++++
 .../typed/internal/routing/RoutingLogicSpec.scala  |  9 +++++++++
 .../typed/javadsl/AdaptationFailureSpec.scala      |  9 +++++++++
 .../pekko/actor/typed/pubsub/LocalPubSubSpec.scala |  9 +++++++++
 .../typed/receptionist/ReceptionistApiSpec.scala   |  9 +++++++++
 .../actor/typed/scaladsl/ActorContextAskSpec.scala |  9 +++++++++
 .../typed/scaladsl/ActorContextDelegateSpec.scala  |  9 +++++++++
 .../scaladsl/ActorContextPipeToSelfSpec.scala      |  9 +++++++++
 .../actor/typed/scaladsl/ActorLoggingSpec.scala    |  9 +++++++++
 .../actor/typed/scaladsl/ActorThreadSpec.scala     |  9 +++++++++
 .../typed/scaladsl/AdaptationFailureSpec.scala     |  9 +++++++++
 .../typed/scaladsl/DispatcherSelectorSpec.scala    |  9 +++++++++
 .../actor/typed/scaladsl/GracefulStopSpec.scala    |  9 +++++++++
 .../pekko/actor/typed/scaladsl/LoggerOpsSpec.scala |  9 +++++++++
 .../actor/typed/scaladsl/MessageAdapterSpec.scala  |  9 +++++++++
 .../pekko/actor/typed/scaladsl/OnSignalSpec.scala  |  9 +++++++++
 .../actor/typed/scaladsl/ReceivePartialSpec.scala  |  9 +++++++++
 .../pekko/actor/typed/scaladsl/RoutersSpec.scala   |  9 +++++++++
 .../actor/typed/scaladsl/StashBufferSpec.scala     |  9 +++++++++
 .../pekko/actor/typed/scaladsl/StashSpec.scala     |  9 +++++++++
 .../pekko/actor/typed/scaladsl/StopSpec.scala      |  9 +++++++++
 .../actor/typed/scaladsl/adapter/AdapterSpec.scala |  9 +++++++++
 .../scaladsl/adapter/GuardianStartupSpec.scala     |  9 +++++++++
 .../typed/internal/receptionist/Platform.scala     |  9 +++++++++
 .../pekko/actor/typed/internal/jfr/Events.scala    |  9 +++++++++
 .../internal/jfr/JFRActorFlightRecorder.scala      |  9 +++++++++
 .../org/apache/pekko/actor/typed/ActorRef.scala    |  9 +++++++++
 .../pekko/actor/typed/ActorRefResolver.scala       |  9 +++++++++
 .../org/apache/pekko/actor/typed/ActorSystem.scala |  9 +++++++++
 .../org/apache/pekko/actor/typed/Behavior.scala    |  9 +++++++++
 .../pekko/actor/typed/BehaviorInterceptor.scala    |  9 +++++++++
 .../org/apache/pekko/actor/typed/Dispatchers.scala |  9 +++++++++
 .../org/apache/pekko/actor/typed/Extensions.scala  |  9 +++++++++
 .../org/apache/pekko/actor/typed/LogOptions.scala  |  9 +++++++++
 .../pekko/actor/typed/MessageAndSignals.scala      |  9 +++++++++
 .../scala/org/apache/pekko/actor/typed/Props.scala |  9 +++++++++
 .../org/apache/pekko/actor/typed/Scheduler.scala   |  9 +++++++++
 .../apache/pekko/actor/typed/SpawnProtocol.scala   |  9 +++++++++
 .../pekko/actor/typed/SupervisorStrategy.scala     |  9 +++++++++
 .../pekko/actor/typed/TypedActorContext.scala      |  9 +++++++++
 .../actor/typed/delivery/ConsumerController.scala  |  9 +++++++++
 .../typed/delivery/DurableProducerQueue.scala      |  9 +++++++++
 .../actor/typed/delivery/ProducerController.scala  |  9 +++++++++
 .../delivery/WorkPullingProducerController.scala   |  9 +++++++++
 .../typed/delivery/internal/ChunkedMessage.scala   |  9 +++++++++
 .../delivery/internal/ConsumerControllerImpl.scala |  9 +++++++++
 .../delivery/internal/DeliverySerializable.scala   |  9 +++++++++
 .../delivery/internal/ProducerControllerImpl.scala |  9 +++++++++
 .../WorkPullingProducerControllerImpl.scala        |  9 +++++++++
 .../actor/typed/eventstream/EventStream.scala      |  9 +++++++++
 .../actor/typed/internal/ActorContextImpl.scala    |  9 +++++++++
 .../actor/typed/internal/ActorFlightRecorder.scala |  9 +++++++++
 .../pekko/actor/typed/internal/ActorMdc.scala      |  9 +++++++++
 .../pekko/actor/typed/internal/ActorRefImpl.scala  |  9 +++++++++
 .../pekko/actor/typed/internal/BehaviorImpl.scala  |  9 +++++++++
 .../typed/internal/EventStreamExtension.scala      |  9 +++++++++
 .../actor/typed/internal/ExtensionsImpl.scala      |  9 +++++++++
 .../actor/typed/internal/InterceptorImpl.scala     |  9 +++++++++
 .../actor/typed/internal/InternalMessage.scala     |  9 +++++++++
 .../typed/internal/InternalRecipientRef.scala      |  9 +++++++++
 .../pekko/actor/typed/internal/LoggerClass.scala   |  9 +++++++++
 .../typed/internal/MiscMessageSerializer.scala     |  9 +++++++++
 .../pekko/actor/typed/internal/PoisonPill.scala    |  9 +++++++++
 .../pekko/actor/typed/internal/PropsImpl.scala     |  9 +++++++++
 .../actor/typed/internal/StashBufferImpl.scala     |  9 +++++++++
 .../pekko/actor/typed/internal/Supervision.scala   |  9 +++++++++
 .../pekko/actor/typed/internal/SystemMessage.scala |  9 +++++++++
 .../actor/typed/internal/TimerSchedulerImpl.scala  |  9 +++++++++
 .../internal/WithMdcBehaviorInterceptor.scala      |  9 +++++++++
 .../typed/internal/adapter/ActorAdapter.scala      |  9 +++++++++
 .../internal/adapter/ActorContextAdapter.scala     |  9 +++++++++
 .../typed/internal/adapter/ActorRefAdapter.scala   |  9 +++++++++
 .../internal/adapter/ActorRefFactoryAdapter.scala  |  9 +++++++++
 .../internal/adapter/ActorSystemAdapter.scala      |  9 +++++++++
 .../typed/internal/adapter/AdapterExtension.scala  |  9 +++++++++
 .../internal/adapter/EventStreamAdapter.scala      |  9 +++++++++
 .../internal/adapter/GuardianStartupBehavior.scala |  9 +++++++++
 .../typed/internal/adapter/PropsAdapter.scala      |  9 +++++++++
 .../typed/internal/adapter/SchedulerAdapter.scala  |  9 +++++++++
 .../actor/typed/internal/pubsub/TopicImpl.scala    |  9 +++++++++
 .../internal/receptionist/LocalReceptionist.scala  |  9 +++++++++
 .../internal/receptionist/ReceptionistImpl.scala   |  9 +++++++++
 .../receptionist/ReceptionistMessages.scala        |  9 +++++++++
 .../typed/internal/receptionist/ServiceKey.scala   |  9 +++++++++
 .../receptionist/ServiceKeySerializer.scala        |  9 +++++++++
 .../typed/internal/routing/GroupRouterImpl.scala   |  9 +++++++++
 .../typed/internal/routing/PoolRouterImpl.scala    |  9 +++++++++
 .../typed/internal/routing/RoutingLogic.scala      |  9 +++++++++
 .../actor/typed/javadsl/AbstractBehavior.scala     |  9 +++++++++
 .../pekko/actor/typed/javadsl/ActorContext.scala   |  9 +++++++++
 .../apache/pekko/actor/typed/javadsl/Adapter.scala |  9 +++++++++
 .../pekko/actor/typed/javadsl/AskPattern.scala     |  9 +++++++++
 .../actor/typed/javadsl/BehaviorBuilder.scala      |  9 +++++++++
 .../pekko/actor/typed/javadsl/Behaviors.scala      |  9 +++++++++
 .../apache/pekko/actor/typed/javadsl/Receive.scala |  9 +++++++++
 .../pekko/actor/typed/javadsl/ReceiveBuilder.scala |  9 +++++++++
 .../apache/pekko/actor/typed/javadsl/Routers.scala |  9 +++++++++
 .../pekko/actor/typed/javadsl/StashBuffer.scala    |  9 +++++++++
 .../pekko/actor/typed/javadsl/TimerScheduler.scala |  9 +++++++++
 .../apache/pekko/actor/typed/pubsub/Topic.scala    |  9 +++++++++
 .../actor/typed/receptionist/Receptionist.scala    |  9 +++++++++
 .../actor/typed/scaladsl/AbstractBehavior.scala    |  9 +++++++++
 .../pekko/actor/typed/scaladsl/ActorContext.scala  |  9 +++++++++
 .../pekko/actor/typed/scaladsl/AskPattern.scala    |  9 +++++++++
 .../pekko/actor/typed/scaladsl/Behaviors.scala     |  9 +++++++++
 .../pekko/actor/typed/scaladsl/Routers.scala       |  9 +++++++++
 .../pekko/actor/typed/scaladsl/StashBuffer.scala   |  9 +++++++++
 .../actor/typed/scaladsl/TimerScheduler.scala      |  9 +++++++++
 .../typed/scaladsl/adapter/PropsAdapter.scala      |  9 +++++++++
 .../actor/typed/scaladsl/adapter/package.scala     |  9 +++++++++
 .../pekko/actor/typed/scaladsl/package.scala       |  9 +++++++++
 .../pekko/japi/function/Functions.scala.template   |  9 +++++++++
 .../apache/pekko/japi/tuple/Tuples.scala.template  |  9 +++++++++
 .../org/apache/pekko/actor/AbstractActorRef.java   |  9 +++++++++
 .../org/apache/pekko/actor/AbstractScheduler.java  |  9 +++++++++
 .../pekko/actor/dungeon/AbstractActorCell.java     |  9 +++++++++
 .../org/apache/pekko/annotation/ApiMayChange.java  |  9 +++++++++
 .../org/apache/pekko/annotation/DoNotInherit.java  |  9 +++++++++
 .../org/apache/pekko/annotation/InternalApi.java   |  9 +++++++++
 .../apache/pekko/annotation/InternalStableApi.java |  9 +++++++++
 .../pekko/dispatch/AbstractBoundedNodeQueue.java   |  9 +++++++++
 .../org/apache/pekko/dispatch/AbstractMailbox.java |  9 +++++++++
 .../pekko/dispatch/AbstractMessageDispatcher.java  |  9 +++++++++
 .../apache/pekko/dispatch/AbstractNodeQueue.java   |  9 +++++++++
 .../apache/pekko/dispatch/affinity/OnSpinWait.java |  9 +++++++++
 .../src/main/java/org/apache/pekko/japi/JAPI.java  |  9 +++++++++
 .../org/apache/pekko/japi/pf/AbstractMatch.java    |  9 +++++++++
 .../apache/pekko/japi/pf/AbstractPFBuilder.java    |  9 +++++++++
 .../org/apache/pekko/japi/pf/DeciderBuilder.java   |  9 +++++++++
 .../src/main/java/org/apache/pekko/japi/pf/FI.java |  9 +++++++++
 .../pekko/japi/pf/FSMStateFunctionBuilder.java     |  9 +++++++++
 .../org/apache/pekko/japi/pf/FSMStopBuilder.java   |  9 +++++++++
 .../pekko/japi/pf/FSMTransitionHandlerBuilder.java |  9 +++++++++
 .../main/java/org/apache/pekko/japi/pf/Match.java  |  9 +++++++++
 .../java/org/apache/pekko/japi/pf/PFBuilder.java   |  9 +++++++++
 .../org/apache/pekko/japi/pf/ReceiveBuilder.java   |  9 +++++++++
 .../java/org/apache/pekko/japi/pf/UnitMatch.java   |  9 +++++++++
 .../org/apache/pekko/japi/pf/UnitPFBuilder.java    |  9 +++++++++
 .../pekko/pattern/AbstractCircuitBreaker.java      |  9 +++++++++
 .../pekko/pattern/AbstractPromiseActorRef.java     |  9 +++++++++
 .../main/java/org/apache/pekko/util/Unsafe.java    |  9 +++++++++
 .../org/apache/pekko/compat/Future.scala           |  9 +++++++++
 .../org/apache/pekko/compat/PartialFunction.scala  |  9 +++++++++
 .../internal/SameThreadExecutionContext.scala      |  9 +++++++++
 .../pekko/util/ccompat/ccompatUsedUntil213.scala   |  9 +++++++++
 .../org/apache/pekko/util/ccompat/package.scala    |  9 +++++++++
 .../pekko/dispatch/internal/ScalaBatchable.scala   |  9 +++++++++
 .../org/apache/pekko/util/ByteIterator.scala       |  9 +++++++++
 .../org/apache/pekko/util/ByteString.scala         |  9 +++++++++
 actor/src/main/scala/org/apache/pekko/Done.scala   |  9 +++++++++
 actor/src/main/scala/org/apache/pekko/Main.scala   |  9 +++++++++
 .../src/main/scala/org/apache/pekko/NotUsed.scala  |  9 +++++++++
 .../scala/org/apache/pekko/PekkoException.scala    |  9 +++++++++
 .../main/scala/org/apache/pekko/PekkoVersion.scala |  9 +++++++++
 .../org/apache/pekko/actor/AbstractActor.scala     |  9 +++++++++
 .../scala/org/apache/pekko/actor/AbstractFSM.scala |  9 +++++++++
 .../org/apache/pekko/actor/AbstractProps.scala     |  9 +++++++++
 .../main/scala/org/apache/pekko/actor/Actor.scala  |  9 +++++++++
 .../scala/org/apache/pekko/actor/ActorCell.scala   |  9 +++++++++
 .../org/apache/pekko/actor/ActorLogMarker.scala    |  9 +++++++++
 .../scala/org/apache/pekko/actor/ActorPath.scala   |  9 +++++++++
 .../scala/org/apache/pekko/actor/ActorRef.scala    |  9 +++++++++
 .../org/apache/pekko/actor/ActorRefProvider.scala  |  9 +++++++++
 .../org/apache/pekko/actor/ActorSelection.scala    |  9 +++++++++
 .../scala/org/apache/pekko/actor/ActorSystem.scala |  9 +++++++++
 .../scala/org/apache/pekko/actor/Address.scala     |  9 +++++++++
 .../pekko/actor/ClassicActorSystemProvider.scala   |  9 +++++++++
 .../apache/pekko/actor/CoordinatedShutdown.scala   |  9 +++++++++
 .../scala/org/apache/pekko/actor/Deployer.scala    |  9 +++++++++
 .../org/apache/pekko/actor/DynamicAccess.scala     |  9 +++++++++
 .../scala/org/apache/pekko/actor/Extension.scala   |  9 +++++++++
 .../main/scala/org/apache/pekko/actor/FSM.scala    |  9 +++++++++
 .../org/apache/pekko/actor/FaultHandling.scala     |  9 +++++++++
 .../apache/pekko/actor/IndirectActorProducer.scala |  9 +++++++++
 .../pekko/actor/LightArrayRevolverScheduler.scala  |  9 +++++++++
 .../main/scala/org/apache/pekko/actor/Props.scala  |  9 +++++++++
 .../pekko/actor/ReflectiveDynamicAccess.scala      |  9 +++++++++
 .../apache/pekko/actor/RepointableActorRef.scala   |  9 +++++++++
 .../scala/org/apache/pekko/actor/Scheduler.scala   |  9 +++++++++
 .../main/scala/org/apache/pekko/actor/Stash.scala  |  9 +++++++++
 .../main/scala/org/apache/pekko/actor/Timers.scala |  9 +++++++++
 .../scala/org/apache/pekko/actor/TypedActor.scala  |  9 +++++++++
 .../org/apache/pekko/actor/dungeon/Children.scala  |  9 +++++++++
 .../pekko/actor/dungeon/ChildrenContainer.scala    |  9 +++++++++
 .../apache/pekko/actor/dungeon/DeathWatch.scala    |  9 +++++++++
 .../org/apache/pekko/actor/dungeon/Dispatch.scala  |  9 +++++++++
 .../apache/pekko/actor/dungeon/FaultHandling.scala |  9 +++++++++
 .../pekko/actor/dungeon/ReceiveTimeout.scala       |  9 +++++++++
 .../pekko/actor/dungeon/TimerSchedulerImpl.scala   |  9 +++++++++
 .../scala/org/apache/pekko/actor/package.scala     |  9 +++++++++
 .../pekko/actor/setup/ActorSystemSetup.scala       |  9 +++++++++
 .../apache/pekko/dispatch/AbstractDispatcher.scala |  9 +++++++++
 .../pekko/dispatch/BalancingDispatcher.scala       |  9 +++++++++
 .../apache/pekko/dispatch/BatchingExecutor.scala   |  9 +++++++++
 .../org/apache/pekko/dispatch/CachingConfig.scala  |  9 +++++++++
 .../org/apache/pekko/dispatch/Dispatcher.scala     |  9 +++++++++
 .../org/apache/pekko/dispatch/Dispatchers.scala    |  9 +++++++++
 .../dispatch/ForkJoinExecutorConfigurator.scala    |  9 +++++++++
 .../scala/org/apache/pekko/dispatch/Future.scala   |  9 +++++++++
 .../scala/org/apache/pekko/dispatch/Mailbox.scala  |  9 +++++++++
 .../org/apache/pekko/dispatch/Mailboxes.scala      |  9 +++++++++
 .../apache/pekko/dispatch/PinnedDispatcher.scala   |  9 +++++++++
 .../apache/pekko/dispatch/ThreadPoolBuilder.scala  |  9 +++++++++
 .../pekko/dispatch/affinity/AffinityPool.scala     |  9 +++++++++
 .../pekko/dispatch/sysmsg/SystemMessage.scala      |  9 +++++++++
 .../event/ActorClassificationUnsubscriber.scala    |  9 +++++++++
 .../pekko/event/AddressTerminatedTopic.scala       |  9 +++++++++
 .../apache/pekko/event/DeadLetterListener.scala    |  9 +++++++++
 .../scala/org/apache/pekko/event/EventBus.scala    |  9 +++++++++
 .../scala/org/apache/pekko/event/EventStream.scala |  9 +++++++++
 .../pekko/event/EventStreamUnsubscriber.scala      |  9 +++++++++
 .../org/apache/pekko/event/LoggerMailbox.scala     |  9 +++++++++
 .../scala/org/apache/pekko/event/Logging.scala     |  9 +++++++++
 .../org/apache/pekko/event/LoggingReceive.scala    |  9 +++++++++
 .../apache/pekko/event/japi/EventBusJavaAPI.scala  |  9 +++++++++
 .../org/apache/pekko/event/jul/JavaLogger.scala    |  9 +++++++++
 .../org/apache/pekko/io/DirectByteBufferPool.scala |  9 +++++++++
 actor/src/main/scala/org/apache/pekko/io/Dns.scala |  9 +++++++++
 .../scala/org/apache/pekko/io/DnsProvider.scala    |  9 +++++++++
 actor/src/main/scala/org/apache/pekko/io/IO.scala  |  9 +++++++++
 .../src/main/scala/org/apache/pekko/io/Inet.scala  |  9 +++++++++
 .../apache/pekko/io/InetAddressDnsProvider.scala   |  9 +++++++++
 .../apache/pekko/io/InetAddressDnsResolver.scala   |  9 +++++++++
 .../org/apache/pekko/io/SelectionHandler.scala     |  9 +++++++++
 .../scala/org/apache/pekko/io/SimpleDnsCache.scala |  9 +++++++++
 .../org/apache/pekko/io/SimpleDnsManager.scala     |  9 +++++++++
 actor/src/main/scala/org/apache/pekko/io/Tcp.scala |  9 +++++++++
 .../scala/org/apache/pekko/io/TcpConnection.scala  |  9 +++++++++
 .../apache/pekko/io/TcpIncomingConnection.scala    |  9 +++++++++
 .../scala/org/apache/pekko/io/TcpListener.scala    |  9 +++++++++
 .../scala/org/apache/pekko/io/TcpManager.scala     |  9 +++++++++
 .../apache/pekko/io/TcpOutgoingConnection.scala    |  9 +++++++++
 actor/src/main/scala/org/apache/pekko/io/Udp.scala |  9 +++++++++
 .../scala/org/apache/pekko/io/UdpConnected.scala   |  9 +++++++++
 .../org/apache/pekko/io/UdpConnectedManager.scala  |  9 +++++++++
 .../scala/org/apache/pekko/io/UdpConnection.scala  |  9 +++++++++
 .../scala/org/apache/pekko/io/UdpListener.scala    |  9 +++++++++
 .../scala/org/apache/pekko/io/UdpManager.scala     |  9 +++++++++
 .../main/scala/org/apache/pekko/io/UdpSender.scala |  9 +++++++++
 .../scala/org/apache/pekko/io/WithUdpSend.scala    |  9 +++++++++
 .../org/apache/pekko/io/dns/CachePolicy.scala      |  9 +++++++++
 .../org/apache/pekko/io/dns/DnsProtocol.scala      |  9 +++++++++
 .../apache/pekko/io/dns/DnsResourceRecords.scala   |  9 +++++++++
 .../org/apache/pekko/io/dns/DnsSettings.scala      |  9 +++++++++
 .../org/apache/pekko/io/dns/RecordClass.scala      |  9 +++++++++
 .../scala/org/apache/pekko/io/dns/RecordType.scala |  9 +++++++++
 .../pekko/io/dns/internal/AsyncDnsManager.scala    |  9 +++++++++
 .../pekko/io/dns/internal/AsyncDnsProvider.scala   |  9 +++++++++
 .../pekko/io/dns/internal/AsyncDnsResolver.scala   |  9 +++++++++
 .../apache/pekko/io/dns/internal/DnsClient.scala   |  9 +++++++++
 .../apache/pekko/io/dns/internal/DnsMessage.scala  |  9 +++++++++
 .../apache/pekko/io/dns/internal/DomainName.scala  |  9 +++++++++
 .../apache/pekko/io/dns/internal/Question.scala    |  9 +++++++++
 .../io/dns/internal/RecordClassSerializer.scala    |  9 +++++++++
 .../io/dns/internal/RecordTypeSerializer.scala     |  9 +++++++++
 .../pekko/io/dns/internal/ResolvConfParser.scala   |  9 +++++++++
 .../pekko/io/dns/internal/TcpDnsClient.scala       |  9 +++++++++
 .../org/apache/pekko/io/dns/internal/package.scala |  9 +++++++++
 .../main/scala/org/apache/pekko/japi/JavaAPI.scala |  9 +++++++++
 .../scala/org/apache/pekko/japi/Throwables.scala   |  9 +++++++++
 .../org/apache/pekko/japi/function/Function.scala  |  9 +++++++++
 .../org/apache/pekko/japi/pf/CaseStatements.scala  |  9 +++++++++
 .../org/apache/pekko/pattern/AskSupport.scala      |  9 +++++++++
 .../scala/org/apache/pekko/pattern/Backoff.scala   |  9 +++++++++
 .../org/apache/pekko/pattern/BackoffOptions.scala  |  9 +++++++++
 .../apache/pekko/pattern/BackoffSupervisor.scala   |  9 +++++++++
 .../org/apache/pekko/pattern/CircuitBreaker.scala  |  9 +++++++++
 .../pekko/pattern/CircuitBreakersRegistry.scala    |  9 +++++++++
 .../pekko/pattern/FutureTimeoutSupport.scala       |  9 +++++++++
 .../apache/pekko/pattern/GracefulStopSupport.scala |  9 +++++++++
 .../org/apache/pekko/pattern/HandleBackoff.scala   |  9 +++++++++
 .../scala/org/apache/pekko/pattern/Patterns.scala  |  9 +++++++++
 .../org/apache/pekko/pattern/PipeToSupport.scala   |  9 +++++++++
 .../org/apache/pekko/pattern/PromiseRef.scala      |  9 +++++++++
 .../org/apache/pekko/pattern/RetrySupport.scala    |  9 +++++++++
 .../org/apache/pekko/pattern/StatusReply.scala     |  9 +++++++++
 .../apache/pekko/pattern/extended/package.scala    |  9 +++++++++
 .../internal/BackoffOnRestartSupervisor.scala      |  9 +++++++++
 .../pattern/internal/BackoffOnStopSupervisor.scala |  9 +++++++++
 .../pattern/internal/CircuitBreakerTelemetry.scala |  9 +++++++++
 .../scala/org/apache/pekko/pattern/package.scala   |  9 +++++++++
 .../scala/org/apache/pekko/routing/Balancing.scala |  9 +++++++++
 .../scala/org/apache/pekko/routing/Broadcast.scala |  9 +++++++++
 .../org/apache/pekko/routing/ConsistentHash.scala  |  9 +++++++++
 .../apache/pekko/routing/ConsistentHashing.scala   |  9 +++++++++
 .../scala/org/apache/pekko/routing/Listeners.scala |  9 +++++++++
 .../routing/OptimalSizeExploringResizer.scala      |  9 +++++++++
 .../scala/org/apache/pekko/routing/Random.scala    |  9 +++++++++
 .../scala/org/apache/pekko/routing/Resizer.scala   |  9 +++++++++
 .../org/apache/pekko/routing/RoundRobin.scala      |  9 +++++++++
 .../org/apache/pekko/routing/RoutedActorCell.scala |  9 +++++++++
 .../org/apache/pekko/routing/RoutedActorRef.scala  |  9 +++++++++
 .../scala/org/apache/pekko/routing/Router.scala    |  9 +++++++++
 .../org/apache/pekko/routing/RouterConfig.scala    |  9 +++++++++
 .../routing/ScatterGatherFirstCompleted.scala      |  9 +++++++++
 .../org/apache/pekko/routing/SmallestMailbox.scala |  9 +++++++++
 .../org/apache/pekko/routing/TailChopping.scala    |  9 +++++++++
 .../pekko/serialization/AsyncSerializer.scala      |  9 +++++++++
 .../pekko/serialization/PrimitiveSerializers.scala |  9 +++++++++
 .../apache/pekko/serialization/Serialization.scala |  9 +++++++++
 .../serialization/SerializationExtension.scala     |  9 +++++++++
 .../pekko/serialization/SerializationSetup.scala   |  9 +++++++++
 .../apache/pekko/serialization/Serializer.scala    |  9 +++++++++
 .../apache/pekko/util/BoundedBlockingQueue.scala   |  9 +++++++++
 .../scala/org/apache/pekko/util/BoxedType.scala    |  9 +++++++++
 .../pekko/util/ClassLoaderObjectInputStream.scala  |  9 +++++++++
 .../scala/org/apache/pekko/util/Collections.scala  |  9 +++++++++
 .../scala/org/apache/pekko/util/ConstantFun.scala  |  9 +++++++++
 .../org/apache/pekko/util/DoubleLinkedList.scala   |  9 +++++++++
 .../org/apache/pekko/util/ErrorMessages.scala      |  9 +++++++++
 .../apache/pekko/util/FlightRecorderLoader.scala   |  9 +++++++++
 .../org/apache/pekko/util/FrequencyList.scala      |  9 +++++++++
 .../org/apache/pekko/util/FrequencySketch.scala    |  9 +++++++++
 .../scala/org/apache/pekko/util/HashCode.scala     |  9 +++++++++
 .../main/scala/org/apache/pekko/util/Helpers.scala |  9 +++++++++
 .../org/apache/pekko/util/ImmutableIntMap.scala    |  9 +++++++++
 .../main/scala/org/apache/pekko/util/Index.scala   |  9 +++++++++
 .../apache/pekko/util/JavaDurationConverters.scala |  9 +++++++++
 .../scala/org/apache/pekko/util/JavaVersion.scala  |  9 +++++++++
 .../scala/org/apache/pekko/util/LineNumbers.scala  |  9 +++++++++
 .../scala/org/apache/pekko/util/LockUtil.scala     |  9 +++++++++
 .../scala/org/apache/pekko/util/ManifestInfo.scala |  9 +++++++++
 .../org/apache/pekko/util/MessageBuffer.scala      |  9 +++++++++
 .../scala/org/apache/pekko/util/OptionVal.scala    |  9 +++++++++
 .../org/apache/pekko/util/PrettyByteString.scala   |  9 +++++++++
 .../org/apache/pekko/util/PrettyDuration.scala     |  9 +++++++++
 .../scala/org/apache/pekko/util/RecencyList.scala  |  9 +++++++++
 .../main/scala/org/apache/pekko/util/Reflect.scala |  9 +++++++++
 .../apache/pekko/util/SegmentedRecencyList.scala   |  9 +++++++++
 .../SerializedSuspendableExecutionContext.scala    |  9 +++++++++
 .../apache/pekko/util/StablePriorityQueue.scala    |  9 +++++++++
 .../org/apache/pekko/util/SubclassifiedIndex.scala |  9 +++++++++
 .../main/scala/org/apache/pekko/util/Timeout.scala |  9 +++++++++
 .../scala/org/apache/pekko/util/TokenBucket.scala  |  9 +++++++++
 .../org/apache/pekko/util/TypedMultiMap.scala      |  9 +++++++++
 .../org/apache/pekko/util/UUIDComparator.scala     |  9 +++++++++
 .../main/scala/org/apache/pekko/util/Unused.scala  |  9 +++++++++
 .../main/scala/org/apache/pekko/util/Version.scala |  9 +++++++++
 .../scala/org/apache/pekko/util/WallClock.scala    |  9 +++++++++
 .../org/apache/pekko/util/WildcardIndex.scala      |  9 +++++++++
 .../akka/serialization/jackson/JavaMessages.java   |  9 +++++++++
 .../main/scala/org/apache/pekko/BenchRunner.scala  |  9 +++++++++
 .../org/apache/pekko/actor/ActorBenchmark.scala    |  9 +++++++++
 .../pekko/actor/ActorCreationBenchmark.scala       |  9 +++++++++
 .../pekko/actor/ActorPathValidationBenchmark.scala |  9 +++++++++
 .../actor/AffinityPoolComparativeBenchmark.scala   |  9 +++++++++
 .../actor/AffinityPoolIdleCPULevelBenchmark.scala  |  9 +++++++++
 .../AffinityPoolRequestResponseBenchmark.scala     |  9 +++++++++
 .../org/apache/pekko/actor/BenchmarkActors.scala   |  9 +++++++++
 .../actor/DirectByteBufferPoolBenchmark.scala      |  9 +++++++++
 .../pekko/actor/ForkJoinActorBenchmark.scala       |  9 +++++++++
 .../org/apache/pekko/actor/JCToolsMailbox.scala    |  9 +++++++++
 .../apache/pekko/actor/ManyToOneArrayMailbox.scala |  9 +++++++++
 .../apache/pekko/actor/RequestResponseActors.scala |  9 +++++++++
 .../pekko/actor/RouterPoolCreationBenchmark.scala  |  9 +++++++++
 .../org/apache/pekko/actor/ScheduleBenchmark.scala |  9 +++++++++
 .../pekko/actor/StashCreationBenchmark.scala       |  9 +++++++++
 .../org/apache/pekko/actor/TellOnlyBenchmark.scala |  9 +++++++++
 .../pekko/actor/typed/TypedActorBenchmark.scala    |  9 +++++++++
 .../pekko/actor/typed/TypedBenchmarkActors.scala   |  9 +++++++++
 .../actor/typed/TypedForkJoinActorBenchmark.scala  |  9 +++++++++
 .../typed/delivery/ReliableDeliveryBenchmark.scala |  9 +++++++++
 .../pekko/cluster/ddata/ORSetMergeBenchmark.scala  |  9 +++++++++
 .../ddata/ORSetSerializationBenchmark.scala        |  9 +++++++++
 .../cluster/ddata/VersionVectorBenchmark.scala     |  9 +++++++++
 .../pekko/dispatch/CachingConfigBenchmark.scala    |  9 +++++++++
 .../apache/pekko/dispatch/NodeQueueBenchmark.scala |  9 +++++++++
 .../pekko/event/LogLevelAccessBenchmark.scala      |  9 +++++++++
 .../org/apache/pekko/persistence/Common.scala      |  9 +++++++++
 .../persistence/LevelDbBatchingBenchmark.scala     |  9 +++++++++
 .../PersistenceActorDeferBenchmark.scala           |  9 +++++++++
 .../persistence/PersistentActorBenchmark.scala     |  9 +++++++++
 ...tentActorWithAtLeastOnceDeliveryBenchmark.scala |  9 +++++++++
 .../pekko/remote/artery/BenchTestSource.scala      |  9 +++++++++
 .../pekko/remote/artery/CodecBenchmark.scala       |  9 +++++++++
 .../org/apache/pekko/remote/artery/LatchSink.scala |  9 +++++++++
 .../remote/artery/LiteralEncodingBenchmark.scala   |  9 +++++++++
 .../pekko/remote/artery/SendQueueBenchmark.scala   |  9 +++++++++
 .../artery/compress/CountMinSketchBenchmark.scala  |  9 +++++++++
 .../compress/InvertCompressionTableBenchmark.scala |  9 +++++++++
 .../SerializationFormatCacheBenchmark.scala        |  9 +++++++++
 .../remote/compress/HeavyHittersBenchmark.scala    |  9 +++++++++
 .../jackson/JacksonSerializationBench.scala        |  9 +++++++++
 .../org/apache/pekko/stream/AskBenchmark.scala     |  9 +++++++++
 .../apache/pekko/stream/EmptySourceBenchmark.scala |  9 +++++++++
 .../pekko/stream/FlatMapConcatBenchmark.scala      |  9 +++++++++
 .../pekko/stream/FlatMapMergeBenchmark.scala       |  9 +++++++++
 .../org/apache/pekko/stream/FlowMapBenchmark.scala |  9 +++++++++
 .../org/apache/pekko/stream/FramingBenchmark.scala |  9 +++++++++
 .../apache/pekko/stream/FusedGraphsBenchmark.scala |  9 +++++++++
 .../pekko/stream/GraphBuilderBenchmark.scala       |  9 +++++++++
 .../apache/pekko/stream/InterpreterBenchmark.scala |  9 +++++++++
 .../pekko/stream/InvokeWithFeedbackBenchmark.scala |  9 +++++++++
 .../apache/pekko/stream/JsonFramingBenchmark.scala |  9 +++++++++
 .../apache/pekko/stream/MapAsyncBenchmark.scala    |  9 +++++++++
 .../pekko/stream/MaterializationBenchmark.scala    |  9 +++++++++
 .../pekko/stream/PartitionHubBenchmark.scala       |  9 +++++++++
 .../apache/pekko/stream/SourceRefBenchmark.scala   |  9 +++++++++
 .../impl/OutputStreamSourceStageBenchmark.scala    |  9 +++++++++
 .../pekko/stream/io/FileSourcesBenchmark.scala     |  9 +++++++++
 .../stream/io/FileSourcesScaleBenchmark.scala      |  9 +++++++++
 .../pekko/util/ByteString_append_Benchmark.scala   |  9 +++++++++
 .../pekko/util/ByteString_apply_Benchmark.scala    |  9 +++++++++
 .../util/ByteString_copyToBuffer_Benchmark.scala   |  9 +++++++++
 .../pekko/util/ByteString_decode_Benchmark.scala   |  9 +++++++++
 .../util/ByteString_dropRight_Benchmark.scala      |  9 +++++++++
 .../util/ByteString_dropSliceTake_Benchmark.scala  |  9 +++++++++
 .../pekko/util/ByteString_drop_Benchmark.scala     |  9 +++++++++
 .../pekko/util/ByteString_grouped_Benchmark.scala  |  9 +++++++++
 .../pekko/util/ByteString_indexOf_Benchmark.scala  |  9 +++++++++
 .../pekko/util/ByteString_take_Benchmark.scala     |  9 +++++++++
 .../pekko/util/ByteString_toArray_Benchmark.scala  |  9 +++++++++
 .../pekko/util/FastFrequencySketchBenchmark.scala  |  9 +++++++++
 .../pekko/util/FrequencySketchBenchmark.scala      |  9 +++++++++
 .../apache/pekko/util/ImmutableIntMapBench.scala   |  9 +++++++++
 .../apache/pekko/util/LruBoundedCacheBench.scala   |  9 +++++++++
 .../scala/org/apache/pekko/util/StackBench.scala   |  9 +++++++++
 .../protobuf/msg/ClusterMetricsMessages.java       |  9 +++++++++
 .../src/main/protobuf/ClusterMetricsMessages.proto |  9 +++++++++
 .../cluster/metrics/ClusterMetricsCollector.scala  |  9 +++++++++
 .../cluster/metrics/ClusterMetricsExtension.scala  |  9 +++++++++
 .../cluster/metrics/ClusterMetricsRouting.scala    |  9 +++++++++
 .../cluster/metrics/ClusterMetricsSettings.scala   |  9 +++++++++
 .../cluster/metrics/ClusterMetricsStrategy.scala   |  9 +++++++++
 .../org/apache/pekko/cluster/metrics/EWMA.scala    |  9 +++++++++
 .../org/apache/pekko/cluster/metrics/Metric.scala  |  9 +++++++++
 .../pekko/cluster/metrics/MetricsCollector.scala   |  9 +++++++++
 .../apache/pekko/cluster/metrics/Provision.scala   |  9 +++++++++
 .../metrics/protobuf/MessageSerializer.scala       |  9 +++++++++
 .../metrics/ClusterMetricsExtensionSpec.scala      |  9 +++++++++
 .../metrics/ClusterMetricsRoutingSpec.scala        |  9 +++++++++
 .../cluster/metrics/sample/StatsMessages.scala     |  9 +++++++++
 .../cluster/metrics/sample/StatsSampleSpec.scala   |  9 +++++++++
 .../cluster/metrics/sample/StatsService.scala      |  9 +++++++++
 .../pekko/cluster/metrics/sample/StatsWorker.scala |  9 +++++++++
 .../metrics/ClusterMetricsExtensionSpec.scala      |  9 +++++++++
 .../metrics/ClusterMetricsRoutingSpec.scala        |  9 +++++++++
 .../metrics/ClusterMetricsSettingsSpec.scala       |  9 +++++++++
 .../apache/pekko/cluster/metrics/EWMASpec.scala    |  9 +++++++++
 .../apache/pekko/cluster/metrics/MetricSpec.scala  |  9 +++++++++
 .../cluster/metrics/MetricsCollectorSpec.scala     |  9 +++++++++
 .../apache/pekko/cluster/metrics/TestUtil.scala    |  9 +++++++++
 .../cluster/metrics/WeightedRouteesSpec.scala      |  9 +++++++++
 .../metrics/protobuf/MessageSerializerSpec.scala   |  9 +++++++++
 .../typed/internal/protobuf/ShardingMessages.java  |  9 +++++++++
 .../src/main/protobuf/ShardingMessages.proto       |  9 +++++++++
 .../sharding/typed/ClusterShardingQuery.scala      |  9 +++++++++
 .../sharding/typed/ClusterShardingSettings.scala   |  9 +++++++++
 .../sharding/typed/Murmur2MessageExtractor.scala   |  9 +++++++++
 .../sharding/typed/ReplicatedEntityProvider.scala  |  9 +++++++++
 .../typed/ReplicatedShardingExtension.scala        |  9 +++++++++
 .../typed/ShardedDaemonProcessSettings.scala       |  9 +++++++++
 .../sharding/typed/ShardingDirectReplication.scala |  9 +++++++++
 .../sharding/typed/ShardingMessageExtractor.scala  |  9 +++++++++
 .../delivery/ShardingConsumerController.scala      |  9 +++++++++
 .../delivery/ShardingProducerController.scala      |  9 +++++++++
 .../internal/ShardingConsumerControllerImpl.scala  |  9 +++++++++
 .../internal/ShardingProducerControllerImpl.scala  |  9 +++++++++
 .../typed/internal/ClusterShardingImpl.scala       |  9 +++++++++
 .../JoinConfigCompatCheckerClusterSharding.scala   |  9 +++++++++
 .../internal/ReplicatedShardingExtensionImpl.scala |  9 +++++++++
 .../typed/internal/ShardedDaemonProcessImpl.scala  |  9 +++++++++
 .../typed/internal/ShardingSerializer.scala        |  9 +++++++++
 .../sharding/typed/internal/ShardingState.scala    |  9 +++++++++
 .../typed/internal/testkit/TestEntityRefImpl.scala |  9 +++++++++
 .../sharding/typed/javadsl/ClusterSharding.scala   |  9 +++++++++
 .../typed/javadsl/ShardedDaemonProcess.scala       |  9 +++++++++
 .../sharding/typed/scaladsl/ClusterSharding.scala  |  9 +++++++++
 .../typed/scaladsl/ShardedDaemonProcess.scala      |  9 +++++++++
 .../sharding/typed/testkit/javadsl/EntityRef.scala |  9 +++++++++
 .../typed/testkit/scaladsl/EntityRef.scala         |  9 +++++++++
 .../ClusterShardingRememberEntitiesPerfSpec.scala  |  9 +++++++++
 .../ClusterShardingPreparingForShutdownSpec.scala  |  9 +++++++++
 .../sharding/typed/ClusterShardingStatsSpec.scala  |  9 +++++++++
 .../typed/MultiDcClusterShardingSpec.scala         |  9 +++++++++
 .../sharding/typed/ReplicatedShardingSpec.scala    |  9 +++++++++
 .../sharding/typed/ShardedDaemonProcessSpec.scala  |  9 +++++++++
 .../typed/delivery/DeliveryThroughputSpec.scala    |  9 +++++++++
 .../jdocs/delivery/PointToPointDocExample.java     |  9 +++++++++
 .../java/jdocs/delivery/ShardingDocExample.java    |  9 +++++++++
 .../java/jdocs/delivery/WorkPullingDocExample.java |  9 +++++++++
 .../sharding/typed/AccountExampleDocTest.java      |  9 +++++++++
 .../cluster/sharding/typed/AccountExampleTest.java |  9 +++++++++
 .../AccountExampleWithEventHandlersInState.java    |  9 +++++++++
 .../typed/AccountExampleWithMutableState.java      |  9 +++++++++
 .../typed/AccountExampleWithNullDurableState.java  |  9 +++++++++
 .../typed/AccountExampleWithNullState.java         |  9 +++++++++
 ...DurableStateStoreQueryUsageCompileOnlyTest.java |  9 +++++++++
 .../ExternalShardAllocationCompileOnlyTest.java    |  9 +++++++++
 .../HelloWorldEventSourcedEntityExampleTest.java   |  9 +++++++++
 .../typed/HelloWorldPersistentEntityExample.java   |  9 +++++++++
 .../typed/ReplicatedShardingCompileOnlySpec.java   |  9 +++++++++
 .../sharding/typed/ShardingCompileOnlyTest.java    |  9 +++++++++
 .../typed/ShardingReplyCompileOnlyTest.java        |  9 +++++++++
 .../sharding/typed/ReplicatedShardingTest.java     |  9 +++++++++
 .../javadsl/ClusterShardingPersistenceTest.java    |  9 +++++++++
 .../ClusterShardingSettingsCompileOnly.java        |  9 +++++++++
 .../ShardedDaemonProcessCompileOnlyTest.java       |  9 +++++++++
 ...edEntityWithEnforcedRepliesCompileOnlyTest.java |  9 +++++++++
 .../docs/delivery/PointToPointDocExample.scala     |  9 +++++++++
 .../scala/docs/delivery/ShardingDocExample.scala   |  9 +++++++++
 .../docs/delivery/WorkPullingDocExample.scala      |  9 +++++++++
 .../sharding/typed/AccountExampleDocSpec.scala     |  9 +++++++++
 .../sharding/typed/AccountExampleSpec.scala        |  9 +++++++++
 ...tExampleWithCommandHandlersInDurableState.scala |  9 +++++++++
 .../AccountExampleWithCommandHandlersInState.scala |  9 +++++++++
 .../AccountExampleWithEventHandlersInState.scala   |  9 +++++++++
 .../AccountExampleWithOptionDurableState.scala     |  9 +++++++++
 .../typed/AccountExampleWithOptionState.scala      |  9 +++++++++
 ...urableStateStoreQueryUsageCompileOnlySpec.scala |  9 +++++++++
 .../ExternalShardAllocationCompileOnlySpec.scala   |  9 +++++++++
 .../HelloWorldEventSourcedEntityExampleSpec.scala  |  9 +++++++++
 .../typed/HelloWorldPersistentEntityExample.scala  |  9 +++++++++
 .../typed/ReplicatedShardingCompileOnlySpec.scala  |  9 +++++++++
 .../sharding/typed/ShardingCompileOnlySpec.scala   |  9 +++++++++
 .../pekko/cluster/sharding/FlightRecording.scala   |  9 +++++++++
 ...oinConfigCompatCheckerClusterShardingSpec.scala |  9 +++++++++
 .../ReplicatedShardingDirectReplicationSpec.scala  |  9 +++++++++
 .../sharding/typed/ReplicatedShardingSpec.scala    |  9 +++++++++
 .../sharding/typed/ShardingSerializerSpec.scala    |  9 +++++++++
 .../typed/delivery/DurableShardingSpec.scala       |  9 +++++++++
 .../delivery/ReliableDeliveryShardingSpec.scala    |  9 +++++++++
 .../sharding/typed/internal/Murmur2Spec.scala      |  9 +++++++++
 .../scaladsl/ClusterShardingPersistenceSpec.scala  |  9 +++++++++
 .../typed/scaladsl/ClusterShardingSpec.scala       |  9 +++++++++
 .../typed/scaladsl/ClusterShardingStateSpec.scala  |  9 +++++++++
 .../typed/scaladsl/ClusterShardingStatsSpec.scala  |  9 +++++++++
 .../typed/scaladsl/ShardedDaemonProcessSpec.scala  |  9 +++++++++
 .../typed/testkit/scaladsl/TestEntityRefSpec.scala |  9 +++++++++
 .../protobuf/msg/ClusterShardingMessages.java      |  9 +++++++++
 .../main/protobuf/ClusterShardingMessages.proto    |  9 +++++++++
 .../cluster/sharding/internal/jfr/Events.scala     |  9 +++++++++
 .../internal/jfr/JFRShardingFlightRecorder.scala   |  9 +++++++++
 .../pekko/cluster/sharding/ClusterSharding.scala   |  9 +++++++++
 .../sharding/ClusterShardingHealthCheck.scala      |  9 +++++++++
 .../sharding/ClusterShardingSerializable.scala     |  9 +++++++++
 .../cluster/sharding/ClusterShardingSettings.scala |  9 +++++++++
 .../sharding/JoinConfigCompatCheckSharding.scala   |  9 +++++++++
 .../OldCoordinatorStateMigrationEventAdapter.scala |  9 +++++++++
 .../RemoveInternalClusterShardingData.scala        |  9 +++++++++
 .../org/apache/pekko/cluster/sharding/Shard.scala  |  9 +++++++++
 .../pekko/cluster/sharding/ShardCoordinator.scala  |  9 +++++++++
 .../pekko/cluster/sharding/ShardRegion.scala       |  9 +++++++++
 .../cluster/sharding/ShardingFlightRecorder.scala  |  9 +++++++++
 .../pekko/cluster/sharding/ShardingLogMarker.scala |  9 +++++++++
 .../pekko/cluster/sharding/ShardingQueries.scala   |  9 +++++++++
 .../sharding/external/ClientTimeoutException.scala |  9 +++++++++
 .../external/ExternalShardAllocation.scala         |  9 +++++++++
 .../external/ExternalShardAllocationStrategy.scala |  9 +++++++++
 .../cluster/sharding/external/ShardLocations.scala |  9 +++++++++
 .../ExternalShardAllocationClientImpl.scala        |  9 +++++++++
 .../javadsl/ExternalShardAllocationClient.scala    |  9 +++++++++
 .../scaladsl/ExternalShardAllocationClient.scala   |  9 +++++++++
 .../AbstractLeastShardAllocationStrategy.scala     |  9 +++++++++
 .../internal/CustomStateStoreModeProvider.scala    |  9 +++++++++
 .../DDataRememberEntitiesCoordinatorStore.scala    |  9 +++++++++
 .../internal/DDataRememberEntitiesProvider.scala   |  9 +++++++++
 .../internal/DDataRememberEntitiesShardStore.scala |  9 +++++++++
 .../internal/EntityPassivationStrategy.scala       |  9 +++++++++
 ...ntSourcedRememberEntitiesCoordinatorStore.scala |  9 +++++++++
 .../EventSourcedRememberEntitiesProvider.scala     |  9 +++++++++
 .../EventSourcedRememberEntitiesShardStore.scala   |  9 +++++++++
 .../internal/LeastShardAllocationStrategy.scala    |  9 +++++++++
 .../sharding/internal/RememberEntitiesStore.scala  |  9 +++++++++
 .../sharding/internal/RememberEntityStarter.scala  |  9 +++++++++
 .../ClusterShardingMessageSerializer.scala         |  9 +++++++++
 .../apache/pekko/cluster/sbr/GlobalRegistry.scala  |  9 +++++++++
 .../pekko/cluster/sbr/GremlinController.scala      |  9 +++++++++
 .../RandomizedBrainResolverIntegrationSpec.scala   |  9 +++++++++
 .../pekko/cluster/sbr/SbrTestLeaseActor.scala      |  9 +++++++++
 .../sbr/SplitBrainResolverIntegrationSpec.scala    |  9 +++++++++
 .../ClusterShardCoordinatorDowning2Spec.scala      |  9 +++++++++
 .../ClusterShardCoordinatorDowningSpec.scala       |  9 +++++++++
 .../ClusterShardingCustomShardAllocationSpec.scala |  9 +++++++++
 .../sharding/ClusterShardingFailureSpec.scala      |  9 +++++++++
 .../sharding/ClusterShardingGetStateSpec.scala     |  9 +++++++++
 .../sharding/ClusterShardingGetStatsSpec.scala     |  9 +++++++++
 ...ClusterShardingGracefulShutdownOldestSpec.scala |  9 +++++++++
 .../ClusterShardingGracefulShutdownSpec.scala      |  9 +++++++++
 .../ClusterShardingIncorrectSetupSpec.scala        |  9 +++++++++
 .../sharding/ClusterShardingLeavingSpec.scala      |  9 +++++++++
 .../sharding/ClusterShardingMinMembersSpec.scala   |  9 +++++++++
 .../sharding/ClusterShardingQueriesSpec.scala      |  9 +++++++++
 ...ardingRegistrationCoordinatedShutdownSpec.scala |  9 +++++++++
 ...rShardingRememberEntitiesNewExtractorSpec.scala |  9 +++++++++
 .../ClusterShardingRememberEntitiesSpec.scala      |  9 +++++++++
 .../ClusterShardingRolePartitioningSpec.scala      |  9 +++++++++
 .../ClusterShardingSingleShardPerEntitySpec.scala  |  9 +++++++++
 .../cluster/sharding/ClusterShardingSpec.scala     |  9 +++++++++
 .../sharding/ExternalShardAllocationSpec.scala     |  9 +++++++++
 .../sharding/MultiDcClusterShardingSpec.scala      |  9 +++++++++
 .../sharding/MultiNodeClusterShardingConfig.scala  |  9 +++++++++
 .../sharding/MultiNodeClusterShardingSpec.scala    |  9 +++++++++
 .../RollingUpdateShardAllocationSpec.scala         |  9 +++++++++
 .../sharding/ClusterShardingHealthCheckSpec.scala  |  9 +++++++++
 .../sharding/ClusterShardingInternalsSpec.scala    |  9 +++++++++
 .../sharding/ClusterShardingLeaseSpec.scala        |  9 +++++++++
 .../sharding/ClusterShardingSettingsSpec.scala     |  9 +++++++++
 .../sharding/ConcurrentStartupShardingSpec.scala   |  9 +++++++++
 .../sharding/CoordinatedShutdownShardingSpec.scala |  9 +++++++++
 ...eprecatedLeastShardAllocationStrategySpec.scala |  9 +++++++++
 .../pekko/cluster/sharding/EntitiesSpec.scala      |  9 +++++++++
 .../cluster/sharding/EntityTerminationSpec.scala   |  9 +++++++++
 .../cluster/sharding/GetShardTypeNamesSpec.scala   |  9 +++++++++
 .../JoinConfigCompatCheckShardingSpec.scala        |  9 +++++++++
 ...eastShardAllocationStrategyRandomizedSpec.scala |  9 +++++++++
 .../LeastShardAllocationStrategySpec.scala         |  9 +++++++++
 .../sharding/PersistentShardingMigrationSpec.scala |  9 +++++++++
 .../pekko/cluster/sharding/ProxyShardingSpec.scala |  9 +++++++++
 .../RememberEntitiesAndStartEntitySpec.scala       |  9 +++++++++
 .../RememberEntitiesBatchedUpdatesSpec.scala       |  9 +++++++++
 .../sharding/RememberEntitiesFailureSpec.scala     |  9 +++++++++
 ...ememberEntitiesShardIdExtractorChangeSpec.scala |  9 +++++++++
 .../RemoveInternalClusterShardingDataSpec.scala    |  9 +++++++++
 .../pekko/cluster/sharding/ShardRegionSpec.scala   |  9 +++++++++
 .../cluster/sharding/ShardWithLeaseSpec.scala      |  9 +++++++++
 .../cluster/sharding/ShardingQueriesSpec.scala     |  9 +++++++++
 .../pekko/cluster/sharding/StartEntitySpec.scala   |  9 +++++++++
 .../pekko/cluster/sharding/SupervisionSpec.scala   |  9 +++++++++
 .../ExternalShardAllocationStrategySpec.scala      |  9 +++++++++
 .../internal/RememberEntitiesShardStoreSpec.scala  |  9 +++++++++
 .../internal/RememberEntitiesStarterSpec.scala     |  9 +++++++++
 .../sharding/passivation/CompositeSpec.scala       |  9 +++++++++
 .../passivation/EntityPassivationSpec.scala        |  9 +++++++++
 .../HillClimbingAdmissionOptimizerSpec.scala       |  9 +++++++++
 .../cluster/sharding/passivation/IdleSpec.scala    |  9 +++++++++
 .../passivation/LeastFrequentlyUsedSpec.scala      |  9 +++++++++
 .../passivation/LeastRecentlyUsedSpec.scala        |  9 +++++++++
 .../passivation/MostRecentlyUsedSpec.scala         |  9 +++++++++
 .../passivation/simulator/AccessPattern.scala      |  9 +++++++++
 .../sharding/passivation/simulator/Simulator.scala |  9 +++++++++
 .../passivation/simulator/SimulatorSettings.scala  |  9 +++++++++
 .../passivation/simulator/SimulatorStats.scala     |  9 +++++++++
 .../ClusterShardingMessageSerializerSpec.scala     |  9 +++++++++
 .../client/protobuf/msg/ClusterClientMessages.java |  9 +++++++++
 .../protobuf/msg/DistributedPubSubMessages.java    |  9 +++++++++
 .../src/main/protobuf/ClusterClientMessages.proto  |  9 +++++++++
 .../main/protobuf/DistributedPubSubMessages.proto  |  9 +++++++++
 .../pekko/cluster/client/ClusterClient.scala       |  9 +++++++++
 .../protobuf/ClusterClientMessageSerializer.scala  |  9 +++++++++
 .../cluster/pubsub/DistributedPubSubMediator.scala |  9 +++++++++
 .../pekko/cluster/pubsub/PerGroupingBuffer.scala   |  9 +++++++++
 .../DistributedPubSubMessageSerializer.scala       |  9 +++++++++
 .../singleton/ClusterSingletonManager.scala        |  9 +++++++++
 .../cluster/singleton/ClusterSingletonProxy.scala  |  9 +++++++++
 .../ClusterSingletonMessageSerializer.scala        |  9 +++++++++
 .../cluster/client/ClusterClientHandoverSpec.scala |  9 +++++++++
 .../pekko/cluster/client/ClusterClientSpec.scala   |  9 +++++++++
 .../cluster/client/ClusterClientStopSpec.scala     |  9 +++++++++
 .../pubsub/DistributedPubSubMediatorSpec.scala     |  9 +++++++++
 .../pubsub/DistributedPubSubRestartSpec.scala      |  9 +++++++++
 .../ClusterSingletonManagerChaosSpec.scala         |  9 +++++++++
 .../ClusterSingletonManagerDownedSpec.scala        |  9 +++++++++
 .../ClusterSingletonManagerLeaseSpec.scala         |  9 +++++++++
 .../ClusterSingletonManagerLeave2Spec.scala        |  9 +++++++++
 .../ClusterSingletonManagerLeaveSpec.scala         |  9 +++++++++
 ...rSingletonManagerPreparingForShutdownSpec.scala |  9 +++++++++
 .../singleton/ClusterSingletonManagerSpec.scala    |  9 +++++++++
 .../ClusterSingletonManagerStartupSpec.scala       |  9 +++++++++
 .../singleton/MultiDcSingletonManagerSpec.scala    |  9 +++++++++
 .../pekko/cluster/client/ClusterClientTest.java    |  9 +++++++++
 .../pubsub/DistributedPubSubMediatorTest.java      |  9 +++++++++
 .../singleton/ClusterSingletonManagerTest.java     |  9 +++++++++
 .../apache/pekko/cluster/singleton/Consumer.java   |  9 +++++++++
 .../cluster/singleton/TestSingletonMessages.java   |  9 +++++++++
 .../ClusterClientMessageSerializerSpec.scala       |  9 +++++++++
 .../DistributedPubSubMediatorDeadLettersSpec.scala |  9 +++++++++
 .../DistributedPubSubMediatorRouterSpec.scala      |  9 +++++++++
 .../DistributedPubSubMessageSerializerSpec.scala   |  9 +++++++++
 .../singleton/ClusterSingletonLeaseSpec.scala      |  9 +++++++++
 .../ClusterSingletonLeavingSpeedSpec.scala         |  9 +++++++++
 .../singleton/ClusterSingletonProxySpec.scala      |  9 +++++++++
 .../singleton/ClusterSingletonRestart2Spec.scala   |  9 +++++++++
 .../singleton/ClusterSingletonRestartSpec.scala    |  9 +++++++++
 .../ClusterSingletonMessageSerializerSpec.scala    |  9 +++++++++
 .../typed/internal/protobuf/ClusterMessages.java   |  9 +++++++++
 .../typed/internal/protobuf/ReliableDelivery.java  |  9 +++++++++
 .../src/main/protobuf/ClusterMessages.proto        |  9 +++++++++
 .../src/main/protobuf/ReliableDelivery.proto       |  9 +++++++++
 .../receptionist/ClusterReceptionistProtocol.scala |  9 +++++++++
 .../ddata/typed/internal/ReplicatorBehavior.scala  |  9 +++++++++
 .../ddata/typed/javadsl/DistributedData.scala      |  9 +++++++++
 .../cluster/ddata/typed/javadsl/Replicator.scala   |  9 +++++++++
 .../typed/javadsl/ReplicatorMessageAdapter.scala   |  9 +++++++++
 .../ddata/typed/javadsl/ReplicatorSettings.scala   |  9 +++++++++
 .../ddata/typed/scaladsl/DistributedData.scala     |  9 +++++++++
 .../cluster/ddata/typed/scaladsl/Replicator.scala  |  9 +++++++++
 .../typed/scaladsl/ReplicatorMessageAdapter.scala  |  9 +++++++++
 .../ddata/typed/scaladsl/ReplicatorSettings.scala  |  9 +++++++++
 .../cluster/ddata/typed/scaladsl/package.scala     |  9 +++++++++
 .../org/apache/pekko/cluster/typed/Cluster.scala   |  9 +++++++++
 .../pekko/cluster/typed/ClusterSingleton.scala     |  9 +++++++++
 .../typed/internal/AdaptedClusterImpl.scala        |  9 +++++++++
 .../internal/AdaptedClusterSingletonImpl.scala     |  9 +++++++++
 .../internal/PekkoClusterTypedSerializer.scala     |  9 +++++++++
 .../delivery/ReliableDeliverySerializer.scala      |  9 +++++++++
 .../receptionist/ClusterReceptionist.scala         |  9 +++++++++
 .../ClusterReceptionistConfigCompatChecker.scala   |  9 +++++++++
 .../receptionist/ClusterReceptionistSettings.scala |  9 +++++++++
 .../typed/internal/receptionist/Registry.scala     |  9 +++++++++
 .../cluster/typed/ChunkLargeMessageSpec.scala      |  9 +++++++++
 .../typed/MultiDcClusterSingletonSpec.scala        |  9 +++++++++
 .../apache/pekko/cluster/typed/MultiDcPinger.scala |  9 +++++++++
 .../cluster/typed/MultiNodeTypedClusterSpec.scala  |  9 +++++++++
 .../apache/pekko/cluster/typed/PubSubSpec.scala    |  9 +++++++++
 .../ClusterReceptionistUnreachabilitySpec.scala    |  9 +++++++++
 .../ddata/typed/javadsl/ReplicatorDocSample.java   |  9 +++++++++
 .../ddata/typed/javadsl/ReplicatorDocTest.java     |  9 +++++++++
 .../cluster/typed/BasicClusterExampleTest.java     |  9 +++++++++
 .../cluster/typed/PingSerializerExampleTest.java   |  9 +++++++++
 .../pekko/cluster/typed/ReceptionistExample.java   |  9 +++++++++
 .../cluster/typed/SingletonCompileOnlyTest.java    |  9 +++++++++
 .../apache/pekko/cluster/typed/ClusterApiTest.java |  9 +++++++++
 .../ddata/typed/scaladsl/ReplicatorDocSpec.scala   |  9 +++++++++
 .../cluster/typed/BasicClusterExampleSpec.scala    |  9 +++++++++
 .../cluster/typed/DistributedPubSubExample.scala   |  9 +++++++++
 .../pekko/cluster/typed/PingSerializer.scala       |  9 +++++++++
 .../pekko/cluster/typed/ReceptionistExample.scala  |  9 +++++++++
 .../cluster/typed/SingletonCompileOnlySpec.scala   |  9 +++++++++
 .../typed/scaladsl/ReplicatorCompileOnlyTest.scala |  9 +++++++++
 .../ddata/typed/scaladsl/ReplicatorSpec.scala      |  9 +++++++++
 .../typed/ActorRefIgnoreSerializationSpec.scala    |  9 +++++++++
 .../pekko/cluster/typed/ActorSystemSpec.scala      |  9 +++++++++
 .../cluster/typed/ClusterActorLoggingSpec.scala    |  9 +++++++++
 .../pekko/cluster/typed/ClusterApiSpec.scala       |  9 +++++++++
 .../typed/ClusterDispatcherSelectorSpec.scala      |  9 +++++++++
 .../cluster/typed/ClusterSingletonApiSpec.scala    |  9 +++++++++
 .../typed/ClusterSingletonPoisonPillSpec.scala     |  9 +++++++++
 .../pekko/cluster/typed/GroupRouterSpec.scala      |  9 +++++++++
 .../pekko/cluster/typed/RemoteContextAskSpec.scala |  9 +++++++++
 .../cluster/typed/RemoteDeployNotAllowedSpec.scala |  9 +++++++++
 .../pekko/cluster/typed/RemoteMessageSpec.scala    |  9 +++++++++
 .../internal/PekkoClusterTypedSerializerSpec.scala |  9 +++++++++
 .../delivery/ReliableDeliverySerializerSpec.scala  |  9 +++++++++
 .../receptionist/ClusterReceptionistSpec.scala     |  9 +++++++++
 .../ClusterReceptionistStateSpec.scala             |  9 +++++++++
 .../cluster/protobuf/msg/ClusterMessages.java      |  9 +++++++++
 cluster/src/main/protobuf/ClusterMessages.proto    |  9 +++++++++
 .../scala/org/apache/pekko/cluster/Cluster.scala   |  9 +++++++++
 .../pekko/cluster/ClusterActorRefProvider.scala    |  9 +++++++++
 .../org/apache/pekko/cluster/ClusterDaemon.scala   |  9 +++++++++
 .../org/apache/pekko/cluster/ClusterEvent.scala    |  9 +++++++++
 .../apache/pekko/cluster/ClusterHeartbeat.scala    |  9 +++++++++
 .../org/apache/pekko/cluster/ClusterJmx.scala      |  9 +++++++++
 .../org/apache/pekko/cluster/ClusterLogClass.scala |  9 +++++++++
 .../apache/pekko/cluster/ClusterLogMarker.scala    |  9 +++++++++
 .../org/apache/pekko/cluster/ClusterReadView.scala |  9 +++++++++
 .../pekko/cluster/ClusterRemoteWatcher.scala       |  9 +++++++++
 .../org/apache/pekko/cluster/ClusterSettings.scala |  9 +++++++++
 .../pekko/cluster/CoordinatedShutdownLeave.scala   |  9 +++++++++
 .../pekko/cluster/CrossDcClusterHeartbeat.scala    |  9 +++++++++
 .../org/apache/pekko/cluster/DowningProvider.scala |  9 +++++++++
 .../scala/org/apache/pekko/cluster/Gossip.scala    |  9 +++++++++
 .../cluster/JoinConfigCompatCheckCluster.scala     |  9 +++++++++
 .../pekko/cluster/JoinConfigCompatChecker.scala    |  9 +++++++++
 .../scala/org/apache/pekko/cluster/Member.scala    |  9 +++++++++
 .../org/apache/pekko/cluster/MembershipState.scala |  9 +++++++++
 .../org/apache/pekko/cluster/Reachability.scala    |  9 +++++++++
 .../org/apache/pekko/cluster/SeedNodeProcess.scala |  9 +++++++++
 .../org/apache/pekko/cluster/VectorClock.scala     |  9 +++++++++
 .../protobuf/ClusterMessageSerializer.scala        |  9 +++++++++
 .../cluster/routing/ClusterRouterConfig.scala      |  9 +++++++++
 .../apache/pekko/cluster/sbr/DowningStrategy.scala |  9 +++++++++
 .../pekko/cluster/sbr/SplitBrainResolver.scala     |  9 +++++++++
 .../cluster/sbr/SplitBrainResolverProvider.scala   |  9 +++++++++
 .../cluster/sbr/SplitBrainResolverSettings.scala   |  9 +++++++++
 .../cluster/AttemptSysMsgRedeliverySpec.scala      |  9 +++++++++
 .../ClientDowningNodeThatIsUnreachableSpec.scala   |  9 +++++++++
 .../cluster/ClientDowningNodeThatIsUpSpec.scala    |  9 +++++++++
 .../ClusterAccrualFailureDetectorSpec.scala        |  9 +++++++++
 .../pekko/cluster/ClusterDeathWatchSpec.scala      |  9 +++++++++
 .../apache/pekko/cluster/ClusterShutdownSpec.scala |  9 +++++++++
 .../ClusterWatcherNoClusterWatcheeSpec.scala       |  9 +++++++++
 .../org/apache/pekko/cluster/ConvergenceSpec.scala |  9 +++++++++
 .../DeterministicOldestWhenJoiningSpec.scala       |  9 +++++++++
 .../cluster/DisallowJoinOfTwoClustersSpec.scala    |  9 +++++++++
 ...henOtherHasQuarantinedThisActorSystemSpec.scala |  9 +++++++++
 .../pekko/cluster/InitialHeartbeatSpec.scala       |  9 +++++++++
 .../pekko/cluster/InitialMembersOfNewDcSpec.scala  |  9 +++++++++
 .../apache/pekko/cluster/JoinInProgressSpec.scala  |  9 +++++++++
 .../apache/pekko/cluster/JoinSeedNodeSpec.scala    |  9 +++++++++
 .../pekko/cluster/LargeMessageClusterSpec.scala    |  9 +++++++++
 .../cluster/LeaderDowningAllOtherNodesSpec.scala   |  9 +++++++++
 .../LeaderDowningNodeThatIsUnreachableSpec.scala   |  9 +++++++++
 .../apache/pekko/cluster/LeaderElectionSpec.scala  |  9 +++++++++
 .../apache/pekko/cluster/LeaderLeavingSpec.scala   |  9 +++++++++
 .../scala/org/apache/pekko/cluster/MBeanSpec.scala |  9 +++++++++
 .../apache/pekko/cluster/MemberWeaklyUpSpec.scala  |  9 +++++++++
 .../MembershipChangeListenerExitingSpec.scala      |  9 +++++++++
 .../cluster/MembershipChangeListenerUpSpec.scala   |  9 +++++++++
 .../pekko/cluster/MinMembersBeforeUpSpec.scala     |  9 +++++++++
 .../apache/pekko/cluster/MultiDcClusterSpec.scala  |  9 +++++++++
 .../cluster/MultiDcHeartbeatTakingOverSpec.scala   |  9 +++++++++
 .../apache/pekko/cluster/MultiDcJoin2Spec.scala    |  9 +++++++++
 .../org/apache/pekko/cluster/MultiDcJoinSpec.scala |  9 +++++++++
 .../apache/pekko/cluster/MultiDcLastNodeSpec.scala |  9 +++++++++
 .../pekko/cluster/MultiDcSplitBrainSpec.scala      |  9 +++++++++
 .../pekko/cluster/MultiDcSunnyWeatherSpec.scala    |  9 +++++++++
 .../pekko/cluster/MultiNodeClusterSpec.scala       |  9 +++++++++
 .../org/apache/pekko/cluster/NodeChurnSpec.scala   |  9 +++++++++
 .../cluster/NodeDowningAndBeingRemovedSpec.scala   |  9 +++++++++
 .../NodeLeavingAndExitingAndBeingRemovedSpec.scala |  9 +++++++++
 .../pekko/cluster/NodeLeavingAndExitingSpec.scala  |  9 +++++++++
 .../apache/pekko/cluster/NodeMembershipSpec.scala  |  9 +++++++++
 .../org/apache/pekko/cluster/NodeUpSpec.scala      |  9 +++++++++
 .../apache/pekko/cluster/QuickRestartSpec.scala    |  9 +++++++++
 .../cluster/RemoteFeaturesWithClusterSpec.scala    |  9 +++++++++
 .../pekko/cluster/RestartFirstSeedNodeSpec.scala   |  9 +++++++++
 .../apache/pekko/cluster/RestartNode2Spec.scala    |  9 +++++++++
 .../apache/pekko/cluster/RestartNode3Spec.scala    |  9 +++++++++
 .../org/apache/pekko/cluster/RestartNodeSpec.scala |  9 +++++++++
 .../pekko/cluster/SharedMediaDriverSupport.scala   |  9 +++++++++
 .../pekko/cluster/SingletonClusterSpec.scala       |  9 +++++++++
 .../pekko/cluster/SplitBrainQuarantineSpec.scala   |  9 +++++++++
 .../org/apache/pekko/cluster/SplitBrainSpec.scala  |  9 +++++++++
 .../org/apache/pekko/cluster/StreamRefSpec.scala   |  9 +++++++++
 .../org/apache/pekko/cluster/StressSpec.scala      |  9 +++++++++
 .../apache/pekko/cluster/SunnyWeatherSpec.scala    |  9 +++++++++
 .../cluster/SurviveNetworkInstabilitySpec.scala    |  9 +++++++++
 .../org/apache/pekko/cluster/TransitionSpec.scala  |  9 +++++++++
 .../cluster/UnreachableNodeJoinsAgainSpec.scala    |  9 +++++++++
 .../ClusterConsistentHashingGroupSpec.scala        |  9 +++++++++
 .../ClusterConsistentHashingRouterSpec.scala       |  9 +++++++++
 .../cluster/routing/ClusterRoundRobinSpec.scala    |  9 +++++++++
 .../pekko/cluster/routing/UseRoleIgnoredSpec.scala |  9 +++++++++
 .../sbr/DownAllIndirectlyConnected5NodeSpec.scala  |  9 +++++++++
 .../cluster/sbr/DownAllUnstable5NodeSpec.scala     |  9 +++++++++
 .../cluster/sbr/IndirectlyConnected3NodeSpec.scala |  9 +++++++++
 .../cluster/sbr/IndirectlyConnected5NodeSpec.scala |  9 +++++++++
 .../pekko/cluster/sbr/LeaseMajority5NodeSpec.scala |  9 +++++++++
 .../pekko/cluster/ClusterJavaCompileTest.java      |  9 +++++++++
 .../apache/pekko/cluster/ClusterConfigSpec.scala   |  9 +++++++++
 .../ClusterDeathWatchNotificationSpec.scala        |  9 +++++++++
 .../apache/pekko/cluster/ClusterDeployerSpec.scala |  9 +++++++++
 .../cluster/ClusterDomainEventPublisherSpec.scala  |  9 +++++++++
 .../pekko/cluster/ClusterDomainEventSpec.scala     |  9 +++++++++
 .../cluster/ClusterHeartbeatReceiverSpec.scala     |  9 +++++++++
 .../pekko/cluster/ClusterHeartbeatSenderSpec.scala |  9 +++++++++
 .../cluster/ClusterHeartbeatSenderStateSpec.scala  |  9 +++++++++
 .../org/apache/pekko/cluster/ClusterLogSpec.scala  |  9 +++++++++
 .../org/apache/pekko/cluster/ClusterSpec.scala     |  9 +++++++++
 .../org/apache/pekko/cluster/ClusterTestKit.scala  |  9 +++++++++
 .../pekko/cluster/CrossDcHeartbeatSenderSpec.scala |  9 +++++++++
 .../apache/pekko/cluster/DowningProviderSpec.scala |  9 +++++++++
 .../pekko/cluster/FailureDetectorPuppet.scala      |  9 +++++++++
 .../org/apache/pekko/cluster/GossipSpec.scala      |  9 +++++++++
 .../pekko/cluster/GossipTargetSelectorSpec.scala   |  9 +++++++++
 .../pekko/cluster/HeartbeatNodeRingPerfSpec.scala  |  9 +++++++++
 .../pekko/cluster/HeartbeatNodeRingSpec.scala      |  9 +++++++++
 .../cluster/JoinConfigCompatCheckClusterSpec.scala |  9 +++++++++
 .../JoinConfigCompatCheckerRollingUpdateSpec.scala |  9 +++++++++
 .../cluster/JoinConfigCompatCheckerSpec.scala      |  9 +++++++++
 .../JoinConfigCompatPreDefinedChecksSpec.scala     |  9 +++++++++
 .../apache/pekko/cluster/MemberOrderingSpec.scala  |  9 +++++++++
 .../apache/pekko/cluster/MembershipStateSpec.scala |  9 +++++++++
 .../pekko/cluster/ReachabilityPerfSpec.scala       |  9 +++++++++
 .../apache/pekko/cluster/ReachabilitySpec.scala    |  9 +++++++++
 .../cluster/ResetSystemMessageSeqNrSpec.scala      |  9 +++++++++
 .../cluster/ShutdownAfterJoinSeedNodesSpec.scala   |  9 +++++++++
 .../pekko/cluster/StartupWithOneThreadSpec.scala   |  9 +++++++++
 .../org/apache/pekko/cluster/TestMember.scala      |  9 +++++++++
 .../apache/pekko/cluster/VectorClockPerfSpec.scala |  9 +++++++++
 .../org/apache/pekko/cluster/VectorClockSpec.scala |  9 +++++++++
 .../protobuf/ClusterMessageSerializerSpec.scala    |  9 +++++++++
 .../routing/ClusterRouterSupervisorSpec.scala      |  9 +++++++++
 .../pekko/cluster/sbr/LeaseMajoritySpec.scala      |  9 +++++++++
 .../pekko/cluster/sbr/SplitBrainResolverSpec.scala |  9 +++++++++
 .../apache/pekko/cluster/sbr/TestAddresses.scala   |  9 +++++++++
 .../apache/pekko/cluster/testkit/AutoDown.scala    |  9 +++++++++
 .../pekko/cluster/testkit/AutoDownSpec.scala       |  9 +++++++++
 .../pekko/coordination/lease/LeaseException.scala  |  9 +++++++++
 .../pekko/coordination/lease/LeaseSettings.scala   |  9 +++++++++
 .../coordination/lease/LeaseUsageSettings.scala    |  9 +++++++++
 .../pekko/coordination/lease/TimeoutSettings.scala |  9 +++++++++
 .../coordination/lease/internal/LeaseAdapter.scala |  9 +++++++++
 .../pekko/coordination/lease/javadsl/Lease.scala   |  9 +++++++++
 .../coordination/lease/javadsl/LeaseProvider.scala |  9 +++++++++
 .../pekko/coordination/lease/scaladsl/Lease.scala  |  9 +++++++++
 .../lease/scaladsl/LeaseProvider.scala             |  9 +++++++++
 .../lease/javadsl/LeaseProviderTest.java           |  9 +++++++++
 .../pekko/coordination/lease/TestLease.scala       |  9 +++++++++
 .../pekko/coordination/lease/TestLeaseActor.scala  |  9 +++++++++
 .../coordination/lease/TimeoutSettingsSpec.scala   |  9 +++++++++
 .../lease/scaladsl/LeaseProviderSpec.scala         |  9 +++++++++
 .../org/apache/pekko/discovery/Discovery.scala     |  9 +++++++++
 .../apache/pekko/discovery/ServiceDiscovery.scala  |  9 +++++++++
 .../aggregate/AggregateServiceDiscovery.scala      |  9 +++++++++
 .../discovery/config/ConfigServiceDiscovery.scala  |  9 +++++++++
 .../pekko/discovery/dns/DnsServiceDiscovery.scala  |  9 +++++++++
 .../apache/pekko/discovery/CompileOnlyTest.java    |  9 +++++++++
 .../apache/pekko/discovery/CompileOnlySpec.scala   |  9 +++++++++
 .../discovery/DiscoveryConfigurationSpec.scala     |  9 +++++++++
 .../org/apache/pekko/discovery/LookupSpec.scala    |  9 +++++++++
 .../aggregate/AggregateServiceDiscoverySpec.scala  |  9 +++++++++
 .../config/ConfigServiceDiscoverySpec.scala        |  9 +++++++++
 .../config/ConfigServicesParserSpec.scala          |  9 +++++++++
 .../pekko/discovery/dns/DnsDiscoverySpec.scala     |  9 +++++++++
 .../discovery/dns/DnsServiceDiscoverySpec.scala    |  9 +++++++++
 .../ddata/protobuf/msg/ReplicatedDataMessages.java |  9 +++++++++
 .../ddata/protobuf/msg/ReplicatorMessages.java     |  9 +++++++++
 .../src/main/protobuf/ReplicatedDataMessages.proto |  9 +++++++++
 .../src/main/protobuf/ReplicatorMessages.proto     |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/GSet.scala      |  9 +++++++++
 .../cluster/ddata/DeltaPropagationSelector.scala   |  9 +++++++++
 .../pekko/cluster/ddata/DistributedData.scala      |  9 +++++++++
 .../apache/pekko/cluster/ddata/DurableStore.scala  |  9 +++++++++
 .../apache/pekko/cluster/ddata/EstimatedSize.scala |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/FastMerge.scala |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/Flag.scala      |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/GCounter.scala  |  9 +++++++++
 .../scala/org/apache/pekko/cluster/ddata/Key.scala |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/LWWMap.scala    |  9 +++++++++
 .../apache/pekko/cluster/ddata/LWWRegister.scala   |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/ORMap.scala     |  9 +++++++++
 .../apache/pekko/cluster/ddata/ORMultiMap.scala    |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/ORSet.scala     |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/PNCounter.scala |  9 +++++++++
 .../apache/pekko/cluster/ddata/PNCounterMap.scala  |  9 +++++++++
 .../cluster/ddata/PayloadSizeAggregator.scala      |  9 +++++++++
 .../apache/pekko/cluster/ddata/PruningState.scala  |  9 +++++++++
 .../pekko/cluster/ddata/ReplicatedData.scala       |  9 +++++++++
 .../apache/pekko/cluster/ddata/Replicator.scala    |  9 +++++++++
 .../apache/pekko/cluster/ddata/VersionVector.scala |  9 +++++++++
 .../ddata/protobuf/ReplicatedDataSerializer.scala  |  9 +++++++++
 .../protobuf/ReplicatorMessageSerializer.scala     |  9 +++++++++
 .../ddata/protobuf/SerializationSupport.scala      |  9 +++++++++
 .../pekko/cluster/ddata/DurableDataSpec.scala      |  9 +++++++++
 .../pekko/cluster/ddata/DurablePruningSpec.scala   |  9 +++++++++
 .../cluster/ddata/JepsenInspiredInsertSpec.scala   |  9 +++++++++
 .../pekko/cluster/ddata/PerformanceSpec.scala      |  9 +++++++++
 .../pekko/cluster/ddata/ReplicatorChaosSpec.scala  |  9 +++++++++
 .../pekko/cluster/ddata/ReplicatorDeltaSpec.scala  |  9 +++++++++
 .../pekko/cluster/ddata/ReplicatorGossipSpec.scala |  9 +++++++++
 .../cluster/ddata/ReplicatorMapDeltaSpec.scala     |  9 +++++++++
 .../cluster/ddata/ReplicatorORSetDeltaSpec.scala   |  9 +++++++++
 .../cluster/ddata/ReplicatorPruningSpec.scala      |  9 +++++++++
 .../pekko/cluster/ddata/ReplicatorSpec.scala       |  9 +++++++++
 .../pekko/cluster/ddata/STMultiNodeSpec.scala      |  9 +++++++++
 .../ddata/JavaImplOfDeltaReplicatedData.java       |  9 +++++++++
 .../ddata/JavaImplOfDeltaReplicatedData2.java      |  9 +++++++++
 .../cluster/ddata/JavaImplOfReplicatedData.java    |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/ORMapTest.java  |  9 +++++++++
 .../apache/pekko/cluster/ddata/ORMultiMapTest.java |  9 +++++++++
 .../apache/pekko/cluster/ddata/PNCounterTest.java  |  9 +++++++++
 .../pekko/cluster/ddata/DataEnvelopeSpec.scala     |  9 +++++++++
 .../ddata/DeltaPropagationSelectorSpec.scala       |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/FlagSpec.scala  |  9 +++++++++
 .../apache/pekko/cluster/ddata/GCounterSpec.scala  |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/GSetSpec.scala  |  9 +++++++++
 .../apache/pekko/cluster/ddata/LWWMapSpec.scala    |  9 +++++++++
 .../pekko/cluster/ddata/LWWRegisterSpec.scala      |  9 +++++++++
 .../pekko/cluster/ddata/LocalConcurrencySpec.scala |  9 +++++++++
 .../apache/pekko/cluster/ddata/LotsOfDataBot.scala |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/ORMapSpec.scala |  9 +++++++++
 .../pekko/cluster/ddata/ORMultiMapSpec.scala       |  9 +++++++++
 .../org/apache/pekko/cluster/ddata/ORSetSpec.scala |  9 +++++++++
 .../pekko/cluster/ddata/PNCounterMapSpec.scala     |  9 +++++++++
 .../apache/pekko/cluster/ddata/PNCounterSpec.scala |  9 +++++++++
 .../pekko/cluster/ddata/PruningStateSpec.scala     |  9 +++++++++
 .../cluster/ddata/ReplicatorSettingsSpec.scala     |  9 +++++++++
 .../pekko/cluster/ddata/VersionVectorSpec.scala    |  9 +++++++++
 .../pekko/cluster/ddata/WriteAggregatorSpec.scala  |  9 +++++++++
 .../protobuf/ReplicatedDataSerializerSpec.scala    |  9 +++++++++
 .../protobuf/ReplicatorMessageSerializerSpec.scala |  9 +++++++++
 .../ddata/protobuf/msg/TwoPhaseSetMessages.java    |  9 +++++++++
 .../docs/persistence/proto/FlightAppModels.java    |  9 +++++++++
 docs/src/main/protobuf/FlightAppModels.proto       |  9 +++++++++
 docs/src/main/protobuf/TwoPhaseSetMessages.proto   |  9 +++++++++
 .../stream/operators/source/AsSubscriber.java      |  9 +++++++++
 .../stream/operators/source/FromPublisher.java     |  9 +++++++++
 docs/src/test/java/jdocs/AbstractJavaTest.java     |  9 +++++++++
 docs/src/test/java/jdocs/actor/ActorDocTest.java   |  9 +++++++++
 .../jdocs/actor/ByteBufferSerializerDocTest.java   |  9 +++++++++
 .../jdocs/actor/DependencyInjectionDocTest.java    |  9 +++++++++
 .../java/jdocs/actor/FaultHandlingDocSample.java   |  9 +++++++++
 .../test/java/jdocs/actor/FaultHandlingTest.java   |  9 +++++++++
 .../test/java/jdocs/actor/GraduallyBuiltActor.java |  9 +++++++++
 .../test/java/jdocs/actor/ImmutableMessage.java    |  9 +++++++++
 .../java/jdocs/actor/InitializationDocTest.java    |  9 +++++++++
 docs/src/test/java/jdocs/actor/Messages.java       |  9 +++++++++
 docs/src/test/java/jdocs/actor/MyActor.java        |  9 +++++++++
 docs/src/test/java/jdocs/actor/MyBoundedActor.java |  9 +++++++++
 .../src/test/java/jdocs/actor/MyStoppingActor.java |  9 +++++++++
 docs/src/test/java/jdocs/actor/SampleActor.java    |  9 +++++++++
 .../src/test/java/jdocs/actor/SampleActorTest.java |  9 +++++++++
 .../test/java/jdocs/actor/SchedulerDocTest.java    |  9 +++++++++
 docs/src/test/java/jdocs/actor/TimerDocTest.java   |  9 +++++++++
 docs/src/test/java/jdocs/actor/fsm/Buncher.java    |  9 +++++++++
 .../src/test/java/jdocs/actor/fsm/BuncherTest.java |  9 +++++++++
 docs/src/test/java/jdocs/actor/fsm/Events.java     |  9 +++++++++
 docs/src/test/java/jdocs/actor/fsm/FSMDocTest.java |  9 +++++++++
 .../jdocs/actor/io/dns/DnsCompileOnlyDocTest.java  |  9 +++++++++
 .../test/java/jdocs/actor/typed/BlockingActor.java |  9 +++++++++
 .../jdocs/actor/typed/BlockingDispatcherTest.java  |  9 +++++++++
 .../actor/typed/CoordinatedActorShutdownTest.java  |  9 +++++++++
 .../java/jdocs/actor/typed/DispatcherDocTest.java  |  9 +++++++++
 .../test/java/jdocs/actor/typed/PrintActor.java    |  9 +++++++++
 .../SeparateDispatcherCompletionStageActor.java    |  9 +++++++++
 .../actor/typed/SharedMutableStateDocTest.java     |  9 +++++++++
 .../jdocs/circuitbreaker/DangerousJavaActor.java   |  9 +++++++++
 .../circuitbreaker/EvenNoFailureJavaExample.java   |  9 +++++++++
 .../jdocs/circuitbreaker/TellPatternJavaActor.java |  9 +++++++++
 .../test/java/jdocs/cluster/ClusterDocTest.java    |  9 +++++++++
 .../test/java/jdocs/cluster/FactorialBackend.java  |  9 +++++++++
 .../test/java/jdocs/cluster/FactorialFrontend.java |  9 +++++++++
 .../java/jdocs/cluster/FactorialFrontendMain.java  |  9 +++++++++
 .../test/java/jdocs/cluster/FactorialResult.java   |  9 +++++++++
 .../test/java/jdocs/cluster/MetricsListener.java   |  9 +++++++++
 .../java/jdocs/cluster/SimpleClusterListener.java  |  9 +++++++++
 .../java/jdocs/cluster/SimpleClusterListener2.java |  9 +++++++++
 .../test/java/jdocs/cluster/StatsAggregator.java   |  9 +++++++++
 .../src/test/java/jdocs/cluster/StatsMessages.java |  9 +++++++++
 .../test/java/jdocs/cluster/StatsSampleClient.java |  9 +++++++++
 .../cluster/StatsSampleOneMasterClientMain.java    |  9 +++++++++
 .../jdocs/cluster/StatsSampleOneMasterMain.java    |  9 +++++++++
 docs/src/test/java/jdocs/cluster/StatsService.java |  9 +++++++++
 docs/src/test/java/jdocs/cluster/StatsWorker.java  |  9 +++++++++
 .../java/jdocs/cluster/TransformationBackend.java  |  9 +++++++++
 .../java/jdocs/cluster/TransformationFrontend.java |  9 +++++++++
 .../java/jdocs/cluster/TransformationMessages.java |  9 +++++++++
 .../singleton/ClusterSingletonSupervision.java     |  9 +++++++++
 .../jdocs/cluster/singleton/SupervisorActor.java   |  9 +++++++++
 docs/src/test/java/jdocs/config/ConfigDocTest.java |  9 +++++++++
 .../test/java/jdocs/coordination/LeaseDocTest.java |  9 +++++++++
 docs/src/test/java/jdocs/ddata/DataBot.java        |  9 +++++++++
 .../java/jdocs/ddata/DistributedDataDocTest.java   |  9 +++++++++
 docs/src/test/java/jdocs/ddata/ShoppingCart.java   |  9 +++++++++
 docs/src/test/java/jdocs/ddata/TwoPhaseSet.java    |  9 +++++++++
 .../ddata/protobuf/TwoPhaseSetSerializer.java      |  9 +++++++++
 .../ddata/protobuf/TwoPhaseSetSerializer2.java     |  9 +++++++++
 .../TwoPhaseSetSerializerWithCompression.java      |  9 +++++++++
 .../java/jdocs/discovery/DnsDiscoveryDocTest.java  |  9 +++++++++
 .../java/jdocs/dispatcher/DispatcherDocTest.java   |  9 +++++++++
 .../java/jdocs/dispatcher/MyUnboundedMailbox.java  |  9 +++++++++
 .../MyUnboundedMessageQueueSemantics.java          |  9 +++++++++
 docs/src/test/java/jdocs/duration/Java.java        |  9 +++++++++
 .../src/test/java/jdocs/event/EventBusDocTest.java |  9 +++++++++
 docs/src/test/java/jdocs/event/LoggingDocTest.java |  9 +++++++++
 .../java/jdocs/extension/ExtensionDocTest.java     |  9 +++++++++
 .../jdocs/extension/SettingsExtensionDocTest.java  |  9 +++++++++
 .../test/java/jdocs/future/ActorWithFuture.java    |  9 +++++++++
 docs/src/test/java/jdocs/future/FutureDocTest.java |  9 +++++++++
 docs/src/test/java/jdocs/io/IODocTest.java         |  9 +++++++++
 .../test/java/jdocs/io/JavaReadBackPressure.java   |  9 +++++++++
 docs/src/test/java/jdocs/io/JavaUdpMulticast.java  |  9 +++++++++
 .../test/java/jdocs/io/JavaUdpMulticastTest.java   |  9 +++++++++
 .../test/java/jdocs/io/UdpConnectedDocTest.java    |  9 +++++++++
 docs/src/test/java/jdocs/io/UdpDocTest.java        |  9 +++++++++
 docs/src/test/java/jdocs/io/japi/EchoHandler.java  |  9 +++++++++
 docs/src/test/java/jdocs/io/japi/EchoManager.java  |  9 +++++++++
 docs/src/test/java/jdocs/io/japi/EchoServer.java   |  9 +++++++++
 docs/src/test/java/jdocs/io/japi/IODocTest.java    |  9 +++++++++
 docs/src/test/java/jdocs/io/japi/Message.java      |  9 +++++++++
 .../test/java/jdocs/io/japi/SimpleEchoHandler.java |  9 +++++++++
 docs/src/test/java/jdocs/io/japi/Watcher.java      |  9 +++++++++
 .../jdocs/pattern/BackoffSupervisorDocTest.java    |  9 +++++++++
 .../src/test/java/jdocs/pattern/SupervisedAsk.java |  9 +++++++++
 .../test/java/jdocs/pattern/SupervisedAskSpec.java |  9 +++++++++
 .../persistence/LambdaPersistenceDocTest.java      |  9 +++++++++
 .../LambdaPersistencePluginDocTest.java            |  9 +++++++++
 .../PersistenceEventAdapterDocTest.java            |  9 +++++++++
 .../jdocs/persistence/PersistenceMultiDocTest.java |  9 +++++++++
 .../jdocs/persistence/PersistenceQueryDocTest.java |  9 +++++++++
 .../PersistenceSchemaEvolutionDocTest.java         |  9 +++++++++
 .../jdocs/persistence/PersistentActorExample.java  |  9 +++++++++
 .../query/LeveldbPersistenceQueryDocTest.java      |  9 +++++++++
 .../persistence/query/MyEventsByTagSource.java     |  9 +++++++++
 .../jdocs/persistence/testkit/Configuration.java   |  9 +++++++++
 .../persistence/testkit/PersistenceInitTest.java   |  9 +++++++++
 .../PersistenceTestKitPolicySampleTest.java        |  9 +++++++++
 .../testkit/PersistenceTestKitSampleTest.java      |  9 +++++++++
 .../jdocs/persistence/testkit/TestKitExamples.java |  9 +++++++++
 .../jdocs/remoting/RemoteDeploymentDocTest.java    |  9 +++++++++
 .../routing/ConsistentHashingRouterDocTest.java    |  9 +++++++++
 .../java/jdocs/routing/CustomRouterDocTest.java    |  9 +++++++++
 .../test/java/jdocs/routing/RedundancyGroup.java   |  9 +++++++++
 .../src/test/java/jdocs/routing/RouterDocTest.java |  9 +++++++++
 .../jdocs/serialization/SerializationDocTest.java  |  9 +++++++++
 .../java/jdocs/sharding/ClusterShardingTest.java   |  9 +++++++++
 .../test/java/jdocs/stream/BidiFlowDocTest.java    |  9 +++++++++
 .../test/java/jdocs/stream/CompositionDocTest.java |  9 +++++++++
 docs/src/test/java/jdocs/stream/FlowDocTest.java   |  9 +++++++++
 .../test/java/jdocs/stream/FlowErrorDocTest.java   |  9 +++++++++
 .../java/jdocs/stream/FlowParallelismDocTest.java  |  9 +++++++++
 .../java/jdocs/stream/FlowStreamRefsDocTest.java   |  9 +++++++++
 .../test/java/jdocs/stream/GraphCyclesDocTest.java |  9 +++++++++
 .../test/java/jdocs/stream/GraphStageDocTest.java  |  9 +++++++++
 .../jdocs/stream/GraphStageLoggingDocTest.java     |  9 +++++++++
 docs/src/test/java/jdocs/stream/HubDocTest.java    |  9 +++++++++
 .../test/java/jdocs/stream/IntegrationDocTest.java |  9 +++++++++
 .../test/java/jdocs/stream/KillSwitchDocTest.java  |  9 +++++++++
 docs/src/test/java/jdocs/stream/Main.java          |  9 +++++++++
 .../src/test/java/jdocs/stream/MigrationsJava.java |  9 +++++++++
 .../test/java/jdocs/stream/QuickStartDocTest.java  |  9 +++++++++
 .../jdocs/stream/RateTransformationDocTest.java    |  9 +++++++++
 .../java/jdocs/stream/ReactiveStreamsDocTest.java  |  9 +++++++++
 .../src/test/java/jdocs/stream/RestartDocTest.java |  9 +++++++++
 .../test/java/jdocs/stream/SilenceSystemOut.java   |  9 +++++++++
 .../test/java/jdocs/stream/SinkRecipeDocTest.java  |  9 +++++++++
 .../jdocs/stream/StreamBuffersRateDocTest.java     |  9 +++++++++
 .../jdocs/stream/StreamPartialGraphDSLDocTest.java |  9 +++++++++
 .../java/jdocs/stream/StreamTestKitDocTest.java    |  9 +++++++++
 .../test/java/jdocs/stream/SubstreamDocTest.java   |  9 +++++++++
 .../stream/TwitterStreamQuickstartDocTest.java     |  9 +++++++++
 .../java/jdocs/stream/io/StreamFileDocTest.java    |  9 +++++++++
 .../java/jdocs/stream/io/StreamTcpDocTest.java     |  9 +++++++++
 .../javadsl/cookbook/RecipeAdhocSourceTest.java    |  9 +++++++++
 .../stream/javadsl/cookbook/RecipeByteStrings.java |  9 +++++++++
 .../stream/javadsl/cookbook/RecipeDecompress.java  |  9 +++++++++
 .../stream/javadsl/cookbook/RecipeDigest.java      |  9 +++++++++
 .../javadsl/cookbook/RecipeDroppyBroadcast.java    |  9 +++++++++
 .../stream/javadsl/cookbook/RecipeFlattenList.java |  9 +++++++++
 .../javadsl/cookbook/RecipeGlobalRateLimit.java    |  9 +++++++++
 .../jdocs/stream/javadsl/cookbook/RecipeHold.java  |  9 +++++++++
 .../stream/javadsl/cookbook/RecipeKeepAlive.java   |  9 +++++++++
 .../javadsl/cookbook/RecipeLoggingElements.java    |  9 +++++++++
 .../javadsl/cookbook/RecipeManualTrigger.java      |  9 +++++++++
 .../stream/javadsl/cookbook/RecipeMissedTicks.java |  9 +++++++++
 .../javadsl/cookbook/RecipeMultiGroupByTest.java   |  9 +++++++++
 .../stream/javadsl/cookbook/RecipeParseLines.java  |  9 +++++++++
 .../javadsl/cookbook/RecipeReduceByKeyTest.java    |  9 +++++++++
 .../jdocs/stream/javadsl/cookbook/RecipeSeq.java   |  9 +++++++++
 .../stream/javadsl/cookbook/RecipeSimpleDrop.java  |  9 +++++++++
 .../javadsl/cookbook/RecipeSourceFromFunction.java |  9 +++++++++
 .../stream/javadsl/cookbook/RecipeSplitter.java    |  9 +++++++++
 .../jdocs/stream/javadsl/cookbook/RecipeTest.java  |  9 +++++++++
 .../stream/javadsl/cookbook/RecipeWorkerPool.java  |  9 +++++++++
 .../stream/operators/BroadcastDocExample.java      |  9 +++++++++
 .../stream/operators/MergeSequenceDocExample.java  |  9 +++++++++
 .../stream/operators/PartitionDocExample.java      |  9 +++++++++
 .../jdocs/stream/operators/SinkDocExamples.java    |  9 +++++++++
 .../jdocs/stream/operators/SourceDocExamples.java  |  9 +++++++++
 .../java/jdocs/stream/operators/SourceOrFlow.java  |  9 +++++++++
 .../jdocs/stream/operators/WithContextTest.java    |  9 +++++++++
 .../converters/StreamConvertersToJava.java         |  9 +++++++++
 .../operators/converters/ToFromJavaIOStreams.java  |  9 +++++++++
 .../stream/operators/flow/FromSinkAndSource.java   |  9 +++++++++
 .../jdocs/stream/operators/flow/FutureFlow.java    |  9 +++++++++
 .../java/jdocs/stream/operators/flow/Lazy.java     |  9 +++++++++
 .../jdocs/stream/operators/flow/StatefulMap.java   |  9 +++++++++
 .../stream/operators/flow/StatefulMapConcat.java   |  9 +++++++++
 .../java/jdocs/stream/operators/sink/Lazy.java     |  9 +++++++++
 .../jdocs/stream/operators/source/Combine.java     |  9 +++++++++
 .../operators/source/CompletionStageSource.java    |  9 +++++++++
 .../java/jdocs/stream/operators/source/From.java   |  9 +++++++++
 .../operators/source/FromCompletionStage.java      |  9 +++++++++
 .../java/jdocs/stream/operators/source/Lazy.java   |  9 +++++++++
 .../jdocs/stream/operators/source/Restart.java     |  9 +++++++++
 .../java/jdocs/stream/operators/source/Tick.java   |  9 +++++++++
 .../java/jdocs/stream/operators/source/Unfold.java |  9 +++++++++
 .../jdocs/stream/operators/source/UnfoldAsync.java |  9 +++++++++
 .../stream/operators/source/UnfoldResource.java    |  9 +++++++++
 .../operators/source/UnfoldResourceAsync.java      |  9 +++++++++
 .../java/jdocs/stream/operators/source/Zip.java    |  9 +++++++++
 .../sourceorflow/ExtrapolateAndExpand.java         |  9 +++++++++
 .../operators/sourceorflow/FlatMapConcat.java      |  9 +++++++++
 .../operators/sourceorflow/FlatMapMerge.java       |  9 +++++++++
 .../stream/operators/sourceorflow/Intersperse.java |  9 +++++++++
 .../jdocs/stream/operators/sourceorflow/Limit.java |  9 +++++++++
 .../operators/sourceorflow/LimitWeighted.java      |  9 +++++++++
 .../stream/operators/sourceorflow/MapAsyncs.java   |  9 +++++++++
 .../stream/operators/sourceorflow/MapConcat.java   |  9 +++++++++
 .../stream/operators/sourceorflow/MapError.java    |  9 +++++++++
 .../stream/operators/sourceorflow/MergeLatest.java |  9 +++++++++
 .../stream/operators/sourceorflow/Monitor.java     |  9 +++++++++
 .../stream/operators/sourceorflow/Sliding.java     |  9 +++++++++
 .../jdocs/stream/operators/sourceorflow/Split.java |  9 +++++++++
 .../stream/operators/sourceorflow/Throttle.java    |  9 +++++++++
 .../test/java/jdocs/testkit/ParentChildTest.java   |  9 +++++++++
 .../test/java/jdocs/testkit/TestKitDocTest.java    |  9 +++++++++
 .../test/java/jdocs/testkit/TestKitSampleTest.java |  9 +++++++++
 .../tutorial_1/ActorHierarchyExperiments.java      |  9 +++++++++
 .../test/java/jdocs/typed/tutorial_2/IotMain.java  |  9 +++++++++
 .../java/jdocs/typed/tutorial_2/IotSupervisor.java |  9 +++++++++
 .../test/java/jdocs/typed/tutorial_3/Device.java   |  9 +++++++++
 .../java/jdocs/typed/tutorial_3/DeviceTest.java    |  9 +++++++++
 .../jdocs/typed/tutorial_3/inprogress1/Device.java |  9 +++++++++
 .../jdocs/typed/tutorial_3/inprogress2/Device.java |  9 +++++++++
 .../jdocs/typed/tutorial_3/inprogress3/Device.java |  9 +++++++++
 .../test/java/jdocs/typed/tutorial_4/Device.java   |  9 +++++++++
 .../java/jdocs/typed/tutorial_4/DeviceGroup.java   |  9 +++++++++
 .../jdocs/typed/tutorial_4/DeviceGroupTest.java    |  9 +++++++++
 .../java/jdocs/typed/tutorial_4/DeviceManager.java |  9 +++++++++
 .../jdocs/typed/tutorial_4/DeviceManagerTest.java  |  9 +++++++++
 .../java/jdocs/typed/tutorial_4/DeviceTest.java    |  9 +++++++++
 .../test/java/jdocs/typed/tutorial_5/Device.java   |  9 +++++++++
 .../java/jdocs/typed/tutorial_5/DeviceGroup.java   |  9 +++++++++
 .../jdocs/typed/tutorial_5/DeviceGroupQuery.java   |  9 +++++++++
 .../typed/tutorial_5/DeviceGroupQueryTest.java     |  9 +++++++++
 .../jdocs/typed/tutorial_5/DeviceGroupTest.java    |  9 +++++++++
 .../java/jdocs/typed/tutorial_5/DeviceManager.java |  9 +++++++++
 .../jdocs/typed/tutorial_5/DeviceManagerTest.java  |  9 +++++++++
 .../java/jdocs/typed/tutorial_5/DeviceTest.java    |  9 +++++++++
 .../stream/operators/source/AsSubscriber.scala     |  9 +++++++++
 .../stream/operators/source/FromPublisher.scala    |  9 +++++++++
 docs/src/test/scala/docs/CompileOnlySpec.scala     |  9 +++++++++
 docs/src/test/scala/docs/actor/ActorDocSpec.scala  |  9 +++++++++
 .../docs/actor/ByteBufferSerializerDocSpec.scala   |  9 +++++++++
 docs/src/test/scala/docs/actor/FSMDocSpec.scala    |  9 +++++++++
 .../scala/docs/actor/FaultHandlingDocSample.scala  |  9 +++++++++
 .../scala/docs/actor/FaultHandlingDocSpec.scala    |  9 +++++++++
 .../scala/docs/actor/InitializationDocSpec.scala   |  9 +++++++++
 .../test/scala/docs/actor/PropsEdgeCaseSpec.scala  |  9 +++++++++
 .../test/scala/docs/actor/SchedulerDocSpec.scala   |  9 +++++++++
 .../docs/actor/SharedMutableStateDocSpec.scala     |  9 +++++++++
 docs/src/test/scala/docs/actor/TimerDocSpec.scala  |  9 +++++++++
 .../test/scala/docs/actor/UnnestedReceives.scala   |  9 +++++++++
 .../docs/actor/io/dns/DnsCompileOnlyDocSpec.scala  |  9 +++++++++
 .../scala/docs/actor/typed/BlockingActor.scala     |  9 +++++++++
 .../actor/typed/BlockingDispatcherSample.scala     |  9 +++++++++
 .../actor/typed/CoordinatedActorShutdownSpec.scala |  9 +++++++++
 .../scala/docs/actor/typed/DispatcherDocSpec.scala |  9 +++++++++
 .../test/scala/docs/actor/typed/PrintActor.scala   |  9 +++++++++
 .../actor/typed/SharedMutableStateDocSpec.scala    |  9 +++++++++
 .../circuitbreaker/CircuitBreakerDocSpec.scala     |  9 +++++++++
 .../test/scala/docs/cluster/ClusterDocSpec.scala   |  9 +++++++++
 .../test/scala/docs/cluster/FactorialBackend.scala |  9 +++++++++
 .../scala/docs/cluster/FactorialFrontend.scala     |  9 +++++++++
 .../test/scala/docs/cluster/MetricsListener.scala  |  9 +++++++++
 .../scala/docs/cluster/SimpleClusterListener.scala |  9 +++++++++
 .../docs/cluster/SimpleClusterListener2.scala      |  9 +++++++++
 .../scala/docs/cluster/TransformationBackend.scala |  9 +++++++++
 .../docs/cluster/TransformationFrontend.scala      |  9 +++++++++
 .../docs/cluster/TransformationMessages.scala      |  9 +++++++++
 .../singleton/ClusterSingletonSupervision.scala    |  9 +++++++++
 .../src/test/scala/docs/config/ConfigDocSpec.scala |  9 +++++++++
 .../scala/docs/coordination/LeaseDocSpec.scala     |  9 +++++++++
 .../scala/docs/ddata/DistributedDataDocSpec.scala  |  9 +++++++++
 docs/src/test/scala/docs/ddata/ShoppingCart.scala  |  9 +++++++++
 docs/src/test/scala/docs/ddata/TwoPhaseSet.scala   |  9 +++++++++
 .../ddata/protobuf/TwoPhaseSetSerializer.scala     |  9 +++++++++
 .../ddata/protobuf/TwoPhaseSetSerializer2.scala    |  9 +++++++++
 .../scala/docs/discovery/DnsDiscoveryDocSpec.scala |  9 +++++++++
 .../scala/docs/dispatcher/DispatcherDocSpec.scala  |  9 +++++++++
 .../scala/docs/dispatcher/MyUnboundedMailbox.scala |  9 +++++++++
 docs/src/test/scala/docs/duration/Sample.scala     |  9 +++++++++
 .../test/scala/docs/event/EventBusDocSpec.scala    |  9 +++++++++
 .../src/test/scala/docs/event/LoggingDocSpec.scala |  9 +++++++++
 .../scala/docs/extension/ExtensionDocSpec.scala    |  9 +++++++++
 .../docs/extension/SettingsExtensionDocSpec.scala  |  9 +++++++++
 docs/src/test/scala/docs/faq/Faq.scala             |  9 +++++++++
 .../src/test/scala/docs/future/FutureDocSpec.scala |  9 +++++++++
 docs/src/test/scala/docs/io/EchoServer.scala       |  9 +++++++++
 docs/src/test/scala/docs/io/IODocSpec.scala        |  9 +++++++++
 docs/src/test/scala/docs/io/ReadBackPressure.scala |  9 +++++++++
 .../src/test/scala/docs/io/ScalaUdpMulticast.scala |  9 +++++++++
 .../test/scala/docs/io/ScalaUdpMulticastSpec.scala |  9 +++++++++
 docs/src/test/scala/docs/io/UdpDocSpec.scala       |  9 +++++++++
 .../docs/pattern/BackoffSupervisorDocSpec.scala    |  9 +++++++++
 .../docs/persistence/PersistenceDocSpec.scala      |  9 +++++++++
 .../PersistenceEventAdapterDocSpec.scala           |  9 +++++++++
 .../docs/persistence/PersistenceMultiDocSpec.scala |  9 +++++++++
 .../persistence/PersistencePluginDocSpec.scala     |  9 +++++++++
 .../PersistenceSchemaEvolutionDocSpec.scala        |  9 +++++++++
 .../persistence/PersistenceSerializerDocSpec.scala |  9 +++++++++
 .../docs/persistence/PersistentActorExample.scala  |  9 +++++++++
 .../query/LeveldbPersistenceQueryDocSpec.scala     |  9 +++++++++
 .../persistence/query/MyEventsByTagSource.scala    |  9 +++++++++
 .../query/PersistenceQueryDocSpec.scala            |  9 +++++++++
 .../docs/persistence/testkit/Configuration.scala   |  9 +++++++++
 .../persistence/testkit/PersistenceInitSpec.scala  |  9 +++++++++
 .../docs/persistence/testkit/TestKitExamples.scala |  9 +++++++++
 .../docs/remoting/RemoteDeploymentDocSpec.scala    |  9 +++++++++
 .../routing/ConsistentHashingRouterDocSpec.scala   |  9 +++++++++
 .../scala/docs/routing/CustomRouterDocSpec.scala   |  9 +++++++++
 .../test/scala/docs/routing/RouterDocSpec.scala    |  9 +++++++++
 .../docs/serialization/SerializationDocSpec.scala  |  9 +++++++++
 .../test/scala/docs/stream/BidiFlowDocSpec.scala   |  9 +++++++++
 .../scala/docs/stream/CompositionDocSpec.scala     |  9 +++++++++
 docs/src/test/scala/docs/stream/FlowDocSpec.scala  |  9 +++++++++
 .../test/scala/docs/stream/FlowErrorDocSpec.scala  |  9 +++++++++
 .../scala/docs/stream/FlowParallelismDocSpec.scala |  9 +++++++++
 .../scala/docs/stream/FlowStreamRefsDocSpec.scala  |  9 +++++++++
 .../test/scala/docs/stream/GraphCyclesSpec.scala   |  9 +++++++++
 .../test/scala/docs/stream/GraphDSLDocSpec.scala   |  9 +++++++++
 .../test/scala/docs/stream/GraphStageDocSpec.scala |  9 +++++++++
 .../docs/stream/GraphStageLoggingDocSpec.scala     |  9 +++++++++
 docs/src/test/scala/docs/stream/HubsDocSpec.scala  |  9 +++++++++
 .../scala/docs/stream/IntegrationDocSpec.scala     |  9 +++++++++
 .../test/scala/docs/stream/KillSwitchDocSpec.scala |  9 +++++++++
 .../test/scala/docs/stream/MigrationsScala.scala   |  9 +++++++++
 .../test/scala/docs/stream/QuickStartDocSpec.scala |  9 +++++++++
 .../docs/stream/RateTransformationDocSpec.scala    |  9 +++++++++
 .../scala/docs/stream/ReactiveStreamsDocSpec.scala |  9 +++++++++
 .../test/scala/docs/stream/RestartDocSpec.scala    |  9 +++++++++
 .../test/scala/docs/stream/SinkRecipeDocSpec.scala |  9 +++++++++
 .../scala/docs/stream/StreamBuffersRateSpec.scala  |  9 +++++++++
 .../docs/stream/StreamPartialGraphDSLDocSpec.scala |  9 +++++++++
 .../scala/docs/stream/StreamTestKitDocSpec.scala   |  9 +++++++++
 .../test/scala/docs/stream/SubstreamDocSpec.scala  |  9 +++++++++
 .../stream/TwitterStreamQuickstartDocSpec.scala    |  9 +++++++++
 .../docs/stream/cookbook/RecipeAdhocSource.scala   |  9 +++++++++
 .../docs/stream/cookbook/RecipeByteStrings.scala   |  9 +++++++++
 .../stream/cookbook/RecipeCollectingMetrics.scala  |  9 +++++++++
 .../docs/stream/cookbook/RecipeDecompress.scala    |  9 +++++++++
 .../scala/docs/stream/cookbook/RecipeDigest.scala  |  9 +++++++++
 .../stream/cookbook/RecipeDroppyBroadcast.scala    |  9 +++++++++
 .../docs/stream/cookbook/RecipeFlattenSeq.scala    |  9 +++++++++
 .../stream/cookbook/RecipeGlobalRateLimit.scala    |  9 +++++++++
 .../scala/docs/stream/cookbook/RecipeHold.scala    |  9 +++++++++
 .../docs/stream/cookbook/RecipeKeepAlive.scala     |  9 +++++++++
 .../stream/cookbook/RecipeLoggingElements.scala    |  9 +++++++++
 .../docs/stream/cookbook/RecipeManualTrigger.scala |  9 +++++++++
 .../docs/stream/cookbook/RecipeMissedTicks.scala   |  9 +++++++++
 .../docs/stream/cookbook/RecipeMultiGroupBy.scala  |  9 +++++++++
 .../docs/stream/cookbook/RecipeParseLines.scala    |  9 +++++++++
 .../docs/stream/cookbook/RecipeReduceByKey.scala   |  9 +++++++++
 .../scala/docs/stream/cookbook/RecipeSeq.scala     |  9 +++++++++
 .../docs/stream/cookbook/RecipeSimpleDrop.scala    |  9 +++++++++
 .../stream/cookbook/RecipeSourceFromFunction.scala |  9 +++++++++
 .../scala/docs/stream/cookbook/RecipeSpec.scala    |  9 +++++++++
 .../docs/stream/cookbook/RecipeSplitter.scala      |  9 +++++++++
 .../docs/stream/cookbook/RecipeWorkerPool.scala    |  9 +++++++++
 .../scala/docs/stream/io/StreamFileDocSpec.scala   |  9 +++++++++
 .../scala/docs/stream/io/StreamTcpDocSpec.scala    |  9 +++++++++
 .../stream/operators/BroadcastDocExample.scala     |  9 +++++++++
 .../src/test/scala/docs/stream/operators/Map.scala |  9 +++++++++
 .../stream/operators/MergeSequenceDocExample.scala |  9 +++++++++
 .../stream/operators/PartitionDocExample.scala     |  9 +++++++++
 .../docs/stream/operators/SourceOperators.scala    |  9 +++++++++
 .../docs/stream/operators/WithContextSpec.scala    |  9 +++++++++
 .../converters/StreamConvertersToJava.scala        |  9 +++++++++
 .../operators/converters/ToFromJavaIOStreams.scala |  9 +++++++++
 .../stream/operators/flow/FromSinkAndSource.scala  |  9 +++++++++
 .../docs/stream/operators/flow/FutureFlow.scala    |  9 +++++++++
 .../scala/docs/stream/operators/flow/Lazy.scala    |  9 +++++++++
 .../docs/stream/operators/flow/StatefulMap.scala   |  9 +++++++++
 .../stream/operators/flow/StatefulMapConcat.scala  |  9 +++++++++
 .../docs/stream/operators/sink/AsPublisher.scala   |  9 +++++++++
 .../docs/stream/operators/sink/Cancelled.scala     |  9 +++++++++
 .../docs/stream/operators/sink/Collection.scala    |  9 +++++++++
 .../scala/docs/stream/operators/sink/Fold.scala    |  9 +++++++++
 .../docs/stream/operators/sink/HeadOption.scala    |  9 +++++++++
 .../scala/docs/stream/operators/sink/Ignore.scala  |  9 +++++++++
 .../scala/docs/stream/operators/sink/Lazy.scala    |  9 +++++++++
 .../docs/stream/operators/source/Combine.scala     |  9 +++++++++
 .../scala/docs/stream/operators/source/From.scala  |  9 +++++++++
 .../stream/operators/source/FutureSource.scala     |  9 +++++++++
 .../scala/docs/stream/operators/source/Lazy.scala  |  9 +++++++++
 .../docs/stream/operators/source/Restart.scala     |  9 +++++++++
 .../scala/docs/stream/operators/source/Tick.scala  |  9 +++++++++
 .../docs/stream/operators/source/Unfold.scala      |  9 +++++++++
 .../docs/stream/operators/source/UnfoldAsync.scala |  9 +++++++++
 .../stream/operators/source/UnfoldResource.scala   |  9 +++++++++
 .../operators/source/UnfoldResourceAsync.scala     |  9 +++++++++
 .../scala/docs/stream/operators/source/Zip.scala   |  9 +++++++++
 .../stream/operators/sourceorflow/Collect.scala    |  9 +++++++++
 .../operators/sourceorflow/CompletionTimeout.scala |  9 +++++++++
 .../stream/operators/sourceorflow/Conflate.scala   |  9 +++++++++
 .../docs/stream/operators/sourceorflow/Drop.scala  |  9 +++++++++
 .../sourceorflow/ExtrapolateAndExpand.scala        |  9 +++++++++
 .../stream/operators/sourceorflow/Filter.scala     |  9 +++++++++
 .../operators/sourceorflow/FlatMapConcat.scala     |  9 +++++++++
 .../operators/sourceorflow/FlatMapMerge.scala      |  9 +++++++++
 .../docs/stream/operators/sourceorflow/Fold.scala  |  9 +++++++++
 .../stream/operators/sourceorflow/FoldAsync.scala  |  9 +++++++++
 .../stream/operators/sourceorflow/GroupBy.scala    |  9 +++++++++
 .../stream/operators/sourceorflow/Grouped.scala    |  9 +++++++++
 .../operators/sourceorflow/GroupedWeighted.scala   |  9 +++++++++
 .../operators/sourceorflow/Intersperse.scala       |  9 +++++++++
 .../docs/stream/operators/sourceorflow/Limit.scala |  9 +++++++++
 .../operators/sourceorflow/LimitWeighted.scala     |  9 +++++++++
 .../docs/stream/operators/sourceorflow/Log.scala   |  9 +++++++++
 .../operators/sourceorflow/LogWithMarker.scala     |  9 +++++++++
 .../stream/operators/sourceorflow/MapAsyncs.scala  |  9 +++++++++
 .../stream/operators/sourceorflow/MapConcat.scala  |  9 +++++++++
 .../stream/operators/sourceorflow/MapError.scala   |  9 +++++++++
 .../operators/sourceorflow/MergeLatest.scala       |  9 +++++++++
 .../stream/operators/sourceorflow/Monitor.scala    |  9 +++++++++
 .../stream/operators/sourceorflow/Reduce.scala     |  9 +++++++++
 .../docs/stream/operators/sourceorflow/Scan.scala  |  9 +++++++++
 .../stream/operators/sourceorflow/ScanAsync.scala  |  9 +++++++++
 .../stream/operators/sourceorflow/Sliding.scala    |  9 +++++++++
 .../docs/stream/operators/sourceorflow/Split.scala |  9 +++++++++
 .../docs/stream/operators/sourceorflow/Take.scala  |  9 +++++++++
 .../stream/operators/sourceorflow/TakeWhile.scala  |  9 +++++++++
 .../stream/operators/sourceorflow/Throttle.scala   |  9 +++++++++
 .../docs/stream/operators/sourceorflow/Watch.scala |  9 +++++++++
 .../operators/sourceorflow/WatchTermination.scala  |  9 +++++++++
 .../test/scala/docs/testkit/ParentChildSpec.scala  |  9 +++++++++
 .../test/scala/docs/testkit/PlainWordSpec.scala    |  9 +++++++++
 .../test/scala/docs/testkit/TestKitUsageSpec.scala |  9 +++++++++
 .../test/scala/docs/testkit/TestkitDocSpec.scala   |  9 +++++++++
 .../tutorial_1/ActorHierarchyExperiments.scala     |  9 +++++++++
 docs/src/test/scala/typed/tutorial_2/IotApp.scala  |  9 +++++++++
 .../scala/typed/tutorial_2/IotSupervisor.scala     |  9 +++++++++
 docs/src/test/scala/typed/tutorial_3/Device.scala  |  9 +++++++++
 .../scala/typed/tutorial_3/DeviceInProgress.scala  |  9 +++++++++
 .../test/scala/typed/tutorial_3/DeviceSpec.scala   |  9 +++++++++
 docs/src/test/scala/typed/tutorial_4/Device.scala  |  9 +++++++++
 .../test/scala/typed/tutorial_4/DeviceGroup.scala  |  9 +++++++++
 .../scala/typed/tutorial_4/DeviceGroupSpec.scala   |  9 +++++++++
 .../scala/typed/tutorial_4/DeviceManager.scala     |  9 +++++++++
 .../scala/typed/tutorial_4/DeviceManagerSpec.scala |  9 +++++++++
 .../test/scala/typed/tutorial_4/DeviceSpec.scala   |  9 +++++++++
 docs/src/test/scala/typed/tutorial_5/Device.scala  |  9 +++++++++
 .../test/scala/typed/tutorial_5/DeviceGroup.scala  |  9 +++++++++
 .../scala/typed/tutorial_5/DeviceGroupQuery.scala  |  9 +++++++++
 .../typed/tutorial_5/DeviceGroupQuerySpec.scala    |  9 +++++++++
 .../scala/typed/tutorial_5/DeviceGroupSpec.scala   |  9 +++++++++
 .../scala/typed/tutorial_5/DeviceManager.scala     |  9 +++++++++
 .../scala/typed/tutorial_5/DeviceManagerSpec.scala |  9 +++++++++
 .../test/scala/typed/tutorial_5/DeviceSpec.scala   |  9 +++++++++
 .../testconductor/TestConductorProtocol.java       |  9 +++++++++
 .../src/main/protobuf/TestConductorProtocol.proto  |  9 +++++++++
 .../pekko/remote/testconductor/Conductor.scala     |  9 +++++++++
 .../pekko/remote/testconductor/DataTypes.scala     |  9 +++++++++
 .../pekko/remote/testconductor/Extension.scala     |  9 +++++++++
 .../apache/pekko/remote/testconductor/Player.scala |  9 +++++++++
 .../remote/testconductor/RemoteConnection.scala    |  9 +++++++++
 .../pekko/remote/testkit/MultiNodeSpec.scala       |  9 +++++++++
 .../pekko/remote/testkit/PerfFlamesSupport.scala   |  9 +++++++++
 .../apache/pekko/osgi/ActorSystemActivator.scala   |  9 +++++++++
 .../pekko/osgi/BundleDelegatingClassLoader.scala   |  9 +++++++++
 .../org/apache/pekko/osgi/DefaultOSGiLogger.scala  |  9 +++++++++
 .../apache/pekko/osgi/OsgiActorSystemFactory.scala |  9 +++++++++
 osgi/src/test/scala/docs/osgi/Activator.scala      |  9 +++++++++
 .../pekko/osgi/ActorSystemActivatorTest.scala      |  9 +++++++++
 .../org/apache/pekko/osgi/PojoSRTestSupport.scala  |  9 +++++++++
 .../org/apache/pekko/osgi/test/PingPong.scala      |  9 +++++++++
 .../apache/pekko/osgi/test/TestActivators.scala    |  9 +++++++++
 .../query/internal/protobuf/QueryMessages.java     |  9 +++++++++
 .../src/main/protobuf/QueryMessages.proto          |  9 +++++++++
 .../persistence/query/DurableStateChange.scala     |  9 +++++++++
 .../pekko/persistence/query/EventEnvelope.scala    |  9 +++++++++
 .../apache/pekko/persistence/query/Offset.scala    |  9 +++++++++
 .../pekko/persistence/query/PersistenceQuery.scala |  9 +++++++++
 .../persistence/query/ReadJournalProvider.scala    |  9 +++++++++
 .../query/internal/QuerySerializer.scala           |  9 +++++++++
 .../CurrentEventsByPersistenceIdQuery.scala        |  9 +++++++++
 .../query/javadsl/CurrentEventsByTagQuery.scala    |  9 +++++++++
 .../query/javadsl/CurrentPersistenceIdsQuery.scala |  9 +++++++++
 ...DurableStateStorePagedPersistenceIdsQuery.scala |  9 +++++++++
 .../query/javadsl/DurableStateStoreQuery.scala     |  9 +++++++++
 .../query/javadsl/EventsByPersistenceIdQuery.scala |  9 +++++++++
 .../query/javadsl/EventsByTagQuery.scala           |  9 +++++++++
 .../query/javadsl/PagedPersistenceIdsQuery.scala   |  9 +++++++++
 .../query/javadsl/PersistenceIdsQuery.scala        |  9 +++++++++
 .../persistence/query/javadsl/ReadJournal.scala    |  9 +++++++++
 .../journal/leveldb/AllPersistenceIdsStage.scala   |  9 +++++++++
 .../persistence/query/journal/leveldb/Buffer.scala |  9 +++++++++
 .../leveldb/EventsByPersistenceIdStage.scala       |  9 +++++++++
 .../query/journal/leveldb/EventsByTagStage.scala   |  9 +++++++++
 .../leveldb/LeveldbReadJournalProvider.scala       |  9 +++++++++
 .../leveldb/javadsl/LeveldbReadJournal.scala       |  9 +++++++++
 .../leveldb/scaladsl/LeveldbReadJournal.scala      |  9 +++++++++
 .../CurrentEventsByPersistenceIdQuery.scala        |  9 +++++++++
 .../query/scaladsl/CurrentEventsByTagQuery.scala   |  9 +++++++++
 .../scaladsl/CurrentPersistenceIdsQuery.scala      |  9 +++++++++
 ...DurableStateStorePagedPersistenceIdsQuery.scala |  9 +++++++++
 .../query/scaladsl/DurableStateStoreQuery.scala    |  9 +++++++++
 .../scaladsl/EventsByPersistenceIdQuery.scala      |  9 +++++++++
 .../query/scaladsl/EventsByTagQuery.scala          |  9 +++++++++
 .../query/scaladsl/PagedPersistenceIdsQuery.scala  |  9 +++++++++
 .../query/scaladsl/PersistenceIdsQuery.scala       |  9 +++++++++
 .../persistence/query/scaladsl/ReadJournal.scala   |  9 +++++++++
 .../persistence/query/typed/EventEnvelope.scala    |  9 +++++++++
 .../typed/javadsl/CurrentEventsBySliceQuery.scala  |  9 +++++++++
 .../javadsl/DurableStateStoreBySliceQuery.scala    |  9 +++++++++
 .../query/typed/javadsl/EventTimestampQuery.scala  |  9 +++++++++
 .../query/typed/javadsl/EventsBySliceQuery.scala   |  9 +++++++++
 .../query/typed/javadsl/LoadEventQuery.scala       |  9 +++++++++
 .../typed/scaladsl/CurrentEventsBySliceQuery.scala |  9 +++++++++
 .../scaladsl/DurableStateStoreBySliceQuery.scala   |  9 +++++++++
 .../query/typed/scaladsl/EventTimestampQuery.scala |  9 +++++++++
 .../query/typed/scaladsl/EventsBySliceQuery.scala  |  9 +++++++++
 .../query/typed/scaladsl/LoadEventQuery.scala      |  9 +++++++++
 .../persistence/query/DummyJavaReadJournal.java    |  9 +++++++++
 .../query/DummyJavaReadJournalForScala.java        |  9 +++++++++
 .../query/DummyJavaReadJournalProvider.java        |  9 +++++++++
 .../persistence/query/PersistenceQueryTest.java    |  9 +++++++++
 .../pekko/persistence/query/DummyReadJournal.scala |  9 +++++++++
 .../pekko/persistence/query/OffsetSpec.scala       |  9 +++++++++
 .../persistence/query/PersistenceQuerySpec.scala   |  9 +++++++++
 .../query/internal/QuerySerializerSpec.scala       |  9 +++++++++
 .../journal/leveldb/AllPersistenceIdsSpec.scala    |  9 +++++++++
 .../query/journal/leveldb/Cleanup.scala            |  9 +++++++++
 .../leveldb/EventsByPersistenceIdSpec.scala        |  9 +++++++++
 .../query/journal/leveldb/EventsByTagSpec.scala    |  9 +++++++++
 .../query/journal/leveldb/TestActor.scala          |  9 +++++++++
 .../leveldb/PersistencePluginProxySpec.scala       |  9 +++++++++
 .../journal/leveldb/SharedLeveldbJournalSpec.scala |  9 +++++++++
 .../persistence/serialization/SerializerSpec.scala |  9 +++++++++
 .../apache/pekko/persistence/CapabilityFlags.scala |  9 +++++++++
 .../org/apache/pekko/persistence/PluginSpec.scala  |  9 +++++++++
 .../apache/pekko/persistence/TestSerializer.scala  |  9 +++++++++
 .../japi/journal/JavaJournalPerfSpec.scala         |  9 +++++++++
 .../persistence/japi/journal/JavaJournalSpec.scala |  9 +++++++++
 .../japi/snapshot/JavaSnapshotStoreSpec.scala      |  9 +++++++++
 .../persistence/journal/JournalPerfSpec.scala      |  9 +++++++++
 .../pekko/persistence/journal/JournalSpec.scala    |  9 +++++++++
 .../pekko/persistence/scalatest/MayVerb.scala      |  9 +++++++++
 .../persistence/scalatest/OptionalTests.scala      |  9 +++++++++
 .../persistence/snapshot/SnapshotStoreSpec.scala   |  9 +++++++++
 .../apache/pekko/persistence/PluginCleanup.scala   |  9 +++++++++
 .../persistence/japi/JavaJournalSpecSpec.scala     |  9 +++++++++
 .../journal/inmem/InmemJournalSpec.scala           |  9 +++++++++
 .../journal/leveldb/LeveldbJournalJavaSpec.scala   |  9 +++++++++
 .../journal/leveldb/LeveldbJournalNativeSpec.scala |  9 +++++++++
 ...bJournalNoAtomicPersistMultipleEventsSpec.scala |  9 +++++++++
 .../snapshot/local/LocalSnapshotStoreSpec.scala    |  9 +++++++++
 .../pekko/persistence/testkit/EventStorage.scala   |  9 +++++++++
 .../testkit/PersistenceTestKitPlugin.scala         |  9 +++++++++
 .../persistence/testkit/ProcessingPolicy.scala     |  9 +++++++++
 .../persistence/testkit/SnapshotStorage.scala      |  9 +++++++++
 .../persistence/testkit/internal/CurrentTime.scala |  9 +++++++++
 .../internal/EventSourcedBehaviorTestKitImpl.scala |  9 +++++++++
 .../testkit/internal/InMemStorageExtension.scala   |  9 +++++++++
 .../testkit/internal/PersistenceInitImpl.scala     |  9 +++++++++
 .../internal/SerializedEventStorageImpl.scala      |  9 +++++++++
 .../internal/SerializedSnapshotStorageImpl.scala   |  9 +++++++++
 .../testkit/internal/SimpleEventStorageImpl.scala  |  9 +++++++++
 .../internal/SimpleSnapshotStorageImpl.scala       |  9 +++++++++
 .../SnapshotStorageEmulatorExtension.scala         |  9 +++++++++
 .../testkit/internal/TestKitStorage.scala          |  9 +++++++++
 .../javadsl/EventSourcedBehaviorTestKit.scala      |  9 +++++++++
 .../testkit/javadsl/PersistenceInit.scala          |  9 +++++++++
 .../testkit/javadsl/PersistenceTestKit.scala       |  9 +++++++++
 .../testkit/javadsl/SnapshotTestKit.scala          |  9 +++++++++
 .../PersistenceTestKitReadJournalProvider.scala    |  9 +++++++++
 .../internal/EventsByPersistenceIdStage.scala      |  9 +++++++++
 .../javadsl/PersistenceTestKitReadJournal.scala    |  9 +++++++++
 .../scaladsl/PersistenceTestKitReadJournal.scala   |  9 +++++++++
 .../scaladsl/EventSourcedBehaviorTestKit.scala     |  9 +++++++++
 .../testkit/scaladsl/PersistenceInit.scala         |  9 +++++++++
 .../testkit/scaladsl/PersistenceTestKit.scala      |  9 +++++++++
 .../persistence/testkit/scaladsl/TestOps.scala     |  9 +++++++++
 ...rsistenceTestKitDurableStateStoreProvider.scala |  9 +++++++++
 .../PersistenceTestKitDurableStateStore.scala      |  9 +++++++++
 .../PersistenceTestKitDurableStateStore.scala      |  9 +++++++++
 .../pekko/persistence/testkit/CommonUtils.scala    |  9 +++++++++
 .../testkit/javadsl/CommonSnapshotTests.scala      |  9 +++++++++
 .../testkit/javadsl/CommonTestKitTests.scala       |  9 +++++++++
 .../persistence/testkit/javadsl/JavaDslUtils.scala |  9 +++++++++
 .../testkit/javadsl/SnapshotNotSerializeSpec.scala |  9 +++++++++
 .../testkit/javadsl/SnapshotSerializeSpec.scala    |  9 +++++++++
 .../testkit/javadsl/TestKitNotSerializeSpec.scala  |  9 +++++++++
 .../testkit/javadsl/TestKitSerializeSpec.scala     |  9 +++++++++
 .../testkit/query/CurrentEventsBySlicesSpec.scala  |  9 +++++++++
 .../testkit/query/CurrentEventsByTagSpec.scala     |  9 +++++++++
 .../testkit/query/EventsByPersistenceIdSpec.scala  |  9 +++++++++
 .../testkit/scaladsl/CommonSnapshotTests.scala     |  9 +++++++++
 .../testkit/scaladsl/CommonTestKitTests.scala      |  9 +++++++++
 ...EventSourcedBehaviorNoSnapshotTestKitSpec.scala |  9 +++++++++
 .../scaladsl/EventSourcedBehaviorTestKitSpec.scala |  9 +++++++++
 .../testkit/scaladsl/MultipleJournalsSpec.scala    |  9 +++++++++
 .../PersistenceTestKitJournalCompatSpec.scala      |  9 +++++++++
 .../testkit/scaladsl/ScalaDslUtils.scala           |  9 +++++++++
 .../scaladsl/SnapshotNotSerializeSpec.scala        |  9 +++++++++
 .../testkit/scaladsl/SnapshotSerializeSpec.scala   |  9 +++++++++
 .../testkit/scaladsl/TestKitNotSerializeSpec.scala |  9 +++++++++
 .../testkit/scaladsl/TestKitSerializeSpec.scala    |  9 +++++++++
 .../PersistenceTestKitDurableStateStoreSpec.scala  |  9 +++++++++
 .../persistence/typed/MyReplicatedBehavior.java    |  9 +++++++++
 .../typed/ReplicatedAuctionExampleTest.java        |  9 +++++++++
 .../persistence/typed/ReplicatedBlogExample.java   |  9 +++++++++
 .../persistence/typed/ReplicatedMovieExample.java  |  9 +++++++++
 .../typed/ReplicatedShoppingCartExample.java       |  9 +++++++++
 .../persistence/typed/ReplicatedStringSet.java     |  9 +++++++++
 .../typed/ReplicatedEventSourcingTest.java         |  9 +++++++++
 .../javadsl/EventSourcedActorFailureTest.java      |  9 +++++++++
 .../javadsl/EventSourcedBehaviorJavaDslTest.java   |  9 +++++++++
 .../typed/ReplicatedAuctionExampleSpec.scala       |  9 +++++++++
 .../typed/ReplicatedBlogExampleSpec.scala          |  9 +++++++++
 .../ReplicatedEventSourcingCompileOnlySpec.scala   |  9 +++++++++
 .../ReplicatedMovieWatchListExampleSpec.scala      |  9 +++++++++
 .../typed/ReplicatedShoppingCartExampleSpec.scala  |  9 +++++++++
 .../persistence/typed/EventPublishingSpec.scala    |  9 +++++++++
 .../typed/EventSourcedBehaviorLoggingSpec.scala    |  9 +++++++++
 .../typed/MultiJournalReplicationSpec.scala        |  9 +++++++++
 .../typed/ReplicatedEventPublishingSpec.scala      |  9 +++++++++
 .../typed/ReplicatedEventSourcingSpec.scala        |  9 +++++++++
 .../typed/ReplicatedEventSourcingTaggingSpec.scala |  9 +++++++++
 .../persistence/typed/ReplicationBaseSpec.scala    |  9 +++++++++
 .../typed/ReplicationIllegalAccessSpec.scala       |  9 +++++++++
 .../typed/ReplicationSnapshotSpec.scala            |  9 +++++++++
 .../pekko/persistence/typed/crdt/CounterSpec.scala |  9 +++++++++
 .../pekko/persistence/typed/crdt/LwwSpec.scala     |  9 +++++++++
 .../pekko/persistence/typed/crdt/ORSetSpec.scala   |  9 +++++++++
 .../ReplicatedEventSourcingJacksonSpec.scala       |  9 +++++++++
 .../scaladsl/EventSourcedBehaviorFailureSpec.scala |  9 +++++++++
 .../EventSourcedBehaviorInterceptorSpec.scala      |  9 +++++++++
 .../EventSourcedBehaviorRecoveryTimeoutSpec.scala  |  9 +++++++++
 .../scaladsl/EventSourcedBehaviorReplySpec.scala   |  9 +++++++++
 .../EventSourcedBehaviorRetentionSpec.scala        |  9 +++++++++
 .../typed/scaladsl/EventSourcedBehaviorSpec.scala  |  9 +++++++++
 .../scaladsl/EventSourcedBehaviorStashSpec.scala   |  9 +++++++++
 .../scaladsl/EventSourcedBehaviorTimersSpec.scala  |  9 +++++++++
 .../scaladsl/EventSourcedBehaviorWatchSpec.scala   |  9 +++++++++
 .../scaladsl/EventSourcedEventAdapterSpec.scala    |  9 +++++++++
 .../scaladsl/EventSourcedSequenceNumberSpec.scala  |  9 +++++++++
 .../scaladsl/EventSourcedSnapshotAdapterSpec.scala |  9 +++++++++
 .../scaladsl/EventSourcedStashOverflowSpec.scala   |  9 +++++++++
 .../typed/scaladsl/LoggerSourceSpec.scala          |  9 +++++++++
 .../typed/scaladsl/NullEmptyStateSpec.scala        |  9 +++++++++
 .../typed/scaladsl/OptionalSnapshotStoreSpec.scala |  9 +++++++++
 .../typed/scaladsl/PerformanceSpec.scala           |  9 +++++++++
 .../typed/scaladsl/PrimitiveStateSpec.scala        |  9 +++++++++
 .../typed/scaladsl/SlowInMemorySnapshotStore.scala |  9 +++++++++
 .../typed/scaladsl/SnapshotMutableStateSpec.scala  |  9 +++++++++
 .../SnapshotRecoveryWithEmptyJournalSpec.scala     |  9 +++++++++
 .../DurableStateBehaviorInterceptorSpec.scala      |  9 +++++++++
 .../scaladsl/DurableStateBehaviorReplySpec.scala   |  9 +++++++++
 .../scaladsl/DurableStateBehaviorTimersSpec.scala  |  9 +++++++++
 .../state/scaladsl/DurableStateRevisionSpec.scala  |  9 +++++++++
 .../typed/state/scaladsl/NullEmptyStateSpec.scala  |  9 +++++++++
 .../typed/state/scaladsl/PrimitiveStateSpec.scala  |  9 +++++++++
 .../serialization/ReplicatedEventSourcing.java     |  9 +++++++++
 .../main/protobuf/ReplicatedEventSourcing.proto    |  9 +++++++++
 .../pekko/persistence/typed/EventAdapter.scala     |  9 +++++++++
 .../persistence/typed/EventRejectedException.scala |  9 +++++++++
 .../persistence/typed/EventSourcedSignal.scala     |  9 +++++++++
 .../pekko/persistence/typed/PersistenceId.scala    |  9 +++++++++
 .../pekko/persistence/typed/PublishedEvent.scala   |  9 +++++++++
 .../apache/pekko/persistence/typed/ReplicaId.scala |  9 +++++++++
 .../pekko/persistence/typed/ReplicationId.scala    |  9 +++++++++
 .../pekko/persistence/typed/SnapshotAdapter.scala  |  9 +++++++++
 .../typed/SnapshotSelectionCriteria.scala          |  9 +++++++++
 .../pekko/persistence/typed/crdt/Counter.scala     |  9 +++++++++
 .../pekko/persistence/typed/crdt/LwwTime.scala     |  9 +++++++++
 .../pekko/persistence/typed/crdt/ORSet.scala       |  9 +++++++++
 .../pekko/persistence/typed/crdt/OpCrdt.scala      |  9 +++++++++
 .../typed/delivery/EventSourcedProducerQueue.scala |  9 +++++++++
 .../persistence/typed/internal/BehaviorSetup.scala |  9 +++++++++
 .../persistence/typed/internal/EffectImpl.scala    |  9 +++++++++
 .../typed/internal/EventSourcedBehaviorImpl.scala  |  9 +++++++++
 .../typed/internal/EventSourcedSettings.scala      |  9 +++++++++
 .../typed/internal/ExternalInteractions.scala      |  9 +++++++++
 .../typed/internal/FastForwardingFilter.scala      |  9 +++++++++
 .../typed/internal/JournalFailureException.scala   |  9 +++++++++
 .../typed/internal/NoOpSnapshotAdapter.scala       |  9 +++++++++
 .../persistence/typed/internal/RecoveryImpl.scala  |  9 +++++++++
 .../typed/internal/ReplayingEvents.scala           |  9 +++++++++
 .../typed/internal/ReplayingSnapshot.scala         |  9 +++++++++
 .../typed/internal/ReplicationSetup.scala          |  9 +++++++++
 .../typed/internal/RequestingRecoveryPermit.scala  |  9 +++++++++
 .../typed/internal/RetentionCriteriaImpl.scala     |  9 +++++++++
 .../pekko/persistence/typed/internal/Running.scala |  9 +++++++++
 .../persistence/typed/internal/SideEffect.scala    |  9 +++++++++
 .../typed/internal/StashManagement.scala           |  9 +++++++++
 .../persistence/typed/internal/VersionVector.scala |  9 +++++++++
 .../persistence/typed/javadsl/CommandHandler.scala |  9 +++++++++
 .../typed/javadsl/CommandHandlerWithReply.scala    |  9 +++++++++
 .../pekko/persistence/typed/javadsl/Effect.scala   |  9 +++++++++
 .../persistence/typed/javadsl/EventHandler.scala   |  9 +++++++++
 .../typed/javadsl/EventSourcedBehavior.scala       |  9 +++++++++
 .../typed/javadsl/PersistentFSMMigration.scala     |  9 +++++++++
 .../pekko/persistence/typed/javadsl/Recovery.scala |  9 +++++++++
 .../javadsl/ReplicatedEventSourcedBehavior.scala   |  9 +++++++++
 .../typed/javadsl/ReplicatedEventSourcing.scala    |  9 +++++++++
 .../typed/javadsl/RetentionCriteria.scala          |  9 +++++++++
 .../persistence/typed/javadsl/SignalHandler.scala  |  9 +++++++++
 .../pekko/persistence/typed/scaladsl/Effect.scala  |  9 +++++++++
 .../typed/scaladsl/EventSourcedBehavior.scala      |  9 +++++++++
 .../typed/scaladsl/PersistentFSMMigration.scala    |  9 +++++++++
 .../persistence/typed/scaladsl/Recovery.scala      |  9 +++++++++
 .../typed/scaladsl/ReplicatedEventSourcing.scala   |  9 +++++++++
 .../typed/scaladsl/RetentionCriteria.scala         |  9 +++++++++
 .../ReplicatedEventSourcingSerializer.scala        |  9 +++++++++
 .../typed/state/DurableStateSignal.scala           |  9 +++++++++
 .../typed/state/internal/BehaviorSetup.scala       |  9 +++++++++
 .../state/internal/DurableStateBehaviorImpl.scala  |  9 +++++++++
 .../state/internal/DurableStateSettings.scala      |  9 +++++++++
 .../internal/DurableStateStoreException.scala      |  9 +++++++++
 .../internal/DurableStateStoreInteractions.scala   |  9 +++++++++
 .../typed/state/internal/EffectImpl.scala          |  9 +++++++++
 .../typed/state/internal/NoOpSnapshotAdapter.scala |  9 +++++++++
 .../typed/state/internal/Recovering.scala          |  9 +++++++++
 .../state/internal/RequestingRecoveryPermit.scala  |  9 +++++++++
 .../persistence/typed/state/internal/Running.scala |  9 +++++++++
 .../typed/state/internal/SideEffect.scala          |  9 +++++++++
 .../typed/state/internal/StashManagement.scala     |  9 +++++++++
 .../typed/state/javadsl/CommandHandler.scala       |  9 +++++++++
 .../state/javadsl/CommandHandlerWithReply.scala    |  9 +++++++++
 .../typed/state/javadsl/DurableStateBehavior.scala |  9 +++++++++
 .../persistence/typed/state/javadsl/Effect.scala   |  9 +++++++++
 .../typed/state/javadsl/SignalHandler.scala        |  9 +++++++++
 .../state/scaladsl/DurableStateBehavior.scala      |  9 +++++++++
 .../persistence/typed/state/scaladsl/Effect.scala  |  9 +++++++++
 .../typed/BasicPersistentBehaviorTest.java         |  9 +++++++++
 .../pekko/persistence/typed/BlogPostEntity.java    |  9 +++++++++
 .../typed/BlogPostEntityDurableState.java          |  9 +++++++++
 .../typed/DurableStatePersistentBehaviorTest.java  |  9 +++++++++
 .../pekko/persistence/typed/MovieWatchList.java    |  9 +++++++++
 .../pekko/persistence/typed/NullBlogState.java     |  9 +++++++++
 .../pekko/persistence/typed/OptionalBlogState.java |  9 +++++++++
 ...rsistentFsmToTypedMigrationCompileOnlyTest.java |  9 +++++++++
 .../pekko/persistence/typed/StashingExample.java   |  9 +++++++++
 .../persistence/typed/WebStoreCustomerFSM.java     |  9 +++++++++
 .../pekko/persistence/typed/auction/Auction.java   |  9 +++++++++
 .../persistence/typed/auction/AuctionCommand.java  |  9 +++++++++
 .../persistence/typed/auction/AuctionEntity.java   |  9 +++++++++
 .../persistence/typed/auction/AuctionEvent.java    |  9 +++++++++
 .../persistence/typed/auction/AuctionState.java    |  9 +++++++++
 .../persistence/typed/auction/AuctionStatus.java   |  9 +++++++++
 .../pekko/persistence/typed/auction/Bid.java       |  9 +++++++++
 .../persistence/typed/auction/BidResultStatus.java |  9 +++++++++
 .../typed/javadsl/LoggerSourceTest.java            |  9 +++++++++
 .../typed/javadsl/NullEmptyStateTest.java          |  9 +++++++++
 .../javadsl/PersistentActorCompileOnlyTest.java    |  9 +++++++++
 .../typed/javadsl/PrimitiveStateTest.java          |  9 +++++++++
 .../typed/BasicPersistentBehaviorCompileOnly.scala |  9 +++++++++
 .../pekko/persistence/typed/BlogPostEntity.scala   |  9 +++++++++
 .../typed/BlogPostEntityDurableState.scala         |  9 +++++++++
 ...DurableStatePersistentBehaviorCompileOnly.scala |  9 +++++++++
 .../pekko/persistence/typed/MovieWatchList.scala   |  9 +++++++++
 .../typed/PersistentFsmToTypedMigrationSpec.scala  |  9 +++++++++
 .../pekko/persistence/typed/StashingExample.scala  |  9 +++++++++
 .../typed/ClusterSingletonPersistenceSpec.scala    |  9 +++++++++
 .../persistence/typed/ManyRecoveriesSpec.scala     |  9 +++++++++
 .../persistence/typed/PersistenceIdSpec.scala      |  9 +++++++++
 .../ReplicatedEventSourcingSerializationSpec.scala |  9 +++++++++
 .../typed/StashingWhenSnapshottingSpec.scala       |  9 +++++++++
 .../delivery/EventSourcedProducerQueueSpec.scala   |  9 +++++++++
 ...DeliveryWithEventSourcedProducerQueueSpec.scala |  9 +++++++++
 ...kPullingWithEventSourcedProducerQueueSpec.scala |  9 +++++++++
 .../typed/internal/RecoveryPermitterSpec.scala     |  9 +++++++++
 .../typed/internal/RetentionCriteriaSpec.scala     |  9 +++++++++
 .../typed/internal/StashStateSpec.scala            |  9 +++++++++
 .../scaladsl/PersistentActorCompileOnlyTest.scala  |  9 +++++++++
 .../typed/scaladsl/SnapshotIsOptionalSpec.scala    |  9 +++++++++
 .../ReplicatedEventSourcingSerializerSpec.scala    |  9 +++++++++
 .../fsm/japi/pf/FSMStateFunctionBuilder.java       |  9 +++++++++
 .../persistence/fsm/japi/pf/FSMStopBuilder.java    |  9 +++++++++
 .../journal/japi/AsyncRecoveryPlugin.java          |  9 +++++++++
 .../persistence/journal/japi/AsyncWritePlugin.java |  9 +++++++++
 .../persistence/serialization/MessageFormats.java  |  9 +++++++++
 .../snapshot/japi/SnapshotStorePlugin.java         |  9 +++++++++
 persistence/src/main/protobuf/MessageFormats.proto |  9 +++++++++
 .../org/apache/pekko/persistence/TraitOrder.scala  |  9 +++++++++
 .../pekko/persistence/AtLeastOnceDelivery.scala    |  9 +++++++++
 .../apache/pekko/persistence/Eventsourced.scala    |  9 +++++++++
 .../apache/pekko/persistence/JournalProtocol.scala |  9 +++++++++
 .../org/apache/pekko/persistence/Persistence.scala |  9 +++++++++
 .../pekko/persistence/PersistencePlugin.scala      |  9 +++++++++
 .../org/apache/pekko/persistence/Persistent.scala  |  9 +++++++++
 .../apache/pekko/persistence/PersistentActor.scala |  9 +++++++++
 .../org/apache/pekko/persistence/Protocol.scala    |  9 +++++++++
 .../pekko/persistence/RecoveryPermitter.scala      |  9 +++++++++
 .../pekko/persistence/SnapshotProtocol.scala       |  9 +++++++++
 .../org/apache/pekko/persistence/Snapshotter.scala |  9 +++++++++
 .../pekko/persistence/fsm/PersistentFSM.scala      |  9 +++++++++
 .../pekko/persistence/fsm/PersistentFSMBase.scala  |  9 +++++++++
 .../pekko/persistence/journal/AsyncRecovery.scala  |  9 +++++++++
 .../persistence/journal/AsyncWriteJournal.scala    |  9 +++++++++
 .../persistence/journal/AsyncWriteProxy.scala      |  9 +++++++++
 .../pekko/persistence/journal/EventAdapter.scala   |  9 +++++++++
 .../pekko/persistence/journal/EventAdapters.scala  |  9 +++++++++
 .../journal/PersistencePluginProxy.scala           |  9 +++++++++
 .../pekko/persistence/journal/ReplayFilter.scala   |  9 +++++++++
 .../apache/pekko/persistence/journal/Tagged.scala  |  9 +++++++++
 .../persistence/journal/WriteJournalBase.scala     |  9 +++++++++
 .../persistence/journal/inmem/InmemJournal.scala   |  9 +++++++++
 .../persistence/journal/japi/AsyncRecovery.scala   |  9 +++++++++
 .../journal/japi/AsyncWriteJournal.scala           |  9 +++++++++
 .../journal/leveldb/LeveldbCompaction.scala        |  9 +++++++++
 .../journal/leveldb/LeveldbIdMapping.scala         |  9 +++++++++
 .../journal/leveldb/LeveldbJournal.scala           |  9 +++++++++
 .../persistence/journal/leveldb/LeveldbKey.scala   |  9 +++++++++
 .../journal/leveldb/LeveldbRecovery.scala          |  9 +++++++++
 .../persistence/journal/leveldb/LeveldbStore.scala |  9 +++++++++
 .../journal/leveldb/SharedLeveldbStore.scala       |  9 +++++++++
 .../serialization/MessageSerializer.scala          |  9 +++++++++
 .../serialization/SnapshotSerializer.scala         |  9 +++++++++
 .../pekko/persistence/serialization/package.scala  |  9 +++++++++
 .../persistence/snapshot/NoSnapshotStore.scala     |  9 +++++++++
 .../pekko/persistence/snapshot/SnapshotStore.scala |  9 +++++++++
 .../persistence/snapshot/japi/SnapshotStore.scala  |  9 +++++++++
 .../snapshot/local/LocalSnapshotStore.scala        |  9 +++++++++
 .../state/DurableStateStoreProvider.scala          |  9 +++++++++
 .../state/DurableStateStoreRegistry.scala          |  9 +++++++++
 .../state/javadsl/DurableStateStore.scala          |  9 +++++++++
 .../state/javadsl/DurableStateUpdateStore.scala    |  9 +++++++++
 .../state/scaladsl/DurableStateStore.scala         |  9 +++++++++
 .../state/scaladsl/DurableStateUpdateStore.scala   |  9 +++++++++
 .../persistence/fsm/AbstractPersistentFSMTest.java |  9 +++++++++
 .../persistence/AtLeastOnceDeliveryCrashSpec.scala |  9 +++++++++
 .../AtLeastOnceDeliveryFailureSpec.scala           |  9 +++++++++
 .../persistence/AtLeastOnceDeliverySpec.scala      |  9 +++++++++
 .../apache/pekko/persistence/AtomicWriteSpec.scala |  9 +++++++++
 .../persistence/EndToEndEventAdapterSpec.scala     |  9 +++++++++
 .../pekko/persistence/EventAdapterSpec.scala       |  9 +++++++++
 .../EventSourcedActorDeleteFailureSpec.scala       |  9 +++++++++
 .../persistence/EventSourcedActorFailureSpec.scala |  9 +++++++++
 .../apache/pekko/persistence/LoadPluginSpec.scala  |  9 +++++++++
 .../pekko/persistence/ManyRecoveriesSpec.scala     |  9 +++++++++
 .../pekko/persistence/OptimizedRecoverySpec.scala  |  9 +++++++++
 .../persistence/OptionalSnapshotStoreSpec.scala    |  9 +++++++++
 .../apache/pekko/persistence/PerformanceSpec.scala |  9 +++++++++
 .../apache/pekko/persistence/PersistenceSpec.scala |  9 +++++++++
 .../PersistentActorBoundedStashingSpec.scala       |  9 +++++++++
 .../PersistentActorJournalProtocolSpec.scala       |  9 +++++++++
 .../PersistentActorRecoveryTimeoutSpec.scala       |  9 +++++++++
 .../pekko/persistence/PersistentActorSpec.scala    |  9 +++++++++
 .../persistence/PersistentActorStashingSpec.scala  |  9 +++++++++
 .../pekko/persistence/RecoveryPermitterSpec.scala  |  9 +++++++++
 .../apache/pekko/persistence/SliceRangesSpec.scala |  9 +++++++++
 .../persistence/SnapshotDecodeFailureSpec.scala    |  9 +++++++++
 .../persistence/SnapshotDirectoryFailureSpec.scala |  9 +++++++++
 .../SnapshotFailureRobustnessSpec.scala            |  9 +++++++++
 .../SnapshotRecoveryLocalStoreSpec.scala           |  9 +++++++++
 .../SnapshotRecoveryWithEmptyJournalSpec.scala     |  9 +++++++++
 .../persistence/SnapshotSerializationSpec.scala    |  9 +++++++++
 .../apache/pekko/persistence/SnapshotSpec.scala    |  9 +++++++++
 .../persistence/TimerPersistentActorSpec.scala     |  9 +++++++++
 .../pekko/persistence/fsm/PersistentFSMSpec.scala  |  9 +++++++++
 .../journal/InmemEventAdaptersSpec.scala           |  9 +++++++++
 .../persistence/journal/ReplayFilterSpec.scala     |  9 +++++++++
 .../persistence/journal/SteppingInmemJournal.scala |  9 +++++++++
 .../persistence/journal/chaos/ChaosJournal.scala   |  9 +++++++++
 .../journal/inmem/InmemJournalSpec.scala           |  9 +++++++++
 .../leveldb/CompactionSegmentManagementSpec.scala  |  9 +++++++++
 .../journal/leveldb/JournalCompactionSpec.scala    |  9 +++++++++
 .../serialization/MessageSerializerSpec.scala      |  9 +++++++++
 .../apache/pekko/pki/pem/DERPrivateKeyLoader.scala |  9 +++++++++
 .../org/apache/pekko/pki/pem/PEMDecoder.scala      |  9 +++++++++
 .../pekko/pki/pem/DERPrivateKeyLoaderSpec.scala    |  9 +++++++++
 .../org/apache/pekko/pki/pem/PEMDecoderSpec.scala  |  9 +++++++++
 project/AddLogTimestamps.scala                     |  9 +++++++++
 project/AutomaticModuleName.scala                  |  9 +++++++++
 project/CliOptions.scala                           |  9 +++++++++
 project/CopyrightHeaderForBoilerplate.scala        |  9 +++++++++
 project/CopyrightHeaderForBuild.scala              |  9 +++++++++
 project/CopyrightHeaderForJdk9.scala               |  9 +++++++++
 project/CopyrightHeaderForProtobuf.scala           |  9 +++++++++
 project/Dependencies.scala                         |  9 +++++++++
 project/Doc.scala                                  |  9 +++++++++
 project/GitHub.scala                               |  9 +++++++++
 project/JavaFormatter.scala                        |  9 +++++++++
 project/Jdk9.scala                                 |  9 +++++++++
 project/JdkOptions.scala                           |  9 +++++++++
 project/Jvm.scala                                  |  9 +++++++++
 project/MiMa.scala                                 |  9 +++++++++
 project/MultiNode.scala                            |  9 +++++++++
 project/OSGi.scala                                 |  9 +++++++++
 project/Paradox.scala                              |  9 +++++++++
 project/ParadoxBrowse.scala                        |  9 +++++++++
 project/PekkoBuild.scala                           |  9 +++++++++
 project/PekkoDisciplinePlugin.scala                |  9 +++++++++
 project/ProjectFileIgnoreSupport.scala             |  9 +++++++++
 project/Protobuf.scala                             |  9 +++++++++
 project/Publish.scala                              |  9 +++++++++
 project/SbtMultiJvm.scala                          |  9 +++++++++
 project/ScalaFixExtraRulesPlugin.scala             |  9 +++++++++
 project/ScalaFixForJdk9Plugin.scala                |  9 +++++++++
 project/ScalafixForMultiNodePlugin.scala           |  9 +++++++++
 project/ScalafixIgnoreFilePlugin.scala             |  9 +++++++++
 project/ScalafixSupport.scala                      |  9 +++++++++
 project/SigarLoader.scala                          |  9 +++++++++
 project/StreamOperatorsIndexGenerator.scala        |  9 +++++++++
 project/TestExtras.scala                           |  9 +++++++++
 project/ValidatePullRequest.scala                  |  9 +++++++++
 project/VersionGenerator.scala                     |  9 +++++++++
 .../org/apache/pekko/protobuf/AbstractMessage.java |  9 +++++++++
 .../apache/pekko/protobuf/AbstractMessageLite.java |  9 +++++++++
 .../org/apache/pekko/protobuf/AbstractParser.java  |  9 +++++++++
 .../apache/pekko/protobuf/BlockingRpcChannel.java  |  9 +++++++++
 .../org/apache/pekko/protobuf/BlockingService.java |  9 +++++++++
 .../apache/pekko/protobuf/BoundedByteString.java   |  9 +++++++++
 .../java/org/apache/pekko/protobuf/ByteString.java |  9 +++++++++
 .../apache/pekko/protobuf/CodedInputStream.java    |  9 +++++++++
 .../apache/pekko/protobuf/CodedOutputStream.java   |  9 +++++++++
 .../apache/pekko/protobuf/DescriptorProtos.java    |  9 +++++++++
 .../org/apache/pekko/protobuf/Descriptors.java     |  9 +++++++++
 .../org/apache/pekko/protobuf/DynamicMessage.java  |  9 +++++++++
 .../apache/pekko/protobuf/ExtensionRegistry.java   |  9 +++++++++
 .../pekko/protobuf/ExtensionRegistryLite.java      |  9 +++++++++
 .../java/org/apache/pekko/protobuf/FieldSet.java   |  9 +++++++++
 .../apache/pekko/protobuf/GeneratedMessage.java    |  9 +++++++++
 .../pekko/protobuf/GeneratedMessageLite.java       |  9 +++++++++
 .../java/org/apache/pekko/protobuf/Internal.java   |  9 +++++++++
 .../protobuf/InvalidProtocolBufferException.java   |  9 +++++++++
 .../java/org/apache/pekko/protobuf/LazyField.java  |  9 +++++++++
 .../apache/pekko/protobuf/LazyStringArrayList.java |  9 +++++++++
 .../org/apache/pekko/protobuf/LazyStringList.java  |  9 +++++++++
 .../apache/pekko/protobuf/LiteralByteString.java   |  9 +++++++++
 .../java/org/apache/pekko/protobuf/Message.java    |  9 +++++++++
 .../org/apache/pekko/protobuf/MessageLite.java     |  9 +++++++++
 .../pekko/protobuf/MessageLiteOrBuilder.java       |  9 +++++++++
 .../apache/pekko/protobuf/MessageOrBuilder.java    |  9 +++++++++
 .../java/org/apache/pekko/protobuf/Parser.java     |  9 +++++++++
 .../apache/pekko/protobuf/ProtocolMessageEnum.java |  9 +++++++++
 .../pekko/protobuf/RepeatedFieldBuilder.java       |  9 +++++++++
 .../org/apache/pekko/protobuf/RopeByteString.java  |  9 +++++++++
 .../org/apache/pekko/protobuf/RpcCallback.java     |  9 +++++++++
 .../java/org/apache/pekko/protobuf/RpcChannel.java |  9 +++++++++
 .../org/apache/pekko/protobuf/RpcController.java   |  9 +++++++++
 .../java/org/apache/pekko/protobuf/RpcUtil.java    |  9 +++++++++
 .../java/org/apache/pekko/protobuf/Service.java    |  9 +++++++++
 .../apache/pekko/protobuf/ServiceException.java    |  9 +++++++++
 .../apache/pekko/protobuf/SingleFieldBuilder.java  |  9 +++++++++
 .../org/apache/pekko/protobuf/SmallSortedMap.java  |  9 +++++++++
 .../java/org/apache/pekko/protobuf/TextFormat.java |  9 +++++++++
 .../protobuf/UninitializedMessageException.java    |  9 +++++++++
 .../org/apache/pekko/protobuf/UnknownFieldSet.java |  9 +++++++++
 .../pekko/protobuf/UnmodifiableLazyStringList.java |  9 +++++++++
 .../main/java/org/apache/pekko/protobuf/Utf8.java  |  9 +++++++++
 .../java/org/apache/pekko/protobuf/WireFormat.java |  9 +++++++++
 .../scala/org/apache/pekko/io/DnsSpec.scala        |  9 +++++++++
 .../pekko/remote/AttemptSysMsgRedeliverySpec.scala |  9 +++++++++
 .../pekko/remote/LookupRemoteActorSpec.scala       |  9 +++++++++
 .../apache/pekko/remote/NewRemoteActorSpec.scala   |  9 +++++++++
 .../remote/PiercingShouldKeepQuarantineSpec.scala  |  9 +++++++++
 .../apache/pekko/remote/RemoteDeliverySpec.scala   |  9 +++++++++
 .../remote/RemoteDeploymentDeathWatchSpec.scala    |  9 +++++++++
 .../apache/pekko/remote/RemoteFeaturesSpec.scala   |  9 +++++++++
 .../pekko/remote/RemoteNodeDeathWatchSpec.scala    |  9 +++++++++
 .../remote/RemoteNodeRestartDeathWatchSpec.scala   |  9 +++++++++
 .../remote/RemoteQuarantinePiercingSpec.scala      |  9 +++++++++
 .../pekko/remote/RemoteReDeploymentSpec.scala      |  9 +++++++++
 .../pekko/remote/RemotingMultiNodeSpec.scala       |  9 +++++++++
 .../apache/pekko/remote/TransportFailSpec.scala    |  9 +++++++++
 .../remote/artery/BenchmarkFileReporter.scala      |  9 +++++++++
 .../pekko/remote/artery/DirectMemorySpec.scala     |  9 +++++++++
 .../pekko/remote/artery/FanInThrougputSpec.scala   |  9 +++++++++
 .../pekko/remote/artery/FanOutThrougputSpec.scala  |  9 +++++++++
 .../artery/HandshakeRestartReceiverSpec.scala      |  9 +++++++++
 .../apache/pekko/remote/artery/LatencySpec.scala   |  9 +++++++++
 .../pekko/remote/artery/MaxThroughputSpec.scala    |  9 +++++++++
 .../apache/pekko/remote/artery/PlotResult.scala    |  9 +++++++++
 .../artery/RemoteRestartedQuarantinedSpec.scala    |  9 +++++++++
 ...dStreamRestartWithCompressionInFlightSpec.scala |  9 +++++++++
 .../artery/SurviveNetworkPartitionSpec.scala       |  9 +++++++++
 .../apache/pekko/remote/artery/TestMessage.scala   |  9 +++++++++
 .../pekko/remote/artery/TestRateReporter.scala     |  9 +++++++++
 .../apache/pekko/remote/artery/UdpPortActor.scala  |  9 +++++++++
 .../artery/aeron/AeronStreamConcistencySpec.scala  |  9 +++++++++
 .../artery/aeron/AeronStreamLatencySpec.scala      |  9 +++++++++
 .../aeron/AeronStreamMaxThroughputSpec.scala       |  9 +++++++++
 .../artery/aeron/AeronStreamMultiNodeSpec.scala    |  9 +++++++++
 .../remote/classic/RemoteGatePiercingSpec.scala    |  9 +++++++++
 .../remote/classic/RemoteNodeRestartGateSpec.scala |  9 +++++++++
 .../RemoteNodeShutdownAndComesBackSpec.scala       |  9 +++++++++
 .../pekko/remote/classic/Ticket15109Spec.scala     |  9 +++++++++
 .../pekko/remote/routing/RemoteRandomSpec.scala    |  9 +++++++++
 .../remote/routing/RemoteRoundRobinSpec.scala      |  9 +++++++++
 .../remote/routing/RemoteScatterGatherSpec.scala   |  9 +++++++++
 .../pekko/remote/sample/MultiNodeSample.scala      |  9 +++++++++
 .../remote/testconductor/TestConductorSpec.scala   |  9 +++++++++
 .../pekko/remote/testkit/MultiNodeSpecSpec.scala   |  9 +++++++++
 .../pekko/remote/artery/protobuf/TestMessages.java |  9 +++++++++
 remote-tests/src/test/protobuf/TestMessages.proto  |  9 +++++++++
 .../remote/artery/ArteryFailedToBindSpec.scala     |  9 +++++++++
 .../remote/classic/RemotingFailedToBindSpec.scala  |  9 +++++++++
 .../pekko/remote/testconductor/BarrierSpec.scala   |  9 +++++++++
 .../remote/testconductor/ControllerSpec.scala      |  9 +++++++++
 .../pekko/remote/testkit/LogRoleReplace.scala      |  9 +++++++++
 .../pekko/remote/testkit/STMultiNodeSpec.scala     |  9 +++++++++
 .../scala/org/scalatest/extra/QuietReporter.scala  |  9 +++++++++
 .../apache/pekko/remote/ArteryControlFormats.java  |  9 +++++++++
 .../org/apache/pekko/remote/ContainerFormats.java  |  9 +++++++++
 .../apache/pekko/remote/SystemMessageFormats.java  |  9 +++++++++
 .../java/org/apache/pekko/remote/WireFormats.java  |  9 +++++++++
 .../pekko/remote/artery/AbstractAssociation.java   |  9 +++++++++
 .../remote/artery/compress/CountMinSketch.java     |  9 +++++++++
 .../src/main/protobuf/ArteryControlFormats.proto   |  9 +++++++++
 remote/src/main/protobuf/ContainerFormats.proto    |  9 +++++++++
 .../src/main/protobuf/SystemMessageFormats.proto   |  9 +++++++++
 remote/src/main/protobuf/WireFormats.proto         |  9 +++++++++
 .../apache/pekko/remote/artery/jfr/Events.scala    |  9 +++++++++
 .../artery/jfr/JFRRemotingFlightRecorder.scala     |  9 +++++++++
 .../org/apache/pekko/remote/AckedDelivery.scala    |  9 +++++++++
 .../apache/pekko/remote/AddressUidExtension.scala  |  9 +++++++++
 .../pekko/remote/BoundAddressesExtension.scala     |  9 +++++++++
 .../org/apache/pekko/remote/ByteStringUtils.scala  |  9 +++++++++
 .../pekko/remote/DeadlineFailureDetector.scala     |  9 +++++++++
 .../remote/DefaultFailureDetectorRegistry.scala    |  9 +++++++++
 .../scala/org/apache/pekko/remote/Endpoint.scala   |  9 +++++++++
 .../org/apache/pekko/remote/FailureDetector.scala  |  9 +++++++++
 .../pekko/remote/FailureDetectorRegistry.scala     |  9 +++++++++
 .../apache/pekko/remote/MessageSerializer.scala    |  9 +++++++++
 .../pekko/remote/PhiAccrualFailureDetector.scala   |  9 +++++++++
 .../pekko/remote/RemoteActorRefProvider.scala      |  9 +++++++++
 .../org/apache/pekko/remote/RemoteDaemon.scala     |  9 +++++++++
 .../org/apache/pekko/remote/RemoteDeployer.scala   |  9 +++++++++
 .../pekko/remote/RemoteDeploymentWatcher.scala     |  9 +++++++++
 .../org/apache/pekko/remote/RemoteLogMarker.scala  |  9 +++++++++
 .../pekko/remote/RemoteMetricsExtension.scala      |  9 +++++++++
 .../org/apache/pekko/remote/RemoteSettings.scala   |  9 +++++++++
 .../org/apache/pekko/remote/RemoteTransport.scala  |  9 +++++++++
 .../org/apache/pekko/remote/RemoteWatcher.scala    |  9 +++++++++
 .../scala/org/apache/pekko/remote/Remoting.scala   |  9 +++++++++
 .../pekko/remote/RemotingLifecycleEvent.scala      |  9 +++++++++
 .../org/apache/pekko/remote/UniqueAddress.scala    |  9 +++++++++
 .../pekko/remote/artery/ArterySettings.scala       |  9 +++++++++
 .../pekko/remote/artery/ArteryTransport.scala      |  9 +++++++++
 .../apache/pekko/remote/artery/Association.scala   |  9 +++++++++
 .../org/apache/pekko/remote/artery/Codecs.scala    |  9 +++++++++
 .../org/apache/pekko/remote/artery/Control.scala   |  9 +++++++++
 .../pekko/remote/artery/EnvelopeBufferPool.scala   |  9 +++++++++
 .../remote/artery/FixedSizePartitionHub.scala      |  9 +++++++++
 .../artery/FlushBeforeDeathWatchNotification.scala |  9 +++++++++
 .../pekko/remote/artery/FlushOnShutdown.scala      |  9 +++++++++
 .../org/apache/pekko/remote/artery/Handshake.scala |  9 +++++++++
 .../pekko/remote/artery/ImmutableLongMap.scala     |  9 +++++++++
 .../pekko/remote/artery/InboundEnvelope.scala      |  9 +++++++++
 .../remote/artery/InboundQuarantineCheck.scala     |  9 +++++++++
 .../pekko/remote/artery/LruBoundedCache.scala      |  9 +++++++++
 .../pekko/remote/artery/MessageDispatcher.scala    |  9 +++++++++
 .../apache/pekko/remote/artery/ObjectPool.scala    |  9 +++++++++
 .../pekko/remote/artery/OutboundEnvelope.scala     |  9 +++++++++
 .../pekko/remote/artery/QuarantinedEvent.scala     |  9 +++++++++
 .../pekko/remote/artery/RemoteInstrument.scala     |  9 +++++++++
 .../remote/artery/RemotingFlightRecorder.scala     |  9 +++++++++
 .../pekko/remote/artery/RestartCounter.scala       |  9 +++++++++
 .../org/apache/pekko/remote/artery/SendQueue.scala |  9 +++++++++
 .../remote/artery/SystemMessageDelivery.scala      |  9 +++++++++
 .../org/apache/pekko/remote/artery/TestStage.scala |  9 +++++++++
 .../pekko/remote/artery/aeron/AeronSink.scala      |  9 +++++++++
 .../pekko/remote/artery/aeron/AeronSource.scala    |  9 +++++++++
 .../artery/aeron/ArteryAeronUdpTransport.scala     |  9 +++++++++
 .../pekko/remote/artery/aeron/TaskRunner.scala     |  9 +++++++++
 .../artery/compress/CompressionProtocol.scala      |  9 +++++++++
 .../remote/artery/compress/CompressionTable.scala  |  9 +++++++++
 .../artery/compress/DecompressionTable.scala       |  9 +++++++++
 .../artery/compress/InboundCompressions.scala      |  9 +++++++++
 .../remote/artery/compress/TopHeavyHitters.scala   |  9 +++++++++
 .../remote/artery/tcp/ArteryTcpTransport.scala     |  9 +++++++++
 .../artery/tcp/ConfigSSLEngineProvider.scala       |  9 +++++++++
 .../remote/artery/tcp/SSLEngineProvider.scala      |  9 +++++++++
 .../remote/artery/tcp/SecureRandomFactory.scala    |  9 +++++++++
 .../pekko/remote/artery/tcp/TcpFraming.scala       |  9 +++++++++
 .../artery/tcp/ssl/PemManagersProvider.scala       |  9 +++++++++
 .../tcp/ssl/RotatingKeysSSLEngineProvider.scala    |  9 +++++++++
 .../remote/artery/tcp/ssl/SSLEngineConfig.scala    |  9 +++++++++
 .../remote/artery/tcp/ssl/SessionVerifier.scala    |  9 +++++++++
 .../pekko/remote/artery/tcp/ssl/X509Readers.scala  |  9 +++++++++
 .../pekko/remote/routing/RemoteRouterConfig.scala  |  9 +++++++++
 .../pekko/remote/security/provider/SeedSize.scala  |  9 +++++++++
 .../serialization/ActorRefResolveCache.scala       |  9 +++++++++
 .../serialization/ArteryMessageSerializer.scala    |  9 +++++++++
 .../serialization/DaemonMsgCreateSerializer.scala  |  9 +++++++++
 .../serialization/MessageContainerSerializer.scala |  9 +++++++++
 .../serialization/MiscMessageSerializer.scala      |  9 +++++++++
 .../serialization/PrimitiveSerializers.scala       |  9 +++++++++
 .../remote/serialization/ProtobufSerializer.scala  |  9 +++++++++
 .../serialization/SystemMessageSerializer.scala    |  9 +++++++++
 .../ThrowableNotSerializableException.scala        |  9 +++++++++
 .../remote/serialization/ThrowableSupport.scala    |  9 +++++++++
 .../serialization/WrappedPayloadSupport.scala      |  9 +++++++++
 .../transport/AbstractTransportAdapter.scala       |  9 +++++++++
 .../FailureInjectorTransportAdapter.scala          |  9 +++++++++
 .../pekko/remote/transport/PekkoPduCodec.scala     |  9 +++++++++
 .../remote/transport/PekkoProtocolTransport.scala  |  9 +++++++++
 .../pekko/remote/transport/TestTransport.scala     |  9 +++++++++
 .../transport/ThrottlerTransportAdapter.scala      |  9 +++++++++
 .../apache/pekko/remote/transport/Transport.scala  |  9 +++++++++
 .../remote/transport/netty/NettyHelpers.scala      |  9 +++++++++
 .../remote/transport/netty/NettySSLSupport.scala   |  9 +++++++++
 .../remote/transport/netty/NettyTransport.scala    |  9 +++++++++
 .../remote/transport/netty/SSLEngineProvider.scala |  9 +++++++++
 .../pekko/remote/transport/netty/TcpSupport.scala  |  9 +++++++++
 .../org/apache/pekko/remote/ProtobufProtocol.java  |  9 +++++++++
 .../remote/protobuf/v3/ProtobufProtocolV3.java     |  9 +++++++++
 .../transport/ThrottlerTransportAdapterTest.java   |  9 +++++++++
 remote/src/test/protobuf/ProtobufProtocol.proto    |  9 +++++++++
 remote/src/test/protobuf/ProtobufProtocolV3.proto  |  9 +++++++++
 .../artery/jfr/JFRRemotingFlightRecorderSpec.scala |  9 +++++++++
 .../pekko/remote/AccrualFailureDetectorSpec.scala  |  9 +++++++++
 .../apache/pekko/remote/AckedDeliverySpec.scala    |  9 +++++++++
 .../org/apache/pekko/remote/DaemonicSpec.scala     |  9 +++++++++
 .../pekko/remote/DeadlineFailureDetectorSpec.scala |  9 +++++++++
 .../apache/pekko/remote/EndpointRegistrySpec.scala |  9 +++++++++
 .../pekko/remote/FailureDetectorRegistrySpec.scala |  9 +++++++++
 .../org/apache/pekko/remote/LogSourceSpec.scala    |  9 +++++++++
 .../apache/pekko/remote/MessageLoggingSpec.scala   |  9 +++++++++
 .../apache/pekko/remote/NetworkFailureSpec.scala   |  9 +++++++++
 .../pekko/remote/RemoteActorMailboxSpec.scala      |  9 +++++++++
 .../org/apache/pekko/remote/RemoteConfigSpec.scala |  9 +++++++++
 .../remote/RemoteConsistentHashingRouterSpec.scala |  9 +++++++++
 .../apache/pekko/remote/RemoteDeployerSpec.scala   |  9 +++++++++
 .../apache/pekko/remote/RemoteFeaturesSpec.scala   |  9 +++++++++
 .../org/apache/pekko/remote/RemoteRouterSpec.scala |  9 +++++++++
 .../pekko/remote/Ticket1978CommunicationSpec.scala |  9 +++++++++
 .../apache/pekko/remote/Ticket1978ConfigSpec.scala |  9 +++++++++
 .../remote/TransientSerializationErrorSpec.scala   |  9 +++++++++
 .../pekko/remote/TypedActorRemoteDeploySpec.scala  |  9 +++++++++
 .../ActorRefResolveCacheQuarantineSpec.scala       |  9 +++++++++
 .../pekko/remote/artery/ArteryMultiNodeSpec.scala  |  9 +++++++++
 .../pekko/remote/artery/ArterySpecSupport.scala    |  9 +++++++++
 .../remote/artery/BindCanonicalAddressSpec.scala   |  9 +++++++++
 .../pekko/remote/artery/DuplicateFlushSpec.scala   |  9 +++++++++
 .../remote/artery/DuplicateHandshakeSpec.scala     |  9 +++++++++
 .../pekko/remote/artery/EnvelopeBufferSpec.scala   |  9 +++++++++
 .../pekko/remote/artery/FlushOnShutdownSpec.scala  |  9 +++++++++
 .../pekko/remote/artery/HandshakeDenySpec.scala    |  9 +++++++++
 .../pekko/remote/artery/HandshakeFailureSpec.scala |  9 +++++++++
 .../pekko/remote/artery/HandshakeRetrySpec.scala   |  9 +++++++++
 .../pekko/remote/artery/ImmutableLongMapSpec.scala |  9 +++++++++
 .../remote/artery/InboundControlJunctionSpec.scala |  9 +++++++++
 .../pekko/remote/artery/InboundHandshakeSpec.scala |  9 +++++++++
 .../remote/artery/LargeMessagesStreamSpec.scala    |  9 +++++++++
 .../pekko/remote/artery/LateConnectSpec.scala      |  9 +++++++++
 .../pekko/remote/artery/LruBoundedCacheSpec.scala  |  9 +++++++++
 .../pekko/remote/artery/MetadataCarryingSpec.scala |  9 +++++++++
 .../artery/OutboundControlJunctionSpec.scala       |  9 +++++++++
 .../remote/artery/OutboundHandshakeSpec.scala      |  9 +++++++++
 .../remote/artery/OutboundIdleShutdownSpec.scala   |  9 +++++++++
 .../remote/artery/RemoteActorRefProviderSpec.scala |  9 +++++++++
 .../remote/artery/RemoteActorSelectionSpec.scala   |  9 +++++++++
 .../pekko/remote/artery/RemoteConnectionSpec.scala |  9 +++++++++
 .../pekko/remote/artery/RemoteDeathWatchSpec.scala |  9 +++++++++
 .../pekko/remote/artery/RemoteDeployerSpec.scala   |  9 +++++++++
 .../pekko/remote/artery/RemoteDeploymentSpec.scala |  9 +++++++++
 .../pekko/remote/artery/RemoteFailureSpec.scala    |  9 +++++++++
 .../RemoteInstrumentsSerializationSpec.scala       |  9 +++++++++
 .../remote/artery/RemoteInstrumentsSpec.scala      |  9 +++++++++
 .../artery/RemoteMessageSerializationSpec.scala    |  9 +++++++++
 .../pekko/remote/artery/RemoteRouterSpec.scala     |  9 +++++++++
 .../remote/artery/RemoteSendConsistencySpec.scala  |  9 +++++++++
 .../pekko/remote/artery/RemoteWatcherSpec.scala    |  9 +++++++++
 .../remote/artery/RemotingFlightRecorderSpec.scala |  9 +++++++++
 .../pekko/remote/artery/RestartCounterSpec.scala   |  9 +++++++++
 .../artery/RollingEventLogSimulationSpec.scala     |  9 +++++++++
 .../apache/pekko/remote/artery/SendQueueSpec.scala |  9 +++++++++
 .../remote/artery/SerializationErrorSpec.scala     |  9 +++++++++
 .../SerializationTransportInformationSpec.scala    |  9 +++++++++
 .../remote/artery/SystemMessageAckerSpec.scala     |  9 +++++++++
 .../remote/artery/SystemMessageDeliverySpec.scala  |  9 +++++++++
 .../apache/pekko/remote/artery/TestContext.scala   |  9 +++++++++
 .../artery/TransientSerializationErrorSpec.scala   |  9 +++++++++
 .../apache/pekko/remote/artery/UntrustedSpec.scala |  9 +++++++++
 .../pekko/remote/artery/aeron/AeronSinkSpec.scala  |  9 +++++++++
 .../compress/CompressionIntegrationSpec.scala      |  9 +++++++++
 .../artery/compress/CompressionTableSpec.scala     |  9 +++++++++
 .../artery/compress/CompressionTestUtils.scala     |  9 +++++++++
 .../HandshakeShouldDropCompressionTableSpec.scala  |  9 +++++++++
 .../remote/artery/compress/HeavyHittersSpec.scala  |  9 +++++++++
 .../artery/compress/OutboundCompressionSpec.scala  |  9 +++++++++
 .../artery/tcp/SecureRandomFactorySpec.scala       |  9 +++++++++
 .../pekko/remote/artery/tcp/TcpFramingSpec.scala   |  9 +++++++++
 .../pekko/remote/artery/tcp/TlsTcpSpec.scala       |  9 +++++++++
 .../artery/tcp/ssl/CipherSuiteSupportCheck.scala   |  9 +++++++++
 .../artery/tcp/ssl/PeerSubjectVerifierSpec.scala   |  9 +++++++++
 .../artery/tcp/ssl/PemManagersProviderSpec.scala   |  9 +++++++++
 .../ssl/RotatingKeysSSLEngineProviderSpec.scala    |  9 +++++++++
 .../remote/artery/tcp/ssl/TlsResourcesSpec.scala   |  9 +++++++++
 .../remote/artery/tcp/ssl/X509ReadersSpec.scala    |  9 +++++++++
 .../pekko/remote/classic/ActorsLeakSpec.scala      |  9 +++++++++
 .../remote/classic/RemoteDeathWatchSpec.scala      |  9 +++++++++
 .../classic/RemoteDeploymentAllowListSpec.scala    |  9 +++++++++
 .../pekko/remote/classic/RemoteInitErrorSpec.scala |  9 +++++++++
 .../pekko/remote/classic/RemoteSettingsSpec.scala  |  9 +++++++++
 .../pekko/remote/classic/RemoteWatcherSpec.scala   |  9 +++++++++
 .../apache/pekko/remote/classic/RemotingSpec.scala |  9 +++++++++
 .../pekko/remote/classic/UntrustedSpec.scala       |  9 +++++++++
 .../classic/transport/GenericTransportSpec.scala   |  9 +++++++++
 .../classic/transport/PekkoProtocolSpec.scala      |  9 +++++++++
 .../transport/PekkoProtocolStressTest.scala        |  9 +++++++++
 .../transport/SwitchableLoggedBehaviorSpec.scala   |  9 +++++++++
 .../SystemMessageDeliveryStressTest.scala          |  9 +++++++++
 .../classic/transport/TestTransportSpec.scala      |  9 +++++++++
 .../classic/transport/ThrottleModeSpec.scala       |  9 +++++++++
 .../transport/ThrottlerTransportAdapterSpec.scala  |  9 +++++++++
 .../transport/netty/NettyTransportSpec.scala       |  9 +++++++++
 .../AllowJavaSerializationOffSpec.scala            |  9 +++++++++
 .../ArteryMessageSerializerSpec.scala              |  9 +++++++++
 ...reateSerializerAllowJavaSerializationSpec.scala |  9 +++++++++
 .../MessageContainerSerializerSpec.scala           |  9 +++++++++
 .../serialization/MiscMessageSerializerSpec.scala  |  9 +++++++++
 .../PrimitivesSerializationSpec.scala              |  9 +++++++++
 .../serialization/ProtobufSerializerSpec.scala     |  9 +++++++++
 .../SerializationTransportInformationSpec.scala    |  9 +++++++++
 .../SystemMessageSerializationSpec.scala           |  9 +++++++++
 .../serialization/jackson/ActorRefModule.scala     |  9 +++++++++
 .../serialization/jackson/ActorSystemAccess.scala  |  9 +++++++++
 .../serialization/jackson/AddressModule.scala      |  9 +++++++++
 .../jackson/AkkaSerializationModule.scala          |  9 +++++++++
 .../jackson/FiniteDurationModule.scala             |  9 +++++++++
 .../serialization/jackson/JacksonMigration.scala   |  9 +++++++++
 .../serialization/jackson/JacksonModule.scala      |  9 +++++++++
 .../jackson/JacksonObjectMapperProvider.scala      |  9 +++++++++
 .../serialization/jackson/JacksonSerializer.scala  |  9 +++++++++
 .../serialization/jackson/PekkoJacksonModule.scala |  9 +++++++++
 .../serialization/jackson/StreamRefModule.scala    |  9 +++++++++
 .../jackson/TypedActorRefModule.scala              |  9 +++++++++
 .../serialization/jackson/MySerializable.java      |  9 +++++++++
 .../jackson/SerializationDocTest.java              |  9 +++++++++
 .../pekko/serialization/jackson/v1/Customer.java   |  9 +++++++++
 .../pekko/serialization/jackson/v1/ItemAdded.java  |  9 +++++++++
 .../pekko/serialization/jackson/v1/OrderAdded.java |  9 +++++++++
 .../jackson/v1withv2/ItemAddedMigration.java       |  9 +++++++++
 .../pekko/serialization/jackson/v2a/Address.java   |  9 +++++++++
 .../pekko/serialization/jackson/v2a/Customer.java  |  9 +++++++++
 .../jackson/v2a/CustomerMigration.java             |  9 +++++++++
 .../pekko/serialization/jackson/v2a/ItemAdded.java |  9 +++++++++
 .../serialization/jackson/v2a/OrderPlaced.java     |  9 +++++++++
 .../jackson/v2a/OrderPlacedMigration.java          |  9 +++++++++
 .../pekko/serialization/jackson/v2b/ItemAdded.java |  9 +++++++++
 .../jackson/v2b/ItemAddedMigration.java            |  9 +++++++++
 .../pekko/serialization/jackson/v2c/ItemAdded.java |  9 +++++++++
 .../jackson/v2c/ItemAddedMigration.java            |  9 +++++++++
 .../jackson/JavaTestEventMigrationV2.java          |  9 +++++++++
 .../jackson/JavaTestEventMigrationV2WithV3.java    |  9 +++++++++
 .../jackson/JavaTestEventMigrationV3.java          |  9 +++++++++
 .../serialization/jackson/JavaTestMessages.java    |  9 +++++++++
 .../jackson/CustomAdtSerializer.scala              |  9 +++++++++
 .../jackson/SerializationDocSpec.scala             |  9 +++++++++
 .../pekko/serialization/jackson/v1/Customer.scala  |  9 +++++++++
 .../pekko/serialization/jackson/v1/ItemAdded.scala |  9 +++++++++
 .../serialization/jackson/v1/OrderAdded.scala      |  9 +++++++++
 .../jackson/v1withv2/ItemAddedMigration.scala      |  9 +++++++++
 .../pekko/serialization/jackson/v2a/Address.scala  |  9 +++++++++
 .../pekko/serialization/jackson/v2a/Customer.scala |  9 +++++++++
 .../jackson/v2a/CustomerMigration.scala            |  9 +++++++++
 .../serialization/jackson/v2a/ItemAdded.scala      |  9 +++++++++
 .../serialization/jackson/v2a/OrderPlaced.scala    |  9 +++++++++
 .../jackson/v2a/OrderPlacedMigration.scala         |  9 +++++++++
 .../serialization/jackson/v2b/ItemAdded.scala      |  9 +++++++++
 .../jackson/v2b/ItemAddedMigration.scala           |  9 +++++++++
 .../serialization/jackson/v2c/ItemAdded.scala      |  9 +++++++++
 .../jackson/v2c/ItemAddedMigration.scala           |  9 +++++++++
 .../serialization/jackson/CborSerializable.scala   |  9 +++++++++
 .../jackson/JacksonSerializerSpec.scala            |  9 +++++++++
 .../serialization/jackson/JsonSerializable.scala   |  9 +++++++++
 .../jackson/ScalaTestEventMigration.scala          |  9 +++++++++
 .../org/apache/pekko/event/slf4j/Slf4jLogger.scala |  9 +++++++++
 .../apache/pekko/event/slf4j/Slf4jLoggerSpec.scala |  9 +++++++++
 .../pekko/event/slf4j/Slf4jLoggingFilterSpec.scala |  9 +++++++++
 .../pekko/stream/testkit/StreamTestKit.scala       |  9 +++++++++
 .../pekko/stream/testkit/TestGraphStage.scala      |  9 +++++++++
 .../stream/testkit/javadsl/StreamTestKit.scala     |  9 +++++++++
 .../pekko/stream/testkit/javadsl/TestSink.scala    |  9 +++++++++
 .../pekko/stream/testkit/javadsl/TestSource.scala  |  9 +++++++++
 .../stream/testkit/scaladsl/StreamTestKit.scala    |  9 +++++++++
 .../pekko/stream/testkit/scaladsl/TestSink.scala   |  9 +++++++++
 .../pekko/stream/testkit/scaladsl/TestSource.scala |  9 +++++++++
 .../impl/fusing/GraphInterpreterSpecKit.scala      |  9 +++++++++
 .../pekko/stream/testkit/BaseTwoStreamsSetup.scala |  9 +++++++++
 .../apache/pekko/stream/testkit/ChainSetup.scala   |  9 +++++++++
 .../apache/pekko/stream/testkit/ScriptedTest.scala |  9 +++++++++
 .../apache/pekko/stream/testkit/StreamSpec.scala   |  9 +++++++++
 .../stream/testkit/StreamTestDefaultMailbox.scala  |  9 +++++++++
 .../pekko/stream/testkit/StreamTestKitSpec.scala   |  9 +++++++++
 .../testkit/TestPublisherSubscriberSpec.scala      |  9 +++++++++
 .../pekko/stream/testkit/TwoStreamsSetup.scala     |  9 +++++++++
 .../org/apache/pekko/stream/testkit/Utils.scala    |  9 +++++++++
 ...IterablePublisherViaJavaFlowPublisherTest.scala |  9 +++++++++
 .../pekko/stream/tck/ActorSystemLifecycle.scala    |  9 +++++++++
 .../stream/tck/AkkaSubscriberVerification.scala    |  9 +++++++++
 .../stream/tck/CancelledSinkSubscriberTest.scala   |  9 +++++++++
 .../org/apache/pekko/stream/tck/ConcatTest.scala   |  9 +++++++++
 .../pekko/stream/tck/EmptyPublisherTest.scala      |  9 +++++++++
 .../pekko/stream/tck/FanoutPublisherTest.scala     |  9 +++++++++
 .../pekko/stream/tck/FilePublisherTest.scala       |  9 +++++++++
 .../tck/FlatMapConcatDoubleSubscriberTest.scala    |  9 +++++++++
 .../pekko/stream/tck/FlatMapPrefixTest.scala       |  9 +++++++++
 .../org/apache/pekko/stream/tck/FlattenTest.scala  |  9 +++++++++
 .../pekko/stream/tck/FoldSinkSubscriberTest.scala  |  9 +++++++++
 .../stream/tck/ForeachSinkSubscriberTest.scala     |  9 +++++++++
 .../pekko/stream/tck/FusableProcessorTest.scala    |  9 +++++++++
 .../pekko/stream/tck/FuturePublisherTest.scala     |  9 +++++++++
 .../org/apache/pekko/stream/tck/GroupByTest.scala  |  9 +++++++++
 .../pekko/stream/tck/InputStreamSourceTest.scala   |  9 +++++++++
 .../pekko/stream/tck/IterablePublisherTest.scala   |  9 +++++++++
 .../org/apache/pekko/stream/tck/MapTest.scala      |  9 +++++++++
 .../apache/pekko/stream/tck/MaybeSourceTest.scala  |  9 +++++++++
 .../tck/PekkoIdentityProcessorVerification.scala   |  9 +++++++++
 .../stream/tck/PekkoPublisherVerification.scala    |  9 +++++++++
 .../pekko/stream/tck/PrefixAndTailTest.scala       |  9 +++++++++
 .../pekko/stream/tck/SingleElementSourceTest.scala |  9 +++++++++
 .../pekko/stream/tck/SinkholeSubscriberTest.scala  |  9 +++++++++
 .../apache/pekko/stream/tck/SplitWhenTest.scala    |  9 +++++++++
 .../org/apache/pekko/stream/tck/Timeouts.scala     |  9 +++++++++
 .../pekko/stream/tck/TransformProcessorTest.scala  |  9 +++++++++
 .../pekko/stream/tck/VirtualPublisherTest.scala    |  9 +++++++++
 .../stream/javadsl/JavaFlowSupportCompileTest.java |  9 +++++++++
 .../pekko/stream/StreamAttributeDocTest.java       |  9 +++++++++
 .../java/org/apache/pekko/stream/StreamTest.java   |  9 +++++++++
 .../pekko/stream/io/InputStreamSinkTest.java       |  9 +++++++++
 .../pekko/stream/io/OutputStreamSinkTest.java      |  9 +++++++++
 .../pekko/stream/io/OutputStreamSourceTest.java    |  9 +++++++++
 .../pekko/stream/io/SinkAsJavaSourceTest.java      |  9 +++++++++
 .../pekko/stream/javadsl/AttributesTest.java       |  9 +++++++++
 .../stream/javadsl/FlowLogWithMarkerTest.java      |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/FlowTest.java  |  9 +++++++++
 .../pekko/stream/javadsl/FlowThrottleTest.java     |  9 +++++++++
 .../pekko/stream/javadsl/FlowWithContextTest.java  |  9 +++++++++
 .../javadsl/FlowWithContextThrottleTest.java       |  9 +++++++++
 .../apache/pekko/stream/javadsl/FramingTest.java   |  9 +++++++++
 .../apache/pekko/stream/javadsl/GraphDslTest.java  |  9 +++++++++
 .../pekko/stream/javadsl/JsonFramingTest.java      |  9 +++++++++
 .../pekko/stream/javadsl/KillSwitchTest.java       |  9 +++++++++
 .../stream/javadsl/LazyAndFutureFlowTest.java      |  9 +++++++++
 .../stream/javadsl/LazyAndFutureSourcesTest.java   |  9 +++++++++
 .../apache/pekko/stream/javadsl/RetryFlowTest.java |  9 +++++++++
 .../pekko/stream/javadsl/RunnableGraphTest.java    |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/SetupTest.java |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/SinkTest.java  |  9 +++++++++
 .../pekko/stream/javadsl/SourceRunWithTest.java    |  9 +++++++++
 .../apache/pekko/stream/javadsl/SourceTest.java    |  9 +++++++++
 .../pekko/stream/javadsl/SourceUnfoldTest.java     |  9 +++++++++
 .../javadsl/SourceWithContextThrottleTest.java     |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/TcpTest.java   |  9 +++++++++
 .../pekko/stream/stage/JavaIdentityStage.java      |  9 +++++++++
 .../org/apache/pekko/stream/stage/StageTest.java   |  9 +++++++++
 .../stream/scaladsl/FlowPublisherSinkSpec.scala    |  9 +++++++++
 .../pekko/stream/ActorMaterializerSpec.scala       |  9 +++++++++
 .../apache/pekko/stream/DslConsistencySpec.scala   |  9 +++++++++
 .../pekko/stream/DslFactoriesConsistencySpec.scala |  9 +++++++++
 .../scala/org/apache/pekko/stream/FusingSpec.scala |  9 +++++++++
 .../pekko/stream/SourceLocationAttributeSpec.scala |  9 +++++++++
 .../pekko/stream/StreamAttributeDocSpec.scala      |  9 +++++++++
 .../apache/pekko/stream/StreamDispatcherSpec.scala |  9 +++++++++
 .../pekko/stream/SystemMaterializerSpec.scala      |  9 +++++++++
 .../pekko/stream/impl/FanoutProcessorSpec.scala    |  9 +++++++++
 .../apache/pekko/stream/impl/FixedBufferSpec.scala |  9 +++++++++
 .../pekko/stream/impl/GraphStageLogicSpec.scala    |  9 +++++++++
 .../stream/impl/LinearTraversalBuilderSpec.scala   |  9 +++++++++
 .../impl/ResizableMultiReaderRingBufferSpec.scala  |  9 +++++++++
 .../pekko/stream/impl/SubInletOutletSpec.scala     |  9 +++++++++
 .../apache/pekko/stream/impl/TimeoutsSpec.scala    |  9 +++++++++
 .../pekko/stream/impl/TraversalBuilderSpec.scala   |  9 +++++++++
 .../pekko/stream/impl/TraversalTestUtils.scala     |  9 +++++++++
 .../impl/fusing/ActorGraphInterpreterSpec.scala    |  9 +++++++++
 .../stream/impl/fusing/AsyncCallbackSpec.scala     |  9 +++++++++
 .../stream/impl/fusing/ChasingEventsSpec.scala     |  9 +++++++++
 .../fusing/GraphInterpreterFailureModesSpec.scala  |  9 +++++++++
 .../impl/fusing/GraphInterpreterPortsSpec.scala    |  9 +++++++++
 .../stream/impl/fusing/GraphInterpreterSpec.scala  |  9 +++++++++
 .../pekko/stream/impl/fusing/InterpreterSpec.scala |  9 +++++++++
 .../stream/impl/fusing/InterpreterStressSpec.scala |  9 +++++++++
 .../impl/fusing/InterpreterSupervisionSpec.scala   |  9 +++++++++
 .../stream/impl/fusing/KeepGoingStageSpec.scala    |  9 +++++++++
 .../impl/fusing/LifecycleInterpreterSpec.scala     |  9 +++++++++
 .../apache/pekko/stream/impl/io/TLSUtilsSpec.scala |  9 +++++++++
 .../pekko/stream/io/ByteStringParserSpec.scala     |  9 +++++++++
 .../apache/pekko/stream/io/DeprecatedTlsSpec.scala |  9 +++++++++
 .../org/apache/pekko/stream/io/FileSinkSpec.scala  |  9 +++++++++
 .../apache/pekko/stream/io/FileSourceSpec.scala    |  9 +++++++++
 .../pekko/stream/io/InputStreamSinkSpec.scala      |  9 +++++++++
 .../pekko/stream/io/InputStreamSourceSpec.scala    |  9 +++++++++
 .../pekko/stream/io/OutputStreamSinkSpec.scala     |  9 +++++++++
 .../pekko/stream/io/OutputStreamSourceSpec.scala   |  9 +++++++++
 .../org/apache/pekko/stream/io/TcpHelper.scala     |  9 +++++++++
 .../scala/org/apache/pekko/stream/io/TcpSpec.scala |  9 +++++++++
 .../scala/org/apache/pekko/stream/io/TlsSpec.scala |  9 +++++++++
 .../stream/io/compression/CodecSpecSupport.scala   |  9 +++++++++
 .../pekko/stream/io/compression/CoderSpec.scala    |  9 +++++++++
 .../io/compression/CompressionTestingTools.scala   |  9 +++++++++
 .../pekko/stream/io/compression/DeflateSpec.scala  |  9 +++++++++
 .../pekko/stream/io/compression/GzipSpec.scala     |  9 +++++++++
 .../GzipWithCustomCompressionLevelSpec.scala       |  9 +++++++++
 .../scaladsl/ActorRefBackpressureSinkSpec.scala    |  9 +++++++++
 .../scaladsl/ActorRefBackpressureSourceSpec.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/ActorRefSinkSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/ActorRefSourceSpec.scala |  9 +++++++++
 .../scaladsl/AggregateWithBoundarySpec.scala       |  9 +++++++++
 .../pekko/stream/scaladsl/AttributesSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/BidiFlowSpec.scala       |  9 +++++++++
 .../stream/scaladsl/BoundedSourceQueueSpec.scala   |  9 +++++++++
 .../stream/scaladsl/CancellationStrategySpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/CollectionSinkSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/CompressionSpec.scala    |  9 +++++++++
 .../scaladsl/CoupledTerminationFlowSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/FailedSourceSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/FlowAlsoToAllSpec.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/FlowAppendSpec.scala     |  9 +++++++++
 .../apache/pekko/stream/scaladsl/FlowAskSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/FlowBatchSpec.scala      |  9 +++++++++
 .../stream/scaladsl/FlowBatchWeightedSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowBufferSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/FlowCollectSpec.scala    |  9 +++++++++
 .../stream/scaladsl/FlowCollectTypeSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/FlowCompileSpec.scala    |  9 +++++++++
 .../stream/scaladsl/FlowConcatAllLazySpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowConcatAllSpec.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/FlowConcatSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/FlowConflateSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/FlowDelaySpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/FlowDetacherSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/FlowDispatcherSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/FlowDropSpec.scala       |  9 +++++++++
 .../pekko/stream/scaladsl/FlowDropWhileSpec.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/FlowDropWithinSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/FlowExpandSpec.scala     |  9 +++++++++
 .../stream/scaladsl/FlowExtrapolateSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/FlowFilterSpec.scala     |  9 +++++++++
 .../stream/scaladsl/FlowFlatMapPrefixSpec.scala    |  9 +++++++++
 .../stream/scaladsl/FlowFlattenMergeSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/FlowFoldAsyncSpec.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/FlowFoldSpec.scala       |  9 +++++++++
 .../pekko/stream/scaladsl/FlowForeachSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowFromFutureSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/FlowFutureFlowSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/FlowGroupBySpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowGroupedSpec.scala    |  9 +++++++++
 .../stream/scaladsl/FlowGroupedWeightedSpec.scala  |  9 +++++++++
 .../stream/scaladsl/FlowGroupedWithinSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowIdleInjectSpec.scala |  9 +++++++++
 .../stream/scaladsl/FlowInitialDelaySpec.scala     |  9 +++++++++
 .../stream/scaladsl/FlowInterleaveAllSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowInterleaveSpec.scala |  9 +++++++++
 .../stream/scaladsl/FlowIntersperseSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/FlowIteratorSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/FlowJoinSpec.scala       |  9 +++++++++
 .../pekko/stream/scaladsl/FlowKillSwitchSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/FlowLimitSpec.scala      |  9 +++++++++
 .../stream/scaladsl/FlowLimitWeightedSpec.scala    |  9 +++++++++
 .../apache/pekko/stream/scaladsl/FlowLogSpec.scala |  9 +++++++++
 .../stream/scaladsl/FlowLogWithMarkerSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowMapAsyncSpec.scala   |  9 +++++++++
 .../scaladsl/FlowMapAsyncUnorderedSpec.scala       |  9 +++++++++
 .../pekko/stream/scaladsl/FlowMapConcatSpec.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/FlowMapErrorSpec.scala   |  9 +++++++++
 .../apache/pekko/stream/scaladsl/FlowMapSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/FlowMergeAllSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/FlowMergeSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/FlowMonitorSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowOnCompleteSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/FlowOrElseSpec.scala     |  9 +++++++++
 .../stream/scaladsl/FlowPrefixAndTailSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowPrependSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowRecoverSpec.scala    |  9 +++++++++
 .../stream/scaladsl/FlowRecoverWithSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/FlowReduceSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/FlowScanAsyncSpec.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/FlowScanSpec.scala       |  9 +++++++++
 .../pekko/stream/scaladsl/FlowSectionSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowSlidingSpec.scala    |  9 +++++++++
 .../apache/pekko/stream/scaladsl/FlowSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowSplitAfterSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/FlowSplitWhenSpec.scala  |  9 +++++++++
 .../scaladsl/FlowStatefulMapConcatSpec.scala       |  9 +++++++++
 .../stream/scaladsl/FlowStatefulMapSpec.scala      |  9 +++++++++
 .../stream/scaladsl/FlowSupervisionSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/FlowTakeSpec.scala       |  9 +++++++++
 .../pekko/stream/scaladsl/FlowTakeWhileSpec.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/FlowTakeWithinSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/FlowThrottleSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/FlowWatchSpec.scala      |  9 +++++++++
 .../stream/scaladsl/FlowWatchTerminationSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/FlowWireTapSpec.scala    |  9 +++++++++
 .../stream/scaladsl/FlowWithContextLogSpec.scala   |  9 +++++++++
 .../stream/scaladsl/FlowWithContextSpec.scala      |  9 +++++++++
 .../scaladsl/FlowWithContextThrottleSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/FlowZipAllSpec.scala     |  9 +++++++++
 .../apache/pekko/stream/scaladsl/FlowZipSpec.scala |  9 +++++++++
 .../stream/scaladsl/FlowZipWithIndexSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/FlowZipWithSpec.scala    |  9 +++++++++
 .../apache/pekko/stream/scaladsl/FramingSpec.scala |  9 +++++++++
 .../stream/scaladsl/FromMaterializationSpec.scala  |  9 +++++++++
 .../stream/scaladsl/GraphBackedFlowSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/GraphBalanceSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/GraphBroadcastSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/GraphConcatSpec.scala    |  9 +++++++++
 .../stream/scaladsl/GraphDSLCompileSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/GraphMatValueSpec.scala  |  9 +++++++++
 .../stream/scaladsl/GraphMergeLatestSpec.scala     |  9 +++++++++
 .../stream/scaladsl/GraphMergePreferredSpec.scala  |  9 +++++++++
 .../scaladsl/GraphMergePrioritizedNSpec.scala      |  9 +++++++++
 .../scaladsl/GraphMergePrioritizedSpec.scala       |  9 +++++++++
 .../stream/scaladsl/GraphMergeSequenceSpec.scala   |  9 +++++++++
 .../stream/scaladsl/GraphMergeSortedSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/GraphMergeSpec.scala     |  9 +++++++++
 .../stream/scaladsl/GraphOpsIntegrationSpec.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/GraphPartialSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/GraphPartitionSpec.scala |  9 +++++++++
 .../stream/scaladsl/GraphStageTimersSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/GraphUnzipSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/GraphUnzipWithSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/GraphWireTapSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/GraphZipLatestSpec.scala |  9 +++++++++
 .../stream/scaladsl/GraphZipLatestWithSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/GraphZipNSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/GraphZipSpec.scala       |  9 +++++++++
 .../pekko/stream/scaladsl/GraphZipWithNSpec.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/GraphZipWithSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/HeadSinkSpec.scala       |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/HubSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/JsonFramingSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/LastSinkSpec.scala       |  9 +++++++++
 .../pekko/stream/scaladsl/LazilyAsyncSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/LazyFlowSpec.scala       |  9 +++++++++
 .../pekko/stream/scaladsl/LazySinkSpec.scala       |  9 +++++++++
 .../pekko/stream/scaladsl/LazySourceSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/MaybeSourceSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/NeverSourceSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/PublisherSinkSpec.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/QueueSinkSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/QueueSourceSpec.scala    |  9 +++++++++
 .../apache/pekko/stream/scaladsl/RestartSpec.scala |  9 +++++++++
 .../pekko/stream/scaladsl/RetryFlowSpec.scala      |  9 +++++++++
 .../pekko/stream/scaladsl/ReverseArrowSpec.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/RunnableGraphSpec.scala  |  9 +++++++++
 .../apache/pekko/stream/scaladsl/SeqSinkSpec.scala |  9 +++++++++
 .../apache/pekko/stream/scaladsl/SetupSpec.scala   |  9 +++++++++
 .../stream/scaladsl/SinkAsJavaStreamSpec.scala     |  9 +++++++++
 .../stream/scaladsl/SinkForeachAsyncSpec.scala     |  9 +++++++++
 .../stream/scaladsl/SinkForeachParallelSpec.scala  |  9 +++++++++
 .../apache/pekko/stream/scaladsl/SinkSpec.scala    |  9 +++++++++
 .../stream/scaladsl/SourceFromPublisherSpec.scala  |  9 +++++++++
 .../apache/pekko/stream/scaladsl/SourceSpec.scala  |  9 +++++++++
 .../stream/scaladsl/SourceWithContextSpec.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/StageActorRefSpec.scala  |  9 +++++++++
 .../stream/scaladsl/StreamConvertersSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/StreamRefsSpec.scala     |  9 +++++++++
 .../pekko/stream/scaladsl/SubscriberSinkSpec.scala |  9 +++++++++
 .../stream/scaladsl/SubscriberSourceSpec.scala     |  9 +++++++++
 .../SubstreamSubscriptionTimeoutSpec.scala         |  9 +++++++++
 .../pekko/stream/scaladsl/TakeLastSinkSpec.scala   |  9 +++++++++
 .../apache/pekko/stream/scaladsl/TestConfig.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/TickSourceSpec.scala     |  9 +++++++++
 .../scaladsl/UnfoldResourceAsyncSourceSpec.scala   |  9 +++++++++
 .../stream/scaladsl/UnfoldResourceSourceSpec.scala |  9 +++++++++
 .../stream/scaladsl/WithContextUsageSpec.scala     |  9 +++++++++
 .../stream/snapshot/MaterializerStateSpec.scala    |  9 +++++++++
 .../pekko/stream/typed/javadsl/ActorFlow.scala     |  9 +++++++++
 .../pekko/stream/typed/javadsl/ActorSink.scala     |  9 +++++++++
 .../pekko/stream/typed/javadsl/ActorSource.scala   |  9 +++++++++
 .../apache/pekko/stream/typed/javadsl/PubSub.scala |  9 +++++++++
 .../pekko/stream/typed/scaladsl/ActorFlow.scala    |  9 +++++++++
 .../pekko/stream/typed/scaladsl/ActorSink.scala    |  9 +++++++++
 .../pekko/stream/typed/scaladsl/ActorSource.scala  |  9 +++++++++
 .../pekko/stream/typed/scaladsl/PubSub.scala       |  9 +++++++++
 .../java/docs/javadsl/ActorFlowCompileTest.java    |  9 +++++++++
 .../pekko/stream/typed/ActorSinkExample.java       |  9 +++++++++
 .../stream/typed/ActorSinkWithAckExample.java      |  9 +++++++++
 .../pekko/stream/typed/ActorSourceExample.java     |  9 +++++++++
 .../typed/ActorSourceWithBackpressureExample.java  |  9 +++++++++
 .../typed/javadsl/ActorSourceSinkCompileTest.java  |  9 +++++++++
 .../javadsl/CustomGuardianAndMaterializerTest.java |  9 +++++++++
 .../stream/typed/ActorSourceSinkExample.scala      |  9 +++++++++
 .../test/scala/docs/scaladsl/ActorFlowSpec.scala   |  9 +++++++++
 .../typed/scaladsl/ActorSourceSinkSpec.scala       |  9 +++++++++
 .../typed/scaladsl/MaterializerForTypedSpec.scala  |  9 +++++++++
 .../pekko/stream/typed/scaladsl/PubSubSpec.scala   |  9 +++++++++
 .../akka/stream/FanInShapeN.scala.template         |  9 +++++++++
 .../akka/stream/FanOutShapeN.scala.template        |  9 +++++++++
 .../akka/stream/javadsl/GraphCreate.scala.template |  9 +++++++++
 .../akka/stream/javadsl/UnzipWith.scala.template   |  9 +++++++++
 .../stream/javadsl/ZipLatestWith.scala.template    |  9 +++++++++
 .../akka/stream/javadsl/ZipWith.scala.template     |  9 +++++++++
 .../akka/stream/scaladsl/GraphApply.scala.template |  9 +++++++++
 .../stream/scaladsl/UnzipWithApply.scala.template  |  9 +++++++++
 .../scaladsl/ZipLatestWithApply.scala.template     |  9 +++++++++
 .../stream/scaladsl/ZipWithApply.scala.template    |  9 +++++++++
 .../pekko/stream/javadsl/JavaFlowSupport.java      |  9 +++++++++
 .../org/apache/pekko/stream/StreamRefMessages.java |  9 +++++++++
 .../apache/pekko/stream/javadsl/AsPublisher.java   |  9 +++++++++
 .../pekko/stream/javadsl/FramingTruncation.java    |  9 +++++++++
 stream/src/main/protobuf/StreamRefMessages.proto   |  9 +++++++++
 .../akka/stream/impl/JavaFlowAndRsConverters.scala |  9 +++++++++
 .../akka/stream/scaladsl/JavaFlowSupport.scala     |  9 +++++++++
 .../typesafe/sslconfig/pekko/PekkoSSLConfig.scala  |  9 +++++++++
 .../sslconfig/pekko/SSLEngineConfigurator.scala    |  9 +++++++++
 .../sslconfig/pekko/util/PekkoLoggerBridge.scala   |  9 +++++++++
 .../apache/pekko/stream/ActorMaterializer.scala    |  9 +++++++++
 .../scala/org/apache/pekko/stream/Attributes.scala |  9 +++++++++
 .../apache/pekko/stream/BoundedSourceQueue.scala   |  9 +++++++++
 .../apache/pekko/stream/CompletionStrategy.scala   |  9 +++++++++
 .../scala/org/apache/pekko/stream/FanInShape.scala |  9 +++++++++
 .../org/apache/pekko/stream/FanInShape1N.scala     |  9 +++++++++
 .../org/apache/pekko/stream/FanOutShape.scala      |  9 +++++++++
 .../org/apache/pekko/stream/FlowMonitor.scala      |  9 +++++++++
 .../main/scala/org/apache/pekko/stream/Graph.scala |  9 +++++++++
 .../scala/org/apache/pekko/stream/IOResult.scala   |  9 +++++++++
 .../scala/org/apache/pekko/stream/KillSwitch.scala |  9 +++++++++
 .../org/apache/pekko/stream/Materializer.scala     |  9 +++++++++
 .../pekko/stream/MaterializerLoggingProvider.scala |  9 +++++++++
 .../pekko/stream/NeverMaterializedException.scala  |  9 +++++++++
 .../org/apache/pekko/stream/OverflowStrategy.scala |  9 +++++++++
 .../org/apache/pekko/stream/QueueOfferResult.scala |  9 +++++++++
 .../org/apache/pekko/stream/RestartSettings.scala  |  9 +++++++++
 .../main/scala/org/apache/pekko/stream/Shape.scala |  9 +++++++++
 .../org/apache/pekko/stream/SslTlsOptions.scala    |  9 +++++++++
 .../pekko/stream/StreamDetachedException.scala     |  9 +++++++++
 .../pekko/stream/StreamLimitReachedException.scala |  9 +++++++++
 .../apache/pekko/stream/StreamRefSettings.scala    |  9 +++++++++
 .../scala/org/apache/pekko/stream/StreamRefs.scala |  9 +++++++++
 .../apache/pekko/stream/StreamTcpException.scala   |  9 +++++++++
 .../stream/SubscriptionWithCancelException.scala   |  9 +++++++++
 .../pekko/stream/SubstreamCancelStrategy.scala     |  9 +++++++++
 .../org/apache/pekko/stream/Supervision.scala      |  9 +++++++++
 .../apache/pekko/stream/SystemMaterializer.scala   |  9 +++++++++
 .../org/apache/pekko/stream/ThrottleMode.scala     |  9 +++++++++
 .../stream/TooManySubstreamsOpenException.scala    |  9 +++++++++
 .../apache/pekko/stream/UniformFanInShape.scala    |  9 +++++++++
 .../apache/pekko/stream/UniformFanOutShape.scala   |  9 +++++++++
 .../stream/WatchedActorTerminatedException.scala   |  9 +++++++++
 .../pekko/stream/impl/ActorMaterializerImpl.scala  |  9 +++++++++
 .../apache/pekko/stream/impl/ActorProcessor.scala  |  9 +++++++++
 .../apache/pekko/stream/impl/ActorPublisher.scala  |  9 +++++++++
 .../impl/ActorRefBackpressureSinkStage.scala       |  9 +++++++++
 .../stream/impl/ActorRefBackpressureSource.scala   |  9 +++++++++
 .../pekko/stream/impl/ActorRefSinkStage.scala      |  9 +++++++++
 .../apache/pekko/stream/impl/ActorRefSource.scala  |  9 +++++++++
 .../pekko/stream/impl/ActorSubscriberMessage.scala |  9 +++++++++
 .../pekko/stream/impl/BoundedSourceQueue.scala     |  9 +++++++++
 .../org/apache/pekko/stream/impl/Buffers.scala     |  9 +++++++++
 .../pekko/stream/impl/CompletedPublishers.scala    |  9 +++++++++
 .../org/apache/pekko/stream/impl/ConstantFun.scala |  9 +++++++++
 .../pekko/stream/impl/ContextPropagation.scala     |  9 +++++++++
 .../org/apache/pekko/stream/impl/EmptySource.scala |  9 +++++++++
 .../stream/impl/ExposedPublisherReceive.scala      |  9 +++++++++
 .../apache/pekko/stream/impl/FailedSource.scala    |  9 +++++++++
 .../scala/org/apache/pekko/stream/impl/FanIn.scala |  9 +++++++++
 .../org/apache/pekko/stream/impl/FanOut.scala      |  9 +++++++++
 .../apache/pekko/stream/impl/FanoutProcessor.scala |  9 +++++++++
 .../pekko/stream/impl/JavaStreamSource.scala       |  9 +++++++++
 .../pekko/stream/impl/JsonObjectParser.scala       |  9 +++++++++
 .../org/apache/pekko/stream/impl/LazySource.scala  |  9 +++++++++
 .../pekko/stream/impl/MaterializerGuardian.scala   |  9 +++++++++
 .../org/apache/pekko/stream/impl/MaybeSource.scala |  9 +++++++++
 .../org/apache/pekko/stream/impl/Messages.scala    |  9 +++++++++
 .../org/apache/pekko/stream/impl/Modules.scala     |  9 +++++++++
 .../impl/PhasedFusingActorMaterializer.scala       |  9 +++++++++
 .../org/apache/pekko/stream/impl/QueueSource.scala |  9 +++++++++
 .../stream/impl/ReactiveStreamsCompliance.scala    |  9 +++++++++
 .../impl/ResizableMultiReaderRingBuffer.scala      |  9 +++++++++
 .../pekko/stream/impl/RetryFlowCoordinator.scala   |  9 +++++++++
 .../apache/pekko/stream/impl/SeqActorName.scala    |  9 +++++++++
 .../org/apache/pekko/stream/impl/SetupStage.scala  |  9 +++++++++
 .../apache/pekko/stream/impl/SingleConcat.scala    |  9 +++++++++
 .../pekko/stream/impl/SinkholeSubscriber.scala     |  9 +++++++++
 .../scala/org/apache/pekko/stream/impl/Sinks.scala |  9 +++++++++
 .../org/apache/pekko/stream/impl/Stages.scala      |  9 +++++++++
 .../apache/pekko/stream/impl/StreamLayout.scala    |  9 +++++++++
 .../stream/impl/StreamSubscriptionTimeout.scala    |  9 +++++++++
 .../org/apache/pekko/stream/impl/SubFlowImpl.scala |  9 +++++++++
 .../pekko/stream/impl/SubscriberManagement.scala   |  9 +++++++++
 .../org/apache/pekko/stream/impl/Throttle.scala    |  9 +++++++++
 .../org/apache/pekko/stream/impl/Timers.scala      |  9 +++++++++
 .../org/apache/pekko/stream/impl/Transfer.scala    |  9 +++++++++
 .../pekko/stream/impl/TraversalBuilder.scala       |  9 +++++++++
 .../org/apache/pekko/stream/impl/Unfold.scala      |  9 +++++++++
 .../pekko/stream/impl/UnfoldResourceSource.scala   |  9 +++++++++
 .../stream/impl/UnfoldResourceSourceAsync.scala    |  9 +++++++++
 .../stream/impl/fusing/ActorGraphInterpreter.scala |  9 +++++++++
 .../stream/impl/fusing/AggregateWithBoundary.scala |  9 +++++++++
 .../pekko/stream/impl/fusing/FlatMapPrefix.scala   |  9 +++++++++
 .../pekko/stream/impl/fusing/FutureFlow.scala      |  9 +++++++++
 .../stream/impl/fusing/GraphInterpreter.scala      |  9 +++++++++
 .../pekko/stream/impl/fusing/GraphStages.scala     |  9 +++++++++
 .../org/apache/pekko/stream/impl/fusing/Ops.scala  |  9 +++++++++
 .../pekko/stream/impl/fusing/StreamOfStreams.scala |  9 +++++++++
 .../pekko/stream/impl/io/ByteStringParser.scala    |  9 +++++++++
 .../pekko/stream/impl/io/FileOutputStage.scala     |  9 +++++++++
 .../apache/pekko/stream/impl/io/IOSources.scala    |  9 +++++++++
 .../stream/impl/io/InputStreamSinkStage.scala      |  9 +++++++++
 .../pekko/stream/impl/io/InputStreamSource.scala   |  9 +++++++++
 .../stream/impl/io/OutputStreamGraphStage.scala    |  9 +++++++++
 .../stream/impl/io/OutputStreamSourceStage.scala   |  9 +++++++++
 .../org/apache/pekko/stream/impl/io/TLSActor.scala |  9 +++++++++
 .../apache/pekko/stream/impl/io/TcpStages.scala    |  9 +++++++++
 .../apache/pekko/stream/impl/io/TlsModule.scala    |  9 +++++++++
 .../impl/io/compression/CompressionUtils.scala     |  9 +++++++++
 .../stream/impl/io/compression/Compressor.scala    |  9 +++++++++
 .../impl/io/compression/DeflateCompressor.scala    |  9 +++++++++
 .../impl/io/compression/DeflateDecompressor.scala  |  9 +++++++++
 .../io/compression/DeflateDecompressorBase.scala   |  9 +++++++++
 .../impl/io/compression/GzipCompressor.scala       |  9 +++++++++
 .../impl/io/compression/GzipDecompressor.scala     |  9 +++++++++
 .../org/apache/pekko/stream/impl/package.scala     |  9 +++++++++
 .../pekko/stream/impl/streamref/SinkRefImpl.scala  |  9 +++++++++
 .../stream/impl/streamref/SourceRefImpl.scala      |  9 +++++++++
 .../impl/streamref/StreamRefResolverImpl.scala     |  9 +++++++++
 .../impl/streamref/StreamRefSettingsImpl.scala     |  9 +++++++++
 .../stream/impl/streamref/StreamRefsMaster.scala   |  9 +++++++++
 .../stream/impl/streamref/StreamRefsProtocol.scala |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/BidiFlow.scala |  9 +++++++++
 .../apache/pekko/stream/javadsl/Compression.scala  |  9 +++++++++
 .../stream/javadsl/CoupledTerminationFlow.scala    |  9 +++++++++
 .../pekko/stream/javadsl/DelayStrategy.scala       |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/FileIO.scala   |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/Flow.scala     |  9 +++++++++
 .../pekko/stream/javadsl/FlowWithContext.scala     |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/Framing.scala  |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/Graph.scala    |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/Hub.scala      |  9 +++++++++
 .../apache/pekko/stream/javadsl/JsonFraming.scala  |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/Keep.scala     |  9 +++++++++
 .../apache/pekko/stream/javadsl/MergeLatest.scala  |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/Queue.scala    |  9 +++++++++
 .../apache/pekko/stream/javadsl/RestartFlow.scala  |  9 +++++++++
 .../apache/pekko/stream/javadsl/RestartSink.scala  |  9 +++++++++
 .../pekko/stream/javadsl/RestartSource.scala       |  9 +++++++++
 .../apache/pekko/stream/javadsl/RetryFlow.scala    |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/Sink.scala     |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/Source.scala   |  9 +++++++++
 .../pekko/stream/javadsl/SourceWithContext.scala   |  9 +++++++++
 .../pekko/stream/javadsl/StreamConverters.scala    |  9 +++++++++
 .../apache/pekko/stream/javadsl/StreamRefs.scala   |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/SubFlow.scala  |  9 +++++++++
 .../apache/pekko/stream/javadsl/SubSource.scala    |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/TLS.scala      |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/Tcp.scala      |  9 +++++++++
 .../org/apache/pekko/stream/javadsl/package.scala  |  9 +++++++++
 .../apache/pekko/stream/scaladsl/BidiFlow.scala    |  9 +++++++++
 .../apache/pekko/stream/scaladsl/Compression.scala |  9 +++++++++
 .../stream/scaladsl/CoupledTerminationFlow.scala   |  9 +++++++++
 .../pekko/stream/scaladsl/DelayStrategy.scala      |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/FileIO.scala  |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/Flow.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowWithContext.scala    |  9 +++++++++
 .../pekko/stream/scaladsl/FlowWithContextOps.scala |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/Framing.scala |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/Graph.scala   |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/Hub.scala     |  9 +++++++++
 .../apache/pekko/stream/scaladsl/JsonFraming.scala |  9 +++++++++
 .../pekko/stream/scaladsl/Materialization.scala    |  9 +++++++++
 .../apache/pekko/stream/scaladsl/MergeLatest.scala |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/Queue.scala   |  9 +++++++++
 .../apache/pekko/stream/scaladsl/RestartFlow.scala |  9 +++++++++
 .../apache/pekko/stream/scaladsl/RestartSink.scala |  9 +++++++++
 .../pekko/stream/scaladsl/RestartSource.scala      |  9 +++++++++
 .../apache/pekko/stream/scaladsl/RetryFlow.scala   |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/Sink.scala    |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/Source.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/SourceWithContext.scala  |  9 +++++++++
 .../pekko/stream/scaladsl/StreamConverters.scala   |  9 +++++++++
 .../apache/pekko/stream/scaladsl/StreamRefs.scala  |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/SubFlow.scala |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/TLS.scala     |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/Tcp.scala     |  9 +++++++++
 .../org/apache/pekko/stream/scaladsl/package.scala |  9 +++++++++
 .../stream/serialization/StreamRefSerializer.scala |  9 +++++++++
 .../pekko/stream/snapshot/MaterializerState.scala  |  9 +++++++++
 .../org/apache/pekko/stream/stage/GraphStage.scala |  9 +++++++++
 .../apache/pekko/stream/stage/StageLogging.scala   |  9 +++++++++
 .../pekko/testkit/CallingThreadDispatcher.scala    |  9 +++++++++
 .../testkit/ExplicitlyTriggeredScheduler.scala     |  9 +++++++++
 .../apache/pekko/testkit/JavaSerializable.scala    |  9 +++++++++
 .../org/apache/pekko/testkit/SocketUtil.scala      |  9 +++++++++
 .../org/apache/pekko/testkit/TestActorRef.scala    |  9 +++++++++
 .../org/apache/pekko/testkit/TestActors.scala      |  9 +++++++++
 .../org/apache/pekko/testkit/TestBarrier.scala     |  9 +++++++++
 .../apache/pekko/testkit/TestEventListener.scala   |  9 +++++++++
 .../org/apache/pekko/testkit/TestException.scala   |  9 +++++++++
 .../org/apache/pekko/testkit/TestFSMRef.scala      |  9 +++++++++
 .../apache/pekko/testkit/TestJavaSerializer.scala  |  9 +++++++++
 .../scala/org/apache/pekko/testkit/TestKit.scala   |  9 +++++++++
 .../apache/pekko/testkit/TestKitExtension.scala    |  9 +++++++++
 .../org/apache/pekko/testkit/TestKitUtils.scala    |  9 +++++++++
 .../scala/org/apache/pekko/testkit/TestLatch.scala |  9 +++++++++
 .../apache/pekko/testkit/javadsl/EventFilter.scala |  9 +++++++++
 .../org/apache/pekko/testkit/javadsl/TestKit.scala |  9 +++++++++
 .../scala/org/apache/pekko/testkit/package.scala   |  9 +++++++++
 .../testkit/PekkoJUnitActorSystemResource.java     |  9 +++++++++
 .../pekko/testkit/TestActorRefJavaCompile.java     |  9 +++++++++
 .../pekko/testkit/javadsl/TestKitApiTest.java      |  9 +++++++++
 .../org/apache/pekko/testkit/AbstractSpec.scala    |  9 +++++++++
 .../scala/org/apache/pekko/testkit/Coroner.scala   |  9 +++++++++
 .../org/apache/pekko/testkit/CoronerSpec.scala     |  9 +++++++++
 .../apache/pekko/testkit/DefaultTimeoutSpec.scala  |  9 +++++++++
 .../testkit/ExplicitlyTriggeredSchedulerSpec.scala |  9 +++++++++
 .../apache/pekko/testkit/ImplicitSenderSpec.scala  |  9 +++++++++
 .../scala/org/apache/pekko/testkit/PekkoSpec.scala |  9 +++++++++
 .../org/apache/pekko/testkit/PekkoSpecSpec.scala   |  9 +++++++++
 .../apache/pekko/testkit/TestActorRefSpec.scala    |  9 +++++++++
 .../org/apache/pekko/testkit/TestActorsSpec.scala  |  9 +++++++++
 .../pekko/testkit/TestEventListenerSpec.scala      |  9 +++++++++
 .../org/apache/pekko/testkit/TestFSMRefSpec.scala  |  9 +++++++++
 .../org/apache/pekko/testkit/TestProbeSpec.scala   |  9 +++++++++
 .../scala/org/apache/pekko/testkit/TestTags.scala  |  9 +++++++++
 .../org/apache/pekko/testkit/TestTimeSpec.scala    |  9 +++++++++
 .../apache/pekko/testkit/WithLogCapturing.scala    |  9 +++++++++
 .../pekko/testkit/metrics/AveragingGauge.scala     |  9 +++++++++
 .../testkit/metrics/FileDescriptorMetricSet.scala  |  9 +++++++++
 .../pekko/testkit/metrics/HdrHistogram.scala       |  9 +++++++++
 .../testkit/metrics/KnownOpsInTimespanTimer.scala  |  9 +++++++++
 .../testkit/metrics/MemoryUsageSnapshotting.scala  |  9 +++++++++
 .../pekko/testkit/metrics/MetricKeyDSL.scala       |  9 +++++++++
 .../apache/pekko/testkit/metrics/MetricsKit.scala  |  9 +++++++++
 .../pekko/testkit/metrics/MetricsKitOps.scala      |  9 +++++++++
 .../pekko/testkit/metrics/MetricsKitSpec.scala     |  9 +++++++++
 .../metrics/reporter/PekkoConsoleReporter.scala    |  9 +++++++++
 3116 files changed, 28051 insertions(+), 7 deletions(-)

diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/CapturedLogEvent.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/CapturedLogEvent.scala
index 0e83b42a64..57ded1325b 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/CapturedLogEvent.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/CapturedLogEvent.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/Effect.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/Effect.scala
index d5c96e5208..c51219bce9 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/Effect.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/Effect.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/FishingOutcome.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/FishingOutcome.scala
index 447b459537..43b06dc6ff 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/FishingOutcome.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/FishingOutcome.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/LoggingEvent.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/LoggingEvent.scala
index 7bbcff28c6..228bda1c1d 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/LoggingEvent.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/LoggingEvent.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/TestException.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/TestException.scala
index 5b1bcc68bf..3167bb3940 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/TestException.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/TestException.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/TestKitSettings.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/TestKitSettings.scala
index ea277de143..5488b2cef7 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/TestKitSettings.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/TestKitSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ActorSystemStub.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ActorSystemStub.scala
index 977a4ce98b..3302d8368c 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ActorSystemStub.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ActorSystemStub.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/BehaviorTestKitImpl.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/BehaviorTestKitImpl.scala
index 3a786f817d..003a219b06 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/BehaviorTestKitImpl.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/BehaviorTestKitImpl.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/CapturingAppender.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/CapturingAppender.scala
index f6a8f027df..69469cb424 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/CapturingAppender.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/CapturingAppender.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ControlledExecutor.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ControlledExecutor.scala
index 299e70b030..b7d31a28aa 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ControlledExecutor.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/ControlledExecutor.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/DebugRef.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/DebugRef.scala
index edc10202c8..074321fbc6 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/DebugRef.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/DebugRef.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/EffectfulActorContext.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/EffectfulActorContext.scala
index 0fa5767755..06ed9051d1 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/EffectfulActorContext.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/EffectfulActorContext.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/LogbackUtil.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/LogbackUtil.scala
index e17074d510..40efed5b03 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/LogbackUtil.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/LogbackUtil.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/LoggingTestKitImpl.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/LoggingTestKitImpl.scala
index feeb964861..0dc6e7762f 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/LoggingTestKitImpl.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/LoggingTestKitImpl.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/StubbedActorContext.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/StubbedActorContext.scala
index aedd3d486a..8e7503f532 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/StubbedActorContext.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/StubbedActorContext.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestAppender.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestAppender.scala
index ce117fca53..7118b891dd 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestAppender.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestAppender.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestInboxImpl.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestInboxImpl.scala
index 4920c94b0e..3f875b6639 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestInboxImpl.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestInboxImpl.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestKitUtils.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestKitUtils.scala
index 03548a50b1..7ed246b3c5 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestKitUtils.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestKitUtils.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestProbeImpl.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestProbeImpl.scala
index 29f81bbb40..82902b53cc 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestProbeImpl.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/internal/TestProbeImpl.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKit.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKit.scala
index e60671363a..c3ce2d2f55 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKit.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/BehaviorTestKit.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/BehaviorTestKit.scala
index fa4d2c0f60..e960598a36 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/BehaviorTestKit.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/BehaviorTestKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/Effects.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/Effects.scala
index 76ba08692f..be33eb25e3 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/Effects.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/Effects.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/LogCapturing.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/LogCapturing.scala
index aea93978fb..456c4f8490 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/LogCapturing.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/LogCapturing.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/LoggingTestKit.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/LoggingTestKit.scala
index 43da82a708..158db16673 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/LoggingTestKit.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/LoggingTestKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/ManualTime.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/ManualTime.scala
index 01c58479a1..a3cc9a7f67 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/ManualTime.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/ManualTime.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/SerializationTestKit.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/SerializationTestKit.scala
index c4b88593e7..877b54e54f 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/SerializationTestKit.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/SerializationTestKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestInbox.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestInbox.scala
index 936cf06b58..6854837f3c 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestInbox.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestInbox.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestKitJunitResource.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestKitJunitResource.scala
index 9a69fa3a38..429bb0683b 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestKitJunitResource.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestKitJunitResource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestProbe.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestProbe.scala
index 3e936a217b..7b92df2b39 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestProbe.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/javadsl/TestProbe.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKit.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKit.scala
index e92733bf34..45cd12547c 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKit.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKitBase.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKitBase.scala
index 1617414a11..8c89492bed 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKitBase.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKitBase.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKit.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKit.scala
index ebbd50a2a8..3a109e17f5 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKit.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/Effects.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/Effects.scala
index e575bc164f..89b8ca31db 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/Effects.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/Effects.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LogCapturing.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LogCapturing.scala
index f08dd38cd4..d505edb6d6 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LogCapturing.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LogCapturing.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingTestKit.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingTestKit.scala
index 3709254d56..47aab2ef3c 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingTestKit.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingTestKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ManualTime.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ManualTime.scala
index baaac6b41d..55a8e4c386 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ManualTime.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ManualTime.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ScalaTestWithActorTestKit.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ScalaTestWithActorTestKit.scala
index a8a8be378b..8a28ed9588 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ScalaTestWithActorTestKit.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ScalaTestWithActorTestKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/SerializationTestKit.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/SerializationTestKit.scala
index ed9af4e086..2da40f1fb4 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/SerializationTestKit.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/SerializationTestKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestInbox.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestInbox.scala
index 5d55910e73..6be8c2df69 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestInbox.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestInbox.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestProbe.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestProbe.scala
index f577f3b3f8..94810485f9 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestProbe.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestProbe.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/package.scala b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/package.scala
index 42c6648a18..13498a2ae6 100644
--- a/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/package.scala
+++ b/actor-testkit-typed/src/main/scala/org/apache/pekko/actor/testkit/typed/scaladsl/package.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/AsyncTestingExampleTest.java b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/AsyncTestingExampleTest.java
index f7c10b9b0e..1c4bb83e28 100644
--- a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/AsyncTestingExampleTest.java
+++ b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/AsyncTestingExampleTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/JunitIntegrationExampleTest.java b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/JunitIntegrationExampleTest.java
index 54b26679d4..94e7d7f661 100644
--- a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/JunitIntegrationExampleTest.java
+++ b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/JunitIntegrationExampleTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/LogCapturingExampleTest.java b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/LogCapturingExampleTest.java
index 4dd03eb910..6a95f5c5e4 100644
--- a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/LogCapturingExampleTest.java
+++ b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/LogCapturingExampleTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/ManualTimerExampleTest.java b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/ManualTimerExampleTest.java
index 1d4dcd187c..4bb3226ad8 100644
--- a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/ManualTimerExampleTest.java
+++ b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/ManualTimerExampleTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/SyncTestingExampleTest.java b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/SyncTestingExampleTest.java
index d6dbc864fe..b52b82631f 100644
--- a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/SyncTestingExampleTest.java
+++ b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/SyncTestingExampleTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/TestConfigExample.java b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/TestConfigExample.java
index 3e19f479dc..deeeb7be45 100644
--- a/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/TestConfigExample.java
+++ b/actor-testkit-typed/src/test/java/jdocs/org/apache/pekko/actor/testkit/typed/javadsl/TestConfigExample.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKitApiTest.java b/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKitApiTest.java
index 54318da838..22b723f950 100644
--- a/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKitApiTest.java
+++ b/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKitApiTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKitTest.java b/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKitTest.java
index d54e5d6944..80820c8107 100644
--- a/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKitTest.java
+++ b/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/ActorTestKitTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/BehaviorTestKitTest.java b/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/BehaviorTestKitTest.java
index 9aa39ae3b0..66f27cb037 100644
--- a/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/BehaviorTestKitTest.java
+++ b/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/BehaviorTestKitTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/LoggingTestKitTest.java b/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/LoggingTestKitTest.java
index 0f640b8297..47d05b169f 100644
--- a/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/LoggingTestKitTest.java
+++ b/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/LoggingTestKitTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/TestProbeTest.java b/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/TestProbeTest.java
index 1fb32a6c4f..c2bb84ecda 100644
--- a/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/TestProbeTest.java
+++ b/actor-testkit-typed/src/test/java/org/apache/pekko/actor/testkit/typed/javadsl/TestProbeTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/AsyncTestingExampleSpec.scala b/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/AsyncTestingExampleSpec.scala
index 070037d8db..67d20b36f9 100644
--- a/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/AsyncTestingExampleSpec.scala
+++ b/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/AsyncTestingExampleSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/ManualTimerExampleSpec.scala b/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/ManualTimerExampleSpec.scala
index 84a2a441f1..f27e4c3907 100644
--- a/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/ManualTimerExampleSpec.scala
+++ b/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/ManualTimerExampleSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/ScalaTestIntegrationExampleSpec.scala b/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/ScalaTestIntegrationExampleSpec.scala
index b97d6be671..13d8716340 100644
--- a/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/ScalaTestIntegrationExampleSpec.scala
+++ b/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/ScalaTestIntegrationExampleSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/SyncTestingExampleSpec.scala b/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/SyncTestingExampleSpec.scala
index 0cc80ed014..8e7440e04a 100644
--- a/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/SyncTestingExampleSpec.scala
+++ b/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/SyncTestingExampleSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/TestConfigExample.scala b/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/TestConfigExample.scala
index 07b53195af..289bf139d1 100644
--- a/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/TestConfigExample.scala
+++ b/actor-testkit-typed/src/test/scala/docs/org/apache/pekko/actor/testkit/typed/scaladsl/TestConfigExample.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKitSpec.scala b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKitSpec.scala
index bd6996cfc0..ee957620cb 100644
--- a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKitSpec.scala
+++ b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/ActorTestKitSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKitSpec.scala b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKitSpec.scala
index 4128cc38c8..fec7920379 100644
--- a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKitSpec.scala
+++ b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/BehaviorTestKitSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingEventFilterSpec.scala b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingEventFilterSpec.scala
index c0ed7dc57f..82e9c71237 100644
--- a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingEventFilterSpec.scala
+++ b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/LoggingEventFilterSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestAppenderSpec.scala b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestAppenderSpec.scala
index 617aff8900..ad6627610e 100644
--- a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestAppenderSpec.scala
+++ b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestAppenderSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestProbeSpec.scala b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestProbeSpec.scala
index 344529aa15..cc4a3f3dae 100644
--- a/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestProbeSpec.scala
+++ b/actor-testkit-typed/src/test/scala/org/apache/pekko/actor/testkit/typed/scaladsl/TestProbeSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/AbstractFSMActorTest.java b/actor-tests/src/test/java/org/apache/pekko/actor/AbstractFSMActorTest.java
index 69432081c0..47c8d70c2d 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/AbstractFSMActorTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/AbstractFSMActorTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/ActorCreationTest.java b/actor-tests/src/test/java/org/apache/pekko/actor/ActorCreationTest.java
index 46d8da19b4..ff0f35f6d3 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/ActorCreationTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/ActorCreationTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/ActorSelectionTest.java b/actor-tests/src/test/java/org/apache/pekko/actor/ActorSelectionTest.java
index 1592b6d135..df85bbbcc4 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/ActorSelectionTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/ActorSelectionTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/ActorSystemTest.java b/actor-tests/src/test/java/org/apache/pekko/actor/ActorSystemTest.java
index 03e5a4a2e3..97ad65331b 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/ActorSystemTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/ActorSystemTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/AddressTest.java b/actor-tests/src/test/java/org/apache/pekko/actor/AddressTest.java
index df2851cd27..22911e0e20 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/AddressTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/AddressTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPI.java b/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPI.java
index c2ab6c0ff8..2889c5fb0a 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPI.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPI.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPITestActor.java b/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPITestActor.java
index 5475099915..cc0d286d0c 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPITestActor.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/JavaAPITestActor.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/JavaExtension.java b/actor-tests/src/test/java/org/apache/pekko/actor/JavaExtension.java
index d76b406cd7..33ce5f1b9b 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/JavaExtension.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/JavaExtension.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/NonPublicClass.java b/actor-tests/src/test/java/org/apache/pekko/actor/NonPublicClass.java
index 5bfe1d4184..97f6ab7329 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/NonPublicClass.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/NonPublicClass.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/NonStaticCreator.java b/actor-tests/src/test/java/org/apache/pekko/actor/NonStaticCreator.java
index 1fe8b8ee39..db3d650205 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/NonStaticCreator.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/NonStaticCreator.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/StashJavaAPI.java b/actor-tests/src/test/java/org/apache/pekko/actor/StashJavaAPI.java
index 51b2136d1e..0ca4da0b88 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/StashJavaAPI.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/StashJavaAPI.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/StashJavaAPITestActors.java b/actor-tests/src/test/java/org/apache/pekko/actor/StashJavaAPITestActors.java
index 40c576e580..6d68fc2f0d 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/StashJavaAPITestActors.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/StashJavaAPITestActors.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/TestAnnotation.java b/actor-tests/src/test/java/org/apache/pekko/actor/TestAnnotation.java
index 137943e4ab..9764c6e10a 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/TestAnnotation.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/TestAnnotation.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/actor/setup/ActorSystemSetupTest.java b/actor-tests/src/test/java/org/apache/pekko/actor/setup/ActorSystemSetupTest.java
index 219d36d9c8..9cb81efaef 100644
--- a/actor-tests/src/test/java/org/apache/pekko/actor/setup/ActorSystemSetupTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/actor/setup/ActorSystemSetupTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/dispatch/JavaFutureTests.java b/actor-tests/src/test/java/org/apache/pekko/dispatch/JavaFutureTests.java
index f66f7f85cf..ab0bda6f99 100644
--- a/actor-tests/src/test/java/org/apache/pekko/dispatch/JavaFutureTests.java
+++ b/actor-tests/src/test/java/org/apache/pekko/dispatch/JavaFutureTests.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/event/ActorWithMDC.java b/actor-tests/src/test/java/org/apache/pekko/event/ActorWithMDC.java
index 46e387bdd7..aeac1b032e 100644
--- a/actor-tests/src/test/java/org/apache/pekko/event/ActorWithMDC.java
+++ b/actor-tests/src/test/java/org/apache/pekko/event/ActorWithMDC.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/event/LoggingAdapterTest.java b/actor-tests/src/test/java/org/apache/pekko/event/LoggingAdapterTest.java
index adf629d70f..64b2a0a2d1 100644
--- a/actor-tests/src/test/java/org/apache/pekko/event/LoggingAdapterTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/event/LoggingAdapterTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/japi/JavaAPITestBase.java b/actor-tests/src/test/java/org/apache/pekko/japi/JavaAPITestBase.java
index 0b2ce34b41..b3ff94c778 100644
--- a/actor-tests/src/test/java/org/apache/pekko/japi/JavaAPITestBase.java
+++ b/actor-tests/src/test/java/org/apache/pekko/japi/JavaAPITestBase.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/japi/MatchBuilderTest.java b/actor-tests/src/test/java/org/apache/pekko/japi/MatchBuilderTest.java
index a09532db94..14a088bb17 100644
--- a/actor-tests/src/test/java/org/apache/pekko/japi/MatchBuilderTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/japi/MatchBuilderTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/japi/ThrowablesTest.java b/actor-tests/src/test/java/org/apache/pekko/japi/ThrowablesTest.java
index 9c75ca85bf..c7f92b600f 100644
--- a/actor-tests/src/test/java/org/apache/pekko/japi/ThrowablesTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/japi/ThrowablesTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/japi/pf/PFBuilderTest.java b/actor-tests/src/test/java/org/apache/pekko/japi/pf/PFBuilderTest.java
index 79e2f601cf..606ac9f04e 100644
--- a/actor-tests/src/test/java/org/apache/pekko/japi/pf/PFBuilderTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/japi/pf/PFBuilderTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/japi/pf/ReceiveBuilderTest.java b/actor-tests/src/test/java/org/apache/pekko/japi/pf/ReceiveBuilderTest.java
index 6280d6ba2d..85f8fc3cc3 100644
--- a/actor-tests/src/test/java/org/apache/pekko/japi/pf/ReceiveBuilderTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/japi/pf/ReceiveBuilderTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/pattern/CircuitBreakerTest.java b/actor-tests/src/test/java/org/apache/pekko/pattern/CircuitBreakerTest.java
index 24d375cb0d..e3209a346f 100644
--- a/actor-tests/src/test/java/org/apache/pekko/pattern/CircuitBreakerTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/pattern/CircuitBreakerTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/pattern/PatternsTest.java b/actor-tests/src/test/java/org/apache/pekko/pattern/PatternsTest.java
index 17c4f577e9..e6437d928f 100644
--- a/actor-tests/src/test/java/org/apache/pekko/pattern/PatternsTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/pattern/PatternsTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/pattern/StatusReplyTest.java b/actor-tests/src/test/java/org/apache/pekko/pattern/StatusReplyTest.java
index eff7084f60..ccc4e6514e 100644
--- a/actor-tests/src/test/java/org/apache/pekko/pattern/StatusReplyTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/pattern/StatusReplyTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/util/ByteStringTest.java b/actor-tests/src/test/java/org/apache/pekko/util/ByteStringTest.java
index 1ac354a66e..7059a12f72 100644
--- a/actor-tests/src/test/java/org/apache/pekko/util/ByteStringTest.java
+++ b/actor-tests/src/test/java/org/apache/pekko/util/ByteStringTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/util/JavaDuration.java b/actor-tests/src/test/java/org/apache/pekko/util/JavaDuration.java
index 15e1543adf..0f081ab146 100644
--- a/actor-tests/src/test/java/org/apache/pekko/util/JavaDuration.java
+++ b/actor-tests/src/test/java/org/apache/pekko/util/JavaDuration.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/java/org/apache/pekko/util/LineNumberSpecCodeForJava.java b/actor-tests/src/test/java/org/apache/pekko/util/LineNumberSpecCodeForJava.java
index c11ae8568b..46a6be669a 100644
--- a/actor-tests/src/test/java/org/apache/pekko/util/LineNumberSpecCodeForJava.java
+++ b/actor-tests/src/test/java/org/apache/pekko/util/LineNumberSpecCodeForJava.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala-2.13/org/apache/pekko/util/LineNumberSpec.scala b/actor-tests/src/test/scala-2.13/org/apache/pekko/util/LineNumberSpec.scala
index 440ce96b28..dc653c3a3d 100644
--- a/actor-tests/src/test/scala-2.13/org/apache/pekko/util/LineNumberSpec.scala
+++ b/actor-tests/src/test/scala-2.13/org/apache/pekko/util/LineNumberSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
@@ -16,21 +25,21 @@ class LineNumberSpec extends PekkoSpec {
       import LineNumberSpecCodeForScala._
 
       "work for small functions" in {
-        LineNumbers(oneline) should ===(SourceFileLines("LineNumberSpecCodeForScala.scala", 13, 13))
+        LineNumbers(oneline) should ===(SourceFileLines("LineNumberSpecCodeForScala.scala", 22, 22))
       }
 
       "work for larger functions" in {
         val result = LineNumbers(twoline)
-        result should ===(SourceFileLines("LineNumberSpecCodeForScala.scala", 15, 15))
+        result should ===(SourceFileLines("LineNumberSpecCodeForScala.scala", 24, 24))
       }
 
       "work for partial functions" in {
-        LineNumbers(partial) should ===(SourceFileLines("LineNumberSpecCodeForScala.scala", 20, 22))
+        LineNumbers(partial) should ===(SourceFileLines("LineNumberSpecCodeForScala.scala", 29, 31))
       }
 
       "work for `def`" in {
         val result = LineNumbers(method("foo"))
-        result should ===(SourceFileLines("LineNumberSpecCodeForScala.scala", 26, 27))
+        result should ===(SourceFileLines("LineNumberSpecCodeForScala.scala", 35, 36))
       }
 
     }
@@ -40,16 +49,16 @@ class LineNumberSpec extends PekkoSpec {
 
       "work for small functions" in {
         // because how java Lambdas are implemented/designed
-        LineNumbers(l.f1()) should ===(SourceFileLines("LineNumberSpecCodeForJava.java", 20, 20))
+        LineNumbers(l.f1()) should ===(SourceFileLines("LineNumberSpecCodeForJava.java", 29, 29))
       }
 
       "work for larger functions" in {
         // because how java Lambdas are implemented/designed
-        LineNumbers(l.f2()) should ===(SourceFileLines("LineNumberSpecCodeForJava.java", 25, 26))
+        LineNumbers(l.f2()) should ===(SourceFileLines("LineNumberSpecCodeForJava.java", 34, 35))
       }
 
       "work for anonymous classes" in {
-        LineNumbers(l.f3()) should ===(SourceFileLines("LineNumberSpecCodeForJava.java", 31, 36))
+        LineNumbers(l.f3()) should ===(SourceFileLines("LineNumberSpecCodeForJava.java", 40, 45))
       }
 
     }
diff --git a/actor-tests/src/test/scala-2.13/org/apache/pekko/util/TypedMultiMapSpec.scala b/actor-tests/src/test/scala-2.13/org/apache/pekko/util/TypedMultiMapSpec.scala
index eb1b40180b..6e9f627c7e 100644
--- a/actor-tests/src/test/scala-2.13/org/apache/pekko/util/TypedMultiMapSpec.scala
+++ b/actor-tests/src/test/scala-2.13/org/apache/pekko/util/TypedMultiMapSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2015-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/Messages.scala b/actor-tests/src/test/scala/org/apache/pekko/Messages.scala
index 99391d145e..fe4c40abe4 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/Messages.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/Messages.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/PekkoExceptionSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/PekkoExceptionSpec.scala
index e98ef473eb..ddc95e7939 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/PekkoExceptionSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/PekkoExceptionSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/PekkoVersionSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/PekkoVersionSpec.scala
index fff3295464..0422e2c126 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/PekkoVersionSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/PekkoVersionSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorConfigurationVerificationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorConfigurationVerificationSpec.scala
index 6f65efcd41..dccbe0adc5 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorConfigurationVerificationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorConfigurationVerificationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorCreationPerfSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorCreationPerfSpec.scala
index 19dfcc3827..b51fdaf65a 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorCreationPerfSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorCreationPerfSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorLifeCycleSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorLifeCycleSpec.scala
index ce8b5cc399..506177ae08 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorLifeCycleSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorLifeCycleSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorMailboxSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorMailboxSpec.scala
index ca0bb6d895..2d64f54caa 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorMailboxSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorMailboxSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorPathSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorPathSpec.scala
index 68d5d126cb..5e5a82f442 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorPathSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorPathSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorRefSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorRefSpec.scala
index 0e6201140f..efd186cfba 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorRefSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorRefSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSelectionSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSelectionSpec.scala
index 47bb044277..048853c245 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSelectionSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSelectionSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemDispatcherSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemDispatcherSpec.scala
index a01b9bf76b..d02c44b002 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemDispatcherSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemDispatcherSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemSpec.scala
index 8e920d0f79..134d542f14 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorSystemSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorTimeoutSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorTimeoutSpec.scala
index 4605eafc25..775f18d6bd 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorTimeoutSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorTimeoutSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorWithBoundedStashSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorWithBoundedStashSpec.scala
index 76500fd0aa..5d48d20610 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorWithBoundedStashSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorWithBoundedStashSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorWithStashSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorWithStashSpec.scala
index f9b1aca22a..d31a2db149 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ActorWithStashSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ActorWithStashSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ConsistencySpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ConsistencySpec.scala
index 5ef6d5e32b..424ac89724 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ConsistencySpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ConsistencySpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/CoordinatedShutdownSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/CoordinatedShutdownSpec.scala
index b77ec65831..d0b5adc267 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/CoordinatedShutdownSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/CoordinatedShutdownSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/DeadLetterSupressionSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/DeadLetterSupressionSpec.scala
index 4562b419d7..f8e08e4759 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/DeadLetterSupressionSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/DeadLetterSupressionSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/DeadLetterSuspensionSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/DeadLetterSuspensionSpec.scala
index 98106e1be7..75c8781640 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/DeadLetterSuspensionSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/DeadLetterSuspensionSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/DeathWatchSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/DeathWatchSpec.scala
index c814a119bb..5592cc7fb9 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/DeathWatchSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/DeathWatchSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/DeployerSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/DeployerSpec.scala
index c247ad6ccf..3d13efdfaf 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/DeployerSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/DeployerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/DynamicAccessSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/DynamicAccessSpec.scala
index 88e48eca14..83cce0aa3c 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/DynamicAccessSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/DynamicAccessSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ExtensionSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ExtensionSpec.scala
index 678e5b2714..ee4bf1eabb 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ExtensionSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ExtensionSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/FSMActorSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/FSMActorSpec.scala
index a521e78883..e82f8b7549 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/FSMActorSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/FSMActorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/FSMTimingSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/FSMTimingSpec.scala
index 621abda129..4cf54a231b 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/FSMTimingSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/FSMTimingSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/FSMTransitionSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/FSMTransitionSpec.scala
index 733927a658..8384aa50c2 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/FSMTransitionSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/FSMTransitionSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ForwardActorSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ForwardActorSpec.scala
index 87368305ea..cca3feda88 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ForwardActorSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ForwardActorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/FunctionRefSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/FunctionRefSpec.scala
index 999971cf99..c09bba5ad8 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/FunctionRefSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/FunctionRefSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/HotSwapSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/HotSwapSpec.scala
index 36585fc5e7..e2a509ed23 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/HotSwapSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/HotSwapSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/LocalActorRefProviderSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/LocalActorRefProviderSpec.scala
index 0ff50028fa..6098a5ea84 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/LocalActorRefProviderSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/LocalActorRefProviderSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/PropsCreationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/PropsCreationSpec.scala
index 48716dc4ef..b95acf7f1e 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/PropsCreationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/PropsCreationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ProviderSelectionSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ProviderSelectionSpec.scala
index 1518260b1d..4a1036fc8b 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ProviderSelectionSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ProviderSelectionSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/ReceiveTimeoutSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/ReceiveTimeoutSpec.scala
index d78dd41891..3f50e7dafd 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/ReceiveTimeoutSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/ReceiveTimeoutSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/RelativeActorPathSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/RelativeActorPathSpec.scala
index 0b990fb753..2de52a4e48 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/RelativeActorPathSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/RelativeActorPathSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/RestartStrategySpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/RestartStrategySpec.scala
index e9470961a4..047df74a56 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/RestartStrategySpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/RestartStrategySpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/SchedulerSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/SchedulerSpec.scala
index 118c04e430..2d6000edb6 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/SchedulerSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/SchedulerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/Supervisor.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/Supervisor.scala
index b6bdfd3436..7a16f276db 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/Supervisor.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/Supervisor.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorHierarchySpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorHierarchySpec.scala
index e6028815bd..4f2841b03f 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorHierarchySpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorHierarchySpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorMiscSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorMiscSpec.scala
index d6fe6f2158..a35d17e921 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorMiscSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorMiscSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorSpec.scala
index 8540bdd26a..5fbca19769 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorTreeSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorTreeSpec.scala
index 947cc2dff6..82fe69100a 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorTreeSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/SupervisorTreeSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/Ticket669Spec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/Ticket669Spec.scala
index fe100741d6..21ec30950f 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/Ticket669Spec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/Ticket669Spec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/TimerSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/TimerSpec.scala
index 3ae054e173..4e6b3665eb 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/TimerSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/TimerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/TypedActorSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/TypedActorSpec.scala
index 0d2833a83c..217ad7bc27 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/TypedActorSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/TypedActorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/UidClashTest.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/UidClashTest.scala
index 9f481e001b..9b4ee12c39 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/UidClashTest.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/UidClashTest.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/ActorModelSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/ActorModelSpec.scala
index e5558b1d57..bb2d072e93 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/ActorModelSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/ActorModelSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/BalancingDispatcherSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/BalancingDispatcherSpec.scala
index 11d7694b34..64f130c90d 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/BalancingDispatcherSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/BalancingDispatcherSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatcherActorSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatcherActorSpec.scala
index 6e51b3a915..8a1af24af3 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatcherActorSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatcherActorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatcherActorsSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatcherActorsSpec.scala
index 0bd8960439..7fe34d8698 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatcherActorsSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatcherActorsSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatchersSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatchersSpec.scala
index 6c961ca497..8a635d23ec 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatchersSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/DispatchersSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/PinnedActorSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/PinnedActorSpec.scala
index e289984b84..829b390912 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/PinnedActorSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/dispatch/PinnedActorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/dungeon/DispatchSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/dungeon/DispatchSpec.scala
index ff7fe49e71..969a471383 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/dungeon/DispatchSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/dungeon/DispatchSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/routing/ListenerSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/routing/ListenerSpec.scala
index 46e79d6da1..caa0972cb7 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/routing/ListenerSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/routing/ListenerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/actor/setup/ActorSystemSetupSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/actor/setup/ActorSystemSetupSpec.scala
index 344afb157e..f238f7d71b 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/actor/setup/ActorSystemSetupSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/actor/setup/ActorSystemSetupSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/config/ConfigSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/config/ConfigSpec.scala
index 1a11eaef7e..68b636bea2 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/config/ConfigSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/config/ConfigSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/dataflow/Future2Actor.scala b/actor-tests/src/test/scala/org/apache/pekko/dataflow/Future2Actor.scala
index fe3b41cfa7..c38175e5fc 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/dataflow/Future2Actor.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/dataflow/Future2Actor.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/dispatch/ControlAwareDispatcherSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/dispatch/ControlAwareDispatcherSpec.scala
index 6b59898757..9e47b92a52 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/dispatch/ControlAwareDispatcherSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/dispatch/ControlAwareDispatcherSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/dispatch/DispatcherShutdownSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/dispatch/DispatcherShutdownSpec.scala
index 95e67c21b0..bdf167b9e0 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/dispatch/DispatcherShutdownSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/dispatch/DispatcherShutdownSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/dispatch/ExecutionContextSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/dispatch/ExecutionContextSpec.scala
index d9f3a894f1..791f91d2ba 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/dispatch/ExecutionContextSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/dispatch/ExecutionContextSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/dispatch/ForkJoinPoolStarvationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/dispatch/ForkJoinPoolStarvationSpec.scala
index 044ed9beff..27996207cf 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/dispatch/ForkJoinPoolStarvationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/dispatch/ForkJoinPoolStarvationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/dispatch/MailboxConfigSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/dispatch/MailboxConfigSpec.scala
index fca306ff48..cd1662516e 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/dispatch/MailboxConfigSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/dispatch/MailboxConfigSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/dispatch/PriorityDispatcherSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/dispatch/PriorityDispatcherSpec.scala
index 2b77c78ecf..cf7ef6d80d 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/dispatch/PriorityDispatcherSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/dispatch/PriorityDispatcherSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/dispatch/SameThreadExecutionContextSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/dispatch/SameThreadExecutionContextSpec.scala
index f1b6d76b73..d3607876ea 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/dispatch/SameThreadExecutionContextSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/dispatch/SameThreadExecutionContextSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/dispatch/StablePriorityDispatcherSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/dispatch/StablePriorityDispatcherSpec.scala
index 35176df5f6..c9c914698a 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/dispatch/StablePriorityDispatcherSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/dispatch/StablePriorityDispatcherSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2015-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/dispatch/sysmsg/SystemMessageListSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/dispatch/sysmsg/SystemMessageListSpec.scala
index fdc2a50be9..112a3ea050 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/dispatch/sysmsg/SystemMessageListSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/dispatch/sysmsg/SystemMessageListSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/event/AddressTerminatedTopicBenchSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/event/AddressTerminatedTopicBenchSpec.scala
index 2c8611cb15..2972690bcc 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/event/AddressTerminatedTopicBenchSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/event/AddressTerminatedTopicBenchSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/event/EventBusSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/event/EventBusSpec.scala
index 6ab1dbc28b..8ed10c1318 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/event/EventBusSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/event/EventBusSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/event/EventStreamSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/event/EventStreamSpec.scala
index 7956c7208a..cfee46f2b3 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/event/EventStreamSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/event/EventStreamSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/event/LoggerSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/event/LoggerSpec.scala
index 7d61d9b701..090ff2c011 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/event/LoggerSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/event/LoggerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/event/LoggingReceiveSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/event/LoggingReceiveSpec.scala
index 3091cf0d5a..06d0f40c0e 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/event/LoggingReceiveSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/event/LoggingReceiveSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/event/MarkerLoggingSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/event/MarkerLoggingSpec.scala
index b633a4337a..c4c8587ae9 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/event/MarkerLoggingSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/event/MarkerLoggingSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/event/jul/JavaLoggerSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/event/jul/JavaLoggerSpec.scala
index cf41de8580..44d63323a3 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/event/jul/JavaLoggerSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/event/jul/JavaLoggerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/CapacityLimitSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/CapacityLimitSpec.scala
index 7a8e6f4180..c625ef1502 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/CapacityLimitSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/CapacityLimitSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/InetAddressDnsResolverSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/InetAddressDnsResolverSpec.scala
index af7cf7c387..261b75272f 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/InetAddressDnsResolverSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/InetAddressDnsResolverSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/SimpleDnsCacheSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/SimpleDnsCacheSpec.scala
index 7405208e61..34bc8527fc 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/SimpleDnsCacheSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/SimpleDnsCacheSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/TcpConnectionSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/TcpConnectionSpec.scala
index aae5c62824..ad801ffc81 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/TcpConnectionSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/TcpConnectionSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/TcpIntegrationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/TcpIntegrationSpec.scala
index 6dbf16b117..5a709d25d3 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/TcpIntegrationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/TcpIntegrationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/TcpIntegrationSpecSupport.scala b/actor-tests/src/test/scala/org/apache/pekko/io/TcpIntegrationSpecSupport.scala
index 7c3bfa73cb..f1237390cc 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/TcpIntegrationSpecSupport.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/TcpIntegrationSpecSupport.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/TcpListenerSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/TcpListenerSpec.scala
index ac32a1e560..7fb42ff4ad 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/TcpListenerSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/TcpListenerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/UdpConnectedIntegrationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/UdpConnectedIntegrationSpec.scala
index c3fd2837b6..8d13e82693 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/UdpConnectedIntegrationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/UdpConnectedIntegrationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/UdpIntegrationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/UdpIntegrationSpec.scala
index 768ff1d4d5..a999343789 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/UdpIntegrationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/UdpIntegrationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/dns/AsyncDnsResolverIntegrationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/dns/AsyncDnsResolverIntegrationSpec.scala
index edb8c4f4aa..bb703f6d7d 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/dns/AsyncDnsResolverIntegrationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/dns/AsyncDnsResolverIntegrationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/dns/DnsSettingsSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/dns/DnsSettingsSpec.scala
index f99eda9c4d..b1f81edce1 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/dns/DnsSettingsSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/dns/DnsSettingsSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/dns/DockerBindDnsService.scala b/actor-tests/src/test/scala/org/apache/pekko/io/dns/DockerBindDnsService.scala
index b9e1e644f7..cb3b6e469a 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/dns/DockerBindDnsService.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/dns/DockerBindDnsService.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/dns/NameserverAddressParserSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/dns/NameserverAddressParserSpec.scala
index c4e4367a2f..43e36d0174 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/dns/NameserverAddressParserSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/dns/NameserverAddressParserSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/AsyncDnsManagerSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/AsyncDnsManagerSpec.scala
index ab83a8bbe4..21c5c6b5a4 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/AsyncDnsManagerSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/AsyncDnsManagerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/AsyncDnsResolverSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/AsyncDnsResolverSpec.scala
index ec1e8b4ebd..a4cb4f9560 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/AsyncDnsResolverSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/AsyncDnsResolverSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/DnsClientSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/DnsClientSpec.scala
index 5faf26f904..3b89db65e0 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/DnsClientSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/DnsClientSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/MessageSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/MessageSpec.scala
index 718bbfda30..7cbbf6a4e0 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/MessageSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/MessageSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/ResolvConfParserSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/ResolvConfParserSpec.scala
index 06c8b4cf13..61fac2be43 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/ResolvConfParserSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/ResolvConfParserSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/TcpDnsClientSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/TcpDnsClientSpec.scala
index c6467797b0..61c7c22004 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/TcpDnsClientSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/io/dns/internal/TcpDnsClientSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/AskSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/AskSpec.scala
index aecce3ef40..d18576309d 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/AskSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/AskSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/BackoffOnRestartSupervisorSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/BackoffOnRestartSupervisorSpec.scala
index c0592e3935..0f325fd648 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/BackoffOnRestartSupervisorSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/BackoffOnRestartSupervisorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2015-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/BackoffSupervisorSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/BackoffSupervisorSpec.scala
index 41052938e2..5b03e25ce2 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/BackoffSupervisorSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/BackoffSupervisorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2015-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerMTSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerMTSpec.scala
index de9da4eb45..cd53dcc7a8 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerMTSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerMTSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerSpec.scala
index 6f2debe9f2..3babcd69f4 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerStressSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerStressSpec.scala
index bebe12745e..e901c1dee6 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerStressSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/CircuitBreakerStressSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2015-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/PatternSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/PatternSpec.scala
index 5d369b104b..d808bce4b8 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/PatternSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/PatternSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/PipeToSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/PipeToSpec.scala
index d175f8a937..27ddfa9134 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/PipeToSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/PipeToSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/PromiseRefSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/PromiseRefSpec.scala
index 20e2ac0ec6..937fe4a99c 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/PromiseRefSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/PromiseRefSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/RetrySpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/RetrySpec.scala
index 5dd6fc01a3..b90bc7bd75 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/RetrySpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/RetrySpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/StatusReplySpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/StatusReplySpec.scala
index e5de885a26..f09cdc513c 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/StatusReplySpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/StatusReplySpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/pattern/extended/ExplicitAskSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/pattern/extended/ExplicitAskSpec.scala
index 50b5c00be0..e69a645e17 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/pattern/extended/ExplicitAskSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/pattern/extended/ExplicitAskSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/BalancingSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/BalancingSpec.scala
index 7dbe2d468a..ee7ae8950d 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/BalancingSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/BalancingSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/BroadcastSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/BroadcastSpec.scala
index 32ab552557..0b321a1354 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/BroadcastSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/BroadcastSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/ConfiguredLocalRoutingSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/ConfiguredLocalRoutingSpec.scala
index cb6ce3ab84..4bf62a3fce 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/ConfiguredLocalRoutingSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/ConfiguredLocalRoutingSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/ConsistentHashingRouterSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/ConsistentHashingRouterSpec.scala
index bb1464364e..56efdea7e4 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/ConsistentHashingRouterSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/ConsistentHashingRouterSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/MetricsBasedResizerSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/MetricsBasedResizerSpec.scala
index a07597c8d6..5ce194038f 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/MetricsBasedResizerSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/MetricsBasedResizerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/RandomSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/RandomSpec.scala
index 8055fa939a..a4b7baf8e0 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/RandomSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/RandomSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/ResizerSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/ResizerSpec.scala
index 6b6df3c2b8..0cdfab9271 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/ResizerSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/ResizerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/RoundRobinSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/RoundRobinSpec.scala
index 5f359c13fb..fb9b5cc022 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/RoundRobinSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/RoundRobinSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/RouteeCreationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/RouteeCreationSpec.scala
index d9a781ecdd..9480e6f2f5 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/RouteeCreationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/RouteeCreationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/RoutingSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/RoutingSpec.scala
index b0ee2e78ad..92d170df56 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/RoutingSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/RoutingSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/ScatterGatherFirstCompletedSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/ScatterGatherFirstCompletedSpec.scala
index ec2ad43deb..c4205ff9fc 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/ScatterGatherFirstCompletedSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/ScatterGatherFirstCompletedSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/SmallestMailboxSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/SmallestMailboxSpec.scala
index 18748c68a3..fdb7e1250d 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/SmallestMailboxSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/SmallestMailboxSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/routing/TailChoppingSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/routing/TailChoppingSpec.scala
index 9b2781a54d..2728b53199 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/routing/TailChoppingSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/routing/TailChoppingSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/serialization/AsyncSerializeSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/serialization/AsyncSerializeSpec.scala
index b20c568569..3b8c9c3b6c 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/serialization/AsyncSerializeSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/serialization/AsyncSerializeSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/serialization/DisabledJavaSerializerWarningSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/serialization/DisabledJavaSerializerWarningSpec.scala
index 88030218af..18001fb6b1 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/serialization/DisabledJavaSerializerWarningSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/serialization/DisabledJavaSerializerWarningSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/serialization/NoVerification.scala b/actor-tests/src/test/scala/org/apache/pekko/serialization/NoVerification.scala
index 7b0cfa9b54..691475e345 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/serialization/NoVerification.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/serialization/NoVerification.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/serialization/PrimitivesSerializationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/serialization/PrimitivesSerializationSpec.scala
index 38296a1f44..bf6cbe7562 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/serialization/PrimitivesSerializationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/serialization/PrimitivesSerializationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/serialization/SerializationSetupSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/serialization/SerializationSetupSpec.scala
index 7897704fa4..5a08aff25b 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/serialization/SerializationSetupSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/serialization/SerializationSetupSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/serialization/SerializeSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/serialization/SerializeSpec.scala
index 65b3042a31..f71f065087 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/serialization/SerializeSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/serialization/SerializeSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/testkit/CallingThreadDispatcherModelSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/testkit/CallingThreadDispatcherModelSpec.scala
index 95ab182515..9bb62c49c5 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/testkit/CallingThreadDispatcherModelSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/testkit/CallingThreadDispatcherModelSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/AsciiStringCopySpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/AsciiStringCopySpec.scala
index 4cd1e9e9d1..19761d0968 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/AsciiStringCopySpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/AsciiStringCopySpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/BoundedBlockingQueueSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/BoundedBlockingQueueSpec.scala
index ef9becc09e..a09ac3bd7b 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/BoundedBlockingQueueSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/BoundedBlockingQueueSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/ByteIteratorSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/ByteIteratorSpec.scala
index ccfdba4757..b1003d1e66 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/ByteIteratorSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/ByteIteratorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringInitializationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringInitializationSpec.scala
index 40a1554bb7..776fa7be0f 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringInitializationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringInitializationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringSpec.scala
index ece58f8757..ed654343c1 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/ByteStringSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/DoubleLinkedListSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/DoubleLinkedListSpec.scala
index e0557aa933..11074fca30 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/DoubleLinkedListSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/DoubleLinkedListSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/DurationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/DurationSpec.scala
index a3331b070b..f09e4b6210 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/DurationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/DurationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/FrequencyListSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/FrequencyListSpec.scala
index 1857d0961a..6c91aad318 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/FrequencyListSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/FrequencyListSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/FrequencySketchSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/FrequencySketchSpec.scala
index 61c84ca9c4..53061bbbae 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/FrequencySketchSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/FrequencySketchSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2021-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/ImmutableIntMapSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/ImmutableIntMapSpec.scala
index cb56fae6ed..d8ead29346 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/ImmutableIntMapSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/ImmutableIntMapSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/IndexSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/IndexSpec.scala
index 57567dfdcf..f3fd034639 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/IndexSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/IndexSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/LineNumberSpecCodeForScala.scala b/actor-tests/src/test/scala/org/apache/pekko/util/LineNumberSpecCodeForScala.scala
index 1b21c709c6..448decd6df 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/LineNumberSpecCodeForScala.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/LineNumberSpecCodeForScala.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/ManifestInfoSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/ManifestInfoSpec.scala
index a4ab6066c8..481dbeda56 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/ManifestInfoSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/ManifestInfoSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/MessageBufferSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/MessageBufferSpec.scala
index 54f2989686..a02f6cb503 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/MessageBufferSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/MessageBufferSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/PrettyDurationSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/PrettyDurationSpec.scala
index d830bb68e4..a103d28045 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/PrettyDurationSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/PrettyDurationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/RecencyListSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/RecencyListSpec.scala
index aed5adf28a..fec2efadbb 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/RecencyListSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/RecencyListSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/ReflectSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/ReflectSpec.scala
index 1b0afbc120..d46c348220 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/ReflectSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/ReflectSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/SegmentedRecencyListSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/SegmentedRecencyListSpec.scala
index d8d544add8..7c2384085c 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/SegmentedRecencyListSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/SegmentedRecencyListSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/SwitchSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/SwitchSpec.scala
index 5f49ac0ff1..170c75edfc 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/SwitchSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/SwitchSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/TokenBucketSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/TokenBucketSpec.scala
index 2e8af85d83..71318fd699 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/TokenBucketSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/TokenBucketSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2015-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/VersionSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/VersionSpec.scala
index cee32b3659..e54d223cdd 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/VersionSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/VersionSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2015-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/WildcardIndexSpec.scala b/actor-tests/src/test/scala/org/apache/pekko/util/WildcardIndexSpec.scala
index 917bfa3aeb..7f62d7b545 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/WildcardIndexSpec.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/WildcardIndexSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/org/apache/pekko/util/ZipfianGenerator.scala b/actor-tests/src/test/scala/org/apache/pekko/util/ZipfianGenerator.scala
index fc5552939c..e04e435680 100644
--- a/actor-tests/src/test/scala/org/apache/pekko/util/ZipfianGenerator.scala
+++ b/actor-tests/src/test/scala/org/apache/pekko/util/ZipfianGenerator.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2021-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-tests/src/test/scala/other/SerializerOutsidePekkoPackage.scala b/actor-tests/src/test/scala/other/SerializerOutsidePekkoPackage.scala
index d787e51be2..de05a9f8e6 100644
--- a/actor-tests/src/test/scala/other/SerializerOutsidePekkoPackage.scala
+++ b/actor-tests/src/test/scala/other/SerializerOutsidePekkoPackage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/Aggregator.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/Aggregator.java
index 939fce8e68..d8b81af1aa 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/Aggregator.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/Aggregator.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/AggregatorTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/AggregatorTest.java
index 0eaa9db310..b195ab3da4 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/AggregatorTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/AggregatorTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/BubblingSample.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/BubblingSample.java
index 40fc63fac5..37293b8c56 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/BubblingSample.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/BubblingSample.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/BubblingSampleTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/BubblingSampleTest.java
index 36a343e17e..0717857f1b 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/BubblingSampleTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/BubblingSampleTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/DispatchersDocTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/DispatchersDocTest.java
index 725fe46a7c..2d7fc56b27 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/DispatchersDocTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/DispatchersDocTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/FSMDocTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/FSMDocTest.java
index 798ae8acdd..5a765fce52 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/FSMDocTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/FSMDocTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/GracefulStopDocTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/GracefulStopDocTest.java
index dc6a01bc4a..6ab510ed6d 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/GracefulStopDocTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/GracefulStopDocTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/InteractionPatternsAskWithStatusTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/InteractionPatternsAskWithStatusTest.java
index 6e5fe5d401..fe6f69d541 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/InteractionPatternsAskWithStatusTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/InteractionPatternsAskWithStatusTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/InteractionPatternsTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/InteractionPatternsTest.java
index 70262ca5e7..1cc8adc5ce 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/InteractionPatternsTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/InteractionPatternsTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/IntroTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/IntroTest.java
index a25bf7bd7d..8661ad3dd8 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/IntroTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/IntroTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/LoggingDocExamples.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/LoggingDocExamples.java
index 02e91d84ba..b092298b26 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/LoggingDocExamples.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/LoggingDocExamples.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/MailboxDocTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/MailboxDocTest.java
index 73a00cfb2c..e20461e94e 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/MailboxDocTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/MailboxDocTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/OOIntroTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/OOIntroTest.java
index e7b18147a4..b82b164896 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/OOIntroTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/OOIntroTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/RouterTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/RouterTest.java
index 64c0ac5bf0..de46e17304 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/RouterTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/RouterTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/SpawnProtocolDocTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/SpawnProtocolDocTest.java
index 2edbc323b1..40eed715f7 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/SpawnProtocolDocTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/SpawnProtocolDocTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StashDocSample.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StashDocSample.java
index cdad2e3147..783efd3883 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StashDocSample.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StashDocSample.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StashDocTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StashDocTest.java
index 295ede4699..43f73dfc0c 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StashDocTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StashDocTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StyleGuideDocExamples.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StyleGuideDocExamples.java
index 4a06ba426d..c8b96cc599 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StyleGuideDocExamples.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/StyleGuideDocExamples.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/TailChopping.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/TailChopping.java
index f0b55515ca..eac2ae0a1f 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/TailChopping.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/TailChopping.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/coexistence/ClassicWatchingTypedTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/coexistence/ClassicWatchingTypedTest.java
index d468b91e38..7498526da5 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/coexistence/ClassicWatchingTypedTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/coexistence/ClassicWatchingTypedTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/coexistence/TypedWatchingClassicTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/coexistence/TypedWatchingClassicTest.java
index 3e36f2b3d7..871a1751ba 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/coexistence/TypedWatchingClassicTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/coexistence/TypedWatchingClassicTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/extensions/ExtensionDocTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/extensions/ExtensionDocTest.java
index 9b3fd7ee49..e6d80df8a4 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/extensions/ExtensionDocTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/extensions/ExtensionDocTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/fromclassic/ClassicSample.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/fromclassic/ClassicSample.java
index 983fb8cffb..4d3bdd0058 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/fromclassic/ClassicSample.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/fromclassic/ClassicSample.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/fromclassic/TypedSample.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/fromclassic/TypedSample.java
index 91c0c8b2e1..4a01848fe3 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/fromclassic/TypedSample.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/fromclassic/TypedSample.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/pubsub/PubSubExample.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/pubsub/PubSubExample.java
index b49449b78c..b5e85b5fbe 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/pubsub/PubSubExample.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/pubsub/PubSubExample.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/supervision/SupervisionCompileOnlyTest.java b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/supervision/SupervisionCompileOnlyTest.java
index b23ccd344c..e642886909 100644
--- a/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/supervision/SupervisionCompileOnlyTest.java
+++ b/actor-typed-tests/src/test/java/jdocs/org/apache/pekko/typed/supervision/SupervisionCompileOnlyTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/ActorSystemTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/ActorSystemTest.java
index f1ef67bf32..8b7b6909ea 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/ActorSystemTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/ActorSystemTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/DispatcherSelectorTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/DispatcherSelectorTest.java
index 887c4ea9bf..58e0492c3c 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/DispatcherSelectorTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/DispatcherSelectorTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/ExtensionsTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/ExtensionsTest.java
index 9d8c03cf93..088d4450a4 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/ExtensionsTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/ExtensionsTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/MailboxSelectorTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/MailboxSelectorTest.java
index 67b50f0e7c..c27d0e7522 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/MailboxSelectorTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/MailboxSelectorTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/SchedulerTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/SchedulerTest.java
index 080b7a3f88..ca80939de6 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/SchedulerTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/SchedulerTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/eventstream/EventStreamTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/eventstream/EventStreamTest.java
index 1f4cf91356..b138a145ca 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/eventstream/EventStreamTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/eventstream/EventStreamTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorCompile.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorCompile.java
index ddc8dd3a6a..f97ac2c223 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorCompile.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorCompile.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorContextAskTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorContextAskTest.java
index 470dd43701..e5affb463c 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorContextAskTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorContextAskTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorContextPipeToSelfTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorContextPipeToSelfTest.java
index b0fb6a9b77..90a0256345 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorContextPipeToSelfTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorContextPipeToSelfTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorLoggingTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorLoggingTest.java
index f3e0f2a0d3..377036eb9b 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorLoggingTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ActorLoggingTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/AdapterTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/AdapterTest.java
index 9c81785ca9..14f73499a7 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/AdapterTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/AdapterTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/BehaviorBuilderTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/BehaviorBuilderTest.java
index 6e9ee44e5d..87644eb84f 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/BehaviorBuilderTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/BehaviorBuilderTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/InterceptTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/InterceptTest.java
index 9e4e81822e..cc12c6c213 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/InterceptTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/InterceptTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ReceiveBuilderTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ReceiveBuilderTest.java
index 3f4bad831e..714c8065f5 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ReceiveBuilderTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/ReceiveBuilderTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/RoutersTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/RoutersTest.java
index 155a44653c..a0dc21fede 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/RoutersTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/RoutersTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/StashBufferTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/StashBufferTest.java
index e5bc573d17..911a137651 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/StashBufferTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/StashBufferTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/WatchTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/WatchTest.java
index 2428584d57..75e1348858 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/WatchTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/javadsl/WatchTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/receptionist/ReceptionistApiTest.java b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/receptionist/ReceptionistApiTest.java
index 5256185b8c..12dded8b24 100644
--- a/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/receptionist/ReceptionistApiTest.java
+++ b/actor-typed-tests/src/test/java/org/apache/pekko/actor/typed/receptionist/ReceptionistApiTest.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/Aggregator.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/Aggregator.scala
index d62302055b..885ff364aa 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/Aggregator.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/Aggregator.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/AggregatorSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/AggregatorSpec.scala
index b22efde060..f3ab962bdb 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/AggregatorSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/AggregatorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/DispatchersDocSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/DispatchersDocSpec.scala
index 015e1db297..d6d8d3872f 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/DispatchersDocSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/DispatchersDocSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/FSMDocSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/FSMDocSpec.scala
index feb167a668..a64176535e 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/FSMDocSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/FSMDocSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/FaultToleranceDocSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/FaultToleranceDocSpec.scala
index 4de0468e8a..83bca92a7a 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/FaultToleranceDocSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/FaultToleranceDocSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/GracefulStopDocSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/GracefulStopDocSpec.scala
index bc53972256..6dd4676c00 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/GracefulStopDocSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/GracefulStopDocSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/InteractionPatternsSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/InteractionPatternsSpec.scala
index 7efd4ac513..e5243e80c6 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/InteractionPatternsSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/InteractionPatternsSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/IntroSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/IntroSpec.scala
index 8390397d5c..284abdffe2 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/IntroSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/IntroSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/LoggingDocExamples.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/LoggingDocExamples.scala
index 5d945aa6f5..7ebb9420d3 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/LoggingDocExamples.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/LoggingDocExamples.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/MailboxDocSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/MailboxDocSpec.scala
index fb09f6f505..d03f37a152 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/MailboxDocSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/MailboxDocSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/OOIntroSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/OOIntroSpec.scala
index a37c5c99b7..652a7138eb 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/OOIntroSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/OOIntroSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/RouterSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/RouterSpec.scala
index 8a275332e6..9fc9c331a0 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/RouterSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/RouterSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/SpawnProtocolDocSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/SpawnProtocolDocSpec.scala
index 38cd772f3a..aac676a134 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/SpawnProtocolDocSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/SpawnProtocolDocSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/StashDocSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/StashDocSpec.scala
index 248a12707d..e77d10d210 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/StashDocSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/StashDocSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/StyleGuideDocExamples.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/StyleGuideDocExamples.scala
index 47d7abeb65..07e8f426c3 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/StyleGuideDocExamples.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/StyleGuideDocExamples.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/TailChopping.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/TailChopping.scala
index 13649fdcef..897d4110dc 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/TailChopping.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/TailChopping.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/coexistence/ClassicWatchingTypedSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/coexistence/ClassicWatchingTypedSpec.scala
index 5f32fc9714..5fb9b81818 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/coexistence/ClassicWatchingTypedSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/coexistence/ClassicWatchingTypedSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/coexistence/TypedWatchingClassicSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/coexistence/TypedWatchingClassicSpec.scala
index 54844ac95e..b55be532c6 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/coexistence/TypedWatchingClassicSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/coexistence/TypedWatchingClassicSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/extensions/ExtensionDocSpec.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/extensions/ExtensionDocSpec.scala
index 56841711b1..025df566f0 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/extensions/ExtensionDocSpec.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/extensions/ExtensionDocSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/fromclassic/ClassicSample.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/fromclassic/ClassicSample.scala
index 95e034c7aa..3fa774d5a8 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/fromclassic/ClassicSample.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/fromclassic/ClassicSample.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/fromclassic/TypedSample.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/fromclassic/TypedSample.scala
index ada8bd7476..8bc8594751 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/fromclassic/TypedSample.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/fromclassic/TypedSample.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/myapp/package.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/myapp/package.scala
index 46e7fe3cce..ab1ab4a51a 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/myapp/package.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/myapp/package.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/pubsub/PubSubExample.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/pubsub/PubSubExample.scala
index a0c5eeb72b..2a6b7d144a 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/pubsub/PubSubExample.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/pubsub/PubSubExample.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/supervision/SupervisionCompileOnly.scala b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/supervision/SupervisionCompileOnly.scala
index 1cfd439c63..06a73fe06d 100644
--- a/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/supervision/SupervisionCompileOnly.scala
+++ b/actor-typed-tests/src/test/scala/docs/org/apache/pekko/typed/supervision/SupervisionCompileOnly.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorContextSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorContextSpec.scala
index 73de97b41a..ad3a7252e5 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorContextSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorContextSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefIgnoreSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefIgnoreSpec.scala
index 7d4bf25a7b..4b65cee1a3 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefIgnoreSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefIgnoreSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefResolverSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefResolverSpec.scala
index 7623158516..edcff07e0d 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefResolverSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ActorRefResolverSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/AskSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/AskSpec.scala
index 7f9762842d..1c61a1279e 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/AskSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/AskSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/BehaviorSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/BehaviorSpec.scala
index 570983a599..4d2d9394bf 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/BehaviorSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/BehaviorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/DeferredSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/DeferredSpec.scala
index 6fe01f322d..1a5b088977 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/DeferredSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/DeferredSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ExtensionsSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ExtensionsSpec.scala
index 4e1e29779b..cd343210a4 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ExtensionsSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/ExtensionsSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/InterceptSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/InterceptSpec.scala
index 9dd54906a9..59341d4db7 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/InterceptSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/InterceptSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LocalActorRefProviderLogMessagesSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LocalActorRefProviderLogMessagesSpec.scala
index 3e7b343e16..cdfc6db1ed 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LocalActorRefProviderLogMessagesSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LocalActorRefProviderLogMessagesSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LogMessagesSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LogMessagesSpec.scala
index 6be3de231a..6928db270f 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LogMessagesSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/LogMessagesSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/MailboxSelectorSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/MailboxSelectorSpec.scala
index 628ef91849..4a10ef91f1 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/MailboxSelectorSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/MailboxSelectorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/MonitorSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/MonitorSpec.scala
index cade3cec64..8df0a78ee7 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/MonitorSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/MonitorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/OrElseSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/OrElseSpec.scala
index 32831d84f7..8ebb96c05b 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/OrElseSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/OrElseSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/PropsSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/PropsSpec.scala
index 629852d6c7..6730a330cb 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/PropsSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/PropsSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SchedulerSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SchedulerSpec.scala
index d594c05273..1a80d4d29c 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SchedulerSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SchedulerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SpawnProtocolSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SpawnProtocolSpec.scala
index 76a8a4ff97..92924f7c44 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SpawnProtocolSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SpawnProtocolSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SupervisionSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SupervisionSpec.scala
index 47f6df1579..ee12312e38 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SupervisionSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/SupervisionSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TerminatedSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TerminatedSpec.scala
index b8da370cfa..0ee8fa67ae 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TerminatedSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TerminatedSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TimerSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TimerSpec.scala
index d79037b942..6104c680e9 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TimerSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TimerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TransformMessagesSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TransformMessagesSpec.scala
index 5ff82ff803..28ac84dc7a 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TransformMessagesSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/TransformMessagesSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/WatchSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/WatchSpec.scala
index e146ca64db..3f42f6408f 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/WatchSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/WatchSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/coexistence/ClassicSupervisingTypedSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/coexistence/ClassicSupervisingTypedSpec.scala
index 787179faf8..2658fd3d39 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/coexistence/ClassicSupervisingTypedSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/coexistence/ClassicSupervisingTypedSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/coexistence/TypedSupervisingClassicSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/coexistence/TypedSupervisingClassicSpec.scala
index 740f0557b1..5238c18d3f 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/coexistence/TypedSupervisingClassicSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/coexistence/TypedSupervisingClassicSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ConsumerControllerSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ConsumerControllerSpec.scala
index b6a3baa0ba..13dfd8eb0f 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ConsumerControllerSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ConsumerControllerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableProducerControllerSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableProducerControllerSpec.scala
index 4340fdbc58..863c83c5be 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableProducerControllerSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableProducerControllerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableProducerQueueSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableProducerQueueSpec.scala
index 62eac14f04..7b783e180a 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableProducerQueueSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableProducerQueueSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableWorkPullingSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableWorkPullingSpec.scala
index 580a8f2ef1..987ea50594 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableWorkPullingSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/DurableWorkPullingSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ProducerControllerSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ProducerControllerSpec.scala
index 74a9c063df..6a784ef948 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ProducerControllerSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ProducerControllerSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ReliableDeliveryRandomSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ReliableDeliveryRandomSpec.scala
index 98039c74ac..984ad16560 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ReliableDeliveryRandomSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ReliableDeliveryRandomSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ReliableDeliverySpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ReliableDeliverySpec.scala
index 01db20f267..bf85792b9e 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ReliableDeliverySpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/ReliableDeliverySpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestConsumer.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestConsumer.scala
index 36497a7d4b..666a1c7280 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestConsumer.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestConsumer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestDurableProducerQueue.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestDurableProducerQueue.scala
index 0a33de77a0..cda0c2ac9d 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestDurableProducerQueue.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestDurableProducerQueue.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducer.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducer.scala
index c2dabb4bed..58f6e7d0c6 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducer.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducerWithAsk.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducerWithAsk.scala
index e7c5033c50..5ddc2c813e 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducerWithAsk.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducerWithAsk.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducerWorkPulling.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducerWorkPulling.scala
index a81b26305d..745431a7ee 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducerWorkPulling.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/TestProducerWorkPulling.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/WorkPullingSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/WorkPullingSpec.scala
index 656891cf8d..92386cfe99 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/WorkPullingSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/delivery/WorkPullingSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/eventstream/EventStreamSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/eventstream/EventStreamSpec.scala
index 9cbbc09fd3..83ecbb4036 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/eventstream/EventStreamSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/eventstream/EventStreamSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorRefSerializationSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorRefSerializationSpec.scala
index d29fdcb528..76bb7f8451 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorRefSerializationSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorRefSerializationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorSystemSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorSystemSpec.scala
index ab4452256c..d716e006cd 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorSystemSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/ActorSystemSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/adpater/PropsAdapterSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/adpater/PropsAdapterSpec.scala
index f4c2cbc910..1bdc8e676b 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/adpater/PropsAdapterSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/adpater/PropsAdapterSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/receptionist/LocalReceptionistSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/receptionist/LocalReceptionistSpec.scala
index 8d17a6907f..5884fa3b5d 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/receptionist/LocalReceptionistSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/receptionist/LocalReceptionistSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/receptionist/ServiceKeySerializationSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/receptionist/ServiceKeySerializationSpec.scala
index fe67f5d7c7..b9e6b7837c 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/receptionist/ServiceKeySerializationSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/receptionist/ServiceKeySerializationSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/routing/PoolRouterSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/routing/PoolRouterSpec.scala
index 270b894be4..05ea6a2c9e 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/routing/PoolRouterSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/routing/PoolRouterSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/routing/RoutingLogicSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/routing/RoutingLogicSpec.scala
index d5a307d508..69155f5eeb 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/routing/RoutingLogicSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/internal/routing/RoutingLogicSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/javadsl/AdaptationFailureSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/javadsl/AdaptationFailureSpec.scala
index e435e538ce..0feb6fe9c5 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/javadsl/AdaptationFailureSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/javadsl/AdaptationFailureSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/pubsub/LocalPubSubSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/pubsub/LocalPubSubSpec.scala
index ce35c94e83..b165667f21 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/pubsub/LocalPubSubSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/pubsub/LocalPubSubSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/receptionist/ReceptionistApiSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/receptionist/ReceptionistApiSpec.scala
index 48afbf853c..8156d6b2b9 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/receptionist/ReceptionistApiSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/receptionist/ReceptionistApiSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextAskSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextAskSpec.scala
index f29b3500c8..dd26dfac22 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextAskSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextAskSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextDelegateSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextDelegateSpec.scala
index b194fe9d01..bbdb52ed2d 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextDelegateSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextDelegateSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextPipeToSelfSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextPipeToSelfSpec.scala
index e23f4774fd..689ff3d2b5 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextPipeToSelfSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorContextPipeToSelfSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorLoggingSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorLoggingSpec.scala
index 29cf6fbbe5..74da12af30 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorLoggingSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorLoggingSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorThreadSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorThreadSpec.scala
index 38640ffd39..189cc2ce2d 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorThreadSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ActorThreadSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/AdaptationFailureSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/AdaptationFailureSpec.scala
index bab36e7915..2065209a9f 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/AdaptationFailureSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/AdaptationFailureSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/DispatcherSelectorSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/DispatcherSelectorSpec.scala
index 1395f0f335..4290fa9d14 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/DispatcherSelectorSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/DispatcherSelectorSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/GracefulStopSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/GracefulStopSpec.scala
index cae5b595f9..d802f4c2e4 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/GracefulStopSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/GracefulStopSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/LoggerOpsSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/LoggerOpsSpec.scala
index a7d55fbb6d..f67b15433b 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/LoggerOpsSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/LoggerOpsSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/MessageAdapterSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/MessageAdapterSpec.scala
index 3e188cd0ad..b5fc7e21d4 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/MessageAdapterSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/MessageAdapterSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/OnSignalSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/OnSignalSpec.scala
index f921888604..d8632a8a14 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/OnSignalSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/OnSignalSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ReceivePartialSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ReceivePartialSpec.scala
index fe402fab8a..faa24a286b 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ReceivePartialSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/ReceivePartialSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/RoutersSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/RoutersSpec.scala
index 43f93aedb5..d93fe0ced8 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/RoutersSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/RoutersSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StashBufferSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StashBufferSpec.scala
index e745c731ae..28abc885f2 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StashBufferSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StashBufferSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StashSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StashSpec.scala
index 0bb5420bb6..a4ffcb8f3c 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StashSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StashSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StopSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StopSpec.scala
index eaa1bbb5a9..b9b49c82a4 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StopSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/StopSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/adapter/AdapterSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/adapter/AdapterSpec.scala
index 8214720d1e..3bf161a7b4 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/adapter/AdapterSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/adapter/AdapterSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/adapter/GuardianStartupSpec.scala b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/adapter/GuardianStartupSpec.scala
index 958061d697..ecebff168b 100644
--- a/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/adapter/GuardianStartupSpec.scala
+++ b/actor-typed-tests/src/test/scala/org/apache/pekko/actor/typed/scaladsl/adapter/GuardianStartupSpec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala-2.13/org/apache/pekko/actor/typed/internal/receptionist/Platform.scala b/actor-typed/src/main/scala-2.13/org/apache/pekko/actor/typed/internal/receptionist/Platform.scala
index 2b09ba303f..260bfe92a7 100644
--- a/actor-typed/src/main/scala-2.13/org/apache/pekko/actor/typed/internal/receptionist/Platform.scala
+++ b/actor-typed/src/main/scala-2.13/org/apache/pekko/actor/typed/internal/receptionist/Platform.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala-jdk-9/org/apache/pekko/actor/typed/internal/jfr/Events.scala b/actor-typed/src/main/scala-jdk-9/org/apache/pekko/actor/typed/internal/jfr/Events.scala
index 282751b4ab..67a35bfc87 100644
--- a/actor-typed/src/main/scala-jdk-9/org/apache/pekko/actor/typed/internal/jfr/Events.scala
+++ b/actor-typed/src/main/scala-jdk-9/org/apache/pekko/actor/typed/internal/jfr/Events.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) extends Event 2009-2019 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala-jdk-9/org/apache/pekko/actor/typed/internal/jfr/JFRActorFlightRecorder.scala b/actor-typed/src/main/scala-jdk-9/org/apache/pekko/actor/typed/internal/jfr/JFRActorFlightRecorder.scala
index 117f4bcc75..1ef64c46a4 100644
--- a/actor-typed/src/main/scala-jdk-9/org/apache/pekko/actor/typed/internal/jfr/JFRActorFlightRecorder.scala
+++ b/actor-typed/src/main/scala-jdk-9/org/apache/pekko/actor/typed/internal/jfr/JFRActorFlightRecorder.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorRef.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorRef.scala
index 493e6743b8..e502db9000 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorRef.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorRef.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorRefResolver.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorRefResolver.scala
index 7e2f9da2e3..42d3af5e80 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorRefResolver.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorRefResolver.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorSystem.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorSystem.scala
index f365fce80a..ff0fba4001 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorSystem.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/ActorSystem.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Behavior.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Behavior.scala
index 6e4c0b4060..c2ac07011c 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Behavior.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Behavior.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/BehaviorInterceptor.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/BehaviorInterceptor.scala
index 8ec14c319f..a874a25622 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/BehaviorInterceptor.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/BehaviorInterceptor.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Dispatchers.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Dispatchers.scala
index 1f5ac9b9bd..c17311845c 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Dispatchers.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Dispatchers.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Extensions.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Extensions.scala
index 17b49c4ad2..1a799e7c33 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Extensions.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Extensions.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/LogOptions.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/LogOptions.scala
index fb46d29d59..7dff051ca4 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/LogOptions.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/LogOptions.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/MessageAndSignals.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/MessageAndSignals.scala
index 202c2e8c2f..85d4a9af32 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/MessageAndSignals.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/MessageAndSignals.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Props.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Props.scala
index bcc05427f0..dff95e063c 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Props.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Props.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2016-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Scheduler.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Scheduler.scala
index 070be7c963..d747700210 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Scheduler.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/Scheduler.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2009-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/SpawnProtocol.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/SpawnProtocol.scala
index 875a9a130b..69ee8cadd4 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/SpawnProtocol.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/SpawnProtocol.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/SupervisorStrategy.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/SupervisorStrategy.scala
index d7d174836f..ba54a2425e 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/SupervisorStrategy.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/SupervisorStrategy.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/TypedActorContext.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/TypedActorContext.scala
index c1a25b163b..8eb9bb042e 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/TypedActorContext.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/TypedActorContext.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2014-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/ConsumerController.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/ConsumerController.scala
index 157c0dacdd..b3defdca2a 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/ConsumerController.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/ConsumerController.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/DurableProducerQueue.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/DurableProducerQueue.scala
index cbdcdcb9c6..b57eea2f84 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/DurableProducerQueue.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/DurableProducerQueue.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/ProducerController.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/ProducerController.scala
index 0f54c1907d..ed314f27f3 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/ProducerController.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/ProducerController.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/WorkPullingProducerController.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/WorkPullingProducerController.scala
index 651df7e230..ad71b6c8d3 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/WorkPullingProducerController.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/WorkPullingProducerController.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ChunkedMessage.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ChunkedMessage.scala
index b654a794c1..acbf8323d5 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ChunkedMessage.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ChunkedMessage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ConsumerControllerImpl.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ConsumerControllerImpl.scala
index 8a3c16ab2c..e91124193e 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ConsumerControllerImpl.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ConsumerControllerImpl.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/DeliverySerializable.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/DeliverySerializable.scala
index 068ba6ae5d..608bbf9fed 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/DeliverySerializable.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/DeliverySerializable.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ProducerControllerImpl.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ProducerControllerImpl.scala
index af6af19451..a9ddb6f49f 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ProducerControllerImpl.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/ProducerControllerImpl.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/WorkPullingProducerControllerImpl.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/WorkPullingProducerControllerImpl.scala
index 68e6819a62..470c7795c1 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/WorkPullingProducerControllerImpl.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/delivery/internal/WorkPullingProducerControllerImpl.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/eventstream/EventStream.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/eventstream/EventStream.scala
index f9092c5cc0..d50c5009d6 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/eventstream/EventStream.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/eventstream/EventStream.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorContextImpl.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorContextImpl.scala
index c9b2ad2944..0b99bc4840 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorContextImpl.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorContextImpl.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2017-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorFlightRecorder.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorFlightRecorder.scala
index 5fde84b3b4..5a3fb1da72 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorFlightRecorder.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorFlightRecorder.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2020-2022 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorMdc.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorMdc.scala
index 7cba7655e3..7eae747040 100644
--- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorMdc.scala
+++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/internal/ActorMdc.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
... 46142 lines suppressed ...


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


[incubator-pekko] 01/02: !sbt Use Apache header for new files.

Posted by he...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit 3323ff6eb3beca3cb36106d324ed8901ab1b84fd
Author: kerr <he...@gmail.com>
AuthorDate: Wed Nov 16 14:02:29 2022 +0800

    !sbt Use Apache header for new files.
---
 project/CopyrightHeader.scala | 92 +++++++++++++++++++++++--------------------
 1 file changed, 49 insertions(+), 43 deletions(-)

diff --git a/project/CopyrightHeader.scala b/project/CopyrightHeader.scala
index 981eca848e..274e6fb2e8 100644
--- a/project/CopyrightHeader.scala
+++ b/project/CopyrightHeader.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
  */
@@ -6,8 +15,9 @@ package org.apache.pekko
 
 import org.apache.pekko.PekkoValidatePullRequest.additionalTasks
 import de.heikoseeberger.sbtheader.HeaderPlugin.autoImport._
-import de.heikoseeberger.sbtheader.{ CommentCreator, HeaderPlugin }
+import de.heikoseeberger.sbtheader.{ CommentCreator, HeaderPlugin, NewLine }
 import com.typesafe.sbt.MultiJvmPlugin.MultiJvmKeys._
+import org.apache.commons.lang3.StringUtils
 import sbt.Keys._
 import sbt._
 
@@ -21,7 +31,7 @@ trait CopyrightHeader extends AutoPlugin {
     Seq(Compile, Test, MultiJvm).flatMap { config =>
       inConfig(config)(
         Seq(
-          headerLicense := Some(HeaderLicense.Custom(headerFor(CurrentYear))),
+          headerLicense := Some(HeaderLicense.Custom(apacheHeader)),
           headerMappings := headerMappings.value ++ Map(
             HeaderFileType.scala -> cStyleComment,
             HeaderFileType.java -> cStyleComment,
@@ -40,60 +50,56 @@ trait CopyrightHeader extends AutoPlugin {
         (Test / compile).value
       })
 
-  // We hard-code this so PR's created in year X will not suddenly fail in X+1.
-  // Of course we should remember to update it early in the year.
-  val CurrentYear = "2022"
-  val CopyrightPattern = "Copyright \\([Cc]\\) (\\d{4}([-–]\\d{4})?) (Lightbend|Typesafe) Inc. <.*>".r
-  val CopyrightHeaderPattern = s"(?s).*${CopyrightPattern}.*".r
-
   def headerFor(year: String): String =
     s"Copyright (C) $year Lightbend Inc. <https://www.lightbend.com>"
 
-  val cStyleComment = HeaderCommentStyle.cStyleBlockComment.copy(commentCreator = new CommentCreator() {
+  def apacheHeader: String =
+    """Licensed to the Apache Software Foundation (ASF) under one or more
+      |license agreements; and to You under the Apache License, version 2.0:
+      |
+      |  https://www.apache.org/licenses/LICENSE-2.0
+      |
+      |This file is part of the Apache Pekko project, derived from Akka.
+      |""".stripMargin
 
-    def updateLightbendHeader(header: String): String = header match {
-      case CopyrightHeaderPattern(years, null, _) =>
-        if (years != CurrentYear)
-          CopyrightPattern.replaceFirstIn(header, headerFor(years + "-" + CurrentYear))
-        else
-          CopyrightPattern.replaceFirstIn(header, headerFor(years))
-      case CopyrightHeaderPattern(years, endYears, _) =>
-        CopyrightPattern.replaceFirstIn(header, headerFor(years.replace(endYears, "-" + CurrentYear)))
-      case _ =>
-        header
-    }
-
-    def parseStartAndEndYear(header: String): Option[(String, Option[String])] = header match {
-      case CopyrightHeaderPattern(years, null, _) =>
-        Some((years, None))
-      case CopyrightHeaderPattern(years, endYears, _) =>
-        Some((years, Some(endYears)))
-      case _ =>
-        None
-    }
+  val cStyleComment = HeaderCommentStyle.cStyleBlockComment.copy(commentCreator = new CommentCreator() {
 
     override def apply(text: String, existingText: Option[String]): String = {
       val formatted = existingText match {
+        case Some(existedText) if isValidCopyRightAnnotated(existedText) =>
+          existedText
+        case Some(existedText) if isOnlyLightbendCopyRightAnnotated(existedText) =>
+          HeaderCommentStyle.cStyleBlockComment.commentCreator(text, existingText) + NewLine * 2 + existedText
         case Some(existedText) =>
-          parseStartAndEndYear(existedText) match {
-            case Some((years, None)) =>
-              if (years != CurrentYear) {
-                val header = headerFor(years + "-" + CurrentYear)
-                HeaderCommentStyle.cStyleBlockComment.commentCreator(header, existingText)
-              } else {
-                HeaderCommentStyle.cStyleBlockComment.commentCreator(headerFor(CurrentYear), existingText)
-              }
-            case Some((years, Some(endYears))) =>
-              val header = headerFor(years.replace(endYears, "-" + CurrentYear))
-              HeaderCommentStyle.cStyleBlockComment.commentCreator(header, existingText)
-            case None =>
-              existedText
-          }
+          throw new IllegalStateException(s"Unable to detect copyright for header:[${existedText}]")
         case None =>
           HeaderCommentStyle.cStyleBlockComment.commentCreator(text, existingText)
       }
       formatted.trim
     }
+
+    private def isApacheCopyRighted(text: String): Boolean =
+      StringUtils.containsIgnoreCase(text, "licensed to the apache software foundation (asf)") ||
+      StringUtils.containsIgnoreCase(text, "www.apache.org/licenses/license-2.0")
+
+    private def isLAMPCopyRighted(text: String): Boolean =
+      StringUtils.containsIgnoreCase(text, "lamp/epfl")
+
+    private def isLightbendCopyRighted(text: String): Boolean =
+      StringUtils.containsIgnoreCase(text, "lightbend inc.")
+
+    private def isDebianCopyRighted(text: String): Boolean =
+      StringUtils.containsIgnoreCase(text, "debian.org")
+
+    private def isValidCopyRightAnnotated(text: String): Boolean = {
+      isApacheCopyRighted(text) || isLAMPCopyRighted(text) || isDebianCopyRighted(text)
+    }
+
+    private def isOnlyLightbendCopyRightAnnotated(text: String): Boolean = {
+      isLightbendCopyRighted(text) && !(isApacheCopyRighted(text) || isLAMPCopyRighted(text) || isDebianCopyRighted(
+        text))
+    }
+
   })
 }
 


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