Once again I prepared a programming contest on GeeCON 2016 for my company. This time the assignment required designing and optionally implementing a system given the following requirements:
A system delivers around one thousand events per second. Each Event
has at least two attributes:
-
clientId
- we expect up to few events per second for one client -
UUID
- globally unique
Consuming one event takes about 10 milliseconds. Design a consumer of such stream that:
- allows processing events in real time
- events related to one client should be processed sequentially and in order, i.e. you can not parallelize events for the same
clientId
- if duplicated
UUID
appeared within 10 seconds, drop it. Assume duplicates will not appear after 10 seconds
There are few important details in these requirements:
- 1000 events/s and 10 ms to consume one event. Clearly we need at least 10 concurrent consumers in order to consume in near real-time.
- Events have natural aggregate ID (
clientId
). During one second we can expect a few events for a given client and we are not allowed to process them concurrently or out of order. - We must somehow ignore duplicated messages, most likely by remembering all unique IDs in last 10 seconds. This gives about 10 thousand
UUID
s to keep temporarily.
In this article I'd like to guide you through couple of correct solutions and few broken attempts. You will also learn how to troubleshoot issues with few precisely targeted metrics.
Naive sequential processing
Let's tackle this problem in iterations. First we must make some assumption on the API. Imagine it looks like that:
interface EventStream {
void consume(EventConsumer consumer);
}
@FunctionalInterface
interface EventConsumer {
Event consume(Event event);
}
@Value
class Event {
private final Instant created = Instant.now();
private final int clientId;
private final UUID uuid;
}
A typical push-based API, similar to JMS. An important note is that EventConsumer
is blocking, meaning it won't deliver new Event
until the previous one was consumed by EventConsumer
. This is just an assumption I made that does not drastically change the requirements. This is also how message listeners work in JMS. The naive implementation simply attaches a listener that takes around 10 milliseconds to complete:
class ClientProjection implements EventConsumer {
@Override
public Event consume(Event event) {
Sleeper.randSleep(10, 1);
return event;
}
}
Of course in real life this consumer would store something in a database, make remote call, etc. I add a bit of randomness to sleep time distribution to make manual testing more realistic:
class Sleeper {
private static final Random RANDOM = new Random();
static void randSleep(double mean, double stdDev) {
final double micros = 1_000 * (mean + RANDOM.nextGaussian() * stdDev);
try {
TimeUnit.MICROSECONDS.sleep((long) micros);
} catch (InterruptedException e) {
throw new RuntimeException(e);
}
}
}
//...
EventStream es = new EventStream(); //some real implementation here
es.consume(new ClientProjection());
It compiles and runs but in order to figure out that the requirements aren't met we must plug in few metrics. The most important metric is the latency of message consumption, measured as a time between message creation and start of processing. We'll use Dropwizard Metrics for that:
class ClientProjection implements EventConsumer {
private final ProjectionMetrics metrics;
ClientProjection(ProjectionMetrics metrics) {
this.metrics = metrics;
}
@Override
public Event consume(Event event) {
metrics.latency(Duration.between(event.getCreated(), Instant.now()));
Sleeper.randSleep(10, 1);
return event;
}
}
The ProjectionMetrics
class was extracted to separate responsibilities:
import com.codahale.metrics.Histogram;
import com.codahale.metrics.MetricRegistry;
import com.codahale.metrics.Slf4jReporter;
import lombok.extern.slf4j.Slf4j;
import java.time.Duration;
import java.util.concurrent.TimeUnit;
@Slf4j
class ProjectionMetrics {
private final Histogram latencyHist;
ProjectionMetrics(MetricRegistry metricRegistry) {
final Slf4jReporter reporter = Slf4jReporter.forRegistry(metricRegistry)
.outputTo(log)
.convertRatesTo(TimeUnit.SECONDS)
.convertDurationsTo(TimeUnit.MILLISECONDS)
.build();
reporter.start(1, TimeUnit.SECONDS);
latencyHist = metricRegistry.histogram(MetricRegistry.name(ProjectionMetrics.class, "latency"));
}
void latency(Duration duration) {
latencyHist.update(duration.toMillis());
}
}
Now when you run the naive solution you'll quickly discover that median latency as well as 99.9th percentile keep growing infinitely:
type=HISTOGRAM, [...] count=84, min=0, max=795, mean=404.88540608274104, [...]
median=414.0, p75=602.0, p95=753.0, p98=783.0, p99=795.0, p999=795.0
type=HISTOGRAM, [...] count=182, min=0, max=1688, mean=861.1706371990878, [...]
median=869.0, p75=1285.0, p95=1614.0, p98=1659.0, p99=1678.0, p999=1688.0
[...30 seconds later...]
type=HISTOGRAM, [...] count=2947, min=14, max=26945, mean=15308.138585757424, [...]
median=16150.0, p75=21915.0, p95=25978.0, p98=26556.0, p99=26670.0, p999=26945.0
After 30 seconds our application processes events on average with 15 second delay. Not entirely real-time. Obviously the lack of concurrency whatsoever is the reason. Our ClientProjection
event consumer takes around 10 ms to complete so it can handle up to 100 events per second, whereas we need an order of magnitude more. We must scale ClientProjection
somehow. And we haven't even touched other requirements!
Naive thread pool
The most obvious solution is to invoke EventConsumer
from multiple threads. The easiest way to do this is by taking advantage of ExecutorService
:
import java.util.concurrent.ExecutorService;
import java.util.concurrent.Executors;
class NaivePool implements EventConsumer, Closeable {
private final EventConsumer downstream;
private final ExecutorService executorService;
NaivePool(int size, EventConsumer downstream) {
this.executorService = Executors.newFixedThreadPool(size);
this.downstream = downstream;
}
@Override
public Event consume(Event event) {
executorService.submit(() -> downstream.consume(event));
return event;
}
@Override
public void close() throws IOException {
executorService.shutdown();
}
}
We use a decorator pattern here. The original ClientProjection
, implementing EventConsumer
was correct. However we wrap it with another implementation of EventConsumer
that adds concurrency. This will allows us to compose complex behaviors without changing ClientProjection
itself. Such design promotes:
- loose coupling: various
EventConsumer
don't know about each other and can be combined freely - single responsibility: each does one job and delegates to the next component
- open/closed principle: we can change the behavior of the system without modifying existing implementations.
Open/closed principle is typically achieved by injecting strategies and template method pattern. Here it's even simpler. Whole wiring looks as follows:
MetricRegistry metricRegistry =
new MetricRegistry();
ProjectionMetrics metrics =
new ProjectionMetrics(metricRegistry);
ClientProjection clientProjection =
new ClientProjection(metrics);
NaivePool naivePool =
new NaivePool(10, clientProjection);
EventStream es = new EventStream();
es.consume(naivePool);
Our carefully crafted metrics reveal that the situation is indeed much better:
type=HISToOGRAM, count=838, min=1, max=422, mean=38.80768197277468, [...]
median=37.0, p75=45.0, p95=51.0, p98=52.0, p99=52.0, p999=422.0
type=HISTOGRAM, count=1814, min=1, max=281, mean=47.82642776789085, [...]
median=51.0, p75=57.0, p95=61.0, p98=62.0, p99=63.0, p999=65.0
[...30 seconds later...]
type=HISTOGRAM, count=30564, min=5, max=3838, mean=364.2904915942238, [...]
median=352.0, p75=496.0, p95=568.0, p98=574.0, p99=1251.0, p999=3531.0
Yet we still see growing delay on a much smaller scale, after 30 seconds the latency reached 364 milliseconds. It keeps growing so the problem is systematic. We... need... more... metrics. Notice that NaivePool
(you'll see soon why it's naive) has exactly 10 threads at its disposal. This should be just about enough to handle thousand events, each taking 10 ms to process. In reality we need a little bit of extra processing power to avoid issues after garbage collection or during small load spikes. To prove that thread pool is actually our bottleneck it's best to monitor its internal queue. This requires a little bit of work:
class NaivePool implements EventConsumer, Closeable {
private final EventConsumer downstream;
private final ExecutorService executorService;
NaivePool(int size, EventConsumer downstream, MetricRegistry metricRegistry) {
LinkedBlockingQueue<Runnable> queue = new LinkedBlockingQueue<>();
String name = MetricRegistry.name(ProjectionMetrics.class, "queue");
Gauge<Integer> gauge = queue::size;
metricRegistry.register(name, gauge);
this.executorService =
new ThreadPoolExecutor(
size, size, 0L, TimeUnit.MILLISECONDS, queue);
this.downstream = downstream;
}
@Override
public Event consume(Event event) {
executorService.submit(() -> downstream.consume(event));
return event;
}
@Override
public void close() throws IOException {
executorService.shutdown();
}
}
The idea here is to create ThreadPoolExecutor
manually in order to provide custom LinkedBlockingQueue
instance. We can later use that queue to monitor its length (see: ExecutorService - 10 tips and tricks).
Gauge
will periodically invoke queue::size
and report it to wherever you need it. Metrics confirm that thread pool size was indeed a problem:
type=GAUGE, name=[...].queue, value=35
type=GAUGE, name=[...].queue, value=52
[...30 seconds later...]
type=GAUGE, name=[...].queue, value=601
The ever-growing size of the queue holding pending tasks hurts the latency. Increasing thread pool size from 10 to 20 finally reports decent results and no stalls. However we still didn't address duplicates and protecting from concurrent modification of events for the same clientId
.
Obscure locking
Let's start from avoiding concurrent processing of events for the same clientId
. If two events come very quickly one after another, both related to the same clientId
, NaivePool
will pick both of them and start processing them concurrently. First we'll at least discover such situation by having a Lock
for each clientId
:
@Slf4j
class FailOnConcurrentModification implements EventConsumer {
private final ConcurrentMap<Integer, Lock> clientLocks = new ConcurrentHashMap<>();
private final EventConsumer downstream;
FailOnConcurrentModification(EventConsumer downstream) {
this.downstream = downstream;
}
@Override
public Event consume(Event event) {
Lock lock = findClientLock(event);
if (lock.tryLock()) {
try {
downstream.consume(event);
} finally {
lock.unlock();
}
} else {
log.error("Client {} already being modified by another thread", event.getClientId());
}
return event;
}
private Lock findClientLock(Event event) {
return clientLocks.computeIfAbsent(
event.getClientId(),
clientId -> new ReentrantLock());
}
}
This is definitely going in the wrong direction. The amount of complexity is overwhelming but running this code at least reveals there is an issue. The event processing pipeline looks as follows, with one decorator wrapping another:
ClientProjection clientProjection =
new ClientProjection(new ProjectionMetrics(metricRegistry));
FailOnConcurrentModification failOnConcurrentModification =
new FailOnConcurrentModification(clientProjection);
NaivePool naivePool =
new NaivePool(10, failOnConcurrentModification, metricRegistry);
EventStream es = new EventStream();
es.consume(naivePool);
Once in a while the error message will pop-up, telling us that some other thread is already processing event for the same clientId
. For each clientId
we associate a Lock
that we examine in order to figure out if another thread is not processing that client at the moment. As ugly as it gets we are actually quite close to a brutal solution. Rather than failing when Lock
cannot be obtained because another thread is already processing some event, let's wait a little bit, hoping the Lock
will get released:
@Slf4j
class WaitOnConcurrentModification implements EventConsumer {
private final ConcurrentMap<Integer, Lock> clientLocks = new ConcurrentHashMap<>();
private final EventConsumer downstream;
private final Timer lockWait;
WaitOnConcurrentModification(EventConsumer downstream, MetricRegistry metricRegistry) {
this.downstream = downstream;
lockWait = metricRegistry.timer(MetricRegistry.name(WaitOnConcurrentModification.class, "lockWait"));
}
@Override
public Event consume(Event event) {
try {
final Lock lock = findClientLock(event);
final Timer.Context time = lockWait.time();
try {
final boolean locked = lock.tryLock(1, TimeUnit.SECONDS);
time.stop();
if(locked) {
downstream.consume(event);
}
} finally {
lock.unlock();
}
} catch (InterruptedException e) {
log.warn("Interrupted", e);
}
return event;
}
private Lock findClientLock(Event event) {
return clientLocks.computeIfAbsent(
event.getClientId(),
clientId -> new ReentrantLock());
}
}
The idea is very similar. But instead of failing tryLock()
waits up to 1 second hoping the Lock
for given client will be released. If two events come in very quick succession, one will obtain a Lock
and proceed whereas the other will block waiting for unlock()
to happen.
Not only this code is really convoluted, but probably also broken in many subtle ways. For example what if two events for the same clientId
came almost exactly at the same time, but obviously one was first?
Both events will ask for Lock
at the same time and we have no guarantee which event will obtain a non-fair Lock
first, possibly consuming events out of order. There must be a better way...
Dedicated threads
Let's take a step back and a very deep breath. How do you ensure things aren't happening concurrently?
Well, just use one thread!
As a matter of fact that's what we did in the very beginning but the throughput was unsatisfactory. But we don't care about concurrency for different clientId
s, we just have to make sure events with the same clientId
are always processed by the same thread!
Maybe creating a map from clientId
to Thread
comes to your mind?
Well, this would be overly simplistic. We would create thousands of threads, each idle most of the time as per the requirements (only few events per second for given clientId
). A good compromise is a fixed-size pool of threads, each thread responsible for a well-known subset of clientId
s. This way two different clientId
s may end up on the same thread but the same clientId
will always be handled by the same thread. If two events for the same clientId
appear, they will both be routed to the same thread, thus avoiding concurrent processing. The implementation is embarrassingly simple:
class SmartPool implements EventConsumer, Closeable {
private final List<ExecutorService> threadPools;
private final EventConsumer downstream;
SmartPool(int size, EventConsumer downstream, MetricRegistry metricRegistry) {
this.downstream = downstream;
List<ExecutorService> list = IntStream
.range(0, size)
.mapToObj(i -> Executors.newSingleThreadExecutor())
.collect(Collectors.toList());
this.threadPools = new CopyOnWriteArrayList<>(list);
}
@Override
public void close() throws IOException {
threadPools.forEach(ExecutorService::shutdown);
}
@Override
public Event consume(Event event) {
final int threadIdx = event.getClientId() % threadPools.size();
final ExecutorService executor = threadPools.get(threadIdx);
executor.submit(() -> downstream.consume(event));
return event;
}
}
The crucial part is right at the end:
int threadIdx = event.getClientId() % threadPools.size();
ExecutorService executor = threadPools.get(threadIdx);
This simple algorithm will always use the same single-thread ExecutorService
for the same clientId
. Different IDs may end up in the same pool, for example when pool size is 20
, clients 7
, 27
, 47
, etc. will use the same thread. But this is OK, as long as one clientId
always uses the same thread. At this point no locking is necessary and sequential invocation is guaranteed because events for the same client are always executed by the same thread. Side note: one thread per clientId
would not scale, but one actor per clientId
(e.g. in Akka) is a great idea that simplifies a lot.
By the way to be extra safe I plugged in metrics for average queue size in each and every thread pool which made the implementation longer:
class SmartPool implements EventConsumer, Closeable {
private final List<LinkedBlockingQueue<Runnable>> queues;
private final List<ExecutorService> threadPools;
private final EventConsumer downstream;
SmartPool(int size, EventConsumer downstream, MetricRegistry metricRegistry) {
this.downstream = downstream;
this.queues = IntStream
.range(0, size)
.mapToObj(i -> new LinkedBlockingQueue<Runnable>())
.collect(Collectors.toList());
List<ThreadPoolExecutor> list = queues
.stream()
.map(q -> new ThreadPoolExecutor(1, 1, 0L, TimeUnit.MILLISECONDS, q))
.collect(Collectors.toList());
this.threadPools = new CopyOnWriteArrayList<>(list);
metricRegistry.register(MetricRegistry.name(ProjectionMetrics.class, "queue"), (Gauge<Double>) this::averageQueueLength);
}
private double averageQueueLength() {
double totalLength =
queues
.stream()
.mapToDouble(LinkedBlockingQueue::size)
.sum();
return totalLength / queues.size();
}
//...
}
If you are paranoid you can even create one metric per each queue.
Deduplication and idempotency
In distributed environment it's quite common to receive duplicated events when your producer has at least once guarantees. The reasons behind such behavior are beyond the scope of this article but we must learn how to live with that issue. One way is to attach globally unique identifier (UUID
) to every message and make sure on the consumer side that messages with the same identifier aren't processed twice. Each Event
has such UUID
. The most straightforward solution under our requirements is to simply store all seen UUID
s and verify on arrival that received UUID
was never seen before. Using ConcurrentHashMap<UUID, UUID>
(there is no ConcurrentHashSet
in JDK) as-is will lead to memory leak as we will keep accumulating more and more IDs over time. That's why we only look for duplicates in the last 10 seconds. You can technically have ConcurrentHashMap<UUID, Instant>
that maps from UUID
to timestamp when it was encountered. By using a background thread we can then remove elements older than 10 seconds. But if you are a happy Guava user, Cache<UUID, UUID>
with declarative eviction policy will do the trick:
import com.codahale.metrics.Gauge;
import com.codahale.metrics.Meter;
import com.codahale.metrics.MetricRegistry;
import com.google.common.cache.Cache;
import com.google.common.cache.CacheBuilder;
import java.util.UUID;
import java.util.concurrent.TimeUnit;
class IgnoreDuplicates implements EventConsumer {
private final EventConsumer downstream;
private Cache<UUID, UUID> seenUuids = CacheBuilder.newBuilder()
.expireAfterWrite(10, TimeUnit.SECONDS)
.build();
IgnoreDuplicates(EventConsumer downstream) {
this.downstream = downstream;
}
@Override
public Event consume(Event event) {
final UUID uuid = event.getUuid();
if (seenUuids.asMap().putIfAbsent(uuid, uuid) == null) {
return downstream.consume(event);
} else {
return event;
}
}
}
Once again to be safe on production there are at least two metrics I can think of that might become useful: cache size and number of duplicates discovered. Let's plug-in these metrics as well:
class IgnoreDuplicates implements EventConsumer {
private final EventConsumer downstream;
private final Meter duplicates;
private Cache<UUID, UUID> seenUuids = CacheBuilder.newBuilder()
.expireAfterWrite(10, TimeUnit.SECONDS)
.build();
IgnoreDuplicates(EventConsumer downstream, MetricRegistry metricRegistry) {
this.downstream = downstream;
duplicates = metricRegistry.meter(MetricRegistry.name(IgnoreDuplicates.class, "duplicates"));
metricRegistry.register(MetricRegistry.name(IgnoreDuplicates.class, "cacheSize"), (Gauge<Long>) seenUuids::size);
}
@Override
public Event consume(Event event) {
final UUID uuid = event.getUuid();
if (seenUuids.asMap().putIfAbsent(uuid, uuid) == null) {
return downstream.consume(event);
} else {
duplicates.mark();
return event;
}
}
}
Finally we have all the pieces to build our solution. The idea is to compose pipeline from EventConsumer
instances wrapping each other:
- First we apply
IgnoreDuplicates
to reject duplicates - Then we call
SmartPool
that always pins givenclientId
to the same thread and executes next stage in that thread - Finally
ClientProjection
is invoked that does the real business logic.
You can optionally place FailOnConcurrentModification
step between SmartPool
and ClientProjection
for extra safety (concurrent modification shouldn't happen by design):
ClientProjection clientProjection =
new ClientProjection(new ProjectionMetrics(metricRegistry));
FailOnConcurrentModification concurrentModification =
new FailOnConcurrentModification(clientProjection);
SmartPool smartPool =
new SmartPool(12, concurrentModification, metricRegistry);
IgnoreDuplicates withoutDuplicates =
new IgnoreDuplicates(smartPool, metricRegistry);
EventStream es = new EventStream();
es.consume(withoutDuplicates);
It took us a lot of work to come up with relatively simple and well structured (I hope you agree) solution. In the end the best way to tackle concurrency issues is to... avoid concurrency and run code that is subject to race conditions in one thread. This is also the idea behind Akka actors (single message processed per actor) and RxJava (one message processed by Subscriber
).
What we came up so far was a combination of thread pools and shared cache. This time we will implement the solution using RxJava. First of all I never revealed how EventStream
is implemented, only giving the API:
interface EventStream {
void consume(EventConsumer consumer);
}
In fact for manual testing I built a simple RxJava stream that behaves like the system from the requirements:
@Slf4j
class EventStream {
void consume(EventConsumer consumer) {
observe()
.subscribe(
consumer::consume,
e -> log.error("Error emitting event", e)
);
}
Observable<Event> observe() {
return Observable
.interval(1, TimeUnit.MILLISECONDS)
.delay(x -> Observable.timer(RandomUtils.nextInt(0, 1_000), TimeUnit.MICROSECONDS))
.map(x -> new Event(RandomUtils.nextInt(1_000, 1_100), UUID.randomUUID()))
.flatMap(this::occasionallyDuplicate, 100)
.observeOn(Schedulers.io());
}
private Observable<Event> occasionallyDuplicate(Event x) {
final Observable<Event> event = Observable.just(x);
if (Math.random() >= 0.01) {
return event;
}
final Observable<Event> duplicated =
event.delay(RandomUtils.nextInt(10, 5_000), TimeUnit.MILLISECONDS);
return event.concatWith(duplicated);
}
}
Understanding how this simulator works is not essential, but quite interesting. First we generate steady stream of Long
values (0
, 1
, 2
...) every millisecond (thousand events per second) using interval()
operator. Then we delay each event by random amount of time between 0
and 1_000
microseconds with delay()
operator. This way events will appears in less predictable moments in time, a bit more realistic situation. Finally we map (using, ekhem, map()
operator) each Long
value to a random Event
with clientId
somewhere between 1_000
and 1_100
(inclusive-exclusive).
The last bit is interesting. We would like to simulate occasional duplicates. In order to do so we map every event (using flatMap()
) to itself (in 99% of the cases). However in 1% of the cases we return this event twice, where the second occurrence happens between 10 milliseconds and 5 seconds later. In practice the duplicated instance of the event will appear after hundreds of other events, which makes the stream behave really realistically.
There are two ways to interact with the EventStream
- callback based via consume()
and stream based via observe()
. We can take advantage of Observable<Event>
to quickly build processing pipeline very similar in functionality to part 1 but much simpler.
Missing backpressure
The first naive approach to take advantage of RxJava falls short very quickly:
EventStream es = new EventStream();
EventConsumer clientProjection = new ClientProjection(
new ProjectionMetrics(
new MetricRegistry()));
es.observe()
.subscribe(
clientProjection::consume,
e -> log.error("Fatal error", e)
);
(ClientProjection
, ProjectionMetrics
et. al. come from part 1). We get MissingBackpressureException
almost instantaneously and that was expected. Remember how our first solution was lagging by handling events with more and more latency?
RxJava tries to avoid that, as well as avoiding overflow of queues.
MissingBackpressureException
is thrown because consumer (ClientProjection
) is incapable of handling events in real time. This is fail-fast behavior. The quickest solution is to move consumption to a separate thread pool, just like before, but using RxJava's facilities:
EventStream es = new EventStream();
EventConsumer clientProjection = new FailOnConcurrentModification(
new ClientProjection(
new ProjectionMetrics(
new MetricRegistry())));
es.observe()
.flatMap(e -> clientProjection.consume(e, Schedulers.io()))
.window(1, TimeUnit.SECONDS)
.flatMap(Observable::count)
.subscribe(
c -> log.info("Processed {} events/s", c),
e -> log.error("Fatal error", e)
);
EventConsumer
interface has a helper method that can consume events asynchronously on a supplied Scheduler
:
@FunctionalInterface
interface EventConsumer {
Event consume(Event event);
default Observable<Event> consume(Event event, Scheduler scheduler) {
return Observable
.fromCallable(() -> this.consume(event))
.subscribeOn(scheduler);
}
}
By consuming events using flatMap()
in a separate Scheduler.io()
each consumption is invoked asynchronously. This time events are processed near real-time, but there is a bigger problem. I decorated ClientProjection
with FailOnConcurrentModification
for a reason. Events are consumed independently from each other so it may happen that two events for the same clientId
are processed concurrently. Not good. Luckily in RxJava solving this problem is much easier than with plain threads:
es.observe()
.groupBy(Event::getClientId)
.flatMap(byClient -> byClient
.observeOn(Schedulers.io())
.map(clientProjection::consume))
.window(1, TimeUnit.SECONDS)
.flatMap(Observable::count)
.subscribe(
c -> log.info("Processed {} events/s", c),
e -> log.error("Fatal error", e)
);
A little bit has changed. First of all we group events by clientId
. This splits single Observable
stream into stream of streams. Each substream named byClient
represents all events related to the same clientId
. Now if we map over this substream we can be sure that events related to the same clientId
are never processed concurrently. The outer stream is lazy so we must subscribe to it. Rather than subscribing to every event separately we collect events every second and count them. This way we receive a single event of type Integer
every second representing the number of events consumed per second.
Impure, non-idiomatic, error-prone, unsafe solution of deduplication using global state
Now we must drop duplicate UUID
s. The simplest, yet very foolish way of discarding duplicates is by taking advantage of global state. We can simply filter out duplicates by looking them up in cache available outside of filter()
operator:
final Cache<UUID, UUID> seenUuids = CacheBuilder.newBuilder()
.expireAfterWrite(10, TimeUnit.SECONDS)
.build();
es.observe()
.filter(e -> seenUuids.getIfPresent(e.getUuid()) == null)
.doOnNext(e -> seenUuids.put(e.getUuid(), e.getUuid()))
.subscribe(
clientProjection::consume,
e -> log.error("Fatal error", e)
);
If you want to monitor the usage of this mechanism simply add metric:
Meter duplicates = metricRegistry.meter("duplicates");
es.observe()
.filter(e -> {
if (seenUuids.getIfPresent(e.getUuid()) != null) {
duplicates.mark();
return false;
} else {
return true;
}
})
Accessing global, especially mutable state from inside of operators is very dangerous and undermines the sole purposes of RxJava - simplifying concurrency. Obviously we use thread-safe Cache
from Guava, but in many cases it's easy to miss places where shared global mutable state is accessed from multiple threads. If you find yourself mutating some variable outside of the operator chain, be very careful.
Custom distinct()
operator in RxJava 1.x
RxJava 1.x has a distinct()
operator that presumably does the job:
es.observe()
.distinct(Event::getUuid)
.groupBy(Event::getClientId)
Unfortunately distinct()
stores all keys (UUID
s) internally in ever-growing HashSet
. But we only care about duplicates in last 10 seconds!
By copy-pasting the implementation of DistinctOperator
I created DistinctEvent
operator that takes advantage of Guava's cache to only store last 10 seconds worth of UUID's. I intentionally hard-coded Event
in this operator rather than making it more generic to keep code easier to understand:
class DistinctEvent implements Observable.Operator<Event, Event> {
private final Duration duration;
DistinctEvent(Duration duration) {
this.duration = duration;
}
@Override
public Subscriber<? super Event> call(Subscriber<? super Event> child) {
return new Subscriber<Event>(child) {
final Map<UUID, Boolean> keyMemory = CacheBuilder.newBuilder()
.expireAfterWrite(duration.toMillis(), TimeUnit.MILLISECONDS)
.<UUID, Boolean>build().asMap();
@Override
public void onNext(Event event) {
if (keyMemory.put(event.getUuid(), true) == null) {
child.onNext(event);
} else {
request(1);
}
}
@Override
public void onError(Throwable e) {
child.onError(e);
}
@Override
public void onCompleted() {
child.onCompleted();
}
};
}
}
The usage is fairly simple and the whole implementation (plus the custom operator) is as short as:
es.observe()
.lift(new DistinctEvent(Duration.ofSeconds(10)))
.groupBy(Event::getClientId)
.flatMap(byClient -> byClient
.observeOn(Schedulers.io())
.map(clientProjection::consume)
)
.window(1, TimeUnit.SECONDS)
.flatMap(Observable::count)
.subscribe(
c -> log.info("Processed {} events/s", c),
e -> log.error("Fatal error", e)
);
Actually it can be even shorter if you skip logging every second:
es.observe()
.lift(new DistinctEvent(Duration.ofSeconds(10)))
.groupBy(Event::getClientId)
.flatMap(byClient -> byClient
.observeOn(Schedulers.io())
.map(clientProjection::consume)
)
.subscribe(
e -> {},
e -> log.error("Fatal error", e)
);
This solution is much shorter than previous one based on thread pools and decorators. The only awkward part is custom operator that avoid memory leak when storing too many historic UUID
s. Luckily RxJava 2 to the rescue!
RxJava 2.x and more powerful built-in distinct()
I was actually this close from submitting a PR to RxJava with more powerful implementation of distinct()
operator. But before I checked 2.x
branch and there it was: distinct()
that allows providing custom Collection
as opposed to hard-coded HashSet
. Believe it or not, dependency inversion is not only about Spring framework or Java EE. When a library allows you to provide custom implementation of its internal data structure, this is also DI. First I create a helper method that can build Set<UUID>
backed by Map<UUID, Boolean>
backed by Cache<UUID, Boolean>
. We sure like delegation!
private Set<UUID> recentUuids() {
return Collections.newSetFromMap(
CacheBuilder.newBuilder()
.expireAfterWrite(10, TimeUnit.SECONDS)
.<UUID, Boolean>build()
.asMap()
);
}
Having this method we can implement the whole task using this expression:
es.observe()
.distinct(Event::getUuid, this::recentUuids)
.groupBy(Event::getClientId)
.flatMap(byClient -> byClient
.observeOn(Schedulers.io())
.map(clientProjection::consume)
)
.subscribe(
e -> {},
e -> log.error("Fatal error", e)
);
The elegance, the simplicity, the clarity!
It reads almost like a problem:
- observe a stream of events
- take only distinct UUIDs into account
- group events by client
- for each client consume them (sequentially)
Hope you enjoyed all these solutions and you find them useful in your daily work.
Top comments (1)
I'm halfway through the implementation (starting the SmartPools) but this is one of the posts I've ever read. I always liked the Katas idea but disliked some examples for not addressing day to day coding challenges like dealing with Threads.
I look forward to your next posts and more useful challenge like this.
Cheers!