aboutsummaryrefslogtreecommitdiff
path: root/kamon-statsd/src/main/scala/kamon/statsd
diff options
context:
space:
mode:
authorIvan Topolnjak <ivantopo@gmail.com>2014-04-03 20:09:04 -0300
committerIvan Topolnjak <ivantopo@gmail.com>2014-04-03 20:09:04 -0300
commitde6a2c9bd6ab6034f59ee51b0eb48beae3d70561 (patch)
treea4991d2a0e75994bbc33fcac1af2f169ad773df2 /kamon-statsd/src/main/scala/kamon/statsd
parent3fd4751a4e2bc8d98cdbfe4e633c3e312e896cf3 (diff)
parent1d267614d6718e61d6791f293a6451e378181935 (diff)
downloadKamon-de6a2c9bd6ab6034f59ee51b0eb48beae3d70561.tar.gz
Kamon-de6a2c9bd6ab6034f59ee51b0eb48beae3d70561.tar.bz2
Kamon-de6a2c9bd6ab6034f59ee51b0eb48beae3d70561.zip
Merge branch 'statsd'
Diffstat (limited to 'kamon-statsd/src/main/scala/kamon/statsd')
-rw-r--r--kamon-statsd/src/main/scala/kamon/statsd/StatsDMetricsSender.scala65
-rw-r--r--kamon-statsd/src/main/scala/kamon/statsd/Statsd.scala110
-rw-r--r--kamon-statsd/src/main/scala/kamon/statsd/StatsdMetricTranslator.scala61
3 files changed, 236 insertions, 0 deletions
diff --git a/kamon-statsd/src/main/scala/kamon/statsd/StatsDMetricsSender.scala b/kamon-statsd/src/main/scala/kamon/statsd/StatsDMetricsSender.scala
new file mode 100644
index 00000000..b14e6022
--- /dev/null
+++ b/kamon-statsd/src/main/scala/kamon/statsd/StatsDMetricsSender.scala
@@ -0,0 +1,65 @@
+/*
+ * =========================================================================================
+ * Copyright © 2013-2014 the kamon project <http://kamon.io/>
+ *
+ * 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.statsd
+
+import akka.actor.{ ActorLogging, Props, ActorRef, Actor }
+import akka.io.{ Udp, IO }
+import java.net.InetSocketAddress
+import akka.util.ByteString
+import kamon.Kamon
+import scala.annotation.tailrec
+
+class StatsDMetricsSender extends Actor with ActorLogging {
+ import context.system
+
+ val statsDExtension = Kamon(StatsD)
+ val remote = new InetSocketAddress(statsDExtension.hostname, statsDExtension.port)
+ val maxPacketSize = 1024
+
+ IO(Udp) ! Udp.SimpleSender
+
+ def receive = {
+ case Udp.SimpleSenderReady ⇒
+ context.become(ready(sender))
+ }
+
+ def ready(udpSender: ActorRef): Receive = {
+ case StatsD.MetricBatch(metrics) ⇒ writeDown(metrics, ByteString.empty, udpSender)
+ }
+
+
+ def flushToRemote(data: ByteString, udpSender: ActorRef): Unit = udpSender ! Udp.Send(data, remote)
+
+ @tailrec final def writeDown(metrics: Iterable[StatsD.Metric], buffer: ByteString, udpSender: ActorRef): Unit = {
+ if(metrics.isEmpty)
+ flushToRemote(buffer, udpSender)
+ else {
+ val headData = metrics.head.toByteString
+ if(buffer.size + headData.size > maxPacketSize) {
+ flushToRemote(buffer, udpSender)
+ writeDown(metrics.tail, headData, udpSender)
+ } else {
+ writeDown(metrics.tail, buffer ++ headData, udpSender)
+ }
+
+ }
+ }
+}
+
+object StatsDMetricsSender {
+ def props: Props = Props[StatsDMetricsSender]
+} \ No newline at end of file
diff --git a/kamon-statsd/src/main/scala/kamon/statsd/Statsd.scala b/kamon-statsd/src/main/scala/kamon/statsd/Statsd.scala
new file mode 100644
index 00000000..0ded1394
--- /dev/null
+++ b/kamon-statsd/src/main/scala/kamon/statsd/Statsd.scala
@@ -0,0 +1,110 @@
+/*
+ * =========================================================================================
+ * Copyright © 2013-2014 the kamon project <http://kamon.io/>
+ *
+ * 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.statsd
+
+import akka.actor._
+import kamon.Kamon
+import kamon.metrics._
+import scala.concurrent.duration._
+import scala.collection.JavaConverters._
+import akka.util.ByteString
+import com.typesafe.config.Config
+import java.lang.management.ManagementFactory
+
+object StatsD extends ExtensionId[StatsDExtension] with ExtensionIdProvider {
+ override def lookup(): ExtensionId[_ <: Extension] = StatsD
+ override def createExtension(system: ExtendedActorSystem): StatsDExtension = new StatsDExtension(system)
+
+
+ trait MetricKeyGenerator {
+ def generateKey(groupIdentity: MetricGroupIdentity, metricIdentity: MetricIdentity): String
+ }
+
+ sealed trait Metric {
+ def key: String
+ def value: Double
+ def suffix: String
+ def samplingRate: Double
+
+ /*
+ * Creates the stats string to send to StatsD.
+ * For counters, it provides something like {@code key:value|c}.
+ * For timing, it provides something like {@code key:millis|ms}.
+ * If sampling rate is less than 1, it provides something like {@code key:value|type|@rate}
+ */
+ def toByteString: ByteString =
+ if(samplingRate >= 1D)
+ ByteString(s"$key:$value|$suffix")
+ else
+ ByteString(s"$key:$value|$suffix|@$samplingRate")
+ }
+
+ case class Counter(key: String, value: Double = 1D, samplingRate: Double = 1.0) extends Metric {
+ val suffix: String = "c"
+ }
+
+ case class Timing(key: String, value: Double, samplingRate: Double = 1.0) extends Metric {
+ val suffix: String = "ms"
+ }
+
+ case class Gauge(key: String, value: Double, samplingRate: Double = 1.0) extends Metric {
+ val suffix: String = "g"
+ }
+
+ case class MetricBatch(metrics: Iterable[Metric])
+}
+
+
+class StatsDExtension(system: ExtendedActorSystem) extends Kamon.Extension {
+ private val statsDConfig = system.settings.config.getConfig("kamon.statsd")
+
+ val hostname = statsDConfig.getString("hostname")
+ val port = statsDConfig.getInt("port")
+ val flushInterval = statsDConfig.getMilliseconds("flush-interval")
+ val maxPacketSize = statsDConfig.getInt("max-packet-size")
+ val tickInterval = system.settings.config.getMilliseconds("kamon.metrics.tick-interval")
+
+ val statsDMetricsListener = buildMetricsListener(tickInterval, flushInterval)
+
+ val includedActors = statsDConfig.getStringList("includes.actor").asScala
+ for(actorPathPattern <- includedActors) {
+ Kamon(Metrics)(system).subscribe(ActorMetrics, actorPathPattern, statsDMetricsListener, permanently = true)
+ }
+
+
+ def buildMetricsListener(tickInterval: Long, flushInterval: Long): ActorRef = {
+ assert(flushInterval >= tickInterval, "StatsD flush-interval needs to be equal or greater to the tick-interval")
+
+ val metricsTranslator = system.actorOf(StatsDMetricTranslator.props, "statsd-metrics-translator")
+ if(flushInterval == tickInterval) {
+ // No need to buffer the metrics, let's go straight to the metrics translator.
+ metricsTranslator
+ } else {
+ system.actorOf(TickMetricSnapshotBuffer.props(flushInterval.toInt.millis, metricsTranslator), "statsd-metrics-buffer")
+ }
+ }
+}
+
+
+class SimpleMetricKeyGenerator(config: Config) extends StatsD.MetricKeyGenerator {
+ val application = config.getString("kamon.statsd.simple-metric-key-generator.application")
+ val localhostName = ManagementFactory.getRuntimeMXBean.getName.split('@')(1)
+
+ def generateKey(groupIdentity: MetricGroupIdentity, metricIdentity: MetricIdentity): String =
+ application + "." + localhostName + "." + groupIdentity.category.name + "." + groupIdentity.name + "." + metricIdentity.name
+}
+
diff --git a/kamon-statsd/src/main/scala/kamon/statsd/StatsdMetricTranslator.scala b/kamon-statsd/src/main/scala/kamon/statsd/StatsdMetricTranslator.scala
new file mode 100644
index 00000000..2cf672b8
--- /dev/null
+++ b/kamon-statsd/src/main/scala/kamon/statsd/StatsdMetricTranslator.scala
@@ -0,0 +1,61 @@
+/*
+ * =========================================================================================
+ * Copyright © 2013-2014 the kamon project <http://kamon.io/>
+ *
+ * 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.statsd
+
+import akka.actor.{ Props, Actor, ActorRef }
+import kamon.metrics._
+import kamon.metrics.Subscriptions.TickMetricSnapshot
+import kamon.metrics.ActorMetrics.ActorMetricSnapshot
+
+class StatsDMetricTranslator extends Actor {
+ val config = context.system.settings.config
+
+ val metricKeyGenerator = new SimpleMetricKeyGenerator(config)
+ val metricSender = context.actorOf(StatsDMetricsSender.props, "metrics-sender")
+
+ def receive = {
+ case TickMetricSnapshot(from, to, metrics) ⇒
+ val translatedMetrics = metrics.collect {
+ case (am @ ActorMetrics(_), snapshot: ActorMetricSnapshot) => transformActorMetric(am, snapshot)
+ }
+
+ metricSender ! StatsD.MetricBatch(translatedMetrics.flatten)
+ }
+
+ def transformActorMetric(actorIdentity: ActorMetrics, snapshot: ActorMetricSnapshot): Vector[StatsD.Metric] = {
+ val timeInMailboxKey = metricKeyGenerator.generateKey(actorIdentity, ActorMetrics.TimeInMailbox)
+ val processingTimeKey = metricKeyGenerator.generateKey(actorIdentity, ActorMetrics.ProcessingTime)
+
+ roll(timeInMailboxKey, snapshot.timeInMailbox, StatsD.Timing) ++ roll(processingTimeKey, snapshot.processingTime, StatsD.Timing)
+ }
+
+ def roll(key: String, snapshot: MetricSnapshotLike, metricBuilder: (String, Double, Double) => StatsD.Metric): Vector[StatsD.Metric] = {
+ val builder = Vector.newBuilder[StatsD.Metric]
+ for(measurement <- snapshot.measurements) {
+ val samplingRate = 1D / measurement.count
+ val scaledValue = Scale.convert(snapshot.scale, Scale.Milli, measurement.value)
+ builder += metricBuilder.apply(key, scaledValue, samplingRate)
+ }
+
+ builder.result()
+ }
+
+
+}
+
+object StatsDMetricTranslator {
+ def props: Props = Props[StatsDMetricTranslator]
+}