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

hu.akarnokd.rxjava3.operators.FlowableGenerateAsync Maven / Gradle / Ivy

Go to download

RxJava 3.x extra sources, operators and components and ports of many 1.x companion libraries.

There is a newer version: 3.1.1
Show newest version
/*
 * Copyright 2016-2019 David Karnok
 *
 * 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 hu.akarnokd.rxjava3.operators;

import java.util.concurrent.atomic.*;

import org.reactivestreams.*;

import io.reactivex.rxjava3.core.Flowable;
import io.reactivex.rxjava3.exceptions.Exceptions;
import io.reactivex.rxjava3.functions.*;
import io.reactivex.rxjava3.internal.subscriptions.EmptySubscription;
import io.reactivex.rxjava3.internal.util.*;
import io.reactivex.rxjava3.plugins.RxJavaPlugins;

/**
 * Generates items by invoking a callback, for each downstream request one by one, that sets up an
 * asynchronous call to some API that eventually responds with an item, an error or termination, while
 * making sure there is only one such outstanding API call in progress and honoring the
 * backpressure of the downstream.
 *
 * @param  the generated item type
 * @param  the state associated with an individual subscription.
 * @since 0.18.9 - experimental
 */
final class FlowableGenerateAsync extends Flowable {

    final Supplier initialState;

    final BiFunction, ? extends S> asyncGenerator;

    final Consumer stateCleanup;

    FlowableGenerateAsync(Supplier initialState,
            BiFunction, ? extends S> asyncGenerator,
            Consumer stateCleanup) {
        this.initialState = initialState;
        this.asyncGenerator = asyncGenerator;
        this.stateCleanup = stateCleanup;
    }

    @Override
    protected void subscribeActual(Subscriber s) {
        S state;

        try {
            state = initialState.get();
        } catch (Throwable ex) {
            Exceptions.throwIfFatal(ex);
            EmptySubscription.error(ex, s);
            return;
        }

        GenerateAsyncSubscription parent = new GenerateAsyncSubscription(s, state, asyncGenerator, stateCleanup);
        s.onSubscribe(parent);
        parent.moveNext();
    }

