SlideShare una empresa de Scribd logo
1 de 106
Descargar para leer sin conexión
Reactive Systems Toolkit - Akka
• Microservice Systems
• Clusters within clusters
• System Orchestration
Clustering
Streams
Actors
Cluster Features
• Reactive Services
• Akka & Play Services
• Lagom Microservices
• Membership
• Sharding
• Event Sourcing & CQRS
• Publish & Subscribe
• Distributed Data
• Reactive Streams
• Akka Streams
• Alpakka
• Actor Model
• Supervision
• Routing
Akka History
Akka - Initially developed by Jonas Bonér in 2009
First public release 2009
Inspired by Carl Hewitt’s early 70’s work
and the
Erlang runtime system
A distributed, highly concurrent, and event driven
implementation of the Actor Model
on the JVM - Java & Scala
Reactive Systems Toolkit - Akka
• Microservice Systems
• Clusters within clusters
• System Orchestration
Clustering
Streams
Actors
Cluster Features
• Reactive Services
• Akka & Play Services
• Lagom Microservices
• Membership
• Sharding
• Event Sourcing & CQRS
• Publish & Subscribe
• Distributed Data
• Reactive Streams
• Akka Streams
• Alpakka
• Actor Model
• Supervision
• Routing
Actors
Actor Model
Actor Model - breaking free from
imperative, synchronous, thread heavy
systems development
Actors
Actor Messaging
Actors
Actor Messaging
Actors
Actor Messaging
Actors
Actor Messaging
Actors
Actor Messaging
Actors
Actor Messaging
Actors
Actor Messaging
Actors
Actor Messaging
Actors
Actor Messaging
Actors
Actor Model
Actors
Actor Model
Actors
Actor Model
Actors
Actor Model
Actors
Actor Model
Failure is NOT unexpected or unwanted.
It’s just a fact of life.
Failure handing is an architectural feature
not an afterthought.
Actors
Supervision
Actors
Supervision
Actors
Supervision
Actors
Supervision
Actors
Supervision
Actors
Routing & Concurrency
Actors
Routing & Concurrency
Actors
Routing & Concurrency
Actors
Routing & Concurrency
Actors
Routing & Concurrency
Actors
Routing & Concurrency
Actors
Routing & Concurrency
Actors
Routing & Concurrency
Actors
Routing & Concurrency
Actors
Summary
• Actors are message driven, stateful building blocks
• Messages are passed asynchronously
• Actors may create other actors
• Actors form supervision hierarchies
• Actors are lightweight and do not hold threads
Reactive Systems Toolkit - Akka
• Microservice Systems
• Clusters within clusters
• System Orchestration
Clustering
Streams
Actors
Cluster Features
• Reactive Services
• Akka & Play Services
• Lagom Microservices
• Membership
• Sharding
• Event Sourcing & CQRS
• Publish & Subscribe
• Distributed Data
• Reactive Streams
• Akka Streams
• Alpakka
• Actor Model
• Supervision
• Routing
Streams
Reactive Streams
Reactive Streams - standard for
asynchronous stream processing
with non-blocking back pressure
Streams
Reactive Streams
Java 9 Reactive Streams
Streams
Akka Streams
Streams
Akka Streams
Streams
Akka Streams
!= drop log scan
## dropWhile map scanAsync
+ dropWithin mapAsync shape
++ ensuring mapAsyncUnordered sliding
-> eq mapConcat splitAfter
== equals mapError splitWhen
Closed expand mapMaterializedValue statefulMapConcat
ClosedMat filter merge synchronized
Repr filterNot mergeMat take
ReprMat flatMapConcat mergeSorted takeWhile
Shape flatMapMerge mergeSortedMat takeWithin
addAttributes fold monitor throttle
alsoTo foldAsync named to
alsoToMat formatted ne toMat
asInstanceOf getClass notify toString
asJava groupBy notifyAll traversalBuilder
async grouped orElse via
backpressureTimeout groupedWeightedWithin orElseMat viaMat
batch groupedWithin prefixAndTail wait
batchWeighted hashCode prepend watchTermination
buffer idleTimeout prependMat withAttributes
collect initialDelay recover zip
combine initialTimeout recoverWith zipMat
completionTimeout interleave recoverWithRetries zipWith
concat interleaveMat reduce zipWithIndex
concatMat intersperse runFold zipWithMat
conflate isInstanceOf runFoldAsync !
conflateWithSeed keepAlive runForeach
delay limit runReduce
detach limitWeighted runWith
Rich set of flow processing functions
Streams
Akka Streams
import GraphDSL.Implicits._
RunnableGraph.fromGraph(GraphDSL.create() { implicit builder =>
val A: Outlet[Int] = builder.add(Source.single(0)).out
val B: UniformFanOutShape[Int, Int] = builder.add(Broadcast[Int](2))
val C: UniformFanInShape[Int, Int] = builder.add(Merge[Int](2))
val D: FlowShape[Int, Int] = builder.add(Flow[Int].map(_ + 1))
val E: UniformFanOutShape[Int, Int] = builder.add(Balance[Int](2))
val F: UniformFanInShape[Int, Int] = builder.add(Merge[Int](2))
val G: Inlet[Any] = builder.add(Sink.foreach(println)).in
C <~ F
A ~> B ~> C ~> F
B ~> D ~> E ~> F
E ~> G
ClosedShape
})
Streams
Akka Streams
RunnableGraph.fromGraph(
GraphDSL.create(builder -> {
final Outlet<Integer> A = builder.add(Source.single(0)).out();
final UniformFanOutShape<Integer, Integer> B = builder.add(Broadcast.create(2));
final UniformFanInShape<Integer, Integer> C = builder.add(Merge.create(2));
final FlowShape<Integer, Integer> D =
builder.add(Flow.of(Integer.class).map(i -> i + 1));
final UniformFanOutShape<Integer, Integer> E = builder.add(Balance.create(2));
final UniformFanInShape<Integer, Integer> F = builder.add(Merge.create(2));
final Inlet<Integer> G = builder.add(Sink.<Integer> foreach(System.out::println)).in();
builder.from(F).toFanIn(C);
builder.from(A).viaFanOut(B).viaFanIn(C).toFanIn(F);
builder.from(B).via(D).viaFanOut(E).toFanIn(F);
builder.from(E).toInlet(G);
return ClosedShape.getInstance();
}));
Streams
Akka HTTP
Streams
Akka HTTP
Streams
Alpakka
Connectors
• AMQP
• Apache Geode
• AWS DynamoDB
• AWS Kinesis
• AWS Lambda
• AWS S3
• AWS SNS
• AWS SQS
• Azure Storage Queue
• Cassandra
• File
• FTP
• Google Cloud Pub/Sub
• HBbase
• IronMq
• JMS
• MQTT
• Server-sent Events (SSE)
Alpakka - Akka Streams
alternative
to Apache Camel
Streams
Alpakka
// Read huge file with Wikipedia content
Source<WikipediaEntry,
CompletionStage<IOResult>> wikipediaEntries =
FileIO.fromPath(Paths.get("/tmp", "wiki"))
.via(parseWikiEntries());
// Enrich the data by fetching matching image from a
// web service with HTTP
Source<RichWikipediaEntry,
CompletionStage<IOResult>> enrichedData = wikipediaEntries
.via(enrichWithImageData);
// Store content in Kafka
// and corresponding image in AWS S3
enrichedData
.alsoTo(s3ImageStorage())
.to(kafkaTopic)
.run(materializer);
Streams
Summary
• Akka Streams is a Reactive Streams implementation
• Flow control of data via demand based back-pressure
• Provides a rich set of flow processing transformations
Reactive Systems Toolkit - Akka
• Microservice Systems
• Clusters within clusters
• System Orchestration
Clustering
Streams
Actors
Cluster Features
• Reactive Services
• Akka & Play Services
• Lagom Microservices
• Membership
• Sharding
• Event Sourcing & CQRS
• Publish & Subscribe
• Distributed Data
• Reactive Streams
• Akka Streams
• Alpakka
• Actor Model
• Supervision
• Routing
Cluster Features
Cluster Features - actor systems that span
clusters of multiple JVMs
Cluster Features
Cluster Membership
Cluster Features
Cluster Membership
State Diagram of Akka Cluster Member States
Cluster Features
Cluster Sharding
Send messages to actors
distributed across a cluster
via logical identifiers
Cluster Features
Cluster Sharding
Cluster Features
Cluster Sharding
Cluster Features
Cluster Sharding
Cluster Features
Cluster Sharding
Cluster Features
Cluster Sharding
Cluster Features
Cluster Sharding
Cluster Features
Cluster Sharding
Cluster Features
Cluster Sharding
Cluster Features
Cluster Sharding
Cluster Features
Cluster Sharding
Cluster Features
Cluster Sharding
Cluster Features
Event Sourcing & CQRS
Akka Persistence
Akka Persistence Query
Cluster Sharding
Actor implementation of
Event Sourcing & CQRS
(Command Query Responsibility Segregation)
Cluster Features
Event Sourcing & CQRS
Akka Persistence
Akka Persistence Query
Cluster Sharding
Cluster Features
Event Sourcing & CQRS
Akka Persistence
Akka Persistence Query
Cluster Sharding
Cluster Features
Event Sourcing & CQRS
Akka Persistence
Akka Persistence Query
Cluster Sharding
Cluster Features
Event Sourcing & CQRS
Akka Persistence
Akka Persistence Query
Cluster Sharding
Cluster Features
Publish and Subscribe
Distributed
Publish & Subscribe
Cluster Features
Publish and Subscribe
Cluster Features
Publish and Subscribe
Cluster Features
Publish and Subscribe
Cluster Features
Distributed Data
Share data between nodes in an Akka Cluster
Conflict Free Replicated Data Types (CRDTs)
Cluster Features
Distributed Data
Cluster Features
Distributed Data
Cluster Features
Distributed Data
Cluster Features
Distributed Data
Cluster Features
Distributed Data
Cluster Features
Distributed Data
Cluster Features
Summary
• Groups of collaborating actors abstract functionality
• Cluster aware actors react to cluster state changes
• Use out-of-the-box features or create custom features
Reactive Systems Toolkit - Akka
• Microservice Systems
• Clusters within clusters
• System Orchestration
Clustering
Streams
Actors
Cluster Features
• Reactive Services
• Akka & Play Services
• Lagom Microservices
• Membership
• Sharding
• Event Sourcing & CQRS
• Publish & Subscribe
• Distributed Data
• Reactive Streams
• Akka Streams
• Alpakka
• Actor Model
• Supervision
• Routing
Clustering
Clustering - strength in numbers
Clustering
Reactive Services
Clustering
Akka & Play Services
Clustering
Lagom Microservices
Clustering
Lagom Microservices
Clustering
Lagom Microservices
Microservice
Microservice
Microservice
Clustering
Summary
• Clusters dynamically react to node topology changes
• Reactive microservices with Akka, Play, and Lagom
Reactive Systems Toolkit - Akka
• Microservice Systems
• Clusters within clusters
• System Orchestration
Clustering
Streams
Actors
Cluster Features
• Reactive Services
• Akka & Play Services
• Lagom Microservices
• Membership
• Sharding
• Event Sourcing & CQRS
• Publish & Subscribe
• Distributed Data
• Reactive Streams
• Akka Streams
• Alpakka
• Actor Model
• Supervision
• Routing
Reactive Systems
Application landscape is now a city of services
Reactive Systems
Monoliths, Microliths,
Microservices,
and Lambdas
Built with Akka and
Java or Scala
Reactive Systems
Clusters within
a cluster
Towns within
a city
Reactive Systems
System Orchestration
Application Management
Network Partition
Split Brain Resolution
Reactive Systems
System Orchestration
Application Management
Network Partition
Split Brain Resolution
Reactive Systems
System Orchestration
Akka Telemetry
and Monitoring
Diagnostic RecorderConfiguration Checker
Reactive Systems
Reactive, Cognitive,
and
Real-time Data-driven
Applications
Fast Data Platform
Reactive Systems
Reactive, Cognitive,
and
Real-time Data-driven
Applications
Fast Data Platform
Reactive Systems
Reactive, Cognitive,
and
Real-time Data-driven
Applications
Fast Data Platform
Reactive Systems
Reactive, Cognitive,
and
Real-time Data-driven
Applications
Fast Data Platform
Reactive Systems
Summary
Akka is a toolkit for building highly concurrent,
distributed, and resilient message-driven applications
for Java and Scala
Reactive Systems Toolkit - Akka
• Microservice Systems
• Clusters within clusters
• System Orchestration
Clustering
Streams
Actors
Cluster Features
• Reactive Services
• Akka & Play Services
• Lagom Microservices
• Membership
• Sharding
• Event Sourcing & CQRS
• Publish & Subscribe
• Distributed Data
• Reactive Streams
• Akka Streams
• Alpakka
• Actor Model
• Supervision
• Routing
Akka Customers
Reactive Systems Toolkit
Reactive Programming Toolkit
Upgrade your grey matter!

