From d3976b2b46f8fed2d748f4b7539ee466e18b597b Mon Sep 17 00:00:00 2001 From: Ivan Topolnak Date: Wed, 21 May 2014 18:17:30 -0300 Subject: = core: avoid using tuples in favor of case classes --- .../ActorMessagePassingTracing.scala | 7 +-- .../akka/instrumentation/DispatcherTracing.scala | 48 ++++++++++++++++-- .../scala/kamon/metrics/DispatcherMetrics.scala | 4 +- .../dispatcher/DispatcherMetricsCollector.scala | 59 ---------------------- .../kamon/metrics/instruments/MinMaxCounter.scala | 55 ++++++++++++++++++++ .../instruments/counter/MinMaxCounter.scala | 51 ------------------- .../metrics/instrument/MinMaxCounterSpec.scala | 30 ++++++----- 7 files changed, 122 insertions(+), 132 deletions(-) delete mode 100644 kamon-core/src/main/scala/kamon/metrics/dispatcher/DispatcherMetricsCollector.scala create mode 100644 kamon-core/src/main/scala/kamon/metrics/instruments/MinMaxCounter.scala delete mode 100644 kamon-core/src/main/scala/kamon/metrics/instruments/counter/MinMaxCounter.scala (limited to 'kamon-core/src') diff --git a/kamon-core/src/main/scala/akka/instrumentation/ActorMessagePassingTracing.scala b/kamon-core/src/main/scala/akka/instrumentation/ActorMessagePassingTracing.scala index 20bfe564..6db86828 100644 --- a/kamon-core/src/main/scala/akka/instrumentation/ActorMessagePassingTracing.scala +++ b/kamon-core/src/main/scala/akka/instrumentation/ActorMessagePassingTracing.scala @@ -24,7 +24,8 @@ import kamon.trace._ import kamon.metrics.{ ActorMetrics, Metrics } import kamon.Kamon import kamon.metrics.ActorMetrics.ActorMetricRecorder -import kamon.metrics.instruments.counter.MinMaxCounter +import kamon.metrics.instruments.MinMaxCounter +import kamon.metrics.instruments.MinMaxCounter.CounterMeasurement @Aspect class BehaviourInvokeTracing { @@ -46,11 +47,11 @@ class BehaviourInvokeTracing { cellWithMetrics.mailboxSizeCollectorCancellable = metricsExtension.scheduleGaugeRecorder { cellWithMetrics.actorMetricsRecorder.map { am ⇒ import am.mailboxSize._ - val (min, max, sum) = cellWithMetrics.queueSize.collect() + val CounterMeasurement(min, max, current) = cellWithMetrics.queueSize.collect() record(min) record(max) - record(sum) + record(current) } } } diff --git a/kamon-core/src/main/scala/akka/instrumentation/DispatcherTracing.scala b/kamon-core/src/main/scala/akka/instrumentation/DispatcherTracing.scala index 63e96fa0..0747f0d3 100644 --- a/kamon-core/src/main/scala/akka/instrumentation/DispatcherTracing.scala +++ b/kamon-core/src/main/scala/akka/instrumentation/DispatcherTracing.scala @@ -17,12 +17,15 @@ package akka.instrumentation import org.aspectj.lang.annotation._ -import akka.dispatch.{ Dispatcher, MessageDispatcher } +import akka.dispatch.{ ExecutorServiceDelegate, Dispatcher, MessageDispatcher } import kamon.metrics.{ Metrics, DispatcherMetrics } import kamon.metrics.DispatcherMetrics.DispatcherMetricRecorder import kamon.Kamon import akka.actor.{ Cancellable, ActorSystemImpl } -import kamon.metrics.dispatcher.DispatcherMetricsCollector +import scala.concurrent.forkjoin.ForkJoinPool +import java.util.concurrent.ThreadPoolExecutor +import java.lang.reflect.Method +import akka.instrumentation.DispatcherMetricsCollector.DispatcherMetricsMeasurement @Aspect class DispatcherTracing { @@ -60,7 +63,8 @@ class DispatcherTracing { dispatcherWithMetrics.dispatcherCollectorCancellable = metricsExtension.scheduleGaugeRecorder { dispatcherWithMetrics.dispatcherMetricsRecorder.map { dm ⇒ - val (maximumPoolSize, runningThreadCount, queueTaskCount, poolSize) = DispatcherMetricsCollector.collect(dispatcher) + val DispatcherMetricsMeasurement(maximumPoolSize, runningThreadCount, queueTaskCount, poolSize) = + DispatcherMetricsCollector.collect(dispatcher) dm.maximumPoolSize.record(maximumPoolSize) dm.runningThreadCount.record(runningThreadCount) @@ -77,6 +81,7 @@ class DispatcherTracing { @After("onDispatcherShutdown(dispatcher)") def afterDispatcherShutdown(dispatcher: MessageDispatcher): Unit = { val dispatcherWithMetrics = dispatcher.asInstanceOf[DispatcherMessageMetrics] + dispatcherWithMetrics.dispatcherCollectorCancellable.cancel() Kamon(Metrics)(actorSystem).unregister(dispatcherWithMetrics.metricIdentity) } @@ -95,3 +100,40 @@ trait DispatcherMessageMetrics { var dispatcherCollectorCancellable: Cancellable = _ } +object DispatcherMetricsCollector { + + case class DispatcherMetricsMeasurement(maximumPoolSize: Long, runningThreadCount: Long, queueTaskCount: Long, poolSize: Long) + + private def collectForkJoinMetrics(pool: ForkJoinPool): DispatcherMetricsMeasurement = { + DispatcherMetricsMeasurement(pool.getParallelism, pool.getActiveThreadCount, + (pool.getQueuedTaskCount + pool.getQueuedSubmissionCount), pool.getPoolSize) + } + private def collectExecutorMetrics(pool: ThreadPoolExecutor): DispatcherMetricsMeasurement = { + DispatcherMetricsMeasurement(pool.getMaximumPoolSize, pool.getActiveCount, pool.getQueue.size(), pool.getPoolSize) + } + + private val executorServiceMethod: Method = { + // executorService is protected + val method = classOf[Dispatcher].getDeclaredMethod("executorService") + method.setAccessible(true) + method + } + + def collect(dispatcher: MessageDispatcher): DispatcherMetricsMeasurement = { + dispatcher match { + case x: Dispatcher ⇒ { + val executor = executorServiceMethod.invoke(x) match { + case delegate: ExecutorServiceDelegate ⇒ delegate.executor + case other ⇒ other + } + + executor match { + case fjp: ForkJoinPool ⇒ collectForkJoinMetrics(fjp) + case tpe: ThreadPoolExecutor ⇒ collectExecutorMetrics(tpe) + case anything ⇒ DispatcherMetricsMeasurement(0L, 0L, 0L, 0L) + } + } + case _ ⇒ new DispatcherMetricsMeasurement(0L, 0L, 0L, 0L) + } + } +} diff --git a/kamon-core/src/main/scala/kamon/metrics/DispatcherMetrics.scala b/kamon-core/src/main/scala/kamon/metrics/DispatcherMetrics.scala index 77a1c99b..7e9198f3 100644 --- a/kamon-core/src/main/scala/kamon/metrics/DispatcherMetrics.scala +++ b/kamon-core/src/main/scala/kamon/metrics/DispatcherMetrics.scala @@ -26,7 +26,7 @@ case class DispatcherMetrics(name: String) extends MetricGroupIdentity { object DispatcherMetrics extends MetricGroupCategory { val name = "dispatcher" - case object MaximunPoolSize extends MetricIdentity { val name, tag = "maximum-pool-size" } + case object MaximumPoolSize extends MetricIdentity { val name, tag = "maximum-pool-size" } case object RunningThreadCount extends MetricIdentity { val name, tag = "running-thread-count" } case object QueueTaskCount extends MetricIdentity { val name, tag = "queued-task-count" } case object PoolSize extends MetricIdentity { val name, tag = "pool-size" } @@ -43,7 +43,7 @@ object DispatcherMetrics extends MetricGroupCategory { extends MetricGroupSnapshot { val metrics: Map[MetricIdentity, MetricSnapshotLike] = Map( - (MaximunPoolSize -> maximumPoolSize), + (MaximumPoolSize -> maximumPoolSize), (RunningThreadCount -> runningThreadCount), (QueueTaskCount -> queueTaskCount), (PoolSize -> poolSize)) diff --git a/kamon-core/src/main/scala/kamon/metrics/dispatcher/DispatcherMetricsCollector.scala b/kamon-core/src/main/scala/kamon/metrics/dispatcher/DispatcherMetricsCollector.scala deleted file mode 100644 index 529cc542..00000000 --- a/kamon-core/src/main/scala/kamon/metrics/dispatcher/DispatcherMetricsCollector.scala +++ /dev/null @@ -1,59 +0,0 @@ -package kamon.metrics.dispatcher - -/* - * ========================================================================================= - * Copyright © 2013-2014 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. - * ========================================================================================= - */ - -import scala.concurrent.forkjoin.ForkJoinPool -import java.util.concurrent.ThreadPoolExecutor -import akka.dispatch.{ ExecutorServiceDelegate, Dispatcher, MessageDispatcher } -import java.lang.reflect.Method - -object DispatcherMetricsCollector { - - private[this]type DispatcherMetrics = (Long, Long, Long, Long) - - private[this] def collectForkJoinMetrics(pool: ForkJoinPool): DispatcherMetrics = { - (pool.getParallelism, pool.getActiveThreadCount, (pool.getQueuedTaskCount + pool.getQueuedSubmissionCount), pool.getPoolSize) - } - private[this] def collectExecutorMetrics(pool: ThreadPoolExecutor): DispatcherMetrics = { - (pool.getMaximumPoolSize, pool.getActiveCount, pool.getQueue.size(), pool.getPoolSize) - } - - private[this] val executorServiceMethod: Method = { - // executorService is protected - val method = classOf[Dispatcher].getDeclaredMethod("executorService") - method.setAccessible(true) - method - } - - def collect(dispatcher: MessageDispatcher): (Long, Long, Long, Long) = { - dispatcher match { - case x: Dispatcher ⇒ { - val executor = executorServiceMethod.invoke(x) match { - case delegate: ExecutorServiceDelegate ⇒ delegate.executor - case other ⇒ other - } - - executor match { - case fjp: ForkJoinPool ⇒ collectForkJoinMetrics(fjp) - case tpe: ThreadPoolExecutor ⇒ collectExecutorMetrics(tpe) - case anything ⇒ (0L, 0L, 0L, 0L) - } - } - case _ ⇒ new DispatcherMetrics(0L, 0L, 0L, 0L) - } - } -} diff --git a/kamon-core/src/main/scala/kamon/metrics/instruments/MinMaxCounter.scala b/kamon-core/src/main/scala/kamon/metrics/instruments/MinMaxCounter.scala new file mode 100644 index 00000000..7f6c2487 --- /dev/null +++ b/kamon-core/src/main/scala/kamon/metrics/instruments/MinMaxCounter.scala @@ -0,0 +1,55 @@ +package kamon.metrics.instruments + +/* + * ========================================================================================= + * Copyright © 2013-2014 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. + * ========================================================================================= + */ + +import java.lang.Math._ +import jsr166e.LongMaxUpdater +import kamon.util.PaddedAtomicLong +import kamon.metrics.instruments.MinMaxCounter.CounterMeasurement + +class MinMaxCounter { + private val min = new LongMaxUpdater + private val max = new LongMaxUpdater + private val sum = new PaddedAtomicLong + + min.update(0L) + max.update(0L) + + def increment(value: Long = 1L): Unit = { + val currentValue = sum.addAndGet(value) + max.update(currentValue) + } + + def decrement(value: Long = 1L): Unit = { + val currentValue = sum.addAndGet(-value) + min.update(-currentValue) + } + + def collect(): CounterMeasurement = { + val currentValue = sum.get() + val result = CounterMeasurement(abs(min.maxThenReset()), max.maxThenReset(), currentValue) + max.update(currentValue) + min.update(-currentValue) + result + } +} + +object MinMaxCounter { + def apply() = new MinMaxCounter() + + case class CounterMeasurement(min: Long, max: Long, current: Long) +} diff --git a/kamon-core/src/main/scala/kamon/metrics/instruments/counter/MinMaxCounter.scala b/kamon-core/src/main/scala/kamon/metrics/instruments/counter/MinMaxCounter.scala deleted file mode 100644 index 6c89a4d1..00000000 --- a/kamon-core/src/main/scala/kamon/metrics/instruments/counter/MinMaxCounter.scala +++ /dev/null @@ -1,51 +0,0 @@ -package kamon.metrics.instruments.counter -/* - * ========================================================================================= - * Copyright © 2013-2014 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. - * ========================================================================================= - */ - -import java.lang.Math._ -import jsr166e.LongMaxUpdater -import kamon.util.PaddedAtomicLong - -class MinMaxCounter { - private val min = new LongMaxUpdater - private val max = new LongMaxUpdater - private val sum = new PaddedAtomicLong - - min.update(0L) - max.update(0L) - - def increment(value: Long = 1L): Unit = { - val currentValue = sum.addAndGet(value) - max.update(currentValue) - } - - def decrement(value: Long = 1L): Unit = { - val currentValue = sum.addAndGet(-value) - min.update(-currentValue) - } - - def collect(): (Long, Long, Long) = { - val currentValue = sum.get() - val result = (abs(min.maxThenReset()), max.maxThenReset(), currentValue) - max.update(currentValue) - min.update(-currentValue) - result - } -} - -object MinMaxCounter { - def apply() = new MinMaxCounter() -} diff --git a/kamon-core/src/test/scala/kamon/metrics/instrument/MinMaxCounterSpec.scala b/kamon-core/src/test/scala/kamon/metrics/instrument/MinMaxCounterSpec.scala index 4051f2ba..14f1573f 100644 --- a/kamon-core/src/test/scala/kamon/metrics/instrument/MinMaxCounterSpec.scala +++ b/kamon-core/src/test/scala/kamon/metrics/instrument/MinMaxCounterSpec.scala @@ -1,4 +1,3 @@ -package kamon.metrics.instrument /* ========================================================================================= * Copyright © 2013-2014 the kamon project * @@ -13,8 +12,11 @@ package kamon.metrics.instrument * and limitations under the License. * ========================================================================================= */ +package kamon.metrics.instrument + import org.scalatest.{ Matchers, WordSpecLike } -import kamon.metrics.instruments.counter.MinMaxCounter +import kamon.metrics.instruments.MinMaxCounter +import kamon.metrics.instruments.MinMaxCounter.CounterMeasurement class MinMaxCounterSpec extends WordSpecLike with Matchers { @@ -28,9 +30,9 @@ class MinMaxCounterSpec extends WordSpecLike with Matchers { counter.increment() counter.increment() - val (_, _, sum) = counter.collect() + val CounterMeasurement(_, _, current) = counter.collect() - sum should be(5) + current should be(5) } "decrement" in { @@ -43,9 +45,9 @@ class MinMaxCounterSpec extends WordSpecLike with Matchers { counter.decrement() counter.decrement() - val (_, _, sum) = counter.collect() + val CounterMeasurement(_, _, current) = counter.collect() - sum should be(0) + current should be(0) } "reset the min and max with the sum value when the collect method is called" in { @@ -59,11 +61,11 @@ class MinMaxCounterSpec extends WordSpecLike with Matchers { counter.collect() //only for check the last value after reset min max - val (min, max, sum) = counter.collect() + val CounterMeasurement(min, max, current) = counter.collect() - min should be(sum) - max should be(sum) - sum should be(150) + min should be(current) + max should be(current) + current should be(150) } } @@ -76,13 +78,13 @@ class MinMaxCounterSpec extends WordSpecLike with Matchers { counter.increment(40) counter.increment(50) - val (min, _, _) = counter.collect() + val CounterMeasurement(min, _, _) = counter.collect() min should be(0) counter.increment(50) - val (minAfterCollectAndAddSomeValues, _, _) = counter.collect() + val CounterMeasurement(minAfterCollectAndAddSomeValues, _, _) = counter.collect() minAfterCollectAndAddSomeValues should be(150) } @@ -95,13 +97,13 @@ class MinMaxCounterSpec extends WordSpecLike with Matchers { counter.increment(40) counter.increment(50) - val (_, max, _) = counter.collect() + val CounterMeasurement(_, max, _) = counter.collect() max should be(150) counter.increment(200) - val (_, maxAfterCollectAndAddSomeValues, _) = counter.collect() + val CounterMeasurement(_, maxAfterCollectAndAddSomeValues, _) = counter.collect() maxAfterCollectAndAddSomeValues should be(350) } -- cgit v1.2.3