    static final class GenerateAsyncSubscription
    extends AtomicInteger
    implements Subscription, FlowableAsyncEmitter {

        private static final long serialVersionUID = -2460374219999425947L;

        final Subscriber downstream;

        final AtomicInteger wip;

        final AtomicLong requested;

        final AtomicCancellable resource;

        final BiFunction, ? extends S> asyncGenerator;

        final Consumer stateCleanup;

        final AtomicThrowable errors;

        volatile S state;

        T item;
        volatile int itemState;

        static final int ITEM_STATE_NOTHING_YET = 0;
        static final int ITEM_STATE_HAS_VALUE = 1;
        static final int ITEM_STATE_EMPTY = 2;
        static final int ITEM_STATE_DONE = 4;
        static final int ITEM_STATE_HAS_VALUE_DONE = ITEM_STATE_HAS_VALUE | ITEM_STATE_DONE;
        static final int ITEM_STATE_EMPTY_DONE = ITEM_STATE_HAS_VALUE | ITEM_STATE_DONE;

        volatile boolean done;

        volatile boolean cancelled;

        long emitted;

        GenerateAsyncSubscription(Subscriber downstream,
                S state,
                BiFunction, ? extends S> asyncGenerator,
                Consumer stateCleanup) {
            this.downstream = downstream;
            this.state = state;
            this.asyncGenerator = asyncGenerator;
            this.stateCleanup = stateCleanup;
            this.wip = new AtomicInteger();
            this.requested = new AtomicLong();
            this.resource = new AtomicCancellable();
            this.errors = new AtomicThrowable();
        }

        @Override
        public void request(long n) {
            BackpressureHelper.add(requested, n);
            drain();
        }

        @Override
        public void cancel() {
            cancelled = true;
            errors.tryTerminateAndReport();
            resource.cancel();
            if (getAndIncrement() == 0) {
                cleanup();
            }
        }

        void cleanup() {
            try {
                stateCleanup.accept(state);
            } catch (Throwable ex) {
                Exceptions.throwIfFatal(ex);
                RxJavaPlugins.onError(ex);
            }
        }

        @Override
        public void onNext(T value) {
            if (value != null) {
                item = value;
                itemState = ITEM_STATE_HAS_VALUE;
                drain();
            } else {
                onError(new NullPointerException("value is null"));
            }
        }

        @Override
        public void onError(Throwable error) {
            if (error == null) {
                error = new NullPointerException("error is null");
            }
            if (errors.tryAddThrowableOrReport(error)) {
                itemState |= ITEM_STATE_DONE;
                done = true;
                drain();
            }
        }

        @Override
        public void onComplete() {
            itemState |= ITEM_STATE_DONE;
            done = true;
            drain();
        }

        @Override
        public void onNothing() {
            item = null;
            itemState = ITEM_STATE_EMPTY;
            drain();
        }

        @Override
        public boolean isCancelled() {
            return cancelled;
        }

        @Override
        public boolean replaceCancellable(Cancellable c) {
            return resource.replaceCancellable(c);
        }

        @Override
        public boolean setCancellable(Cancellable c) {
            return resource.setCancellable(c);
        }

        void moveNext() {
            if (wip.getAndIncrement() == 0) {
                do {
                    if (cancelled) {
                        return;
                    }
                    try {
                        state = asyncGenerator.apply(state, this);
                    } catch (Throwable ex) {
                        Exceptions.throwIfFatal(ex);
                        onError(ex);
                        return;
                    }
                } while (wip.decrementAndGet() != 0);
            }
        }

        void drain() {
            if (getAndIncrement() != 0) {
                return;
            }

            int missed = 1;
            Subscriber downstream = this.downstream;
            long emitted = this.emitted;
            AtomicLong requested = this.requested;

            for (;;) {

                for (;;) {
                    if (cancelled) {
                        cleanup();
                        return;
                    }

                    boolean d = done;
                    int s = itemState;

                    if (d && s == ITEM_STATE_DONE) {
                        errors.tryTerminateConsumer(downstream);
                        resource.cancel();
                        cleanup();
                        return;
                    }

                    if ((s & ~ITEM_STATE_DONE) == ITEM_STATE_HAS_VALUE) {
                        if (emitted != requested.get()) {
                            T v = item;
                            item = null;

                            downstream.onNext(v);

                            emitted++;

                            if ((s & ITEM_STATE_DONE) != 0) {
                                itemState = ITEM_STATE_DONE;
                            } else {
                                itemState = ITEM_STATE_NOTHING_YET;
                                moveNext();
                            }
                        } else {
                            break;
                        }
                    } else if ((s & ~ITEM_STATE_DONE) == ITEM_STATE_EMPTY) {
                        if ((s & ITEM_STATE_DONE) != 0) {
                            itemState = ITEM_STATE_DONE;
                        } else {
                            itemState = ITEM_STATE_NOTHING_YET;
                            moveNext();
                        }
                    } else {
                        break;
                    }
                }

                this.emitted = emitted;
                missed = addAndGet(-missed);
                if (missed == 0) {
                    break;
                }
            }
        }
    }

    static final class AtomicCancellable extends AtomicReference {

        private static final long serialVersionUID = -8193511349691432602L;

        public boolean replaceCancellable(Cancellable c) {
            for (;;) {
                Cancellable curr = get();
                if (curr == CANCELLED) {
                    cancel(c);
                    return false;
                }
                if (compareAndSet(curr, c)) {
                    return true;
                }
            }
        }

        public boolean setCancellable(Cancellable c) {
            for (;;) {
                Cancellable curr = get();
                if (curr == CANCELLED) {
                    cancel(c);
                    return false;
                }
                if (compareAndSet(curr, c)) {
                    cancel(curr);
                    return true;
                }
            }
        }

        void cancel() {
            Cancellable c = getAndSet(CANCELLED);
            cancel(c);
        }

        void cancel(Cancellable c) {
            if (c != null) {
                try {
                    c.cancel();
                } catch (Throwable ex) {
                    Exceptions.throwIfFatal(ex);
                    RxJavaPlugins.onError(ex);
                }
            }
        }

        static final Cancellable CANCELLED = new Cancellable() {
            @Override
            public void cancel() throws Exception {
            }
        };
    }
}