SlideShare a Scribd company logo
1 of 68
Download to read offline
1
Building Reactive Distributed Systems
For Streaming Big Data, Analytics & ML
Helena Edelson @helenaedelson Reactive Summit 2016
@helenaedelson #reactivesummit
Distributed Systems & Big Data Platform
Engineer, Event-Driven systems, Streaming
Analytics, Machine Learning, Scala
Committer: FiloDB, Spark Cassandra Connector,
Kafka Connect Cassandra
Contributor: Akka (Akka Cluster), prev: Spring
Integration
Speaker: Reactive Summit, Kafka Summit, Spark
Summit, Strata, QCon, Scala Days, Philly ETE
2
I play with big data
twitter.com/helenaedelson
slideshare.net/helenaedelson
linkedin.com/in/helenaedelson
github.com/helena
and think about FT
@helenaedelson #reactivesummit
If you’re here you’ve taken the red pill
@helenaedelson #reactivesummit
It’s Not Easy Being…
Globally Distributed
Eventually Consistent
Highly Available
While handling TBs of data
Self Healing
Fast
4
@helenaedelson #reactivesummit
Massive event spikes & bursty traffic
Fast producers / slow consumers
Network partitioning & out of sync systems
DC down
Failure before commit
DDOS'ing yourself - no backpressure
Lack of graceful lifecycle handling, i.e. data loss
when auto-scaling down
5
@helenaedelson #reactivesummit
Beware the C word
Consistency?
6
Convergence?
@helenaedelson #reactivesummit 7
Complexity, or…
@helenaedelson #reactivesummit 8
http://www.slideshare.net/palvaro/ricon-keynote-outwards-from-the-middle-of-the-maze/42
The Real Topic
^Other
@helenaedelson #reactivesummit
“Everything fails, all the time”
Start with this premise
Build failure, chaos routing
and intelligence into your
platform infrastructure
Be fault proactive vs just
reactive
9
- Werner Vogels
@helenaedelson #reactivesummit 10
The matrix is everywhere…
It is a world where humans
vs machines need to be
directly involved in health of
systems, respond to alerts…
@helenaedelson #reactivesummit 11
Log analysis tools like
Splunk perpetuate this
illusion…
@helenaedelson #reactivesummit 12
Self Healing, Intelligent Platforms
@helenaedelson #reactivesummit 13
Self Healing, Intelligent Platforms
Imagine a world
where engineers designed software
while the machines did triage, failure analysis and
took action to correct failures
and learned from it…
@helenaedelson #reactivesummit 14
Alerting and Failure Response
The New Boilerplate
@helenaedelson #reactivesummit
Building Systems That Learn
You have systems receiving, processing & collecting data. They can provide insight into
trends, patterns, and when they start failing, your monitoring triggers alerts to humans.
Alternative
1. Automatically route data only to nodes that can process it.
2. Automatically route failure contexts to event streams with ML algorithms to learn:
What is normal?
What is an anomaly?
When these anomalies occur, what are they indicative of?
3. Automate proactive actions when those anomalies bubble up to a fault-aware layer.
15
@helenaedelson #reactivesummit
Define Failures vs Error Fault
Tolerance Pathways & Routing
Failures - more network related, connectivity, …
Errors - application errors, user input from REST
requests, config load-time errors…
Escape Loops and Feedback system
Built-in failure detection
@helenaedelson #reactivesummit 17
I want to keep all my apps
healthy, handle errors with a
similar strategies, and failures with
a similar strategy…
…and share that data across
datacenters with my multi-dc
aware kernel to build smarter,
automated systems.
@helenaedelson #reactivesummit 18
In A Nutshell
Event
Stream
Petabytes Multi-DC
Aware Mgmt
Kernel
Clustered
Apps
Clustered
Apps
Clustered
AppsClustered
Apps
Clustered
Apps
Clustered
Apps
Clustered
Apps
Clustered
Apps
@helenaedelson #reactivesummit 19
In A Nutshell
Multi-DC
Aware Mgmt
Kernel
Clustered
Apps
Clustered
Apps
Clustered
AppsClustered
Apps
Clustered
Apps
Clustered
Apps
Clustered
Apps
Clustered
Apps
Danger
Sauce
Event
Stream
Petabytes
@helenaedelson #reactivesummit
Multi-DC
Aware Mgmt
Kernel
20
X-DC-Aware Kernel
Clustered
Apps
Clustered
Apps
Clustered
AppsClustered
Apps
Clustered
Apps
Clustered
Apps
Clustered
Apps
Clustered
Apps
Event
Stream
Petabytes
Danger
Sauce
@helenaedelson #reactivesummit 21
I want to
route failure context
(when a node is alive
enough to talk)
to my.failures.fu Kafka topic for
my X-DC kernel to process through
my ML streams
to learn about usage,
traffic, memory patterns and
anomalies, to anticipate failures,
intercept and correct
Without Human Intervention
@helenaedelson #reactivesummit 22
Akka Cluster it. The cluster knows
the node is down. Many options/
mechanisms to send/publish failure
metadata to learning streams.
If it’s a network failure and my node can’t
report to the kernel?
Bring it
@helenaedelson #reactivesummit 23
I think I’ll start with a
base cluster-aware Akka Extension for
my platform.
Any non-JVM apps can share data
with these via Kafka, ZeroMQ,
Cassandra…
Sew easy.
Might sneak it in without a
PR.
@helenaedelson #reactivesummit 24
Then I can bake my fault tolerance
strategy & route awareness in every
app & node.
And make it know when to use
Kafka and when to use Akka for
communication.
@helenaedelson #reactivesummit 25
And all logic and flows for graceful handling of
node lifecycle are baked in to the framework too.
Dude, that’s tight.
Graceful Lifecycle
@helenaedelson #reactivesummit
Akka Cluster
Node-aware cluster membership
Gossip protocol
Status of all member nodes in the ring
Tunable, automatic failure detection
No single point of failure or bottleneck
A level of composability above Actors & Actor
Hierarchy
26
@helenaedelson #reactivesummit 27
Akka Cluster has tunable Gossip.I
can partition segments of my node ring
by role, and route data by role or
broadcast.
Tunable Gossip
@helenaedelson #reactivesummit 28
Akka Cluster has
AdaptiveLoadBalancing logic.
I can route events away from nodes in trouble and
directed to healthier nodes. Many options, highly
configurable, good granularity.
AdaptiveLoadBalancing*
Router
Cluster Metrics API
@helenaedelson #reactivesummit 29
Dynamically Route by Node Health
Cluster Metrics API & AdaptiveLBR
Leader
Let’s pummel my cluster
with critical data !
@helenaedelson #reactivesummit 30
Dynamically Route by Node Health
Cluster Metrics API & AdaptiveLBR
Oh look,
slow consumers or something in GC
thrash…
Leader
Uses EWMA algo to weight decay of health data
@helenaedelson #reactivesummit 31
Dynamically Route by Node Health
Cluster Metrics API & AdaptiveLBR
Leader
The
Cluster leader ‘knew’ the red
node was nearing capacity & routed my
traffic to healthy nodes.
@helenaedelson #reactivesummit
Reactive - Proactive
32
@helenaedelson #reactivesummit
Proactive - Parallelized
Akka Cluster on nodes
Cluster LB routers
Node router Actors
Kafka replication & routing
across datacenters
33
@helenaedelson #reactivesummit 34
@helenaedelson #reactivesummit 35
I drank the cool aid,
put on the costume,
now what…
@helenaedelson #reactivesummit 36
Embrace Uncertainty
@helenaedelson #reactivesummit
So many opportunities for
failure in this statement
Eventually Consistent Across DCs
37
@helenaedelson #reactivesummit 38
there is no now…
Embrace Asynchrony & Location Transparency
…or where
@helenaedelson #reactivesummit
There Is No Now
39
US-East-1
MirrorMaker
EU-west-1
ZK
ZK
Akka
micro
services
Akka
micro
services
Akka
micro
services
FiloDB Cassandra
Akka
micro
services
Akka
micro
services
Akka
micro
services
Spark
Compute Clusters
Analytics/Timeseries/ML Storage Storage Clusters
S3/
Cold
Raw Event Stream
Event Stream
DC-1
DC-2
Akka Cluster-ed
apps, partitioned
by Role=service Raw Event Replay
Flink
Backpressure
@helenaedelson #reactivesummit 40
US-East-1
MirrorMaker
EU-west-1
ZK
ZK
Akka
micro
services
Akka
micro
services
Akka
micro
services
FiloDB Cassandra
Akka
micro
services
Akka
micro
services
Akka
micro
services
Spark
Compute Clusters
Analytics/Timeseries/ML Storage Storage Clusters
S3/
Cold
Raw Event Stream
Raw Event Replay
Event Stream
But I Can Replay Future[Then]
DC-1
DC-2
Akka Cluster-ed
apps, partitioned
by Role=service
Backpressure
@helenaedelson #reactivesummit
Replaying Data from Time (T)
General time - We updated some compute
algorithms which run on raw and aggregated
data. I need to replay some datasets against the
updated algos
Specific time - A node crashed or there was a
network partitioning event and we lost data
from T1 to T2. I need to replay from T1 to T2
without having to de-dupe data
41
@helenaedelson #reactivesummit
Cassandra Bakes Clustered
Ordering Into Data Model
CREATE TABLE timeseries_t (
id text,
year int,
month int,
day int,
hour int,
PRIMARY KEY ((wsid), year, month, day, hour)
) WITH CLUSTERING ORDER BY (year DESC, month DESC, day DESC,
hour DESC);
42
Now the read path queries automatically return sorted by most
recent. No sorts to do or ordering in your code.
Can also easily bucket in cold storage for faster reads.
@helenaedelson #reactivesummit 43
US-East-1
MirrorMaker
EU-west-1
ZK
ZK
Compute Clusters
Event Stream
Build Apps Not Clusters?
App clusters
vs
Infra clusters
Actors &
Kafka Streams
Actors &
Kafka Streams
Actors &
Kafka Streams
Event Stream
Event Stream
@helenaedelson #reactivesummit
Kafka Streams Key Features
Secure stream processing using Kafka security
Elastic and highly scalable
Fault-tolerant
Stateful and stateless computations
44
@helenaedelson #reactivesummit
Kafka Streams Key Features
Interactive queries
Time Model & Windowing
Supports late-arriving and out-of-order data
Millisecond processing latency
At-least-once processing guarantees
exactly-once is in progress :)
45
@helenaedelson #reactivesummit
val builder = new KStreamBuilder()