Get the free O’Reilly book by Hugh McKee, 

Developer Advocate at Lightbend
https://www.lightbend.com/resources/e-books

Más contenido relacionado

La actualidad más candente

La actualidad más candente (20)

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
 
Lightbend Fast Data Platform
Lightbend Fast Data PlatformLightbend Fast Data Platform
Lightbend Fast Data Platform
 
Building Stateful Microservices With Akka
Building Stateful Microservices With AkkaBuilding Stateful Microservices With Akka
Building Stateful Microservices With Akka
 
Akka and Kubernetes: Reactive From Code To Cloud
Akka and Kubernetes: Reactive From Code To CloudAkka and Kubernetes: Reactive From Code To Cloud
Akka and Kubernetes: Reactive From Code To Cloud
 
Akka 2.4 plus new commercial features in Typesafe Reactive Platform
Akka 2.4 plus new commercial features in Typesafe Reactive PlatformAkka 2.4 plus new commercial features in Typesafe Reactive Platform
Akka 2.4 plus new commercial features in Typesafe Reactive Platform
 
Typesafe Reactive Platform: Monitoring 1.0, Commercial features and more
Typesafe Reactive Platform: Monitoring 1.0, Commercial features and moreTypesafe Reactive Platform: Monitoring 1.0, Commercial features and more
Typesafe Reactive Platform: Monitoring 1.0, Commercial features and more
 
