+ All Categories
Home > Technology > NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Date post: 16-Apr-2017
Category:
Upload: helena-edelson
View: 2,704 times
Download: 0 times
Share this document with a friend
90
NoLambda : Combining Streaming, Ad-Hoc, Machine Learning, and Batch Analytics and Evan Chan Helena Edelson March 2016
Transcript
Page 1: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

NoLambda: Combining Streaming,Ad-Hoc, Machine Learning, and

Batch Analytics 

and Evan Chan Helena EdelsonMarch 2016

Page 2: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Evan Chan

Distinguished Engineer,

User and contributor to Spark since 0.9, Cassandra since0.6Co-creator and maintainer of

Tuplejump@evanfchanhttp://velvia.github.io

Spark Job Server

Page 3: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Helena Edelson | @helenaedelson github.com/helena

VP of Product Engineering, Cloud Engineer, Big Data, Event-Driven systemsCommitter: Kafka Connect Cassandra, Spark CassandraConnectorContributor: Akka, Spring IntegrationSpeaker: Kafka Summit, Spark Summit, Strata, QCon, ScalaDays, Scala World, Philly ETE

Tuplejump

Page 4: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Tuplejump is a big data technology leader providing solutions and

development partnership.Tuplejump

Page 5: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Open Source: on GitHubTuplejump - Distributed Spark + Cassandra analytics database

- Kafka-Cassandra Source andSink

- The �rst Spark Cassandra integration - Lucene indexer for Cassandra - HDFS for Cassandra

FiloDBKafka Connect Cassandra

CalliopeStargateSnackFS

Page 6: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Tuplejump Consulting & Development

Page 7: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Tuplejump Data Blender

Page 8: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

TopicsModern streaming and batch/ad-hoc architecturesPitfalls and Simpli�cationPrecise and scalable streaming ingestionFiloDB and fast analytics with competitive storagecostMachine learning with Spark, Cassandra, and FiloDB

Page 9: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Delivering MeaningDerived From

Many data streamsDisparate sources and schemasOriginating from manylocations

Page 10: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

The Problem DomainBuild scalable, adaptable, self-healing, distributed dataprocessing systems for

24 / 7 UptimeAuto scale outComplex analytics and learning tasksAggregate global dataOps for global, multi-dc clustered data�owsDecoupled servicesIdempotent & Acceptable ConsistencyNo data loss

Page 11: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Factors & Constraints in Architecture

Corner cases, Industry use casesLegal constraints - user data crossingborders% Writes on ingestion, % ReadsHow much in memory?Counters? Geo-locational?JDK version for cloud deploymentsDimensions of data in queriesWhat needs real time feedback loops

The list goes on...

Page 12: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Need Self-Healing SystemsMassive event spikes & bursty traf�cFast producers / slow consumersNetwork partitioning & out of syncsystemsDC downNot DDOS'ing ourselves from fast streamsNo data loss when auto-scaling down

Monitor EverythingEverything fails, all the time

Page 13: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Use CaseI need fast access to historical data on the �y for predictive

modeling with real time data from the stream

Page 14: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Only, It's Not A Stream It's A Flood

Trillions of event writes per dayBillions of event reads per dayMassive events per second atpeakPetabytes of total streaming data

Page 15: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Not All Streams Are Created The Same

Daily, Hourly, Frequency, Event Spikes at Peak, Overall Volume

Sub-second, low latency streamprocessingHigher latency stream processingScheduled or on request batch processing

Page 16: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Real TimeJust means Event Driven or processing events as they arriveDoesn't automatically equal sub-second latencyrequirements

Event TimeWhen an event is created, e.g. on sensorEvents should be uniquely timestamped on ingestion fortracking, metrics and replay

Page 17: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Based on the schema of data in a given streamSome can aggregate with sliding windows (T1...Tn,Tn+1...) usingwindow length + slide interval:

stream.reduceByKeyAndWindow((a:Int,b:Int) => (a + b), Seconds(30), Seconds(10))

Some must aggregate by buckets/Event_Type/YYYY/MM/DD/HH/MM/...

CREATE TABLE timeseries.raw_data_fu ( sensor_id text, year int, month int, day int, hour int,... PRIMARY KEY ((sensor_id), year, month, day, hour) ) WITH CLUSTERING ORDER BY (year DESC, month DESC, day DESC, hour DESC);

Page 18: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Stream ProcessingKafka - Foundation to streamingarchitectureSamza - Just streamingGearpump - Real-time big data streaming

Analytics Stream ProcessingStorm - Real-time Analytics, ML, needs Trident tostreamFlink - Real-time Analytics, ML, GraphSpark Streaming - Micro-batch Analytics, ML, Graph

Page 19: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Legacy Infrastructure

Highly-invested-in existing architecture aroundHadoopExisting analytics logic for scheduled MR jobs

Page 20: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Lambda ArchitectureA data-processing architecture designed to handle massive quantitiesof data by taking advantage of both batch and stream processingmethods.

Page 21: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Lambda Architecture

( )https://www.mapr.com/developercentral/lambda-architecture

Page 22: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

λ The Good

Immutability - retaining master dataWith timestamped eventsAppended versus overwrittenevents

Attempt to beat CAPPre-computed views for

further processingfaster ad-hoc querying

Page 23: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

λ The Bad

Two Analytics systems to supportOperational complexityBy the time a scheduled job is run 90% of the data is staleMany moving parts: KV store, real time platform, batchtechnologiesRunning similar code and reconciling queries in dual systemsAnalytics logic changes on dual systems

Page 24: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

λ The Overly Complicated

Immutable sequence of records is ingested and fed into

a batch processing systemand a stream processingsystemin parallel

Ultimately Very High TCO And...

Page 25: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis
Page 26: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Are Batch and Streaming SystemsFundamentally Different?

Both accumulate events from *T1...Tn,Tn+1...Tn+x,...*Or bucketed by Year-Month-Day-Hour?Streaming frameworks have schedulers

Page 27: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

A Unified Streaming ArchitectureEverything On The Streaming Platform

Scala / SparkStreamingMesosAkkaCassandraKafka

Page 28: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

SNACK (SMACK) Stack

Page 29: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

High Throughput Distributed MessagingHigh Scalability - billions of events perdayDurability - no data lossImmutabilitySupport Massive Number of ConsumersVery ef�cient and low latencyDecouples Data PipelinesAutomatic recovery from broker failures

Page 30: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Stream Processing SimplifiedKafka Streams

In master, coming in v0.10Removes the need to run another framework like Stormalongside KafkaRemoves the need for separate infrastructuresCommon stream operations, e.g. join, �lter, map, etc.WindowingProper time modeling, e.g. event time vs. processing timeLocal state management with persistence and replicationSchema and Avro support

Page 31: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Spark StreamingIterative ML, Interactive Querying, Graph, DataFrames

One runtime for streaming and batch processingJoin streaming and static data setsNo code duplicationEasy Kafka stream integrationEasy to reconcile queries against multiplesourcesEasy integration of KV durable storage

Page 32: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Apache Cassandra

Horizontally scalableMulti-Region / Multi-DatacenterAlways On - Survive regional outagesExtremely fast writes: - perfect for ingestion of real time /machine dataVery �exible data modelling (lists, sets, custom data types)Easy to operateBest of breed storage technology, huge communityBUT: Simple queries onlyOLTP-oriented/center

Page 33: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

High performance concurrency framework for Scala andJavaFault ToleranceAsynchronous messaging and data processingParallelizationLocation TransparencyLocal / Remote RoutingAkka: Cluster / Persistence / Streams

Page 34: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

EnablesStreaming and Batch In One System

Streaming ML and Analytics for Predictions In The Stream

