All Downloads are FREE. Search and download functionalities are using the official Maven repository.
Please wait. This can take some minutes ...
Many resources are needed to download a project. Please understand that we have to compensate our server costs. Thank you in advance.
Project price only 1 $
You can buy this project and download/modify it how often you want.
reactor.rx.action.combination.FanInAction Maven / Gradle / Ivy
/*
* Copyright (c) 2011-2014 Pivotal Software, 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 reactor.rx.action.combination;
import org.reactivestreams.Publisher;
import org.reactivestreams.Subscriber;
import org.reactivestreams.Subscription;
import reactor.Environment;
import reactor.core.Dispatcher;
import reactor.core.dispatch.SynchronousDispatcher;
import reactor.core.dispatch.TailRecurseDispatcher;
import reactor.core.support.NonBlocking;
import reactor.fn.Consumer;
import reactor.rx.Stream;
import reactor.rx.action.Action;
import java.util.concurrent.atomic.AtomicInteger;
import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
/**
* The best moment of my life so far, not.
*
* @author Stephane Maldini
* @since 2.0
*/
abstract public class FanInAction> extends Action {
final static protected int NOT_STARTED = 0;
final static protected int RUNNING = 1;
final static protected int COMPLETING = 2;
final FanInSubscription innerSubscriptions;
final Iterable extends Publisher extends I>> publishers;
final AtomicInteger status = new AtomicInteger();
final protected Dispatcher dispatcher;
DynamicMergeAction, ?> dynamicMergeAction = null;
@SuppressWarnings("unchecked")
public FanInAction(Dispatcher dispatcher) {
this(dispatcher, null);
}
public FanInAction(Dispatcher dispatcher,
Iterable extends Publisher extends I>> publishers) {
super();
this.dispatcher = SynchronousDispatcher.INSTANCE == dispatcher ?
Environment.tailRecurse() : dispatcher;
this.publishers = publishers;
this.upstreamSubscription = this.innerSubscriptions = createFanInSubscription();
}
@Override
public void subscribe(Subscriber super O> subscriber) {
doOnSubscribe(this.innerSubscriptions);
super.subscribe(subscriber);
}
public void addPublisher(Publisher extends I> publisher) {
InnerSubscriber inlineMerge = createSubscriber();
inlineMerge.pendingRequests = innerSubscriptions.pendingRequestSignals() / (innerSubscriptions.runningComposables
+ 1);
publisher.subscribe(inlineMerge);
}
public void scheduleCompletion() {
if (status.compareAndSet(NOT_STARTED, COMPLETING)) {
innerSubscriptions.serialComplete();
} else {
status.set(COMPLETING);
if (innerSubscriptions.runningComposables == 0) {
innerSubscriptions.serialComplete();
}
}
}
@Override
public void cancel() {
if (dynamicMergeAction != null) {
dynamicMergeAction.cancel();
}
innerSubscriptions.cancel();
}
public Action, ?> dynamicMergeAction() {
return dynamicMergeAction;
}
@Override
protected void doOnSubscribe(Subscription subscription) {
if (status.compareAndSet(NOT_STARTED, RUNNING)) {
innerSubscriptions.maxCapacity(capacity);
if (publishers != null) {
if (innerSubscriptions.runningComposables > 0) {
innerSubscriptions.cancel();
return;
}
capacity(initUpstreamPublisherAndCapacity());
}
}
}
protected long initUpstreamPublisherAndCapacity() {
long maxCapacity = capacity;
for (Publisher extends I> composable : publishers) {
if (Stream.class.isAssignableFrom(composable.getClass())) {
maxCapacity = Math.min(maxCapacity, ((Stream>) composable).getCapacity());
}
addPublisher(composable);
}
return maxCapacity;
}
protected final boolean checkDynamicMerge() {
return dynamicMergeAction != null && dynamicMergeAction.isPublishing();
}
@Override
public void onNext(E ev) {
super.onNext(ev);
if (innerSubscriptions.shouldRequestPendingSignals()) {
long left = upstreamSubscription.pendingRequestSignals();
if (left > 0l) {
upstreamSubscription.updatePendingRequests(-left);
dispatcher.dispatch(left, upstreamSubscription, null);
}
}
}
@Override
public void requestMore(long n) {
checkRequest(n);
dispatcher.dispatch(n, upstreamSubscription, null);
}
@Override
protected void requestUpstream(long capacity, boolean terminated, long elements) {
// innerSubscriptions.request(elements);
elements = Math.max(this.capacity, elements);
super.requestUpstream(capacity, terminated, elements);
if (dynamicMergeAction != null) {
dynamicMergeAction.requestUpstream(capacity, terminated, elements);
}
}
@Override
public final Dispatcher getDispatcher() {
return TailRecurseDispatcher.class == dispatcher.getClass() ? SynchronousDispatcher.INSTANCE : dispatcher;
}
@Override
public String toString() {
return super.toString() +
"{runningComposables=" + innerSubscriptions.runningComposables + "}";
}
protected FanInSubscription createFanInSubscription() {
return new FanInSubscription(this);
}
@Override
public FanInSubscription getSubscription() {
return innerSubscriptions;
}
protected abstract InnerSubscriber createSubscriber();
public abstract static class InnerSubscriber implements Subscriber, NonBlocking, Consumer {
final FanInAction> outerAction;
int sequenceId;
FanInSubscription.InnerSubscription> s;
long pendingRequests = 0;
long emittedSignals = 0;
volatile int terminated = 0;
final static AtomicIntegerFieldUpdater TERMINATE_UPDATER =
AtomicIntegerFieldUpdater.newUpdater(InnerSubscriber.class, "terminated");
InnerSubscriber(FanInAction> outerAction) {
this.outerAction = outerAction;
}
public void cancel() {
Subscription s = this.s;
if (s != null) {
s.cancel();
}
}
@SuppressWarnings("unchecked")
void setSubscription(FanInSubscription.InnerSubscription s) {
this.s = s;
this.sequenceId = outerAction.innerSubscriptions.addSubscription(this);
}
public void accept(Long pendingRequests) {
try {
if (pendingRequests > 0) {
request(pendingRequests);
}
} catch (Throwable e) {
outerAction.onError(e);
}
}
public void request(long n) {
if (s == null || n <= 0) return;
if ((pendingRequests += n) < 0l) {
pendingRequests = Long.MAX_VALUE;
}
emittedSignals = 0;
s.request(n);
}
@Override
public void onError(Throwable t) {
FanInSubscription.RUNNING_COMPOSABLE_UPDATER.decrementAndGet(outerAction.innerSubscriptions);
outerAction.innerSubscriptions.serialError(t);
}
@Override
public void onComplete() {
//Action.log.debug("event [complete] by: " + this);
if (TERMINATE_UPDATER.compareAndSet(this, 0, 1)) {
if(s != null) s.cancel();
outerAction.status.set(COMPLETING);
long left = FanInSubscription.RUNNING_COMPOSABLE_UPDATER.decrementAndGet(outerAction.innerSubscriptions);
left = left < 0l ? 0l : left;
outerAction.innerSubscriptions.remove(sequenceId);
if (left == 0) {
if (!outerAction.checkDynamicMerge()) {
outerAction.innerSubscriptions.serialComplete();
}
}
}
}
@Override
public boolean isReactivePull(Dispatcher dispatcher, long producerCapacity) {
return outerAction.isReactivePull(dispatcher, producerCapacity);
}
@Override
public long getCapacity() {
return outerAction.capacity;
}
@Override
public String toString() {
return "FanInAction.InnerSubscriber{pending=" + pendingRequests + ", emitted=" + emittedSignals + "}";
}
}
}