Do's and don'ts when deploying akka in production
Do's and don'ts when deploying akka in productionDo's and don'ts when deploying akka in production
Do's and don'ts when deploying akka in production
 
Bootstrapping Microservices with Kafka, Akka and Spark
Bootstrapping Microservices with Kafka, Akka and SparkBootstrapping Microservices with Kafka, Akka and Spark
Bootstrapping Microservices with Kafka, Akka and Spark
 
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)
 
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
 
Lambda Architecture with Spark Streaming, Kafka, Cassandra, Akka, Scala
Lambda Architecture with Spark Streaming, Kafka, Cassandra, Akka, ScalaLambda Architecture with Spark Streaming, Kafka, Cassandra, Akka, Scala
Lambda Architecture with Spark Streaming, Kafka, Cassandra, Akka, Scala
 
Akka Streams And Kafka Streams: Where Microservices Meet Fast Data
Akka Streams And Kafka Streams: Where Microservices Meet Fast DataAkka Streams And Kafka Streams: Where Microservices Meet Fast Data
Akka Streams And Kafka Streams: Where Microservices Meet Fast Data
 
Building stateful systems with akka cluster sharding
Building stateful systems with akka cluster shardingBuilding stateful systems with akka cluster sharding
Building stateful systems with akka cluster sharding
 
