From 57e433c07a271b4e5e4159500cdc828cd7bb6a83 Mon Sep 17 00:00:00 2001 From: Ivan Topolnak Date: Tue, 4 Feb 2014 18:16:07 -0300 Subject: partial rewrite of kamon-newrelic --- .../scala/kamon/metrics/MetricsExtension.scala | 2 +- .../main/scala/kamon/metrics/Subscriptions.scala | 46 +++++++++++- .../kamon/metrics/TickMetricSnapshotBuffer.scala | 64 ----------------- .../src/main/scala/kamon/trace/UowTracing.scala | 82 ---------------------- .../instrumentation/TraceAggregatorSpec.scala | 51 -------------- 5 files changed, 45 insertions(+), 200 deletions(-) delete mode 100644 kamon-core/src/main/scala/kamon/metrics/TickMetricSnapshotBuffer.scala delete mode 100644 kamon-core/src/main/scala/kamon/trace/UowTracing.scala delete mode 100644 kamon-core/src/test/scala/kamon/trace/instrumentation/TraceAggregatorSpec.scala (limited to 'kamon-core/src') diff --git a/kamon-core/src/main/scala/kamon/metrics/MetricsExtension.scala b/kamon-core/src/main/scala/kamon/metrics/MetricsExtension.scala index a8b90b57..359540fc 100644 --- a/kamon-core/src/main/scala/kamon/metrics/MetricsExtension.scala +++ b/kamon-core/src/main/scala/kamon/metrics/MetricsExtension.scala @@ -25,7 +25,7 @@ import akka.actor import kamon.metrics.Metrics.MetricGroupFilter import kamon.metrics.Subscriptions.Subscribe -class MetricsExtension(val system: ExtendedActorSystem) extends Kamon.Extension { +class MetricsExtension(system: ExtendedActorSystem) extends Kamon.Extension { val config = system.settings.config val storage = TrieMap[MetricGroupIdentity, MetricGroupRecorder]() val filters = loadFilters(config) diff --git a/kamon-core/src/main/scala/kamon/metrics/Subscriptions.scala b/kamon-core/src/main/scala/kamon/metrics/Subscriptions.scala index 654c37b0..2111563b 100644 --- a/kamon-core/src/main/scala/kamon/metrics/Subscriptions.scala +++ b/kamon-core/src/main/scala/kamon/metrics/Subscriptions.scala @@ -16,12 +16,13 @@ package kamon.metrics -import akka.actor.{ ActorRef, Actor } +import akka.actor.{Props, ActorRef, Actor} import kamon.metrics.Subscriptions.{ MetricGroupFilter, FlushMetrics, TickMetricSnapshot, Subscribe } import kamon.util.GlobPathFilter -import scala.concurrent.duration.Duration +import scala.concurrent.duration.{FiniteDuration, Duration} import java.util.concurrent.TimeUnit import kamon.Kamon +import kamon.metrics.TickMetricSnapshotBuffer.FlushBuffer class Subscriptions extends Actor { import context.system @@ -85,5 +86,46 @@ object Subscriptions { category.equals(identity.category) && globFilter.accept(identity.name) } } +} + + +class TickMetricSnapshotBuffer(flushInterval: FiniteDuration, receiver: ActorRef) extends Actor { + val flushSchedule = context.system.scheduler.schedule(flushInterval, flushInterval, self, FlushBuffer)(context.dispatcher) + + def receive = empty + + def empty: Actor.Receive = { + case tick : TickMetricSnapshot => context become(buffering(tick)) + case FlushBuffer => // Nothing to flush. + } + + def buffering(buffered: TickMetricSnapshot): Actor.Receive = { + case TickMetricSnapshot(_, to, tickMetrics) => + val combinedMetrics = combineMaps(buffered.metrics, tickMetrics)(mergeMetricGroup) + val combinedSnapshot = TickMetricSnapshot(buffered.from, to, combinedMetrics) + + context become(buffering(combinedSnapshot)) + + case FlushBuffer => + receiver ! buffered + context become(empty) + + } + + + override def postStop(): Unit = { + flushSchedule.cancel() + super.postStop() + } + + def mergeMetricGroup(left: MetricGroupSnapshot, right: MetricGroupSnapshot) = new MetricGroupSnapshot { + val metrics = combineMaps(left.metrics, right.metrics)((l, r) => l.merge(r)) + } +} + +object TickMetricSnapshotBuffer { + case object FlushBuffer + def props(flushInterval: FiniteDuration, receiver: ActorRef): Props = + Props[TickMetricSnapshotBuffer](new TickMetricSnapshotBuffer(flushInterval, receiver)) } diff --git a/kamon-core/src/main/scala/kamon/metrics/TickMetricSnapshotBuffer.scala b/kamon-core/src/main/scala/kamon/metrics/TickMetricSnapshotBuffer.scala deleted file mode 100644 index 11c58cae..00000000 --- a/kamon-core/src/main/scala/kamon/metrics/TickMetricSnapshotBuffer.scala +++ /dev/null @@ -1,64 +0,0 @@ -/* - * ========================================================================================= - * Copyright © 2013 the kamon project - * - * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file - * except in compliance with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software distributed under the - * License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, - * either express or implied. See the License for the specific language governing permissions - * and limitations under the License. - * ========================================================================================= - */ - -package kamon.metrics - -import akka.actor.{Props, ActorRef, Actor} -import kamon.metrics.Subscriptions.TickMetricSnapshot -import kamon.metrics.TickMetricSnapshotBuffer.FlushBuffer -import scala.concurrent.duration.FiniteDuration - - -class TickMetricSnapshotBuffer(flushInterval: FiniteDuration, receiver: ActorRef) extends Actor { - val flushSchedule = context.system.scheduler.schedule(flushInterval, flushInterval, self, FlushBuffer)(context.dispatcher) - - def receive = empty - - def empty: Actor.Receive = { - case tick : TickMetricSnapshot => context become(buffering(tick)) - case FlushBuffer => // Nothing to flush. - } - - def buffering(buffered: TickMetricSnapshot): Actor.Receive = { - case TickMetricSnapshot(_, to, tickMetrics) => - val combinedMetrics = combineMaps(buffered.metrics, tickMetrics)(mergeMetricGroup) - val combinedSnapshot = TickMetricSnapshot(buffered.from, to, combinedMetrics) - - context become(buffering(combinedSnapshot)) - - case FlushBuffer => - receiver ! buffered - context become(empty) - - } - - - override def postStop(): Unit = { - flushSchedule.cancel() - super.postStop() - } - - def mergeMetricGroup(left: MetricGroupSnapshot, right: MetricGroupSnapshot) = new MetricGroupSnapshot { - val metrics = combineMaps(left.metrics, right.metrics)((l, r) => l.merge(r)) - } -} - -object TickMetricSnapshotBuffer { - case object FlushBuffer - - def props(flushInterval: FiniteDuration, receiver: ActorRef): Props = - Props[TickMetricSnapshotBuffer](new TickMetricSnapshotBuffer(flushInterval, receiver)) -} diff --git a/kamon-core/src/main/scala/kamon/trace/UowTracing.scala b/kamon-core/src/main/scala/kamon/trace/UowTracing.scala deleted file mode 100644 index 20cce830..00000000 --- a/kamon-core/src/main/scala/kamon/trace/UowTracing.scala +++ /dev/null @@ -1,82 +0,0 @@ -/* =================================================== - * Copyright © 2013 the kamon project - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - * ========================================================== */ -package kamon.trace - -import akka.actor._ -import scala.concurrent.duration.Duration -import kamon.trace.UowTracing._ - -sealed trait UowSegment { - def id: Long - def timestamp: Long -} - -trait AutoTimestamp extends UowSegment { - val timestamp = System.nanoTime -} - -object UowTracing { - case class Start(id: Long, name: String) extends AutoTimestamp - case class Finish(id: Long) extends AutoTimestamp - case class Rename(id: Long, name: String) extends AutoTimestamp - case class WebExternalStart(id: Long, host: String) extends AutoTimestamp - case class WebExternalFinish(id: Long) extends AutoTimestamp - case class WebExternal(id: Long, start: Long, finish: Long, host: String) extends AutoTimestamp -} - -case class UowTrace(name: String, uow: String, start: Long, end: Long, segments: Seq[UowSegment]) { - def elapsed: Long = end - start -} - -class UowTraceAggregator(reporting: ActorRef, aggregationTimeout: Duration) extends Actor with ActorLogging { - context.setReceiveTimeout(aggregationTimeout) - - var name: String = "UNKNOWN" - var segments: Seq[UowSegment] = Nil - - var pendingExternal = List[WebExternalStart]() - - var start = 0L - var end = 0L - - def receive = { - case start: Start ⇒ - this.start = start.timestamp - segments = segments :+ start - name = start.name - case finish: Finish ⇒ - end = finish.timestamp - segments = segments :+ finish; finishTracing() - case wes: WebExternalStart ⇒ pendingExternal = pendingExternal :+ wes - case finish @ WebExternalFinish(id) ⇒ pendingExternal.find(_.id == id).map(start ⇒ { - segments = segments :+ WebExternal(finish.id, start.timestamp, finish.timestamp, start.host) - }) - case Rename(id, newName) ⇒ name = newName - case segment: UowSegment ⇒ segments = segments :+ segment - case ReceiveTimeout ⇒ - log.warning("Transaction {} did not complete properly, the recorded segments are: {}", name, segments) - context.stop(self) - } - - def finishTracing(): Unit = { - reporting ! UowTrace(name, "", start, end, segments) - context.stop(self) - } -} - -object UowTraceAggregator { - def props(reporting: ActorRef, aggregationTimeout: Duration) = Props(classOf[UowTraceAggregator], reporting, aggregationTimeout) -} diff --git a/kamon-core/src/test/scala/kamon/trace/instrumentation/TraceAggregatorSpec.scala b/kamon-core/src/test/scala/kamon/trace/instrumentation/TraceAggregatorSpec.scala deleted file mode 100644 index 3b32f3ac..00000000 --- a/kamon-core/src/test/scala/kamon/trace/instrumentation/TraceAggregatorSpec.scala +++ /dev/null @@ -1,51 +0,0 @@ -/* =================================================== - * Copyright © 2013 the kamon project - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - * ========================================================== */ -package kamon.trace.instrumentation - -import org.scalatest.{ WordSpecLike, WordSpec } -import akka.testkit.{ TestKitBase, TestKit } -import akka.actor.ActorSystem -import scala.concurrent.duration._ -import kamon.trace.UowTracing.{ Finish, Rename, Start } -import kamon.trace.{ UowTrace, UowTraceAggregator } - -class TraceAggregatorSpec extends TestKit(ActorSystem("TraceAggregatorSpec")) with WordSpecLike { - - "a TraceAggregator" should { - "send a UowTrace message out after receiving a Finish message" in new AggregatorFixture { - within(1 second) { - aggregator ! Start(1, "/accounts") - aggregator ! Finish(1) - - //expectMsg(UowTrace("UNKNOWN", Seq(Start(1, "/accounts"), Finish(1)))) - } - } - - "change the uow name after receiving a Rename message" in new AggregatorFixture { - within(1 second) { - aggregator ! Start(1, "/accounts") - aggregator ! Rename(1, "test-uow") - aggregator ! Finish(1) - - //expectMsg(UowTrace("test-uow", Seq(Start(1, "/accounts"), Finish(1)))) - } - } - } - - trait AggregatorFixture { - val aggregator = system.actorOf(UowTraceAggregator.props(testActor, 10 seconds)) - } -} -- cgit v1.2.3