Page 35: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Kafka Streamsval builder = new KStreamBuilder() val stream: KStream[K,V] = builder.stream(des, des, "raw.data.topic") .flatMapValues(value -> Arrays.asList(value.toLowerCase.split(" ") .map((k,v) -> new KeyValue(k,v)) .countByKey(ser, ser, des, des, "kTable") .toStream() stream.to("results.topic", ...) val streams = new KafkaStreams(builder, props) streams.start()

 

https://github.com/con�uentinc/demos

Page 36: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Spark Streaming KafkaImmutable Raw Data From Kafka Stream

Replaying data streams: for fault tolerance, logic changes..class KafkaStreamingActor(ssc: StreamingContext) extends MyAggregationActor { val stream = KafkaUtils.createDirectStream(...).map(RawWeatherData(_)) stream .foreachRDD(_.toDF.write.format("filodb.spark") .option("dataset", "rawdata").save()) /* Pre-Aggregate data in the stream for fast querying and aggregation later. */ stream.map(hour => (hour.wsid, hour.year, hour.month, hour.day, hour.oneHourPrecip) ).saveToCassandra(timeseriesKeyspace, dailyPrecipTable) }

Page 37: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Reading Data From Cassandra On Request, FurtherAggregation

Compute isolation in Akka Actorclass TemperatureActor(sc: SparkContext) extends AggregationActor { import akka.pattern.pipe def receive: Actor.Receive = { case e: GetMonthlyHiLowTemperature => highLow(e, sender) } def highLow(e: GetMonthlyHiLowTemperature, requester: ActorRef): Unit = sc.cassandraTable[DailyTemperature](timeseriesKeyspace, dailyTempAggregTable) .where("wsid = ? AND year = ? AND month = ?", e.wsid, e.year, e.month) .collectAsync() .map(MonthlyTemperature(_, e.wsid, e.year, e.month)) pipeTo requester }

Page 38: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Spark Streaming, MLLibKafka, Cassandra

val ssc = new StreamingContext(sparkConf, Seconds(5)) val testData = ssc.cassandraTable[String](keyspace,table) .map(LabeledPoint.parse) val trainingStream = KafkaUtils.createDirectStream[_,_,_,_](..) .map(transformFunc) .map(LabeledPoint.parse) trainingStream.saveToCassandra("ml_training_keyspace", "raw_training_data") val model = new StreamingLinearRegressionWithSGD() .setInitialWeights(Vectors.dense(weights)) .trainOn(trainingStream) model .predictOnValues(testData.map(lp => (lp.label, lp.features))) .saveToCassandra("ml_predictions_keyspace", "predictions")

Page 39: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

What's Missing? One Pipeline For Fast +Big Data

Page 40: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Using Cassandra for Batch Analytics /Event Storage / ML?

Storage ef�ciency and scan speeds for reading large volumesof data (for complex analytics, ML) become importantconcernsRegular Cassandra CQL tables are not very good at eitherstorage ef�ciency or scan speedsA different, analytics-optimized solution is needed...

Page 41: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

All hard work leads to pro�t, but mere talk leadsto poverty.- Proverbs 14:23

Page 42: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Introducing FiloDBA distributed, versioned, columnar analytics database.

Built for Streaming.

 

github.com/tuplejump/FiloDB

Page 43: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Fast Analytics StorageScan speeds competitive with Apache Parquet

Up to 200x faster scan speeds than with Cassandra 2.xFlexible �ltering along two dimensions

Much more ef�cient and �exible partition key �lteringEf�cient columnar storage, up to 40x more ef�cient thanCassandra 2.x

Page 44: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Comparing Storage Costs and Query Speeds

https://www.oreilly.com/ideas/apache-cassandra-for-analytics-a-performance-and-storage-analysis

Page 45: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Robust Distributed StorageApache Cassandra as the rock-solid storage engine. Scale outwith no SPOF. Cross-datacenter replication. Proven storage anddatabase technology.

Page 46: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

 

Cassandra-Like Data ModelColumn A Column B

Partitionkey 1

Segment1

Segment2

Segment1

Segment2

Partitionkey 2

Segment1

Segment2

Segment1

Segment2

partition keys - distributes data around a cluster, and allowsfor �ne grained and �exible �lteringsegment keys - do range scans within a partition, e.g. by timesliceprimary key based ingestion and updates

Page 47: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Flexible FilteringUnlike Cassandra, FiloDB offers very �exible and ef�cient�ltering on partition keys. Partial key matches, fast IN queries onany part of the partition key.

No need to write multiple tables to work around answering differentqueries.

Page 48: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Spark SQL Queries!CREATE TABLE gdelt USING filodb.spark OPTIONS (dataset "gdelt"); SELECT Actor1Name, Actor2Name, AvgTone FROM gdelt ORDER BY AvgTone DESC LIMIT 15 INSERT INTO gdelt SELECT * FROM NewMonthData;

Read to and write from Spark DataframesAppend/merge to FiloDB table from SparkStreamingUse Tableau or any other JDBC tool

Page 49: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

What's in the name?

Rich sweet layers of distributed, versioned database goodness

Page 50: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

SNACK (SMACK) stack for all yourAnalytics

Regular Cassandra tables for highly concurrent, aggregate /key-value lookups (dashboards)FiloDB + C* + Spark for ef�cient long term event storage

Ad hoc / SQL / BIData source for MLLib / building modelsData storage for classi�ed / predicted / scored data

Page 51: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis
Page 52: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Being Productionized as we speak...One enterprise with many TB of �nancial and reporting data ismoving their data warehouse to FiloDB + Cassandra + SparkAnother startup uses FiloDB as event storage, feeds the eventsinto Spark MLlib, scores incoming data, then stores the resultsback in FiloDB for low-latency use cases

From their CTO: “I see close to MemSQL / Vertica or evenbetter” “More cost effective than Redshift”

Page 53: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

FiloDB Use CasesData Warehousing / BI

< 10 second SLA, nontrivial reports, some concurrencyneed to store and query lots of data ef�ciently

Time seriesidempotent write API, simultaneous write and readworkloads

In-memory SQL web server700 queries per second using in-memory column store

Page 54: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

FiloDB vs HDFS/ParquetFiloDB Parquet

Ingestion Idempotent primary-keybased; appends andreplaces; deletes coming

File-basedappendAPI only

Filtering Partition-key and segment-key �ltering

Mostly�le-based

Scanspeeds

Parquet-like Good forOLAP

Storagecost

Within 35% of Parquet  

Page 55: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

FiloDB vs HDFS/ParquetIn practice, with good data modeling, FiloDB is a far better �t forlow-latency / concurrent BI / reporting / dashboard applications.

Page 56: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

FiloDB vs DruidDifferent use cases:

Druid is optimized mostly for OLAP cube / slice and diceanalysis. Append only, keeps only aggregates, not a raw eventstore.FiloDB stores raw data - can be used to build ML models,visualize and analyze raw time series data, do complex event�ow analysis - much more �exibleFiloDB can update/replace dataFiloDB does not require data denormalization - can handletraditional BI star schemas with slowly changing dimensiontables

Page 57: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Come check out the demo!

Visit FiloDB at the Developer Showcase (Expo hall) today!

Page 58: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Machine Learning with Spark, Cassandra,and FiloDB

Page 59: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Building a static model of NYC Taxi TripsPredict time to get to destination based on pickup point, timeof day, other varsNeed to read all data (full table scan)

Page 60: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Dynamic models are better than staticmodels

Everything changes!Continuously re�ne model based on recent streaming data +historical data + existing model

Page 61: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

val ssc = new StreamingContext(sparkConf, Seconds(5)) val dataStream = KafkaUtils.createDirectStream[..](..) .map(transformFunc) .map(LabeledPoint.parse) dataStream.foreachRDD(_.toDF.write.format("filodb.spark") .option("dataset", "training").save()) if (trainNow) { var model = new StreamingLinearRegressionWithSGD() .setInitialWeights(Vectors.dense(weights)) .trainOn(dataStream.join(historicalEvents)) } model.predictOnValues(dataStream.map(lp => (lp.label, lp.features))) .insertIntoFilo("predictions")

Page 62: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis
Page 63: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

The FiloDB Advantage for MLAble to update dynamic models based on massive data�ow/updates

Integrate historical and recent events to build modelsMore data -> better models!Can store scored raw data / predictions back in FiloDB

for fast user queries

Page 64: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

FiloDB - RoadmapYour input is appreciated!

Productionization and automated stress testingKafka input API / connector (without needing Spark)In-memory caching for signi�cant query speedupTrue columnar querying and execution, using latematerialization and vectorization techniques. GPU/SIMD.Projections. Often-repeated queries can be sped upsigni�cantly with projections.

Page 65: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Thanks For Attending!@helenaedelson@evanfchan@tuplejump

Page 66: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

EXTRA SLIDES

Page 67: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

What are my storage needs?Non-persistent / in-memory: concurrentviewersShort term: latest trendsLonger term: raw event and aggregate storageML Models, predictions, scored data

Page 68: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Spark RDDsImmutable, cache in memory and/or ondiskSpark Streaming: UpdateStateByKeyIndexedRDD - can update bits of dataSnapshotting for recovery

Page 69: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Using Cassandra for Short Term Storage1020s 1010s 1000s

Bus A Speed, GPS

Bus B

Bus CPrimary key = (Bus UUID, timestamp)Easy queries: location and speed of single bus for a range oftimeCan also query most recent location + speed of all buses(slower)

Page 70: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Data Warehousing with FiloDB

Page 71: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

ScenariosBI Reporting, concurrency + seconds latencyAd-hoc queriesNeeding to do JOINs with fact tables + dimensiontables

Slowly changing dim tables / hard to denormalizeNeed to work with legacy BI tools

Page 72: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Real-world DW Architecture Stack

Ef�cient columnar storage + �ltering = low latency BI

Page 73: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Modeling Fact Tables for FiloDBSingle partition queries are really fast and take up only onethread

Given the following two partition key columns:entity_number, year_monthWHERE entity_number = '0453' ANDyear_month = '2014 December'

Exact match for partition key is pushed down as onepartition

Consider the partition key carefully

Page 74: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Cassandra often requires multiple tablesWhat about the queries that do not translate to one partition?Cassandra has many restrictions on partition key �ltering (as of2.x).

Table 1: partition key = (entity_number, year_month)Can push down: WHERE entity_number = NN ANDyear_month IN ('2014 Jan', '2014 Feb') aswell as equals

Table 2: partition key = (year_month, entity_number)Can push down: WHERE year_month = YYMM ANDentity_number IN (123, 456) as well as equals

IN clause must be the last column to be pushed down. Two tablesare needed just for ef�cient IN queries on either entity_numberor year_month.

Page 75: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

FiloDB Flexible Partition Filters = WINWith ONE table, FiloDB offers FAST, arbitrary partition key�ltering. All of the below are pushed down:

WHERE year_month IN ('2014 Jan', '2014 Feb')(all entities)WHERE entity_number = 146 (all year months)Any combo of =, IN

Space savings: 27 * 2 = 54x

Page 76: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Multi-Table JOINs with just Cassandra

Page 77: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Sub-second Multi-Table JOINs with FiloDB

Page 78: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Sub-second Multi-Table JOINs with FiloDBFour tables, all of them single-partition queriesTwo tables were switched from regular Cassandra tables toFiloDB tables. 40-60 columns each, ~60k items in partition.Scan times went down from 5-6 seconds to < 250ms

For more details, please see this .Planet Cassandra blog post

Page 79: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Scalable Time-Series / Event Storage withFiloDB

Page 80: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Designed for StreamingNew rows appended via Spark Streaming or KafkaWrites are idempotent - easy exactly once ingestionConverted to columnar chunks on ingest and stored inC*FiloDB keeps your data sorted as it is being ingested

Page 81: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Spark Streaming -> FiloDB val ratingsStream = KafkaUtils.createDirectStream[String, String, StringDecoder, StringDecoder](ssc, kafkaParams, topics) ratingsStream.foreachRDD { (message: RDD[(String, String)], batchTime: Time) => { val df = message.map(_._2.split(",")).map(rating => Rating(rating(0).trim.toInt, rating( toDF("fromuserid", "touserid", "rating") // add the batch time to the DataFrame val dfWithBatchTime = df.withColumn("batch_time", org.apache.spark.sql.functions.lit(batchTime.milliseconds)) // save the DataFrame to FiloDB dfWithBatchTime.write.format("filodb.spark") .option("dataset", "ratings") .save() } }

One-line change to write to FiloDB vs Cassandra

Page 82: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Modeling example: NYC Taxi DatasetThe public contains telemetry (pickup, dropofflocations, times) info on millions of taxi rides in NYC.

NYC Taxi Dataset

Medallion pre�x 1/1 - 1/6 1/7 - 1/12AA records records

AB records recordsPartition key - :stringPrefix medallion 2 - hashmultiple drivers trips into ~300 partitionsSegment key - :timeslice pickup_datetime 6dRow key - hack_license, pickup_datetime

Allows for easy �ltering by individual drivers, and slicing by time.

Page 83: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

DEMO TIMENew York City Taxi Data Demo (Spark Notebook)

To follow along:https://github.com/tuplejump/FiloDB/blob/master/doc/FiloDB_Taxi_Geo_demo.snb

Page 84: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Fast, Updatable In-MemoryColumnar Storage

Unlike RDDs and DataFrames, FiloDB can ingest new data, andstill be fastUnlike RDDs, FiloDB can �lter in multiple ways, no need forentire table scanFAIR scheduler + sub-second latencies => web speed queries

Page 85: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

700 Queries Per Second in Apache Spark!Even for datasets with 15 million rows!Using FiloDB's InMemoryColumnStore, single host / MBP,5GB RAMSQL to DataFrame caching

For more details, see .this blog post

Page 86: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

FiloDB - How?

Page 87: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Multiple ways to Accelerate QueriesColumnar projection - read fewer columns, saves I/OPartition key �ltering - read less dataSort key / PK �ltering - read from subset of keys

Possible because FiloDB keeps data sortedVersioning - write to multiple versions, read from the one youchoose

Page 88: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

Cassandra CQL vs Columnar LayoutCassandra stores CQL tables row-major, each row spans multiplecells:

PartitionKey 01:�rst 01:last 01:age 02:�rst 02:last 02:ageSales Bob Jones 34 Susan O'Connor 40

Engineering Dilbert P ? Dogbert Dog 1 

Columnar layouts are column-major:

PartitionKey �rst last ageSales Bob, Susan Jones,

O'Connor34,40

Engineering Dilbert,Dogbert

P, Dog ?, 1

Page 89: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

FiloDB Cassandra SchemaCREATE TABLE filodb.gdelt_chunks ( partition text, version int, columnname text, segmentid blob, chunkid int, data blob, PRIMARY KEY ((partition, version), columnname, segmentid, chunkid) ) WITH CLUSTERING ORDER BY (columnname ASC, segmentid ASC, chunkid ASC)

Page 90: NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis

FiloDB Architecture

ColumnStore API - currently Cassandra and InMemory, you canimplement other backends - ElasticSearch? etc.


Recommended