Why Actor-Based Systems Are The Best For Microservices
Why Actor-Based Systems Are The Best For MicroservicesWhy Actor-Based Systems Are The Best For Microservices
Why Actor-Based Systems Are The Best For Microservices
 
How to deploy Apache Spark 
to Mesos/DCOS
How to deploy Apache Spark 
to Mesos/DCOSHow to deploy Apache Spark 
to Mesos/DCOS
How to deploy Apache Spark 
to Mesos/DCOS
 
Making Scala Faster: 3 Expert Tips For Busy Development Teams
Making Scala Faster: 3 Expert Tips For Busy Development TeamsMaking Scala Faster: 3 Expert Tips For Busy Development Teams
Making Scala Faster: 3 Expert Tips For Busy Development Teams
 
Building Eventing Systems for Microservice Architecture
Building Eventing Systems for Microservice Architecture  Building Eventing Systems for Microservice Architecture
Building Eventing Systems for Microservice Architecture
 
Akka Microservices Architecture And Design
Akka Microservices Architecture And DesignAkka Microservices Architecture And Design
Akka Microservices Architecture And Design
 
Akka streams kafka kinesis
Akka streams kafka kinesisAkka streams kafka kinesis
Akka streams kafka kinesis
 
A Journey to Reactive Function Programming
A Journey to Reactive Function ProgrammingA Journey to Reactive Function Programming
A Journey to Reactive Function Programming
 

Similar a Akka Revealed: A JVM Architect's Journey From Resilient Actors To Scalable Clusters

Real world Scala hAkking NLJUG JFall 2011
Real world Scala hAkking NLJUG JFall 2011Real world Scala hAkking NLJUG JFall 2011
Real world Scala hAkking NLJUG JFall 2011
Raymond Roestenburg
 
