import org.apache.spark.sql.types._ // Create DataFrame representing the stream of input lines from files in distributed file store //val textFileSchema = new StructType().add("line", "string") // for a custom schema val streamingLines = spark .readStream //.schema(textFileSchema) // using default -> makes a column of String named value .option("MaxFilesPerTrigger", 1) // maximum number of new files to be considered in every trigger (default: no max) .format("text") .load("/datasets/streamingFiles")
import org.apache.spark.sql.types._
streamingLines: org.apache.spark.sql.DataFrame = [value: string]
val words = streamingLines.as[String] .map(line => line.split(";").drop(1)(0)) // this is to simply cut out the timestamp from this stream .flatMap(_.split(" ")) // flat map by splitting the animal words separated by whitespace .filter( _ != "") // remove empty words that may be artifacts of opening whitespace
words: org.apache.spark.sql.Dataset[String] = [value: string]
// Start running the query that prints the running counts to the console val query = wordCounts.writeStream .outputMode("complete") .format("console") .start() query.awaitTermination() // hit cancel to terminate - killall the bash script in 037a_AnimalNamesStructStreamingFiles
Stream initializing...
-------------------------------------------
Batch: 0
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| owl| 1|
| bat| 1|
+-----+-----+
-------------------------------------------
Batch: 1
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 1|
| pig| 1|
| owl| 1|
| bat| 1|
+-----+-----+
-------------------------------------------
Batch: 2
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| bat| 2|
| dog| 1|
| cat| 1|
| pig| 1|
| owl| 1|
+-----+-----+
-------------------------------------------
Batch: 3
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| bat| 2|
| dog| 2|
| owl| 2|
| cat| 1|
| pig| 1|
+-----+-----+
-------------------------------------------
Batch: 4
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| dog| 3|
| cat| 2|
| owl| 2|
| bat| 2|
| pig| 1|
+-----+-----+
-------------------------------------------
Batch: 5
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| dog| 3|
| bat| 3|
| cat| 2|
| owl| 2|
| pig| 1|
| rat| 1|
+-----+-----+
-------------------------------------------
Batch: 6
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| bat| 4|
| dog| 3|
| cat| 3|
| owl| 2|
| pig| 1|
| rat| 1|
+-----+-----+
-------------------------------------------
Batch: 7
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 4|
| bat| 4|
| dog| 3|
| owl| 3|
| pig| 1|
| rat| 1|
+-----+-----+
-------------------------------------------
Batch: 8
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 5|
| owl| 4|
| bat| 4|
| dog| 3|
| pig| 1|
| rat| 1|
+-----+-----+
-------------------------------------------
Batch: 9
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 6|
| owl| 5|
| bat| 4|
| dog| 3|
| rat| 1|
| pig| 1|
+-----+-----+
-------------------------------------------
Batch: 10
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 6|
| owl| 5|
| bat| 4|
| dog| 3|
| rat| 2|
| pig| 2|
+-----+-----+
-------------------------------------------
Batch: 11
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 7|
| owl| 5|
| bat| 4|
| dog| 3|
| pig| 3|
| rat| 2|
+-----+-----+
-------------------------------------------
Batch: 12
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 8|
| owl| 5|
| bat| 5|
| dog| 3|
| pig| 3|
| rat| 2|
+-----+-----+
-------------------------------------------
Batch: 13
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 8|
| owl| 6|
| bat| 5|
| dog| 3|
| rat| 3|
| pig| 3|
+-----+-----+
-------------------------------------------
Batch: 14
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 8|
| bat| 6|
| owl| 6|
| pig| 4|
| dog| 3|
| rat| 3|
+-----+-----+
-------------------------------------------
Batch: 15
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 8|
| bat| 7|
| owl| 6|
| dog| 4|
| pig| 4|
| rat| 3|
+-----+-----+
-------------------------------------------
Batch: 16
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 8|
| bat| 7|
| owl| 7|
| pig| 5|
| dog| 4|
| rat| 3|
+-----+-----+
-------------------------------------------
Batch: 17
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 9|
| bat| 8|
| owl| 7|
| pig| 5|
| dog| 4|
| rat| 3|
+-----+-----+
-------------------------------------------
Batch: 18
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 10|
| bat| 9|
| owl| 7|
| pig| 5|
| dog| 4|
| rat| 3|
+-----+-----+
-------------------------------------------
Batch: 19
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 11|
| bat| 9|
| owl| 7|
| pig| 5|
| dog| 4|
| rat| 4|
+-----+-----+
-------------------------------------------
Batch: 20
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 12|
| bat| 9|
| owl| 7|
| dog| 5|
| pig| 5|
| rat| 4|
+-----+-----+
-------------------------------------------
Batch: 21
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 12|
| bat| 9|
| owl| 7|
| dog| 6|
| rat| 5|
| pig| 5|
+-----+-----+
-------------------------------------------
Batch: 22
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 12|
| bat| 9|
| owl| 7|
| rat| 6|
| dog| 6|
| pig| 6|
+-----+-----+
-------------------------------------------
Batch: 23
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 12|
| bat| 10|
| owl| 7|
| rat| 7|
| dog| 6|
| pig| 6|
+-----+-----+
-------------------------------------------
Batch: 24
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 13|
| bat| 10|
| rat| 8|
| owl| 7|
| dog| 6|
| pig| 6|
+-----+-----+
-------------------------------------------
Batch: 25
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 14|
| bat| 11|
| rat| 8|
| owl| 7|
| dog| 6|
| pig| 6|
+-----+-----+
-------------------------------------------
Batch: 26
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 15|
| bat| 11|
| rat| 8|
| pig| 7|
| owl| 7|
| dog| 6|
+-----+-----+
-------------------------------------------
Batch: 27
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 15|
| bat| 11|
| rat| 9|
| pig| 8|
| owl| 7|
| dog| 6|
+-----+-----+
-------------------------------------------
Batch: 28
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 16|
| bat| 11|
| rat| 9|
| pig| 9|
| owl| 7|
| dog| 6|
+-----+-----+
-------------------------------------------
Batch: 29
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 16|
| bat| 12|
| pig| 9|
| rat| 9|
| owl| 8|
| dog| 6|
+-----+-----+
-------------------------------------------
Batch: 30
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 17|
| bat| 12|
| rat| 9|
| pig| 9|
| owl| 9|
| dog| 6|
+-----+-----+
-------------------------------------------
Batch: 31
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 18|
| bat| 12|
| pig| 9|
| owl| 9|
| rat| 9|
| dog| 7|
+-----+-----+
-------------------------------------------
Batch: 32
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 19|
| bat| 12|
| rat| 10|
| pig| 9|
| owl| 9|
| dog| 7|
+-----+-----+
-------------------------------------------
Batch: 33
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 20|
| bat| 12|
| rat| 11|
| pig| 9|
| owl| 9|
| dog| 7|
+-----+-----+
-------------------------------------------
Batch: 34
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 20|
| rat| 12|
| bat| 12|
| pig| 10|
| owl| 9|
| dog| 7|
+-----+-----+
-------------------------------------------
Batch: 35
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 20|
| bat| 13|
| rat| 12|
| pig| 11|
| owl| 9|
| dog| 7|
+-----+-----+
-------------------------------------------
Batch: 36
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 20|
| bat| 13|
| pig| 12|
| rat| 12|
| owl| 10|
| dog| 7|
+-----+-----+
-------------------------------------------
Batch: 37
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 20|
| rat| 13|
| bat| 13|
| pig| 13|
| owl| 10|
| dog| 7|
+-----+-----+
-------------------------------------------
Batch: 38
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 20|
| pig| 14|
| rat| 13|
| bat| 13|
| owl| 10|
| dog| 8|
+-----+-----+
-------------------------------------------
Batch: 39
-------------------------------------------
+-----+-----+
|value|count|
+-----+-----+
| cat| 21|
| pig| 14|
| rat| 13|
| bat| 13|
| owl| 11|
| dog| 8|
+-----+-----+
Cancelled
peekIn.show(5, false) // let's take a quick peek at what's in the CSV files
+-----------------------+--------------------+
|_c0 |_c1 |
+-----------------------+--------------------+
|2019-05-31 15:20:26.901|0.21791376679544772 |
|2019-05-31 15:20:26.906|0.011291967445604012|
|2019-05-31 15:20:26.911|-0.30293144696154806|
|2019-05-31 15:20:26.916|0.4303254534802833 |
|2019-05-31 15:20:26.922|1.5521304466388752 |
+-----------------------+--------------------+
only showing top 5 rows
// Read all the csv files written atomically from a directory import org.apache.spark.sql.types._ //make a user-specified schema - this is needed for structured streaming from files val userSchema = new StructType() .add("time", "timestamp") .add("score", "Double") // a static DF is convenient val csvStaticDF = spark .read .option("sep", ",") // delimiter is ',' .schema(userSchema) // Specify schema of the csv files as pre-defined by user .csv("/datasets/streamingFilesNormalMixture/*/*.csv") // Equivalent to format("csv").load("/path/to/directory") // streaming DF val csvStreamingDF = spark .readStream .option("sep", ",") // delimiter is ',' .schema(userSchema) // Specify schema of the csv files as pre-defined by user .option("MaxFilesPerTrigger", 1) // maximum number of new files to be considered in every trigger (default: no max) .csv("/datasets/streamingFilesNormalMixture/*/*.csv") // Equivalent to format("csv").load("/path/to/directory")
import org.apache.spark.sql.types._
userSchema: org.apache.spark.sql.types.StructType = StructType(StructField(time,TimestampType,true), StructField(score,DoubleType,true))
csvStaticDF: org.apache.spark.sql.DataFrame = [time: timestamp, score: double]
csvStreamingDF: org.apache.spark.sql.DataFrame = [time: timestamp, score: double]
import org.apache.spark.sql.functions._ // Start running the query that prints the running counts to the console val query = csvStreamingDF // bround simply rounds the double to the desired decimal place - 0 in our case here. // see https://spark.apache.org/docs/latest/api/java/org/apache/spark/sql/functions.html#bround-org.apache.spark.sql.Column- // we are using bround to simply coarsen out data into bins for counts .select(bround($"score", 0).as("binnedScore")) .groupBy($"binnedScore") .agg(count($"binnedScore") as "binnedScoreCounts") .orderBy($"binnedScore") .writeStream .outputMode("complete") .format("console") .start() query.awaitTermination() // hit cancel to terminate
Stream initializing...
-------------------------------------------
Batch: 0
-------------------------------------------
+-----------+-----------------+
|binnedScore|binnedScoreCounts|
+-----------+-----------------+
| -1.0| 9|
| 0.0| 18|
| 1.0| 41|
| 2.0| 25|
| 3.0| 5|
| 4.0| 1|
| 10.0| 1|
+-----------+-----------------+
-------------------------------------------
Batch: 1
-------------------------------------------
+-----------+-----------------+
|binnedScore|binnedScoreCounts|
+-----------+-----------------+
| -2.0| 1|
| -1.0| 13|
| 0.0| 44|
| 1.0| 83|
| 2.0| 46|
| 3.0| 10|
| 4.0| 1|
| 10.0| 1|
| 12.0| 1|
+-----------+-----------------+
-------------------------------------------
Batch: 2
-------------------------------------------
+-----------+-----------------+
|binnedScore|binnedScoreCounts|
+-----------+-----------------+
| -2.0| 2|
| -1.0| 20|
| 0.0| 74|
| 1.0| 118|
| 2.0| 70|
| 3.0| 12|
| 4.0| 1|
| 9.0| 1|
| 10.0| 1|
| 12.0| 1|
+-----------+-----------------+
-------------------------------------------
Batch: 3
-------------------------------------------
+-----------+-----------------+
|binnedScore|binnedScoreCounts|
+-----------+-----------------+
| -2.0| 4|
| -1.0| 27|
| 0.0| 104|
| 1.0| 144|
| 2.0| 96|
| 3.0| 21|
| 4.0| 1|
| 9.0| 1|
| 10.0| 1|
| 12.0| 1|
+-----------+-----------------+
-------------------------------------------
Batch: 4
-------------------------------------------
+-----------+-----------------+
|binnedScore|binnedScoreCounts|
+-----------+-----------------+
| -2.0| 4|
| -1.0| 32|
| 0.0| 125|
| 1.0| 179|
| 2.0| 125|
| 3.0| 30|
| 4.0| 2|
| 9.0| 1|
| 10.0| 1|
| 12.0| 1|
+-----------+-----------------+
Cancelled
import org.apache.spark.sql.types._ import java.sql.Timestamp // create a case class to make the datset case class timedScores(time: Timestamp, score: Double) val csvStaticDS = csvStaticDF.as[timedScores] // create a dataset from the dataframe
import org.apache.spark.sql.types._
import java.sql.Timestamp
defined class timedScores
csvStaticDS: org.apache.spark.sql.Dataset[timedScores] = [time: timestamp, score: double]
csvStaticDS.show(5,false) // looks like we got the dataset we want with strong typing
+-----------------------+--------------------+
|time |score |
+-----------------------+--------------------+
|2019-05-31 15:20:26.901|0.21791376679544772 |
|2019-05-31 15:20:26.906|0.011291967445604012|
|2019-05-31 15:20:26.911|-0.30293144696154806|
|2019-05-31 15:20:26.916|0.4303254534802833 |
|2019-05-31 15:20:26.922|1.5521304466388752 |
+-----------------------+--------------------+
only showing top 5 rows
import org.apache.spark.sql.functions._ import org.apache.spark.sql.types._ import java.sql.Timestamp // create a case class to make the datset case class timedScores(time: Timestamp, score: Double) val csvStreamingDS = csvStreamingDF.as[timedScores] // create a dataset from the dataframe // Start running the query that prints the running counts to the console val query = csvStreamingDS // bround simply rounds the double to the desired decimal place - 0 in our case here. // see https://spark.apache.org/docs/latest/api/java/org/apache/spark/sql/functions.html#bround-org.apache.spark.sql.Column- // we are using bround to simply coarsen out data into bins for counts .select(bround($"score", 0).as("binnedScore")) .groupBy($"binnedScore") .agg(count($"binnedScore") as "binnedScoreCounts") .orderBy($"binnedScore") .writeStream .outputMode("complete") .format("console") .start() query.awaitTermination() // hit cancel to terminate
Stream initializing...
-------------------------------------------
Batch: 0
-------------------------------------------
+-----------+-----------------+
|binnedScore|binnedScoreCounts|
+-----------+-----------------+
| -1.0| 9|
| 0.0| 18|
| 1.0| 41|
| 2.0| 25|
| 3.0| 5|
| 4.0| 1|
| 10.0| 1|
+-----------+-----------------+
-------------------------------------------
Batch: 1
-------------------------------------------
+-----------+-----------------+
|binnedScore|binnedScoreCounts|
+-----------+-----------------+
| -2.0| 1|
| -1.0| 13|
| 0.0| 44|
| 1.0| 83|
| 2.0| 46|
| 3.0| 10|
| 4.0| 1|
| 10.0| 1|
| 12.0| 1|
+-----------+-----------------+
-------------------------------------------
Batch: 2
-------------------------------------------
+-----------+-----------------+
|binnedScore|binnedScoreCounts|
+-----------+-----------------+
| -2.0| 2|
| -1.0| 20|
| 0.0| 74|
| 1.0| 118|
| 2.0| 70|
| 3.0| 12|
| 4.0| 1|
| 9.0| 1|
| 10.0| 1|
| 12.0| 1|
+-----------+-----------------+
-------------------------------------------
Batch: 3
-------------------------------------------
+-----------+-----------------+
|binnedScore|binnedScoreCounts|
+-----------+-----------------+
| -2.0| 4|
| -1.0| 27|
| 0.0| 104|
| 1.0| 144|
| 2.0| 96|
| 3.0| 21|
| 4.0| 1|
| 9.0| 1|
| 10.0| 1|
| 12.0| 1|
+-----------+-----------------+
-------------------------------------------
Batch: 4
-------------------------------------------
+-----------+-----------------+
|binnedScore|binnedScoreCounts|
+-----------+-----------------+
| -2.0| 4|
| -1.0| 32|
| 0.0| 125|
| 1.0| 179|
| 2.0| 125|
| 3.0| 30|
| 4.0| 2|
| 9.0| 1|
| 10.0| 1|
| 12.0| 1|
+-----------+-----------------+
Cancelled
spark.read.format("text").load("/datasets/streamingFiles").show(5,false) // let's just read five entries
+----------------------------------+
|value |
+----------------------------------+
|2019-05-31 15:00:01+00:00; bat dog|
|2019-05-31 15:00:03+00:00; bat owl|
|2019-05-31 15:00:05+00:00; rat bat|
|2019-05-31 15:00:07+00:00; dog cat|
|2019-05-31 15:00:09+00:00; cat pig|
+----------------------------------+
only showing top 5 rows
import spark.implicits._ import org.apache.spark.sql.types._ import org.apache.spark.sql.functions._ import java.sql.Timestamp // a static DS is convenient to work with val csvStaticDS = spark .read .option("sep", ";") // delimiter is ';' .csv("/datasets/streamingFiles/*.log") // Equivalent to format("csv").load("/path/to/directory") .toDF("time","animals") .as[(Timestamp, String)] .flatMap( line => line._2.split(" ") .filter(_ != "") // Gustav's improvement .map(animal => (line._1, animal)) ) //.filter(_._2 != "") // remove empty strings from the leading whitespaces .toDF("timestamp", "animal") .as[(Timestamp, String)]
import spark.implicits._
import org.apache.spark.sql.types._
import org.apache.spark.sql.functions._
import java.sql.Timestamp
csvStaticDS: org.apache.spark.sql.Dataset[(java.sql.Timestamp, String)] = [timestamp: timestamp, animal: string]
//make a user-specified schema for structured streaming val userSchema = new StructType() .add("time", "String") // we will read it as String and then convert into timestamp later .add("animals", "String") // streaming DS val csvStreamingDS = spark // the next three lines are needed for structured streaming from file streams .readStream // for streaming .option("MaxFilesPerTrigger", 1) // for streaming .schema(userSchema) // for streaming .option("sep", ";") // delimiter is ';' .csv("/datasets/streamingFiles/*.log") // Equivalent to format("csv").load("/path/to/directory") .toDF("time","animals") .as[(Timestamp, String)] .flatMap( line => line._2.split(" ").map(animal => (line._1, animal)) ) .filter(_._2 != "") .toDF("timestamp", "animal") .as[(Timestamp, String)]
userSchema: org.apache.spark.sql.types.StructType = StructType(StructField(time,StringType,true), StructField(animals,StringType,true))
csvStreamingDS: org.apache.spark.sql.Dataset[(java.sql.Timestamp, String)] = [timestamp: timestamp, animal: string]
// Group the data by window and word and compute the count of each group val windowDuration = "180 seconds" val slideDuration = "90 seconds" val windowedCounts = csvStreamingDS.groupBy( window($"timestamp", windowDuration, slideDuration), $"animal" ).count().orderBy("window") // Start running the query that prints the windowed word counts to the console val query = windowedCounts.writeStream .outputMode("complete") .format("console") .option("truncate", "false") .start() query.awaitTermination()
Stream initializing...
-------------------------------------------
Batch: 0
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
+------------------------------------------+------+-----+
-------------------------------------------
Batch: 1
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|bat |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|bat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|cat |1 |
+------------------------------------------+------+-----+
-------------------------------------------
Batch: 2
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|bat |2 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|owl |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|bat |2 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|cat |1 |
+------------------------------------------+------+-----+
-------------------------------------------
Batch: 3
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|bat |2 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|bat |2 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|owl |1 |
+------------------------------------------+------+-----+
-------------------------------------------
Batch: 4
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|cat |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|bat |2 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|bat |2 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|owl |1 |
+------------------------------------------+------+-----+
-------------------------------------------
Batch: 5
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|bat |2 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|owl |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 6
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|bat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|dog |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 7
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|dog |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|bat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|pig |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|pig |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|rat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 8
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|pig |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|dog |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|bat |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|pig |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|rat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 9
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|bat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|dog |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|pig |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|pig |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|rat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 10
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|pig |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 11
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |2 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |2 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|pig |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 12
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |2 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|pig |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |2 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|pig |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 13
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|dog |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|dog |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|bat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |2 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|pig |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|pig |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 14
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|dog |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|dog |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|bat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|owl |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|cat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|cat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|owl |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |2 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 15
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|dog |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|dog |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|bat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|owl |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|cat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|bat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|owl |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|cat |2 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
Cancelled
// Group the data by window and word and compute the count of each group val windowDuration = "180 seconds" val slideDuration = "90 seconds" val watermarkDuration = "10 minutes" val windowedCounts = csvStreamingDS .withWatermark("timestamp", watermarkDuration) .groupBy( window($"timestamp", windowDuration, slideDuration), $"animal" ).count().orderBy("window") // Start running the query that prints the windowed word counts to the console val query = windowedCounts.writeStream .outputMode("complete") .format("console") .option("truncate", "false") .start() query.awaitTermination()
Stream initializing...
-------------------------------------------
Batch: 0
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
+------------------------------------------+------+-----+
-------------------------------------------
Batch: 1
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|bat |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|bat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|cat |1 |
+------------------------------------------+------+-----+
-------------------------------------------
Batch: 2
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|bat |2 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|bat |2 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|owl |1 |
+------------------------------------------+------+-----+
-------------------------------------------
Batch: 3
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|bat |2 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|bat |2 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|owl |1 |
+------------------------------------------+------+-----+
-------------------------------------------
Batch: 4
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|bat |2 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|cat |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|bat |2 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|owl |1 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|cat |1 |
+------------------------------------------+------+-----+
-------------------------------------------
Batch: 5
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|cat |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|owl |1 |
|[2019-05-31 15:04:30, 2019-05-31 15:07:30]|bat |2 |
|[2019-05-31 15:06:00, 2019-05-31 15:09:00]|bat |2 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 6
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|bat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|dog |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|owl |1 |
|[2019-05-31 15:00:00, 2019-05-31 15:03:00]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|pig |1 |
|[2019-05-31 15:01:30, 2019-05-31 15:04:30]|owl |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 7
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|dog |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|bat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|pig |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|pig |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|rat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 8
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|bat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|pig |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|dog |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|pig |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|rat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 9
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|dog |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|rat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|bat |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|pig |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|rat |1 |
|[2019-05-31 14:55:30, 2019-05-31 14:58:30]|pig |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 10
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|dog |1 |
|[2019-05-31 14:54:00, 2019-05-31 14:57:00]|rat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 11
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |2 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|pig |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|pig |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |2 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 12
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |2 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|pig |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|pig |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|owl |2 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|dog |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|bat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 13
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|dog |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |2 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|bat |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|dog |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|owl |2 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|pig |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|rat |1 |
|[2019-05-31 14:52:30, 2019-05-31 14:55:30]|pig |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 14
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|dog |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |2 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|bat |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|dog |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|cat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|owl |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|cat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|owl |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:51:00, 2019-05-31 14:54:00]|rat |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 15
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|dog |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|bat |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|dog |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|cat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|owl |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|cat |2 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|bat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|owl |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 16
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|dog |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |2 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|bat |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|dog |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|owl |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|cat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|cat |2 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |2 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|bat |2 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|owl |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 17
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|dog |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |2 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|dog |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|bat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|cat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|owl |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|bat |2 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|owl |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|pig |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|cat |2 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|rat |2 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 18
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|dog |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|bat |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|pig |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|cat |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|dog |1 |
|[2019-05-31 14:45:00, 2019-05-31 14:48:00]|pig |1 |
|[2019-05-31 14:45:00, 2019-05-31 14:48:00]|cat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|cat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|owl |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|cat |2 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 19
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|dog |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|pig |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|cat |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|dog |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|bat |1 |
|[2019-05-31 14:45:00, 2019-05-31 14:48:00]|cat |1 |
|[2019-05-31 14:45:00, 2019-05-31 14:48:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|owl |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|cat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|cat |3 |
+------------------------------------------+------+-----+
only showing top 20 rows
-------------------------------------------
Batch: 20
-------------------------------------------
+------------------------------------------+------+-----+
|window |animal|count|
+------------------------------------------+------+-----+
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|rat |2 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|cat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|bat |1 |
|[2019-05-31 14:40:30, 2019-05-31 14:43:30]|pig |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|cat |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|dog |1 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|pig |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|rat |2 |
|[2019-05-31 14:42:00, 2019-05-31 14:45:00]|bat |2 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|pig |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|cat |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|dog |1 |
|[2019-05-31 14:43:30, 2019-05-31 14:46:30]|bat |1 |
|[2019-05-31 14:45:00, 2019-05-31 14:48:00]|cat |1 |
|[2019-05-31 14:45:00, 2019-05-31 14:48:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|pig |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|owl |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|cat |1 |
|[2019-05-31 14:48:00, 2019-05-31 14:51:00]|rat |1 |
|[2019-05-31 14:49:30, 2019-05-31 14:52:30]|cat |3 |
+------------------------------------------+------+-----+
only showing top 20 rows
Cancelled
SDS-2.x, Scalable Data Engineering Science
Last refresh: Never