Package io.druid.data.input.impl

Examples of io.druid.data.input.impl.TimestampSpec


    rollupSpec.rollupGranularity = QueryGranularity.MINUTE;

    HadoopIngestionSpec spec = new HadoopIngestionSpec(
        null, null, null,
        "foo",
        new TimestampSpec("timestamp", "auto"),
        new JSONDataSpec(ImmutableList.of("foo"), null),
        new UniformGranularitySpec(
            Granularity.HOUR,
            QueryGranularity.MINUTE,
            ImmutableList.of(new Interval("2010-01-01/P1D")),
View Full Code Here


    FireDepartment schema = new FireDepartment(
        new DataSchema(
            "foo",
            new StringInputRowParser(
                new JSONParseSpec(
                    new TimestampSpec(
                        "timestamp",
                        "auto"
                    ),
                    new DimensionsSpec(
                        Arrays.asList("dim1", "dim2"),
View Full Code Here

  {
    DataSchema schema = new DataSchema(
        "test",
        new StringInputRowParser(
            new JSONParseSpec(
                new TimestampSpec("time", "auto"),
                new DimensionsSpec(ImmutableList.of("dimB", "dimA"), null, null)
            ),
            null, null, null, null
        ),
        new AggregatorFactory[]{
View Full Code Here

  {
    DataSchema schema = new DataSchema(
        "test",
        new StringInputRowParser(
            new JSONParseSpec(
                new TimestampSpec("time", "auto"),
                new DimensionsSpec(ImmutableList.of("time", "dimA", "dimB", "col2"), ImmutableList.of("dimC"), null)
            ),
            null, null, null, null
        ),
        new AggregatorFactory[]{
View Full Code Here

    RabbitMQFirehoseFactory factory = new RabbitMQFirehoseFactory(
        connectionFactory,
        config,
        new StringInputRowParser(
            new JSONParseSpec(
                new TimestampSpec("timestamp", "auto"),
                new DimensionsSpec(
                    Arrays.asList("dim"),
                    Lists.<String>newArrayList(),
                    Lists.<SpatialDimensionSchema>newArrayList()
                )
View Full Code Here

    RabbitMQFirehoseFactory factory = new RabbitMQFirehoseFactory(
        connectionFactory,
        config,
        new StringInputRowParser(
            new JSONParseSpec(
                new TimestampSpec("timestamp", "auto"),
                new DimensionsSpec(
                    Arrays.asList("dim"),
                    Lists.<String>newArrayList(),
                    Lists.<SpatialDimensionSchema>newArrayList()
                )
View Full Code Here

          ),
          new LineProcessor<Integer>()
          {
            StringInputRowParser parser = new StringInputRowParser(
                new DelimitedParseSpec(
                    new TimestampSpec("ts", "iso"),
                    new DimensionsSpec(Arrays.asList(DIMENSIONS), null, null),
                    "\t",
                    "\u0001",
                    Arrays.asList(COLUMNS)
                ),
View Full Code Here

  {

    //configure parser with desc file
    ProtoBufInputRowParser parser = new ProtoBufInputRowParser(
        new JSONParseSpec(
            new TimestampSpec("timestamp", "iso"),
            new DimensionsSpec(Arrays.asList(DIMENSIONS), Arrays.<String>asList(), null)
        ),
        "prototest.desc",
        null, null, null, null
    );
View Full Code Here

          @Override
          public ParseSpec getParseSpec()
          {
            return new JSONParseSpec(
                new TimestampSpec("timestamp", "auto"),
                new DimensionsSpec(null, null, null)
            );
          }

          @Override
View Full Code Here

    for (AggregatorFactory aggregator : aggregators) {
      dimensionExclusions.addAll(aggregator.requiredFields());
    }
    if (parser != null && parser.getParseSpec() != null) {
      final DimensionsSpec dimensionsSpec = parser.getParseSpec().getDimensionsSpec();
      final TimestampSpec timestampSpec = parser.getParseSpec().getTimestampSpec();

      // exclude timestamp from dimensions by default, unless explicitly included in the list of dimensions
      if (timestampSpec != null) {
        final String timestampColumn = timestampSpec.getTimestampColumn();
        if (!(dimensionsSpec.hasCustomDimensions() && dimensionsSpec.getDimensions().contains(timestampColumn))) {
          dimensionExclusions.add(timestampColumn);
        }
      }
      if (dimensionsSpec != null) {
View Full Code Here

TOP

Related Classes of io.druid.data.input.impl.TimestampSpec

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.