Typesafe stack - Scala, Akka and Play
Typesafe stack - Scala, Akka and PlayTypesafe stack - Scala, Akka and Play
Typesafe stack - Scala, Akka and Play
Luka Zakrajšek
 

Similar a Akka Revealed: A JVM Architect's Journey From Resilient Actors To Scalable Clusters (20)

Developing distributed applications with Akka and Akka Cluster
Developing distributed applications with Akka and Akka ClusterDeveloping distributed applications with Akka and Akka Cluster
Developing distributed applications with Akka and Akka Cluster
 
Building a High-Performance Database with Scala, Akka, and Spark
Building a High-Performance Database with Scala, Akka, and SparkBuilding a High-Performance Database with Scala, Akka, and Spark
Building a High-Performance Database with Scala, Akka, and Spark
 
Build Real-Time Streaming ETL Pipelines With Akka Streams, Alpakka And Apache...
Build Real-Time Streaming ETL Pipelines With Akka Streams, Alpakka And Apache...Build Real-Time Streaming ETL Pipelines With Akka Streams, Alpakka And Apache...
Build Real-Time Streaming ETL Pipelines With Akka Streams, Alpakka And Apache...
 
Reactive Streams - László van den Hoek
Reactive Streams - László van den HoekReactive Streams - László van den Hoek
Reactive Streams - László van den Hoek
 
Back-Pressure in Action: Handling High-Burst Workloads with Akka Streams & Ka...
Back-Pressure in Action: Handling High-Burst Workloads with Akka Streams & Ka...Back-Pressure in Action: Handling High-Burst Workloads with Akka Streams & Ka...
Back-Pressure in Action: Handling High-Burst Workloads with Akka Streams & Ka...
 
Back-Pressure in Action: Handling High-Burst Workloads with Akka Streams & Kafka
Back-Pressure in Action: Handling High-Burst Workloads with Akka Streams & KafkaBack-Pressure in Action: Handling High-Burst Workloads with Akka Streams & Kafka
Back-Pressure in Action: Handling High-Burst Workloads with Akka Streams & Kafka
 
Kafka On YARN (KOYA): An Open Source Initiative to integrate Kafka & YARN
Kafka On YARN (KOYA): An Open Source Initiative to integrate Kafka & YARNKafka On YARN (KOYA): An Open Source Initiative to integrate Kafka & YARN
Kafka On YARN (KOYA): An Open Source Initiative to integrate Kafka & YARN
 
Event Streaming Architectures with Confluent and ScyllaDB
Event Streaming Architectures with Confluent and ScyllaDBEvent Streaming Architectures with Confluent and ScyllaDB
Event Streaming Architectures with Confluent and ScyllaDB
 
DevOps.2D: two dimensions
of engineering
DevOps.2D: two dimensions
of  engineeringDevOps.2D: two dimensions
of  engineering
DevOps.2D: two dimensions
of engineering
 
From Code to Kubernetes
From Code to KubernetesFrom Code to Kubernetes
From Code to Kubernetes
 
Real world Scala hAkking NLJUG JFall 2011
Real world Scala hAkking NLJUG JFall 2011Real world Scala hAkking NLJUG JFall 2011
Real world Scala hAkking NLJUG JFall 2011
 
A Practical Guide To End-to-End Tracing In Event Driven Architectures
A Practical Guide To End-to-End Tracing In Event Driven ArchitecturesA Practical Guide To End-to-End Tracing In Event Driven Architectures
A Practical Guide To End-to-End Tracing In Event Driven Architectures
 
Levelling up in Akka
Levelling up in AkkaLevelling up in Akka
Levelling up in Akka
 
Reactive integrations with Akka Streams
Reactive integrations with Akka StreamsReactive integrations with Akka Streams
Reactive integrations with Akka Streams
 
Akka in Production - ScalaDays 2015
Akka in Production - ScalaDays 2015Akka in Production - ScalaDays 2015
Akka in Production - ScalaDays 2015
 
Spark on Yarn
Spark on YarnSpark on Yarn
Spark on Yarn
 
Typesafe stack - Scala, Akka and Play
Typesafe stack - Scala, Akka and PlayTypesafe stack - Scala, Akka and Play
Typesafe stack - Scala, Akka and Play
 
Load Balancing in the Cloud using Nginx & Kubernetes
Load Balancing in the Cloud using Nginx & KubernetesLoad Balancing in the Cloud using Nginx & Kubernetes
Load Balancing in the Cloud using Nginx & Kubernetes
 
