You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@openwhisk.apache.org by cs...@apache.org on 2018/02/10 16:27:31 UTC

[incubator-openwhisk] branch master updated: Remove unneeded logline and revive old marker. (#3270)

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

csantanapr pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-openwhisk.git


The following commit(s) were added to refs/heads/master by this push:
     new e61d49d  Remove unneeded logline and revive old marker. (#3270)
e61d49d is described below

commit e61d49d6f0ebc7d733db35cbaa826fef6f8586d0
Author: Markus Thömmes <ma...@me.com>
AuthorDate: Sat Feb 10 17:27:28 2018 +0100

    Remove unneeded logline and revive old marker. (#3270)
---
 .../whisk/core/loadBalancer/ContainerPoolBalancer.scala     | 13 ++++---------
 1 file changed, 4 insertions(+), 9 deletions(-)

diff --git a/core/controller/src/main/scala/whisk/core/loadBalancer/ContainerPoolBalancer.scala b/core/controller/src/main/scala/whisk/core/loadBalancer/ContainerPoolBalancer.scala
index 5d8b22d..46cb15d 100644
--- a/core/controller/src/main/scala/whisk/core/loadBalancer/ContainerPoolBalancer.scala
+++ b/core/controller/src/main/scala/whisk/core/loadBalancer/ContainerPoolBalancer.scala
@@ -26,14 +26,13 @@ import akka.stream.ActorMaterializer
 import akka.util.Timeout
 import org.apache.kafka.clients.producer.RecordMetadata
 import pureconfig._
-import whisk.common.{Logging, LoggingMarkers, TransactionId}
+import whisk.common.{Logging, LoggingMarkers, MetricEmitter, TransactionId}
 import whisk.core.WhiskConfig._
 import whisk.core.connector._
 import whisk.core.entity._
 import whisk.core.{ConfigKeys, WhiskConfig}
 import whisk.spi.SpiLoader
 import akka.event.Logging.InfoLevel
-
 import pureconfig._
 
 import scala.annotation.tailrec
@@ -155,12 +154,6 @@ class ContainerPoolBalancer(config: WhiskConfig, controllerInstance: InstanceId)
           processCompletion(Left(activationId), transid, forced = true, invoker = invokerName)
         }
 
-        transid.mark(
-          this,
-          LoggingMarkers.LOADBALANCER_ACTIVATION_START(namespaceId.asString),
-          s"loadbalancer: activation started for namespace $namespaceId and activation $activationId",
-          logLevel = InfoLevel)
-
         // please note: timeoutHandler.cancel must be called on all non-timeout paths, e.g. Success
         ActivationEntry(
           activationId,
@@ -180,11 +173,13 @@ class ContainerPoolBalancer(config: WhiskConfig, controllerInstance: InstanceId)
                                       invoker: InstanceId): Future[RecordMetadata] = {
     implicit val transid = msg.transid
 
+    MetricEmitter.emitCounterMetric(LoggingMarkers.LOADBALANCER_ACTIVATION_START(msg.user.uuid.asString))
     val topic = s"invoker${invoker.toInt}"
     val start = transid.started(
       this,
       LoggingMarkers.CONTROLLER_KAFKA,
-      s"posting topic '$topic' with activation id '${msg.activationId}'")
+      s"posting topic '$topic' with activation id '${msg.activationId}'",
+      logLevel = InfoLevel)
 
     producer.send(topic, msg).andThen {
       case Success(status) =>

-- 
To stop receiving notification emails like this one, please contact
csantanapr@apache.org.