// Consume from topic x in the stream, from any or one DC
val kstream: KStream[K,V] = builder.stream(des, des, “fu.input.topic")
// Do some analytics computations
// Publish to subscribers in all DCs in the stream
kstream.to(“serviceA.questionB.aggregC.topic”, …)
// Start the stream
val streams = new KafkaStreams(builder, props)
streams.start()
// Do some more work then close the stream
streams.close()
Kafka Streams: KStream
46
@helenaedelson #reactivesummit 47
Kafka Streams: KTable
val locations: KTable[UserId, Location] = builder.table(“user-locations-topic”)
val userPrefs: KTable[UserId, Prefs] = builder.table(“user-preferences-topic”)
// Join detailed info from 2 streams as events stream in
val userProfiles: KTable[UserId, UserProfile] =

locations.join(userPrefs, (loc, prefs) -> new UserProfile(loc, prefs))
// Compute statistics
val usersPerRegion: KTable[UserId, Long] = userProfiles
.filter((userId, profile) -> profile.age < 30)
.groupBy((userId, profile) -> profile.location)
.count()
@helenaedelson #reactivesummit
val streams = new KafkaStreams(builder, props)
streams.start()
// Called when a stream thread abruptly terminates
// due to an uncaught exception.
streams.setUncaughtExceptionHandler(myErrorHandler)
Kafka Streams DSL Basics
48
@helenaedelson #reactivesummit 49
Integrating Intelligence
For Fast Data and Feedback Loops
@helenaedelson #reactivesummit
Translation Layer
50
US-East-1
MirrorMaker
EU-west-1
PubSub
Apps
PubSub
Apps
PubSub
Apps
Compute Clusters
Event Stream
DC-1
Raw Data
Cassandra
Spark SQL
Spark MLLib
Spark
Streaming
Kafka
@helenaedelson #reactivesummit
Translation Layer
51
US-East-1
MirrorMaker
EU-west-1
PubSub
Apps
PubSub
Apps
PubSub
Apps
Compute Clusters
Event Stream
DC-1
Raw Data
Cassandra
To Columnar Format
Reads chunks,
translates to spark
rows
Spark MLLib
Spark SQL
Spark
Streaming
Kafka
FiloDB
@helenaedelson #reactivesummit
Translation Layer
52
US-East-1
MirrorMaker
EU-west-1
PubSub
Apps
PubSub
Apps
PubSub
Apps
Compute Clusters
Event Stream
DC-1
Raw Data
Cassandra
To Columnar Format
Reads chunks,
translates to spark
rows
Spark MLLib
Spark SQL
Spark
Streaming
Kafka
FiloDB
Faster
Ad Hoc
Querying
Faster
ML
Feedback
Instead of slowing things
down, it makes it faster.
@helenaedelson #reactivesummit 53
Your Akka Cluster got in my
Reactive Distributed Analytics
Database!
Walking with a jar of PB as one does…
@helenaedelson #reactivesummit
FiloDB: Reactive
Scala & SBT
Spark (also written in scala)
Akka actors & Akka Cluster for Coordinators
Futures for IO
Typesafe Config
54
@helenaedelson #reactivesummit
import filodb.spark._
KafkaUtils.createDirectStream[..](..)
.map(_._2)
.map(FuEvent(_))
.foreachRDD { rdd =>
sql.insertIntoFilo(rdd.toDF, “fu_events”, database = Some(“org1Keyspace”))}
55
FiloDB API:
Append only, to existing dataset
Write: Kafka, Spark Streaming,
Spark SQL & FiloDB
@helenaedelson #reactivesummit
Read: FiloDB & Spark SQL
56
import filodb.spark._
val df1 = sqlContext.read.format(“filodb.spark”)
.option(“dataset”, “aggrTable”)
.load()
val df2 = sqlContext.filoDataset(“aggrTable”, database = Some(“ks2”))
More typesafe than the
dataframe read (df1)
@helenaedelson #reactivesummit 57
Determine
Train the
model
Train on historic data
Score
Based on Objectives
Proactive
Responses
React in real time
Machine Learning
@helenaedelson #reactivesummit
What do I want to predict & what can I learn from the data?
Which attributes in datasets are valuable predictors?
Which algorithms will best uncover valuable patterns?
58
Optimization &
Predictive Models
@helenaedelson #reactivesummit 59
I need fast ML feedback loops,
what tools should I pick?
Depends…
@helenaedelson #reactivesummit
Read from stored training data
into MLLib
60
import org.apache.spark.mllib.stat.Statistics
import filodb.spark._
val df = sqlContext.filoDataset(“table”, database = Some(“ks”))
val seriesX = df.select(“NumX”).map(_.getInt(0).toDouble)
val seriesY = df.select(“NumY”).map(_.getInt(0).toDouble)
val correlation: Double = Statistics.corr(seriesX, seriesY, “pearson”)
Calculate correlation between multiple series of data
@helenaedelson #reactivesummit
Read from the stream to MLLib
& store for later work in FiloDB
61
val stream = KafkaUtils.createDirectStream[..](..)
.map(transformFunc)
.map(LabeledPoint.parse)
val trainingData = sqlContext.filoDataset(“trainings_fu")
val model = new StreamingLinearRegressionWithSGD()
.setInitialWeights(Vectors.dense(weights))
.setStepSize(0.2).setNumIterations(25)
.trainOn(trainingData)
model
.predictOnValues(stream.map(lp => (lp.label, lp.features)))
.insertIntoFilo(“predictions_fu")
@helenaedelson #reactivesummit 62
Parting Thoughts
@helenaedelson #reactivesummit
Don’t take when someone says X
doesn’t work at face value.
It may not have been the right choice
for their use case
They may not have configured/
deployed/wrote code for it properly for
their load
All technologies are optimized for
a set of things vs every thing
Invest in R&D
63
Cultivate Skepticism
@helenaedelson #reactivesummit
Modular
does one thing
Decoupled
knows one thing
Reusable & Extendable
when not final or
private for a reason
64
Keep Everything Separate
@helenaedelson #reactivesummit 65
Did you just duplicate codez?
@helenaedelson #reactivesummit 66
Versus duplicating, with disparate
strategies, all over your teams & orgs
Build A Reactive / Proactive Failure & Chaos
Intelligence System for platform infrastructure
@helenaedelson #reactivesummit
Byzantine Fault Tolerance?
67
Looks
like I'll miss
standup
@helenaedelson #reactivesummit
twitter.com/helenaedelson
slideshare.net/helenaedelson
github.com/helena
Thanks!

More Related Content

What's hot

SMACK Stack - Fast Data Done Right by Stefan Siprell at Codemotion Dubai
SMACK Stack - Fast Data Done Right by Stefan Siprell at Codemotion DubaiSMACK Stack - Fast Data Done Right by Stefan Siprell at Codemotion Dubai
SMACK Stack - Fast Data Done Right by Stefan Siprell at Codemotion DubaiCodemotion Dubai
 
Fast and Simplified Streaming, Ad-Hoc and Batch Analytics with FiloDB and Spa...
Fast and Simplified Streaming, Ad-Hoc and Batch Analytics with FiloDB and Spa...Fast and Simplified Streaming, Ad-Hoc and Batch Analytics with FiloDB and Spa...
Fast and Simplified Streaming, Ad-Hoc and Batch Analytics with FiloDB and Spa...Helena Edelson
 
Moving from Big Data to Fast Data? Here's How To Pick The Right Streaming Engine
Moving from Big Data to Fast Data? Here's How To Pick The Right Streaming EngineMoving from Big Data to Fast Data? Here's How To Pick The Right Streaming Engine
Moving from Big Data to Fast Data? Here's How To Pick The Right Streaming EngineLightbend
 
Using Spark, Kafka, Cassandra and Akka on Mesos for Real-Time Personalization
Using Spark, Kafka, Cassandra and Akka on Mesos for Real-Time PersonalizationUsing Spark, Kafka, Cassandra and Akka on Mesos for Real-Time Personalization
Using Spark, Kafka, Cassandra and Akka on Mesos for Real-Time PersonalizationPatrick Di Loreto
 
Akka at Enterprise Scale: Performance Tuning Distributed Applications
Akka at Enterprise Scale: Performance Tuning Distributed ApplicationsAkka at Enterprise Scale: Performance Tuning Distributed Applications
Akka at Enterprise Scale: Performance Tuning Distributed ApplicationsLightbend
 
How Credit Karma Makes Real-Time Decisions For 60 Million Users With Akka Str...
How Credit Karma Makes Real-Time Decisions For 60 Million Users With Akka Str...How Credit Karma Makes Real-Time Decisions For 60 Million Users With Akka Str...
How Credit Karma Makes Real-Time Decisions For 60 Million Users With Akka Str...Lightbend
 
Reactive Stream Processing with Mantis
Reactive Stream Processing with MantisReactive Stream Processing with Mantis
Reactive Stream Processing with MantisNick Mahilani
 
Real-time personal trainer on the SMACK stack
Real-time personal trainer on the SMACK stackReal-time personal trainer on the SMACK stack
Real-time personal trainer on the SMACK stackAnirvan Chakraborty
 
Reactive app using actor model & apache spark
Reactive app using actor model & apache sparkReactive app using actor model & apache spark
Reactive app using actor model & apache sparkRahul Kumar
 
NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis
NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch AnalysisNoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis
NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch AnalysisHelena Edelson
 
Streaming Big Data with Spark, Kafka, Cassandra, Akka & Scala (from webinar)
Streaming Big Data with Spark, Kafka, Cassandra, Akka & Scala (from webinar)Streaming Big Data with Spark, Kafka, Cassandra, Akka & Scala (from webinar)
Streaming Big Data with Spark, Kafka, Cassandra, Akka & Scala (from webinar)Helena Edelson
 
Spark Kernel Talk - Apache Spark Meetup San Francisco (July 2015)
Spark Kernel Talk - Apache Spark Meetup San Francisco (July 2015)Spark Kernel Talk - Apache Spark Meetup San Francisco (July 2015)
Spark Kernel Talk - Apache Spark Meetup San Francisco (July 2015)Robert "Chip" Senkbeil
 
Near Real Time Indexing Kafka Messages into Apache Blur: Presented by Dibyend...
Near Real Time Indexing Kafka Messages into Apache Blur: Presented by Dibyend...Near Real Time Indexing Kafka Messages into Apache Blur: Presented by Dibyend...
Near Real Time Indexing Kafka Messages into Apache Blur: Presented by Dibyend...Lucidworks
 
Being Ready for Apache Kafka - Apache: Big Data Europe 2015
Being Ready for Apache Kafka - Apache: Big Data Europe 2015Being Ready for Apache Kafka - Apache: Big Data Europe 2015
Being Ready for Apache Kafka - Apache: Big Data Europe 2015Michael Noll
 
Building Realtime Data Pipelines with Kafka Connect and Spark Streaming by Ew...
Building Realtime Data Pipelines with Kafka Connect and Spark Streaming by Ew...Building Realtime Data Pipelines with Kafka Connect and Spark Streaming by Ew...
Building Realtime Data Pipelines with Kafka Connect and Spark Streaming by Ew...Spark Summit
 
Delivering Meaning In Near-Real Time At High Velocity In Massive Scale with A...
Delivering Meaning In Near-Real Time At High Velocity In Massive Scale with A...Delivering Meaning In Near-Real Time At High Velocity In Massive Scale with A...
Delivering Meaning In Near-Real Time At High Velocity In Massive Scale with A...Helena Edelson
 
Real-Time Anomaly Detection with Spark MLlib, Akka and Cassandra
Real-Time Anomaly Detection  with Spark MLlib, Akka and  CassandraReal-Time Anomaly Detection  with Spark MLlib, Akka and  Cassandra
Real-Time Anomaly Detection with Spark MLlib, Akka and CassandraNatalino Busa
 
Streaming Microservices With Akka Streams And Kafka Streams
Streaming Microservices With Akka Streams And Kafka StreamsStreaming Microservices With Akka Streams And Kafka Streams
Streaming Microservices With Akka Streams And Kafka StreamsLightbend
 
Real Time Data Processing Using Spark Streaming
Real Time Data Processing Using Spark StreamingReal Time Data Processing Using Spark Streaming
Real Time Data Processing Using Spark StreamingHari Shreedharan
 
Lightbend Fast Data Platform
Lightbend Fast Data PlatformLightbend Fast Data Platform
Lightbend Fast Data PlatformLightbend
 

What's hot (20)

SMACK Stack - Fast Data Done Right by Stefan Siprell at Codemotion Dubai
SMACK Stack - Fast Data Done Right by Stefan Siprell at Codemotion DubaiSMACK Stack - Fast Data Done Right by Stefan Siprell at Codemotion Dubai
SMACK Stack - Fast Data Done Right by Stefan Siprell at Codemotion Dubai
 
Fast and Simplified Streaming, Ad-Hoc and Batch Analytics with FiloDB and Spa...
Fast and Simplified Streaming, Ad-Hoc and Batch Analytics with FiloDB and Spa...Fast and Simplified Streaming, Ad-Hoc and Batch Analytics with FiloDB and Spa...
Fast and Simplified Streaming, Ad-Hoc and Batch Analytics with FiloDB and Spa...
 
Moving from Big Data to Fast Data? Here's How To Pick The Right Streaming Engine
Moving from Big Data to Fast Data? Here's How To Pick The Right Streaming EngineMoving from Big Data to Fast Data? Here's How To Pick The Right Streaming Engine
Moving from Big Data to Fast Data? Here's How To Pick The Right Streaming Engine
 
Using Spark, Kafka, Cassandra and Akka on Mesos for Real-Time Personalization
Using Spark, Kafka, Cassandra and Akka on Mesos for Real-Time PersonalizationUsing Spark, Kafka, Cassandra and Akka on Mesos for Real-Time Personalization
Using Spark, Kafka, Cassandra and Akka on Mesos for Real-Time Personalization
 
Akka at Enterprise Scale: Performance Tuning Distributed Applications
Akka at Enterprise Scale: Performance Tuning Distributed ApplicationsAkka at Enterprise Scale: Performance Tuning Distributed Applications
Akka at Enterprise Scale: Performance Tuning Distributed Applications
 
How Credit Karma Makes Real-Time Decisions For 60 Million Users With Akka Str...
How Credit Karma Makes Real-Time Decisions For 60 Million Users With Akka Str...How Credit Karma Makes Real-Time Decisions For 60 Million Users With Akka Str...
How Credit Karma Makes Real-Time Decisions For 60 Million Users With Akka Str...
 
Reactive Stream Processing with Mantis
Reactive Stream Processing with MantisReactive Stream Processing with Mantis
Reactive Stream Processing with Mantis
 
Real-time personal trainer on the SMACK stack
Real-time personal trainer on the SMACK stackReal-time personal trainer on the SMACK stack
Real-time personal trainer on the SMACK stack
 
Reactive app using actor model & apache spark
Reactive app using actor model & apache sparkReactive app using actor model & apache spark
Reactive app using actor model & apache spark
 
NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis
NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch AnalysisNoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis
NoLambda: Combining Streaming, Ad-Hoc, Machine Learning and Batch Analysis
 
Streaming Big Data with Spark, Kafka, Cassandra, Akka & Scala (from webinar)
Streaming Big Data with Spark, Kafka, Cassandra, Akka & Scala (from webinar)Streaming Big Data with Spark, Kafka, Cassandra, Akka & Scala (from webinar)
Streaming Big Data with Spark, Kafka, Cassandra, Akka & Scala (from webinar)
 
Spark Kernel Talk - Apache Spark Meetup San Francisco (July 2015)
Spark Kernel Talk - Apache Spark Meetup San Francisco (July 2015)Spark Kernel Talk - Apache Spark Meetup San Francisco (July 2015)
Spark Kernel Talk - Apache Spark Meetup San Francisco (July 2015)
 
Near Real Time Indexing Kafka Messages into Apache Blur: Presented by Dibyend...
Near Real Time Indexing Kafka Messages into Apache Blur: Presented by Dibyend...Near Real Time Indexing Kafka Messages into Apache Blur: Presented by Dibyend...
Near Real Time Indexing Kafka Messages into Apache Blur: Presented by Dibyend...
 
Being Ready for Apache Kafka - Apache: Big Data Europe 2015
Being Ready for Apache Kafka - Apache: Big Data Europe 2015Being Ready for Apache Kafka - Apache: Big Data Europe 2015
Being Ready for Apache Kafka - Apache: Big Data Europe 2015
 
Building Realtime Data Pipelines with Kafka Connect and Spark Streaming by Ew...
Building Realtime Data Pipelines with Kafka Connect and Spark Streaming by Ew...Building Realtime Data Pipelines with Kafka Connect and Spark Streaming by Ew...
Building Realtime Data Pipelines with Kafka Connect and Spark Streaming by Ew...
 
Delivering Meaning In Near-Real Time At High Velocity In Massive Scale with A...
Delivering Meaning In Near-Real Time At High Velocity In Massive Scale with A...Delivering Meaning In Near-Real Time At High Velocity In Massive Scale with A...
Delivering Meaning In Near-Real Time At High Velocity In Massive Scale with A...
 
Real-Time Anomaly Detection with Spark MLlib, Akka and Cassandra
Real-Time Anomaly Detection  with Spark MLlib, Akka and  CassandraReal-Time Anomaly Detection  with Spark MLlib, Akka and  Cassandra
Real-Time Anomaly Detection with Spark MLlib, Akka and Cassandra
 
Streaming Microservices With Akka Streams And Kafka Streams
Streaming Microservices With Akka Streams And Kafka StreamsStreaming Microservices With Akka Streams And Kafka Streams
Streaming Microservices With Akka Streams And Kafka Streams
 
Real Time Data Processing Using Spark Streaming
Real Time Data Processing Using Spark StreamingReal Time Data Processing Using Spark Streaming
Real Time Data Processing Using Spark Streaming
 
Lightbend Fast Data Platform
Lightbend Fast Data PlatformLightbend Fast Data Platform
Lightbend Fast Data Platform
 

Similar to Building Reactive Distributed Systems For Streaming Big Data, Analytics & Machine Learning

Toward Predictability and Stability At The Edge Of Chaos
Toward Predictability and Stability At The Edge Of ChaosToward Predictability and Stability At The Edge Of Chaos
Toward Predictability and Stability At The Edge Of ChaosJ On The Beach
 
Toward Predictability and Stability
Toward Predictability and StabilityToward Predictability and Stability
Toward Predictability and StabilityHelena Edelson
 
Actor model in F# and Akka.NET
Actor model in F# and Akka.NETActor model in F# and Akka.NET
Actor model in F# and Akka.NETRiccardo Terrell
 
Shared time-series-analysis-using-an-event-streaming-platform -_v2
Shared   time-series-analysis-using-an-event-streaming-platform -_v2Shared   time-series-analysis-using-an-event-streaming-platform -_v2
Shared time-series-analysis-using-an-event-streaming-platform -_v2confluent
 
Fundamentals Of Transaction Systems - Part 1: Causality banishes Acausality ...
Fundamentals Of Transaction Systems - Part 1: Causality banishes Acausality ...Fundamentals Of Transaction Systems - Part 1: Causality banishes Acausality ...
Fundamentals Of Transaction Systems - Part 1: Causality banishes Acausality ...Valverde Computing
 
Time series-analysis-using-an-event-streaming-platform -_v3_final
Time series-analysis-using-an-event-streaming-platform -_v3_finalTime series-analysis-using-an-event-streaming-platform -_v3_final
Time series-analysis-using-an-event-streaming-platform -_v3_finalconfluent
 
Event Driven Architecture with a RESTful Microservices Architecture (Kyle Ben...
Event Driven Architecture with a RESTful Microservices Architecture (Kyle Ben...Event Driven Architecture with a RESTful Microservices Architecture (Kyle Ben...
Event Driven Architecture with a RESTful Microservices Architecture (Kyle Ben...confluent
 
Training Slides: 202 - Monitoring & Troubleshooting
Training Slides: 202 - Monitoring & TroubleshootingTraining Slides: 202 - Monitoring & Troubleshooting
Training Slides: 202 - Monitoring & TroubleshootingContinuent
 
Time Series Analysis… using an Event Streaming Platform
Time Series Analysis… using an Event Streaming PlatformTime Series Analysis… using an Event Streaming Platform
Time Series Analysis… using an Event Streaming Platformconfluent
 
Time Series Analysis Using an Event Streaming Platform
 Time Series Analysis Using an Event Streaming Platform Time Series Analysis Using an Event Streaming Platform
Time Series Analysis Using an Event Streaming PlatformDr. Mirko Kämpf
 
Cassandra at eBay - Cassandra Summit 2012
Cassandra at eBay - Cassandra Summit 2012Cassandra at eBay - Cassandra Summit 2012
Cassandra at eBay - Cassandra Summit 2012Jay Patel
 
JPA and Coherence with TopLink Grid
JPA and Coherence with TopLink GridJPA and Coherence with TopLink Grid
JPA and Coherence with TopLink GridJames Bayer
 
Cassandra & Python - Springfield MO User Group
Cassandra & Python - Springfield MO User GroupCassandra & Python - Springfield MO User Group
Cassandra & Python - Springfield MO User GroupAdam Hutson
 
Software architecture for data applications
Software architecture for data applicationsSoftware architecture for data applications
Software architecture for data applicationsDing Li
 
REEF: Towards a Big Data Stdlib
REEF: Towards a Big Data StdlibREEF: Towards a Big Data Stdlib
REEF: Towards a Big Data StdlibDataWorks Summit
 
SignalFx Elasticsearch Metrics Monitoring and Alerting
SignalFx Elasticsearch Metrics Monitoring and AlertingSignalFx Elasticsearch Metrics Monitoring and Alerting
SignalFx Elasticsearch Metrics Monitoring and AlertingSignalFx
 
Reactive Systems that focus on High Availability with Lerna
Reactive Systems that focus on High Availability with LernaReactive Systems that focus on High Availability with Lerna
Reactive Systems that focus on High Availability with LernaTIS Inc.
 
Lessons From HPE: From Batch To Streaming For 20 Billion Sensors With Lightbe...
Lessons From HPE: From Batch To Streaming For 20 Billion Sensors With Lightbe...Lessons From HPE: From Batch To Streaming For 20 Billion Sensors With Lightbe...
Lessons From HPE: From Batch To Streaming For 20 Billion Sensors With Lightbe...Lightbend
 

Similar to Building Reactive Distributed Systems For Streaming Big Data, Analytics & Machine Learning (20)

Toward Predictability and Stability At The Edge Of Chaos
Toward Predictability and Stability At The Edge Of ChaosToward Predictability and Stability At The Edge Of Chaos
Toward Predictability and Stability At The Edge Of Chaos
 
Toward Predictability and Stability
Toward Predictability and StabilityToward Predictability and Stability
Toward Predictability and Stability
 
Actor model in F# and Akka.NET
Actor model in F# and Akka.NETActor model in F# and Akka.NET
Actor model in F# and Akka.NET
 
Shared time-series-analysis-using-an-event-streaming-platform -_v2
Shared   time-series-analysis-using-an-event-streaming-platform -_v2Shared   time-series-analysis-using-an-event-streaming-platform -_v2
Shared time-series-analysis-using-an-event-streaming-platform -_v2
 
Fundamentals Of Transaction Systems - Part 1: Causality banishes Acausality ...
Fundamentals Of Transaction Systems - Part 1: Causality banishes Acausality ...Fundamentals Of Transaction Systems - Part 1: Causality banishes Acausality ...
Fundamentals Of Transaction Systems - Part 1: Causality banishes Acausality ...
 
Time series-analysis-using-an-event-streaming-platform -_v3_final
Time series-analysis-using-an-event-streaming-platform -_v3_finalTime series-analysis-using-an-event-streaming-platform -_v3_final
Time series-analysis-using-an-event-streaming-platform -_v3_final
 
Stream Processing Overview
Stream Processing OverviewStream Processing Overview
Stream Processing Overview
 
Event Driven Architecture with a RESTful Microservices Architecture (Kyle Ben...
Event Driven Architecture with a RESTful Microservices Architecture (Kyle Ben...Event Driven Architecture with a RESTful Microservices Architecture (Kyle Ben...
Event Driven Architecture with a RESTful Microservices Architecture (Kyle Ben...
 
Training Slides: 202 - Monitoring & Troubleshooting
Training Slides: 202 - Monitoring & TroubleshootingTraining Slides: 202 - Monitoring & Troubleshooting
Training Slides: 202 - Monitoring & Troubleshooting
 
SVCC-2014
SVCC-2014SVCC-2014
SVCC-2014
 
Time Series Analysis… using an Event Streaming Platform
Time Series Analysis… using an Event Streaming PlatformTime Series Analysis… using an Event Streaming Platform
Time Series Analysis… using an Event Streaming Platform
 
Time Series Analysis Using an Event Streaming Platform
 Time Series Analysis Using an Event Streaming Platform Time Series Analysis Using an Event Streaming Platform
Time Series Analysis Using an Event Streaming Platform
 
Cassandra at eBay - Cassandra Summit 2012
Cassandra at eBay - Cassandra Summit 2012Cassandra at eBay - Cassandra Summit 2012
Cassandra at eBay - Cassandra Summit 2012
 
JPA and Coherence with TopLink Grid
JPA and Coherence with TopLink GridJPA and Coherence with TopLink Grid
JPA and Coherence with TopLink Grid
 
Cassandra & Python - Springfield MO User Group
Cassandra & Python - Springfield MO User GroupCassandra & Python - Springfield MO User Group
Cassandra & Python - Springfield MO User Group
 
Software architecture for data applications
Software architecture for data applicationsSoftware architecture for data applications
Software architecture for data applications
 
REEF: Towards a Big Data Stdlib
REEF: Towards a Big Data StdlibREEF: Towards a Big Data Stdlib
REEF: Towards a Big Data Stdlib
 
SignalFx Elasticsearch Metrics Monitoring and Alerting
SignalFx Elasticsearch Metrics Monitoring and AlertingSignalFx Elasticsearch Metrics Monitoring and Alerting
SignalFx Elasticsearch Metrics Monitoring and Alerting
 
Reactive Systems that focus on High Availability with Lerna
Reactive Systems that focus on High Availability with LernaReactive Systems that focus on High Availability with Lerna
Reactive Systems that focus on High Availability with Lerna
 
Lessons From HPE: From Batch To Streaming For 20 Billion Sensors With Lightbe...
Lessons From HPE: From Batch To Streaming For 20 Billion Sensors With Lightbe...Lessons From HPE: From Batch To Streaming For 20 Billion Sensors With Lightbe...
Lessons From HPE: From Batch To Streaming For 20 Billion Sensors With Lightbe...
 

Recently uploaded

Take control of your SAP testing with UiPath Test Suite
Take control of your SAP testing with UiPath Test SuiteTake control of your SAP testing with UiPath Test Suite
Take control of your SAP testing with UiPath Test SuiteDianaGray10
 
Designing IA for AI - Information Architecture Conference 2024
Designing IA for AI - Information Architecture Conference 2024Designing IA for AI - Information Architecture Conference 2024
Designing IA for AI - Information Architecture Conference 2024Enterprise Knowledge
 
DevoxxFR 2024 Reproducible Builds with Apache Maven
DevoxxFR 2024 Reproducible Builds with Apache MavenDevoxxFR 2024 Reproducible Builds with Apache Maven
DevoxxFR 2024 Reproducible Builds with Apache MavenHervé Boutemy
 
SAP Build Work Zone - Overview L2-L3.pptx
SAP Build Work Zone - Overview L2-L3.pptxSAP Build Work Zone - Overview L2-L3.pptx
SAP Build Work Zone - Overview L2-L3.pptxNavinnSomaal
 
Powerpoint exploring the locations used in television show Time Clash
Powerpoint exploring the locations used in television show Time ClashPowerpoint exploring the locations used in television show Time Clash
Powerpoint exploring the locations used in television show Time Clashcharlottematthew16
 
New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024
New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024
New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024BookNet Canada
 
TeamStation AI System Report LATAM IT Salaries 2024
TeamStation AI System Report LATAM IT Salaries 2024TeamStation AI System Report LATAM IT Salaries 2024
TeamStation AI System Report LATAM IT Salaries 2024Lonnie McRorey
 
Transcript: New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024
Transcript: New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024Transcript: New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024
Transcript: New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024BookNet Canada
 
Leverage Zilliz Serverless - Up to 50X Saving for Your Vector Storage Cost
Leverage Zilliz Serverless - Up to 50X Saving for Your Vector Storage CostLeverage Zilliz Serverless - Up to 50X Saving for Your Vector Storage Cost
Leverage Zilliz Serverless - Up to 50X Saving for Your Vector Storage CostZilliz
 
Nell’iperspazio con Rocket: il Framework Web di Rust!
Nell’iperspazio con Rocket: il Framework Web di Rust!Nell’iperspazio con Rocket: il Framework Web di Rust!
Nell’iperspazio con Rocket: il Framework Web di Rust!Commit University
 
Vertex AI Gemini Prompt Engineering Tips
Vertex AI Gemini Prompt Engineering TipsVertex AI Gemini Prompt Engineering Tips
Vertex AI Gemini Prompt Engineering TipsMiki Katsuragi
 
Anypoint Exchange: It’s Not Just a Repo!
Anypoint Exchange: It’s Not Just a Repo!Anypoint Exchange: It’s Not Just a Repo!
Anypoint Exchange: It’s Not Just a Repo!Manik S Magar
 
How AI, OpenAI, and ChatGPT impact business and software.
How AI, OpenAI, and ChatGPT impact business and software.How AI, OpenAI, and ChatGPT impact business and software.
How AI, OpenAI, and ChatGPT impact business and software.Curtis Poe
 
Hyperautomation and AI/ML: A Strategy for Digital Transformation Success.pdf
Hyperautomation and AI/ML: A Strategy for Digital Transformation Success.pdfHyperautomation and AI/ML: A Strategy for Digital Transformation Success.pdf
Hyperautomation and AI/ML: A Strategy for Digital Transformation Success.pdfPrecisely
 
DevEX - reference for building teams, processes, and platforms
DevEX - reference for building teams, processes, and platformsDevEX - reference for building teams, processes, and platforms
DevEX - reference for building teams, processes, and platformsSergiu Bodiu
 
Streamlining Python Development: A Guide to a Modern Project Setup
Streamlining Python Development: A Guide to a Modern Project SetupStreamlining Python Development: A Guide to a Modern Project Setup
Streamlining Python Development: A Guide to a Modern Project SetupFlorian Wilhelm
 
How to write a Business Continuity Plan
How to write a Business Continuity PlanHow to write a Business Continuity Plan
How to write a Business Continuity PlanDatabarracks
 
Advanced Computer Architecture – An Introduction
Advanced Computer Architecture – An IntroductionAdvanced Computer Architecture – An Introduction
Advanced Computer Architecture – An IntroductionDilum Bandara
 

Recently uploaded (20)

Take control of your SAP testing with UiPath Test Suite
Take control of your SAP testing with UiPath Test SuiteTake control of your SAP testing with UiPath Test Suite
Take control of your SAP testing with UiPath Test Suite
 
Designing IA for AI - Information Architecture Conference 2024
Designing IA for AI - Information Architecture Conference 2024Designing IA for AI - Information Architecture Conference 2024
Designing IA for AI - Information Architecture Conference 2024
 
DevoxxFR 2024 Reproducible Builds with Apache Maven
DevoxxFR 2024 Reproducible Builds with Apache MavenDevoxxFR 2024 Reproducible Builds with Apache Maven
DevoxxFR 2024 Reproducible Builds with Apache Maven
 
SAP Build Work Zone - Overview L2-L3.pptx
SAP Build Work Zone - Overview L2-L3.pptxSAP Build Work Zone - Overview L2-L3.pptx
SAP Build Work Zone - Overview L2-L3.pptx
 
DMCC Future of Trade Web3 - Special Edition
DMCC Future of Trade Web3 - Special EditionDMCC Future of Trade Web3 - Special Edition
DMCC Future of Trade Web3 - Special Edition
 
Powerpoint exploring the locations used in television show Time Clash
Powerpoint exploring the locations used in television show Time ClashPowerpoint exploring the locations used in television show Time Clash
Powerpoint exploring the locations used in television show Time Clash
 
E-Vehicle_Hacking_by_Parul Sharma_null_owasp.pptx
E-Vehicle_Hacking_by_Parul Sharma_null_owasp.pptxE-Vehicle_Hacking_by_Parul Sharma_null_owasp.pptx
E-Vehicle_Hacking_by_Parul Sharma_null_owasp.pptx
 
New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024
New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024
New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024
 
TeamStation AI System Report LATAM IT Salaries 2024
TeamStation AI System Report LATAM IT Salaries 2024TeamStation AI System Report LATAM IT Salaries 2024
TeamStation AI System Report LATAM IT Salaries 2024
 
Transcript: New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024
Transcript: New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024Transcript: New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024
Transcript: New from BookNet Canada for 2024: BNC CataList - Tech Forum 2024
 
Leverage Zilliz Serverless - Up to 50X Saving for Your Vector Storage Cost
Leverage Zilliz Serverless - Up to 50X Saving for Your Vector Storage CostLeverage Zilliz Serverless - Up to 50X Saving for Your Vector Storage Cost
Leverage Zilliz Serverless - Up to 50X Saving for Your Vector Storage Cost
 
Nell’iperspazio con Rocket: il Framework Web di Rust!
Nell’iperspazio con Rocket: il Framework Web di Rust!Nell’iperspazio con Rocket: il Framework Web di Rust!
Nell’iperspazio con Rocket: il Framework Web di Rust!
 
Vertex AI Gemini Prompt Engineering Tips
Vertex AI Gemini Prompt Engineering TipsVertex AI Gemini Prompt Engineering Tips
Vertex AI Gemini Prompt Engineering Tips
 
Anypoint Exchange: It’s Not Just a Repo!
Anypoint Exchange: It’s Not Just a Repo!Anypoint Exchange: It’s Not Just a Repo!
Anypoint Exchange: It’s Not Just a Repo!
 
How AI, OpenAI, and ChatGPT impact business and software.
How AI, OpenAI, and ChatGPT impact business and software.How AI, OpenAI, and ChatGPT impact business and software.
How AI, OpenAI, and ChatGPT impact business and software.
 
Hyperautomation and AI/ML: A Strategy for Digital Transformation Success.pdf
Hyperautomation and AI/ML: A Strategy for Digital Transformation Success.pdfHyperautomation and AI/ML: A Strategy for Digital Transformation Success.pdf
Hyperautomation and AI/ML: A Strategy for Digital Transformation Success.pdf
 
DevEX - reference for building teams, processes, and platforms
DevEX - reference for building teams, processes, and platformsDevEX - reference for building teams, processes, and platforms
DevEX - reference for building teams, processes, and platforms
 
Streamlining Python Development: A Guide to a Modern Project Setup
Streamlining Python Development: A Guide to a Modern Project SetupStreamlining Python Development: A Guide to a Modern Project Setup
Streamlining Python Development: A Guide to a Modern Project Setup
 
How to write a Business Continuity Plan
How to write a Business Continuity PlanHow to write a Business Continuity Plan
How to write a Business Continuity Plan
 
Advanced Computer Architecture – An Introduction
Advanced Computer Architecture – An IntroductionAdvanced Computer Architecture – An Introduction
Advanced Computer Architecture – An Introduction
 

Building Reactive Distributed Systems For Streaming Big Data, Analytics & Machine Learning