Package

com.metamx.tranquility

druid

Permalink

package druid

Visibility
  1. Public
  2. All

Type Members

  1. class CuratorOverlordLocator extends OverlordLocator

    Permalink
  2. class CuratorTaskLocator extends TaskLocator

    Permalink
  3. class DruidBeam[A] extends Beam[A] with Logging with Closable

    Permalink

    A Beam that writes all messages to a fixed set of Druid tasks.

  4. case class DruidBeamConfig(firehoseGracePeriod: org.scala_tools.time.Imports.Period = 5.minutes, firehoseQuietPeriod: org.scala_tools.time.Imports.Period = 1.minute, firehoseRetryPeriod: org.scala_tools.time.Imports.Period = 1.minute, firehoseChunkSize: Int = 1000, randomizeTaskId: Boolean = false, indexRetryPeriod: org.scala_tools.time.Imports.Period = 1.minute, firehoseBufferSize: Int = 100000, overlordLocator: String = OverlordLocator.Curator, taskLocator: String = TaskLocator.Curator, overlordPollPeriod: org.scala_tools.time.Imports.Period = 20.seconds) extends IndexServiceConfig with Product with Serializable

    Permalink
  5. class DruidBeamMaker[A] extends BeamMaker[A, DruidBeam[A]] with Logging

    Permalink
  6. sealed abstract class DruidDimensions extends AnyRef

    Permalink
  7. class DruidEnvironment extends Equals

    Permalink
  8. class DruidGuicer extends AnyRef

    Permalink
  9. case class DruidLocation(environment: DruidEnvironment, dataSource: String) extends Product with Serializable

    Permalink
  10. class DruidRollup extends AnyRef

    Permalink

    Describes rollup (dimensions, aggregators, index granularity) desired for a Druid datasource.

    Describes rollup (dimensions, aggregators, index granularity) desired for a Druid datasource. Java users should use the create methods on DruidRollup$, as those accepts Java collections rather than Scala ones.

    See DruidDimensions.specific, DruidDimensions.schemaless, and DruidDimensions.schemalessWithExclusions for three common ways of creating druid dimensions objects.

  11. sealed abstract class DruidSpatialDimension extends AnyRef

    Permalink
  12. case class DruidTuning(maxRowsInMemory: Int = 75000, intermediatePersistPeriod: Period = 10.minutes, maxPendingPersists: Int = 0, buildV9Directly: Boolean = false) extends Product with Serializable

    Permalink
  13. class IndexService extends Closable

    Permalink
  14. trait IndexServiceConfig extends AnyRef

    Permalink
  15. sealed trait IndexServiceException extends AnyRef

    Permalink
  16. class IndexServicePermanentException extends Exception with IndexServiceException

    Permalink

    Exceptions that are permanent in nature, and are useless to retry externally.

    Exceptions that are permanent in nature, and are useless to retry externally. The assumption is that all other exceptions may be transient.

  17. class IndexServiceTransientException extends Exception with IndexServiceException

    Permalink

    Exceptions that indicate transient indexing service failures.

    Exceptions that indicate transient indexing service failures. Can be retried if desired.

  18. sealed trait IndexStatus extends AnyRef

    Permalink
  19. case class MultipleFieldDruidSpatialDimension(name: String, fieldNames: Seq[String]) extends DruidSpatialDimension with Product with Serializable

    Permalink
  20. trait OverlordLocator extends AnyRef

    Permalink
  21. class OverlordTaskLocator extends TaskLocator

    Permalink
  22. case class SchemalessDruidDimensions(dimensionExclusions: Set[String], spatialDimensions: Seq[DruidSpatialDimension] = Nil) extends DruidDimensions with Product with Serializable

    Permalink
  23. case class SingleFieldDruidSpatialDimension(name: String) extends DruidSpatialDimension with Product with Serializable

    Permalink
  24. case class SpecificDruidDimensions(dimensions: Seq[String], spatialDimensions: Seq[DruidSpatialDimension] = Nil) extends DruidDimensions with Product with Serializable

    Permalink
  25. class TaskClient extends Logging with Closable

    Permalink

    Client for a single Druid task.

  26. trait TaskLocator extends AnyRef

    Permalink
  27. case class TaskPointer(id: String, serviceKey: String) extends Product with Serializable

    Permalink

Value Members

  1. object DruidBeamConfig extends Serializable

    Permalink
  2. object DruidBeamMaker

    Permalink
  3. object DruidBeams

    Permalink

    Builds Beams or Finagle services that send events to the Druid indexing service.

    Builds Beams or Finagle services that send events to the Druid indexing service.

    val curator = CuratorFrameworkFactory.newClient("localhost:2181", new BoundedExponentialBackoffRetry(100, 30000, 30))
    curator.start()
    val dataSource = "foo"
    val dimensions = Seq("bar")
    val aggregators = Seq(new LongSumAggregatorFactory("baz", "baz"))
    val sender = DruidBeams
      .builder[Map[String, Any]](eventMap => new DateTime(eventMap("timestamp")))
      .curator(curator)
      .discoveryPath("/test/discovery")
      .location(DruidLocation(new DruidEnvironment("druid:local:indexer", "druid:local:firehose:%s"), dataSource))
      .rollup(DruidRollup(dimensions, aggregators, QueryGranularities.MINUTE))
      .tuning(new ClusteredBeamTuning(Granularity.HOUR, 10.minutes, 1, 1))
      .buildTranquilizer()
    val future = sender.send(Map("timestamp" -> "2010-01-02T03:04:05.678Z", "bar" -> "hey", "baz" -> 3))
    println("result = %s" format Await.result(future))

    Your event type (in this case, Map[String, Any]) must be serializable via Jackson to JSON that Druid can understand. If Jackson is not an appropriate choice, you can provide an ObjectWriter via .objectWriter(...).

  4. object DruidDimensions

    Permalink
  5. object DruidEnvironment

    Permalink
  6. object DruidGuicer

    Permalink
  7. object DruidLocation extends Serializable

    Permalink
  8. object DruidRollup

    Permalink
  9. object DruidSpatialDimension

    Permalink
  10. object DruidTuning extends Serializable

    Permalink
  11. object IndexService

    Permalink
  12. object IndexStatus

    Permalink
  13. object OverlordLocator

    Permalink
  14. object SchemalessDruidDimensions extends Serializable

    Permalink
  15. object TaskClient

    Permalink
  16. object TaskFailed extends IndexStatus with Product with Serializable

    Permalink
  17. object TaskLocator

    Permalink
  18. object TaskNotFound extends IndexStatus with Product with Serializable

    Permalink
  19. object TaskPointer extends Serializable

    Permalink
  20. object TaskRunning extends IndexStatus with Product with Serializable

    Permalink
  21. object TaskSuccess extends IndexStatus with Product with Serializable

    Permalink
  22. package input

    Permalink

Ungrouped