Akka streams - Umeå java usergroup
Akka streams - Umeå java usergroupAkka streams - Umeå java usergroup
Akka streams - Umeå java usergroup
 
Changing landscapes in data integration - Kafka Connect for near real-time da...
Changing landscapes in data integration - Kafka Connect for near real-time da...Changing landscapes in data integration - Kafka Connect for near real-time da...
Changing landscapes in data integration - Kafka Connect for near real-time da...
 

Más de Lightbend

Más de Lightbend (20)

IoT 'Megaservices' - High Throughput Microservices with Akka
IoT 'Megaservices' - High Throughput Microservices with AkkaIoT 'Megaservices' - High Throughput Microservices with Akka
IoT 'Megaservices' - High Throughput Microservices with Akka
 
How Akka Cluster Works: Actors Living in a Cluster
How Akka Cluster Works: Actors Living in a ClusterHow Akka Cluster Works: Actors Living in a Cluster
How Akka Cluster Works: Actors Living in a Cluster
 
The Reactive Principles: Eight Tenets For Building Cloud Native Applications
The Reactive Principles: Eight Tenets For Building Cloud Native ApplicationsThe Reactive Principles: Eight Tenets For Building Cloud Native Applications
The Reactive Principles: Eight Tenets For Building Cloud Native Applications
 
Putting the 'I' in IoT - Building Digital Twins with Akka Microservices
Putting the 'I' in IoT - Building Digital Twins with Akka MicroservicesPutting the 'I' in IoT - Building Digital Twins with Akka Microservices
Putting the 'I' in IoT - Building Digital Twins with Akka Microservices
 
Digital Transformation with Kubernetes, Containers, and Microservices
Digital Transformation with Kubernetes, Containers, and MicroservicesDigital Transformation with Kubernetes, Containers, and Microservices
Digital Transformation with Kubernetes, Containers, and Microservices
 
Detecting Real-Time Financial Fraud with Cloudflow on Kubernetes
Detecting Real-Time Financial Fraud with Cloudflow on KubernetesDetecting Real-Time Financial Fraud with Cloudflow on Kubernetes
Detecting Real-Time Financial Fraud with Cloudflow on Kubernetes
 
Cloudstate - Towards Stateful Serverless
Cloudstate - Towards Stateful ServerlessCloudstate - Towards Stateful Serverless
Cloudstate - Towards Stateful Serverless
 
Digital Transformation from Monoliths to Microservices to Serverless and Beyond
Digital Transformation from Monoliths to Microservices to Serverless and BeyondDigital Transformation from Monoliths to Microservices to Serverless and Beyond
Digital Transformation from Monoliths to Microservices to Serverless and Beyond
 
Akka Anti-Patterns, Goodbye: Six Features of Akka 2.6
Akka Anti-Patterns, Goodbye: Six Features of Akka 2.6Akka Anti-Patterns, Goodbye: Six Features of Akka 2.6
Akka Anti-Patterns, Goodbye: Six Features of Akka 2.6
 
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...
 
How to build streaming data pipelines with Akka Streams, Flink, and Spark usi...
How to build streaming data pipelines with Akka Streams, Flink, and Spark usi...How to build streaming data pipelines with Akka Streams, Flink, and Spark usi...
How to build streaming data pipelines with Akka Streams, Flink, and Spark usi...
 
Microservices, Kubernetes, and Application Modernization Done Right
Microservices, Kubernetes, and Application Modernization Done RightMicroservices, Kubernetes, and Application Modernization Done Right
Microservices, Kubernetes, and Application Modernization Done Right
 
Full Stack Reactive In Practice
Full Stack Reactive In PracticeFull Stack Reactive In Practice
Full Stack Reactive In Practice
 
Akka and Kubernetes: A Symbiotic Love Story
Akka and Kubernetes: A Symbiotic Love StoryAkka and Kubernetes: A Symbiotic Love Story
Akka and Kubernetes: A Symbiotic Love Story
 
Scala 3 Is Coming: Martin Odersky Shares What To Know
Scala 3 Is Coming: Martin Odersky Shares What To KnowScala 3 Is Coming: Martin Odersky Shares What To Know
Scala 3 Is Coming: Martin Odersky Shares What To Know
 
Migrating From Java EE To Cloud-Native Reactive Systems
Migrating From Java EE To Cloud-Native Reactive SystemsMigrating From Java EE To Cloud-Native Reactive Systems
Migrating From Java EE To Cloud-Native Reactive Systems
 
