Skip to content

Commit

Permalink
2: State: fix column positions for multiline strings
Browse files Browse the repository at this point in the history
  • Loading branch information
Albert Meltzer committed Jun 8, 2020
1 parent 6324b32 commit 050689f
Show file tree
Hide file tree
Showing 363 changed files with 699 additions and 1,445 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -21,8 +21,7 @@ import scala.util.control.NoStackTrace

object SchedulerSpec {
val testConfRevolver = ConfigFactory
.parseString(
"""
.parseString("""
akka.scheduler.implementation = akka.actor.LightArrayRevolverScheduler
akka.scheduler.ticks-per-wheel = 32
akka.actor.serialize-messages = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -97,8 +97,7 @@ object SupervisorSpec {
throw failure
}

val config =
ConfigFactory.parseString("""
val config = ConfigFactory.parseString("""
akka.actor.serialize-messages = off
error-mailbox {
mailbox-type = "akka.actor.SupervisorSpec$Mailbox"
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -16,8 +16,7 @@ import java.util.concurrent.ConcurrentLinkedQueue
import java.util.concurrent.atomic.AtomicBoolean

object DispatchersSpec {
val config =
"""
val config = """
myapp {
mydispatcher {
throughput = 17
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -5,8 +5,7 @@ import akka.testkit.{ImplicitSender, AkkaSpec}
import com.typesafe.config.ConfigFactory

object ForkJoinPoolStarvationSpec {
val config = ConfigFactory.parseString(
"""
val config = ConfigFactory.parseString("""
|actorhang {
|
| task-dispatcher {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -299,8 +299,7 @@ class SingleConsumerOnlyMailboxSpec extends MailboxSpec {

object SingleConsumerOnlyMailboxVerificationSpec {
case object Ping
val mailboxConf = ConfigFactory.parseString(
"""
val mailboxConf = ConfigFactory.parseString("""
akka.actor.serialize-messages = off
test-unbounded-dispatcher {
mailbox-type = "akka.dispatch.SingleConsumerOnlyUnboundedMailbox"
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -12,8 +12,7 @@ import akka.testkit.{DefaultTimeout, AkkaSpec}
import scala.concurrent.duration._

object StablePriorityDispatcherSpec {
val config =
"""
val config = """
unbounded-stable-prio-dispatcher {
mailbox-type = "akka.dispatch.StablePriorityDispatcherSpec$Unbounded"
}
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -12,8 +12,7 @@ import akka.testkit.{TestProbe, AkkaSpec}

object EventStreamSpec {

val config = ConfigFactory.parseString(
"""
val config = ConfigFactory.parseString("""
akka {
actor.serialize-messages = off
stdout-loglevel = WARNING
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -50,8 +50,7 @@ object LoggerSpec {
.withFallback(AkkaSpec.testConf)

val multipleConfig = ConfigFactory
.parseString(
"""
.parseString("""
akka {
stdout-loglevel = "OFF"
loglevel = "WARNING"
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -27,8 +27,7 @@ class LoggingReceiveSpec extends WordSpec with BeforeAndAfterAll {

import LoggingReceiveSpec._
val config = ConfigFactory
.parseString(
"""
.parseString("""
akka.loglevel=DEBUG
akka.actor.serialize-messages = off # debug noise from serialization
""")
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -107,8 +107,7 @@ object SerializationTests {
ActorSystem("SerializationSystem", mostlyReferenceConf)
}

val systemMessageMultiSerializerConf =
"""
val systemMessageMultiSerializerConf = """
akka {
actor {
serializers {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,8 +26,7 @@ class NodeQueueBenchmark {
import NodeQueueBenchmark._

val config = ConfigFactory
.parseString(
"""
.parseString("""
dispatcher {
executor = "thread-pool-executor"
throughput = 1000
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -23,8 +23,7 @@ import scala.concurrent.duration._
class FlowMapBenchmark {

val config = ConfigFactory
.parseString(
"""
.parseString("""
akka {
log-config-on-start = off
log-dead-letters-during-shutdown = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -37,15 +37,13 @@ trait ClusterMetricsCommonConfig extends MultiNodeConfig {
def disableMetricsLegacy = parseString("""akka.cluster.metrics.enabled=off""")

// Enable metrics extension in akka-cluster-metrics.
def enableMetricsExtension =
parseString("""
def enableMetricsExtension = parseString("""
akka.extensions=["akka.cluster.metrics.ClusterMetricsExtension"]
akka.cluster.metrics.collector.enabled = on
""")

// Disable metrics extension in akka-cluster-metrics.
def disableMetricsExtension =
parseString("""
def disableMetricsExtension = parseString("""
akka.extensions=["akka.cluster.metrics.ClusterMetricsExtension"]
akka.cluster.metrics.collector.enabled = off
""")
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -73,8 +73,7 @@ object AdaptiveLoadBalancingRouterConfig extends MultiNodeConfig {

commonConfig(
debugConfig(on = false)
.withFallback(ConfigFactory.parseString(
"""
.withFallback(ConfigFactory.parseString("""
# Disable legacy metrics.
akka.cluster.metrics.enabled=off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -153,8 +153,7 @@ object MetricsConfig {
val defaultDecayFactor = 2.0 / (1 + 10)

/** Test w/o cluster, with collection enabled. */
val defaultEnabled =
"""
val defaultEnabled = """
akka.cluster.metrics {
collector {
enabled = on
Expand All @@ -166,8 +165,7 @@ object MetricsConfig {
"""

/** Test w/o cluster, with collection disabled. */
val defaultDisabled =
"""
val defaultDisabled = """
akka.cluster.metrics {
collector {
enabled = off
Expand All @@ -177,8 +175,7 @@ object MetricsConfig {
"""

/** Test in cluster, with manual collection activation, collector mock, fast. */
val clusterSigarMock =
"""
val clusterSigarMock = """
akka.cluster.metrics {
periodic-tasks-initial-delay = 100ms
collector {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -44,9 +44,7 @@ object ClusterShardingGetStateSpecConfig extends MultiNodeConfig {
val first = role("first")
val second = role("second")

commonConfig(
ConfigFactory.parseString(
"""
commonConfig(ConfigFactory.parseString("""
akka.loglevel = INFO
akka.actor.provider = "akka.cluster.ClusterActorRefProvider"
akka.remote.log-remote-lifecycle-events = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -45,9 +45,7 @@ object ClusterShardingGetStatsSpecConfig extends MultiNodeConfig {
val second = role("second")
val third = role("third")

commonConfig(
ConfigFactory.parseString(
"""
commonConfig(ConfigFactory.parseString("""
akka.loglevel = INFO
akka.actor.provider = "akka.cluster.ClusterActorRefProvider"
akka.remote.log-remote-lifecycle-events = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -25,8 +25,7 @@ import akka.testkit.TestActors.EchoActor
import org.apache.commons.io.FileUtils

object RemoveInternalClusterShardingDataSpec {
val config =
"""
val config = """
akka.loglevel = INFO
akka.actor.provider = "akka.cluster.ClusterActorRefProvider"
akka.remote.netty.tcp.port = 0
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -31,8 +31,7 @@ object ClusterClientSpec extends MultiNodeConfig {
val third = role("third")
val fourth = role("fourth")

commonConfig(ConfigFactory.parseString(
"""
commonConfig(ConfigFactory.parseString("""
akka.loglevel = INFO
akka.actor.provider = "akka.cluster.ClusterActorRefProvider"
akka.remote.log-remote-lifecycle-events = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -17,9 +17,7 @@ object ClusterClientStopSpec extends MultiNodeConfig {
val client = role("client")
val first = role("first")
val second = role("second")
commonConfig(
ConfigFactory.parseString(
"""
commonConfig(ConfigFactory.parseString("""
akka.loglevel = INFO
akka.actor.provider = "akka.cluster.ClusterActorRefProvider"
akka.remote.log-remote-lifecycle-events = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,9 +26,7 @@ object DistributedPubSubMediatorSpec extends MultiNodeConfig {
val second = role("second")
val third = role("third")

commonConfig(
ConfigFactory.parseString(
"""
commonConfig(ConfigFactory.parseString("""
akka.loglevel = INFO
akka.actor.provider = "akka.cluster.ClusterActorRefProvider"
akka.remote.log-remote-lifecycle-events = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -36,9 +36,7 @@ object ClusterSingletonManagerChaosSpec extends MultiNodeConfig {
val fifth = role("fifth")
val sixth = role("sixth")

commonConfig(
ConfigFactory.parseString(
"""
commonConfig(ConfigFactory.parseString("""
akka.loglevel = INFO
akka.actor.provider = "akka.cluster.ClusterActorRefProvider"
akka.remote.log-remote-lifecycle-events = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -33,9 +33,7 @@ object ClusterSingletonManagerLeaveSpec extends MultiNodeConfig {
val second = role("second")
val third = role("third")

commonConfig(
ConfigFactory.parseString(
"""
commonConfig(ConfigFactory.parseString("""
akka.loglevel = INFO
akka.actor.provider = "akka.cluster.ClusterActorRefProvider"
akka.remote.log-remote-lifecycle-events = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -39,9 +39,7 @@ object ClusterSingletonManagerSpec extends MultiNodeConfig {
val fifth = role("fifth")
val sixth = role("sixth")

commonConfig(
ConfigFactory.parseString(
"""
commonConfig(ConfigFactory.parseString("""
akka.loglevel = INFO
akka.actor.provider = "akka.cluster.ClusterActorRefProvider"
akka.remote.log-remote-lifecycle-events = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -33,9 +33,7 @@ object ClusterSingletonManagerStartupSpec extends MultiNodeConfig {
val second = role("second")
val third = role("third")

commonConfig(
ConfigFactory.parseString(
"""
commonConfig(ConfigFactory.parseString("""
akka.loglevel = INFO
akka.actor.provider = "akka.cluster.ClusterActorRefProvider"
akka.remote.log-remote-lifecycle-events = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -21,8 +21,7 @@ object DeterministicOldestWhenJoiningMultiJvmSpec extends MultiNodeConfig {

commonConfig(
debugConfig(on = false)
.withFallback(ConfigFactory.parseString(
"""
.withFallback(ConfigFactory.parseString("""
# not too quick to trigger problematic scenario more often
akka.cluster.leader-actions-interval = 2000 ms
akka.cluster.gossip-interval = 500 ms
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -21,8 +21,7 @@ object InitialHeartbeatMultiJvmSpec extends MultiNodeConfig {

commonConfig(
debugConfig(on = false)
.withFallback(
ConfigFactory.parseString("""
.withFallback(ConfigFactory.parseString("""
akka.cluster.failure-detector.threshold = 4"""))
.withFallback(MultiNodeClusterSpec.clusterConfig))

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -19,8 +19,7 @@ object LeaderDowningAllOtherNodesMultiJvmSpec extends MultiNodeConfig {

commonConfig(
debugConfig(on = false)
.withFallback(ConfigFactory.parseString(
"""
.withFallback(ConfigFactory.parseString("""
akka.cluster.failure-detector.monitored-by-nr-of-members = 2
akka.cluster.auto-down-unreachable-after = 1s
"""))
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -21,8 +21,7 @@ object MemberWeaklyUpSpec extends MultiNodeConfig {

commonConfig(
debugConfig(on = false)
.withFallback(
ConfigFactory.parseString("""
.withFallback(ConfigFactory.parseString("""
akka.remote.retry-gate-closed-for = 3 s
akka.cluster.allow-weakly-up-members = on
"""))
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -34,14 +34,11 @@ object MinMembersBeforeUpWithWeaklyUpMultiJvmSpec extends MultiNodeConfig {
val second = role("second")
val third = role("third")

commonConfig(
debugConfig(on = false)
.withFallback(
ConfigFactory.parseString("""
commonConfig(debugConfig(on = false)
.withFallback(ConfigFactory.parseString("""
akka.cluster.min-nr-of-members = 3
akka.cluster.allow-weakly-up-members = on"""))
.withFallback(
MultiNodeClusterSpec.clusterConfigWithFailureDetectorPuppet))
.withFallback(MultiNodeClusterSpec.clusterConfigWithFailureDetectorPuppet))
}

object MinMembersOfRoleBeforeUpMultiJvmSpec extends MultiNodeConfig {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -36,9 +36,7 @@ object MultiNodeClusterSpec {
if (failureDetectorPuppet) clusterConfigWithFailureDetectorPuppet
else clusterConfig

def clusterConfig: Config =
ConfigFactory.parseString(
"""
def clusterConfig: Config = ConfigFactory.parseString("""
akka.actor.provider = akka.cluster.ClusterActorRefProvider
akka.cluster {
jmx.enabled = off
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,8 +26,7 @@ object NodeChurnMultiJvmSpec extends MultiNodeConfig {

commonConfig(
debugConfig(on = false)
.withFallback(
ConfigFactory.parseString("""
.withFallback(ConfigFactory.parseString("""
akka.cluster.auto-down-unreachable-after = 1s
akka.remote.log-frame-size-exceeding = 2000b
"""))
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,8 +26,7 @@ object RestartFirstSeedNodeMultiJvmSpec extends MultiNodeConfig {

commonConfig(
debugConfig(on = false)
.withFallback(ConfigFactory.parseString(
"""
.withFallback(ConfigFactory.parseString("""
akka.cluster.auto-down-unreachable-after = off
akka.cluster.retry-unsuccessful-join-after = 3s
"""))
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,8 +26,7 @@ object RestartNode2SpecMultiJvmSpec extends MultiNodeConfig {

commonConfig(
debugConfig(on = false)
.withFallback(ConfigFactory.parseString(
"""
.withFallback(ConfigFactory.parseString("""
akka.cluster.auto-down-unreachable-after = 2s
akka.cluster.retry-unsuccessful-join-after = 3s
akka.remote.retry-gate-closed-for = 45s
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -25,8 +25,7 @@ final case class SplitBrainMultiNodeConfig(failureDetectorPuppet: Boolean)

commonConfig(
debugConfig(on = false)
.withFallback(
ConfigFactory.parseString("""
.withFallback(ConfigFactory.parseString("""
akka.remote.retry-gate-closed-for = 3 s
akka.cluster {
auto-down-unreachable-after = 1s
Expand Down

0 comments on commit 050689f

Please sign in to comment.