All Downloads are FREE. Search and download functionalities are using the official Maven repository.

rx.internal.operators.OperatorGroupByEvicting Maven / Gradle / Ivy

The newest version!
/**
 * Copyright 2018 Netflix, Inc.
 * 
 * Licensed under the Apache License, Version 2.0 (the "License");
 * you may not use this file except in compliance with the License.
 * You may obtain a copy of the License at
 * 
 * http://www.apache.org/licenses/LICENSE-2.0
 * 
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
package rx.internal.operators;

import java.util.*;
import java.util.concurrent.*;
import java.util.concurrent.atomic.*;

import rx.*;
import rx.Observable.*;
import rx.exceptions.Exceptions;
import rx.functions.*;
import rx.internal.producers.ProducerArbiter;
import rx.internal.util.*;
import rx.observables.GroupedObservable;
import rx.plugins.RxJavaHooks;
import rx.observers.Subscribers;
import rx.subscriptions.Subscriptions;

/**
 * Groups the items emitted by an Observable according to a specified criterion, and emits these
 * grouped items as Observables, one Observable per group.
 * 

* * * @param * the key type * @param * the source and group value type * @param * the value type of the groups */ public final class OperatorGroupByEvicting implements Operator, T>{ final Func1 keySelector; final Func1 valueSelector; final int bufferSize; final boolean delayError; final Func1, Map> mapFactory; //nullable @SuppressWarnings({ "unchecked", "rawtypes" }) public OperatorGroupByEvicting(Func1 keySelector) { this(keySelector, (Func1)UtilityFunctions.identity(), RxRingBuffer.SIZE, false, null); } public OperatorGroupByEvicting(Func1 keySelector, Func1 valueSelector) { this(keySelector, valueSelector, RxRingBuffer.SIZE, false, null); } public OperatorGroupByEvicting(Func1 keySelector, Func1 valueSelector, int bufferSize, boolean delayError, Func1, Map> mapFactory) { this.keySelector = keySelector; this.valueSelector = valueSelector; this.bufferSize = bufferSize; this.delayError = delayError; this.mapFactory = mapFactory; } @SuppressWarnings("unchecked") @Override public Subscriber call(Subscriber> child) { Map> groups; Queue> evictedGroups; if (mapFactory == null) { evictedGroups = null; groups = new ConcurrentHashMap>(); } else { evictedGroups = new ConcurrentLinkedQueue>(); Action1 evictionAction = (Action1)(Action1) new EvictionAction(evictedGroups); try { groups = (Map>)(Map) mapFactory.call((Action1)(Action1) evictionAction); } catch (Throwable ex) { //Can reach here because mapFactory.call() may throw Exceptions.throwOrReport(ex, child); Subscriber parent2 = Subscribers.empty(); parent2.unsubscribe(); return parent2; } } final GroupBySubscriber parent = new GroupBySubscriber( child, keySelector, valueSelector, bufferSize, delayError, groups, evictedGroups); child.add(Subscriptions.create(new Action0() { @Override public void call() { parent.cancel(); } })); child.setProducer(parent.producer); return parent; } public static final class GroupByProducer implements Producer { final GroupBySubscriber parent; public GroupByProducer(GroupBySubscriber parent) { this.parent = parent; } @Override public void request(long n) { parent.requestMore(n); } } public static final class GroupBySubscriber extends Subscriber { final Subscriber> actual; final Func1 keySelector; final Func1 valueSelector; final int bufferSize; final boolean delayError; final Map> groups; final Queue> queue; final GroupByProducer producer; final Queue> evictedGroups; static final Object NULL_KEY = new Object(); final ProducerArbiter s; final AtomicBoolean cancelled; final AtomicLong requested; final AtomicInteger groupCount; Throwable error; volatile boolean done; final AtomicInteger wip; public GroupBySubscriber(Subscriber> actual, Func1 keySelector, Func1 valueSelector, int bufferSize, boolean delayError, Map> groups, Queue> evictedGroups) { this.actual = actual; this.keySelector = keySelector; this.valueSelector = valueSelector; this.bufferSize = bufferSize; this.delayError = delayError; this.queue = new ConcurrentLinkedQueue>(); this.s = new ProducerArbiter(); this.s.request(bufferSize); this.producer = new GroupByProducer(this); this.cancelled = new AtomicBoolean(); this.requested = new AtomicLong(); this.groupCount = new AtomicInteger(1); this.wip = new AtomicInteger(); this.groups = groups; this.evictedGroups = evictedGroups; } @Override public void setProducer(Producer s) { this.s.setProducer(s); } @Override public void onNext(T t) { if (done) { return; } final Queue> q = this.queue; final Subscriber> a = this.actual; K key; try { key = keySelector.call(t); } catch (Throwable ex) { unsubscribe(); errorAll(a, q, ex); return; } boolean newGroup = false; @SuppressWarnings("unchecked") K mapKey = key != null ? key : (K) NULL_KEY; GroupedUnicast group = groups.get(mapKey); if (group == null) { // if the main has been cancelled, stop creating groups // and skip this value if (!cancelled.get()) { group = GroupedUnicast.createWith(key, bufferSize, this, delayError); groups.put(mapKey, group); groupCount.getAndIncrement(); newGroup = false; q.offer(group); drain(); } else { return; } } V v; try { v = valueSelector.call(t); } catch (Throwable ex) { unsubscribe(); errorAll(a, q, ex); return; } group.onNext(v); if (evictedGroups != null) { GroupedUnicast evictedGroup; while ((evictedGroup = evictedGroups.poll()) != null) { evictedGroup.onComplete(); } } if (newGroup) { q.offer(group); drain(); } } @Override public void onError(Throwable t) { if (done) { RxJavaHooks.onError(t); return; } error = t; done = true; groupCount.decrementAndGet(); drain(); } @Override public void onCompleted() { if (done) { return; } for (GroupedUnicast e : groups.values()) { e.onComplete(); } groups.clear(); if (evictedGroups != null) { evictedGroups.clear(); } done = true; groupCount.decrementAndGet(); drain(); } public void requestMore(long n) { if (n < 0) { throw new IllegalArgumentException("n >= 0 required but it was " + n); } BackpressureUtils.getAndAddRequest(requested, n); drain(); } public void cancel() { // cancelling the main source means we don't want any more groups // but running groups still require new values if (cancelled.compareAndSet(false, true)) { if (groupCount.decrementAndGet() == 0) { unsubscribe(); } } } public void cancel(K key) { Object mapKey = key != null ? key : NULL_KEY; if (groups.remove(mapKey) != null) { if (groupCount.decrementAndGet() == 0) { unsubscribe(); } } } void drain() { if (wip.getAndIncrement() != 0) { return; } int missed = 1; final Queue> q = this.queue; final Subscriber> a = this.actual; for (;;) { if (checkTerminated(done, q.isEmpty(), a, q)) { return; } long r = requested.get(); boolean unbounded = r == Long.MAX_VALUE; long e = 0L; while (r != 0) { boolean d = done; GroupedObservable t = q.poll(); boolean empty = t == null; if (checkTerminated(d, empty, a, q)) { return; } if (empty) { break; } a.onNext(t); r--; e--; } if (e != 0L) { if (!unbounded) { requested.addAndGet(e); } s.request(-e); } missed = wip.addAndGet(-missed); if (missed == 0) { break; } } } void errorAll(Subscriber> a, Queue q, Throwable ex) { q.clear(); List> list = new ArrayList>(groups.values()); groups.clear(); if (evictedGroups != null) { evictedGroups.clear(); } for (GroupedUnicast e : list) { e.onError(ex); } a.onError(ex); } boolean checkTerminated(boolean d, boolean empty, Subscriber> a, Queue q) { if (d) { Throwable err = error; if (err != null) { errorAll(a, q, err); return true; } else if (empty) { actual.onCompleted(); return true; } } return false; } } static class EvictionAction implements Action1> { final Queue> evictedGroups; EvictionAction(Queue> evictedGroups) { this.evictedGroups = evictedGroups; } @Override public void call(GroupedUnicast group) { evictedGroups.offer(group); } } static final class GroupedUnicast extends GroupedObservable { public static GroupedUnicast createWith(K key, int bufferSize, GroupBySubscriber parent, boolean delayError) { State state = new State(bufferSize, parent, key, delayError); return new GroupedUnicast(key, state); } final State state; protected GroupedUnicast(K key, State state) { super(key, state); this.state = state; } public void onNext(T t) { state.onNext(t); } public void onError(Throwable e) { state.onError(e); } public void onComplete() { state.onComplete(); } } static final class State extends AtomicInteger implements Producer, Subscription, OnSubscribe { /** */ private static final long serialVersionUID = -3852313036005250360L; final K key; final Queue queue; final GroupBySubscriber parent; final boolean delayError; final AtomicLong requested; volatile boolean done; Throwable error; final AtomicBoolean cancelled; final AtomicReference> actual; final AtomicBoolean once; public State(int bufferSize, GroupBySubscriber parent, K key, boolean delayError) { this.queue = new ConcurrentLinkedQueue(); this.parent = parent; this.key = key; this.delayError = delayError; this.cancelled = new AtomicBoolean(); this.actual = new AtomicReference>(); this.once = new AtomicBoolean(); this.requested = new AtomicLong(); } @Override public void request(long n) { if (n < 0) { throw new IllegalArgumentException("n >= required but it was " + n); } if (n != 0L) { BackpressureUtils.getAndAddRequest(requested, n); drain(); } } @Override public boolean isUnsubscribed() { return cancelled.get(); } @Override public void unsubscribe() { if (cancelled.compareAndSet(false, true)) { if (getAndIncrement() == 0) { parent.cancel(key); } } } @Override public void call(Subscriber s) { if (once.compareAndSet(false, true)) { s.add(this); s.setProducer(this); actual.lazySet(s); drain(); } else { s.onError(new IllegalStateException("Only one Subscriber allowed!")); } } public void onNext(T t) { if (t == null) { error = new NullPointerException(); done = true; } else { queue.offer(NotificationLite.next(t)); } drain(); } public void onError(Throwable e) { error = e; done = true; drain(); } public void onComplete() { done = true; drain(); } void drain() { if (getAndIncrement() != 0) { return; } int missed = 1; final Queue q = queue; final boolean delayError = this.delayError; Subscriber a = actual.get(); for (;;) { if (a != null) { if (checkTerminated(done, q.isEmpty(), a, delayError)) { return; } long r = requested.get(); boolean unbounded = r == Long.MAX_VALUE; long e = 0; while (r != 0L) { boolean d = done; Object v = q.poll(); boolean empty = v == null; if (checkTerminated(d, empty, a, delayError)) { return; } if (empty) { break; } a.onNext(NotificationLite.getValue(v)); r--; e--; } if (e != 0L) { if (!unbounded) { requested.addAndGet(e); } parent.s.request(-e); } } missed = addAndGet(-missed); if (missed == 0) { break; } if (a == null) { a = actual.get(); } } } boolean checkTerminated(boolean d, boolean empty, Subscriber a, boolean delayError) { if (cancelled.get()) { queue.clear(); parent.cancel(key); return true; } if (d) { if (delayError) { if (empty) { Throwable e = error; if (e != null) { a.onError(e); } else { a.onCompleted(); } return true; } } else { Throwable e = error; if (e != null) { queue.clear(); a.onError(e); return true; } else if (empty) { a.onCompleted(); return true; } } } return false; } } }