Running Kafka On Kubernetes With Strimzi For Real-Time Streaming Applications
Running Kafka On Kubernetes With Strimzi For Real-Time Streaming ApplicationsRunning Kafka On Kubernetes With Strimzi For Real-Time Streaming Applications
Running Kafka On Kubernetes With Strimzi For Real-Time Streaming Applications
 
Designing Events-First Microservices For A Cloud Native World
Designing Events-First Microservices For A Cloud Native WorldDesigning Events-First Microservices For A Cloud Native World
Designing Events-First Microservices For A Cloud Native World
 
Scala Security: Eliminate 200+ Code-Level Threats With Fortify SCA For Scala
Scala Security: Eliminate 200+ Code-Level Threats With Fortify SCA For ScalaScala Security: Eliminate 200+ Code-Level Threats With Fortify SCA For Scala
Scala Security: Eliminate 200+ Code-Level Threats With Fortify SCA For Scala
 
How To Build, Integrate, and Deploy Real-Time Streaming Pipelines On Kubernetes
How To Build, Integrate, and Deploy Real-Time Streaming Pipelines On KubernetesHow To Build, Integrate, and Deploy Real-Time Streaming Pipelines On Kubernetes
How To Build, Integrate, and Deploy Real-Time Streaming Pipelines On Kubernetes
 

Último

introduction-to-automotive Andoid os-csimmonds-ndctechtown-2021.pdf
introduction-to-automotive Andoid os-csimmonds-ndctechtown-2021.pdfintroduction-to-automotive Andoid os-csimmonds-ndctechtown-2021.pdf
introduction-to-automotive Andoid os-csimmonds-ndctechtown-2021.pdf
VishalKumarJha10
 
+971565801893>>SAFE AND ORIGINAL ABORTION PILLS FOR SALE IN DUBAI AND ABUDHAB...
+971565801893>>SAFE AND ORIGINAL ABORTION PILLS FOR SALE IN DUBAI AND ABUDHAB...+971565801893>>SAFE AND ORIGINAL ABORTION PILLS FOR SALE IN DUBAI AND ABUDHAB...
+971565801893>>SAFE AND ORIGINAL ABORTION PILLS FOR SALE IN DUBAI AND ABUDHAB...
Health
 

Último (20)

Unlocking the Future of AI Agents with Large Language Models
Unlocking the Future of AI Agents with Large Language ModelsUnlocking the Future of AI Agents with Large Language Models
Unlocking the Future of AI Agents with Large Language Models
 
%in kempton park+277-882-255-28 abortion pills for sale in kempton park
%in kempton park+277-882-255-28 abortion pills for sale in kempton park %in kempton park+277-882-255-28 abortion pills for sale in kempton park
%in kempton park+277-882-255-28 abortion pills for sale in kempton park
 
The Top App Development Trends Shaping the Industry in 2024-25 .pdf
The Top App Development Trends Shaping the Industry in 2024-25 .pdfThe Top App Development Trends Shaping the Industry in 2024-25 .pdf
The Top App Development Trends Shaping the Industry in 2024-25 .pdf
 
call girls in Vaishali (Ghaziabad) 🔝 >༒8448380779 🔝 genuine Escort Service 🔝✔️✔️
call girls in Vaishali (Ghaziabad) 🔝 >༒8448380779 🔝 genuine Escort Service 🔝✔️✔️call girls in Vaishali (Ghaziabad) 🔝 >༒8448380779 🔝 genuine Escort Service 🔝✔️✔️
call girls in Vaishali (Ghaziabad) 🔝 >༒8448380779 🔝 genuine Escort Service 🔝✔️✔️
 
introduction-to-automotive Andoid os-csimmonds-ndctechtown-2021.pdf
introduction-to-automotive Andoid os-csimmonds-ndctechtown-2021.pdfintroduction-to-automotive Andoid os-csimmonds-ndctechtown-2021.pdf
introduction-to-automotive Andoid os-csimmonds-ndctechtown-2021.pdf
 
Define the academic and professional writing..pdf
Define the academic and professional writing..pdfDefine the academic and professional writing..pdf
Define the academic and professional writing..pdf
 
Sector 18, Noida Call girls :8448380779 Model Escorts | 100% verified
Sector 18, Noida Call girls :8448380779 Model Escorts | 100% verifiedSector 18, Noida Call girls :8448380779 Model Escorts | 100% verified
Sector 18, Noida Call girls :8448380779 Model Escorts | 100% verified
 
