= akka-*: full name space for loggers - resolve #16138
reflect logger name changes in the migration guide fix typo in migration guide fix typo in migration guide (xml)
This commit is contained in:
parent
9203e0d316
commit
d83acb92c3
14 changed files with 23 additions and 14 deletions
|
|
@ -458,7 +458,7 @@ private[akka] class LocalActorRefProvider private[akka] (
|
|||
|
||||
override val rootPath: ActorPath = RootActorPath(Address("akka", _systemName))
|
||||
|
||||
private[akka] val log: LoggingAdapter = Logging(eventStream, "LocalActorRefProvider(" + rootPath.address + ")")
|
||||
private[akka] val log: LoggingAdapter = Logging(eventStream, getClass.getName + "(" + rootPath.address + ")")
|
||||
|
||||
override val deadLetters: InternalActorRef =
|
||||
_deadLetters.getOrElse((p: ActorPath) ⇒ new DeadLetterActorRef(this, p, eventStream)).apply(rootPath / "deadLetters")
|
||||
|
|
|
|||
|
|
@ -603,7 +603,7 @@ private[akka] class ActorSystemImpl(val name: String, applicationConfig: Config,
|
|||
dynamicAccess.createInstanceFor[LoggingFilter](LoggingFilter, arguments).get
|
||||
}
|
||||
|
||||
val log: LoggingAdapter = new BusLogging(eventStream, "ActorSystem(" + name + ")", this.getClass, logFilter)
|
||||
val log: LoggingAdapter = new BusLogging(eventStream, getClass.getName + "(" + name + ")", this.getClass, logFilter)
|
||||
|
||||
val scheduler: Scheduler = createScheduler()
|
||||
|
||||
|
|
|
|||
|
|
@ -548,7 +548,7 @@ class TcpExt(system: ExtendedActorSystem) extends IO.Extension {
|
|||
|
||||
val WindowsConnectionAbortWorkaroundEnabled: Boolean = getString("windows-connection-abort-workaround-enabled") match {
|
||||
case "auto" ⇒ Helpers.isWindows
|
||||
case _ => getBoolean("windows-connection-abort-workaround-enabled")
|
||||
case _ ⇒ getBoolean("windows-connection-abort-workaround-enabled")
|
||||
}
|
||||
|
||||
private[this] def getIntBytes(path: String): Int = {
|
||||
|
|
|
|||
|
|
@ -28,7 +28,7 @@ import akka.actor.{ ExtendedActorSystem, ActorRef, Props }
|
|||
*/
|
||||
private[camel] class DefaultCamel(val system: ExtendedActorSystem) extends Camel {
|
||||
val supervisor = system.actorOf(Props[CamelSupervisor], "camel-supervisor")
|
||||
private[camel] implicit val log = Logging(system, "Camel")
|
||||
private[camel] implicit val log = Logging(system, getClass.getName)
|
||||
|
||||
lazy val context: DefaultCamelContext = {
|
||||
val ctx = settings.ContextProvider.getContext(system)
|
||||
|
|
|
|||
|
|
@ -97,7 +97,7 @@ class Cluster(val system: ExtendedActorSystem) extends Extension {
|
|||
scala.collection.JavaConverters.setAsJavaSetConverter(selfRoles).asJava
|
||||
|
||||
private val _isTerminated = new AtomicBoolean(false)
|
||||
private val log = Logging(system, "Cluster")
|
||||
private val log = Logging(system, getClass.getName)
|
||||
// ClusterJmx is initialized as the last thing in the constructor
|
||||
private var clusterJmx: Option[ClusterJmx] = None
|
||||
|
||||
|
|
|
|||
|
|
@ -778,7 +778,7 @@ class SigarMetricsCollector(address: Address, decayFactor: Double, sigar: AnyRef
|
|||
private[cluster] object MetricsCollector {
|
||||
def apply(system: ExtendedActorSystem, settings: ClusterSettings): MetricsCollector = {
|
||||
import settings.{ MetricsCollectorClass ⇒ fqcn }
|
||||
def log = Logging(system, "MetricsCollector")
|
||||
def log = Logging(system, getClass.getName)
|
||||
if (fqcn == classOf[SigarMetricsCollector].getName) {
|
||||
Try(new SigarMetricsCollector(system)) match {
|
||||
case Success(sigarCollector) ⇒ sigarCollector
|
||||
|
|
|
|||
|
|
@ -1386,11 +1386,11 @@ object ShardCoordinator {
|
|||
*/
|
||||
sealed trait CoordinatorMessage
|
||||
/**
|
||||
* `ShardRegion` registers to `ShardCoordinator`, until it receives [[RegisterAck]].
|
||||
* `ShardRegion` registers to `ShardCoordinator`, until it receives [[RegisterAck]].
|
||||
*/
|
||||
@SerialVersionUID(1L) final case class Register(shardRegion: ActorRef) extends CoordinatorCommand
|
||||
/**
|
||||
* `ShardRegion` in proxy only mode registers to `ShardCoordinator`, until it receives [[RegisterAck]].
|
||||
* `ShardRegion` in proxy only mode registers to `ShardCoordinator`, until it receives [[RegisterAck]].
|
||||
*/
|
||||
@SerialVersionUID(1L) final case class RegisterProxy(shardRegionProxy: ActorRef) extends CoordinatorCommand
|
||||
/**
|
||||
|
|
|
|||
|
|
@ -131,3 +131,12 @@ In order to make cluster routers smarter about when they can start local routees
|
|||
``nrOfInstances`` defined on ``Pool`` now takes ``ActorSystem`` as an argument.
|
||||
In case you have implemented a custom Pool you will have to update the method's signature,
|
||||
however the implementation can remain the same if you don't need to rely on an ActorSystem in your logic.
|
||||
|
||||
Logger names use full class name
|
||||
================================
|
||||
Previously, few places in akka used "simple" logger names, such as ``Cluster`` or ``Remoting``.
|
||||
Now they use full class names, such as ``akka.cluster.Cluster`` or ``akka.remote.Remoting``,
|
||||
in order to allow package level log level definitions and ease source code lookup.
|
||||
In case you used specific "simple" logger name based rules in your ``logback.xml`` configurations,
|
||||
please change them to reflect appropriate package name, such as
|
||||
``<logger name='akka.cluster' level='warn' />`` or ``<logger name='akka.remote' level='error' />``
|
||||
|
|
|
|||
|
|
@ -389,7 +389,7 @@ private[akka] class Controller(private var initialParticipants: Int, controllerP
|
|||
|
||||
val settings = TestConductor().Settings
|
||||
val connection = RemoteConnection(Server, controllerPort, settings.ServerSocketWorkerPoolSize,
|
||||
new ConductorHandler(settings.QueryTimeout, self, Logging(context.system, "ConductorHandler")))
|
||||
new ConductorHandler(settings.QueryTimeout, self, Logging(context.system, classOf[ConductorHandler].getName)))
|
||||
|
||||
/*
|
||||
* Supervision of the BarrierCoordinator means to catch all his bad emotions
|
||||
|
|
|
|||
|
|
@ -151,7 +151,7 @@ private[akka] class ClientFSM(name: RoleName, controllerAddr: InetSocketAddress)
|
|||
val settings = TestConductor().Settings
|
||||
|
||||
val handler = new PlayerHandler(controllerAddr, settings.ClientReconnects, settings.ReconnectBackoff,
|
||||
settings.ClientSocketWorkerPoolSize, self, Logging(context.system, "PlayerHandler"),
|
||||
settings.ClientSocketWorkerPoolSize, self, Logging(context.system, classOf[PlayerHandler].getName),
|
||||
context.system.scheduler)(context.dispatcher)
|
||||
|
||||
startWith(Connecting, Data(None, None))
|
||||
|
|
|
|||
|
|
@ -178,7 +178,7 @@ private[akka] class RemoteActorRefProvider(
|
|||
_internals = internals
|
||||
remotingTerminator ! internals
|
||||
|
||||
_log = Logging(eventStream, "RemoteActorRefProvider")
|
||||
_log = Logging(eventStream, getClass.getName)
|
||||
|
||||
// this enables reception of remote requests
|
||||
transport.start()
|
||||
|
|
|
|||
|
|
@ -129,7 +129,7 @@ private[remote] class Remoting(_system: ExtendedActorSystem, _provider: RemoteAc
|
|||
|
||||
override def localAddressForRemote(remote: Address): Address = Remoting.localAddressForRemote(transportMapping, remote)
|
||||
|
||||
val log: LoggingAdapter = Logging(system.eventStream, "Remoting")
|
||||
val log: LoggingAdapter = Logging(system.eventStream, getClass.getName)
|
||||
val eventPublisher = new EventPublisher(system, log, RemoteLifecycleEventsLogLevel)
|
||||
|
||||
private def notifyError(msg: String, cause: Throwable): Unit =
|
||||
|
|
|
|||
|
|
@ -57,7 +57,7 @@ private[remote] class FailureInjectorTransportAdapter(wrappedTransport: Transpor
|
|||
extends AbstractTransportAdapter(wrappedTransport)(extendedSystem.dispatcher) with AssociationEventListener {
|
||||
|
||||
private def rng = ThreadLocalRandom.current()
|
||||
private val log = Logging(extendedSystem, "FailureInjector (gremlin)")
|
||||
private val log = Logging(extendedSystem, getClass.getName)
|
||||
private val shouldDebugLog: Boolean = extendedSystem.settings.config.getBoolean("akka.remote.gremlin.debug")
|
||||
|
||||
@volatile private var upstreamListener: Option[AssociationEventListener] = None
|
||||
|
|
|
|||
|
|
@ -130,7 +130,7 @@ class CallingThreadDispatcher(_configurator: MessageDispatcherConfigurator) exte
|
|||
import CallingThreadDispatcher._
|
||||
import configurator.prerequisites._
|
||||
|
||||
val log = akka.event.Logging(eventStream, "CallingThreadDispatcher")
|
||||
val log = akka.event.Logging(eventStream, getClass.getName)
|
||||
|
||||
override def id: String = Id
|
||||
|
||||
|
|
|
|||
Loading…
Add table
Add a link
Reference in a new issue