Crypto Cloud Review - How To Earn Up To $500 Per DAY Of Bitcoin 100% On AutoP...
Crypto Cloud Review - How To Earn Up To $500 Per DAY Of Bitcoin 100% On AutoP...Crypto Cloud Review - How To Earn Up To $500 Per DAY Of Bitcoin 100% On AutoP...
Crypto Cloud Review - How To Earn Up To $500 Per DAY Of Bitcoin 100% On AutoP...
 
+971565801893>>SAFE AND ORIGINAL ABORTION PILLS FOR SALE IN DUBAI AND ABUDHAB...
+971565801893>>SAFE AND ORIGINAL ABORTION PILLS FOR SALE IN DUBAI AND ABUDHAB...+971565801893>>SAFE AND ORIGINAL ABORTION PILLS FOR SALE IN DUBAI AND ABUDHAB...
+971565801893>>SAFE AND ORIGINAL ABORTION PILLS FOR SALE IN DUBAI AND ABUDHAB...
 
W01_panagenda_Navigating-the-Future-with-The-Hitchhikers-Guide-to-Notes-and-D...
W01_panagenda_Navigating-the-Future-with-The-Hitchhikers-Guide-to-Notes-and-D...W01_panagenda_Navigating-the-Future-with-The-Hitchhikers-Guide-to-Notes-and-D...
W01_panagenda_Navigating-the-Future-with-The-Hitchhikers-Guide-to-Notes-and-D...
 
MarTech Trend 2024 Book : Marketing Technology Trends (2024 Edition) How Data...
MarTech Trend 2024 Book : Marketing Technology Trends (2024 Edition) How Data...MarTech Trend 2024 Book : Marketing Technology Trends (2024 Edition) How Data...
MarTech Trend 2024 Book : Marketing Technology Trends (2024 Edition) How Data...
 
ManageIQ - Sprint 236 Review - Slide Deck
ManageIQ - Sprint 236 Review - Slide DeckManageIQ - Sprint 236 Review - Slide Deck
ManageIQ - Sprint 236 Review - Slide Deck
 
LEVEL 5 - SESSION 1 2023 (1).pptx - PDF 123456
LEVEL 5   - SESSION 1 2023 (1).pptx - PDF 123456LEVEL 5   - SESSION 1 2023 (1).pptx - PDF 123456
LEVEL 5 - SESSION 1 2023 (1).pptx - PDF 123456
 
A Secure and Reliable Document Management System is Essential.docx
A Secure and Reliable Document Management System is Essential.docxA Secure and Reliable Document Management System is Essential.docx
A Secure and Reliable Document Management System is Essential.docx
 
HR Software Buyers Guide in 2024 - HRSoftware.com
HR Software Buyers Guide in 2024 - HRSoftware.comHR Software Buyers Guide in 2024 - HRSoftware.com
HR Software Buyers Guide in 2024 - HRSoftware.com
 
Shapes for Sharing between Graph Data Spaces - and Epistemic Querying of RDF-...
Shapes for Sharing between Graph Data Spaces - and Epistemic Querying of RDF-...Shapes for Sharing between Graph Data Spaces - and Epistemic Querying of RDF-...
Shapes for Sharing between Graph Data Spaces - and Epistemic Querying of RDF-...
 
Chinsurah Escorts ☎️8617697112 Starting From 5K to 15K High Profile Escorts ...
Chinsurah Escorts ☎️8617697112  Starting From 5K to 15K High Profile Escorts ...Chinsurah Escorts ☎️8617697112  Starting From 5K to 15K High Profile Escorts ...
Chinsurah Escorts ☎️8617697112 Starting From 5K to 15K High Profile Escorts ...
 
Pharm-D Biostatistics and Research methodology
Pharm-D Biostatistics and Research methodologyPharm-D Biostatistics and Research methodology
Pharm-D Biostatistics and Research methodology
 
Optimizing AI for immediate response in Smart CCTV
Optimizing AI for immediate response in Smart CCTVOptimizing AI for immediate response in Smart CCTV
Optimizing AI for immediate response in Smart CCTV
 
%in kaalfontein+277-882-255-28 abortion pills for sale in kaalfontein
%in kaalfontein+277-882-255-28 abortion pills for sale in kaalfontein%in kaalfontein+277-882-255-28 abortion pills for sale in kaalfontein
%in kaalfontein+277-882-255-28 abortion pills for sale in kaalfontein
 

Akka Revealed: A JVM Architect's Journey From Resilient Actors To Scalable Clusters