Update dependency io.reactivex:rxjava to v1.3.8 - abandoned #30
Add this suggestion to a batch that can be applied as a single commit.
This suggestion is invalid because no changes were made to the code.
Suggestions cannot be applied while the pull request is closed.
Suggestions cannot be applied while viewing a subset of changes.
Only one suggestion per line can be applied in a batch.
Add this suggestion to a batch that can be applied as a single commit.
Applying suggestions on deleted lines is not supported.
You must change the existing code in this line in order to create a valid suggestion.
Outdated suggestions cannot be applied.
This suggestion has been applied or marked resolved.
Suggestions cannot be applied from pending reviews.
Suggestions cannot be applied on multi-line comments.
Suggestions cannot be applied while the pull request is queued to merge.
Suggestion cannot be applied right now. Please check back later.
This PR contains the following updates:
1.1.4->1.3.8Release Notes
ReactiveX/RxJava
v1.3.8: 1.3.8Maven
RxJava 1.x is now officially end-of-life (EOL). No further developments, bugfixes, enhancements, javadoc changes or maintenance will be provided by this project after version 1.3.8 and after today.
Users are encouraged to migrate to 2.x. In accordance, the wiki will be updated in the coming months to describe 2.x features and properties.
Bugfixes
take()to route late errors toRxJavaHooks.v1.3.7: 1.3.7Maven
Bugfixes
groupByand add a new overload with the corrected signature.v1.3.6: 1.3.6Maven
Bugfixes
OperatorMaterializeemit the wrong signals.OperatorMerge.InnerSubscriber#onErrorcausing incorrect terminal event.v1.3.5: 1.3.5Maven
Other
RxJavaPluginslookup workaround forSystem.getProperties()access restrictions.v1.3.4: 1.3.4Maven
Bugfixes
Completable.concatto usereplaceand don't dispose the oldSubscriptionon switching to the next source.unsubscribeOn().Documentation
take()operator will signal theonCompletedevent on the givenSchedulerwhen it times out.v1.3.3: 1.3.3Maven
Bugfixes
timeout(timed, selector) unsubscribe bug.v1.3.2: 1.3.2Maven
Bugfixes
v1.3.1: 1.3.1Maven
API changes
Remark: submitted & merged before the feature freeze of June 1st.
castoperator toSingle.Bugfixes
AsyncOnSubscribewhen the lastObservableis still running.TestSubscriber::assertValuesAndClearshould resetvalueCount.RxJavHooks.onErrorinSafeCompletableSuscriber.v1.3.0: 1.3.0Maven
Summary
Version 1.3.0 is the next minor release of the 1.x series of RxJava containing many formerly experimental API components promoted to standard. Most notably the
Completablebase reactive type is now standard as well.Note that the experimental
rx.Observable.fromEmitter()has been removed in favor for the now also standardObservable.create(Action1<Emitter<T>> emitter, Emitter.BackpressureMode backpressure)The planned lifecycle of the 1.x line is as follows:
Date | Remark
------------|-------------------
June 1, 2017 | Feature freeze, only bugfixes from this on.
September 1, 2017 | Release
1.4.0finalizing the remaining API components.March 31, 2018 | End of development.
The following components have been promoted to standard:
Classes, interfaces
AssemblyStackTraceException,RxJavaCompletableExecutionHook,RxJavaHooks,UnicastSubject,BlockingSingle,Completable,AssertableSubscriber,AsyncCompletableSubscriber,SafeCompletableSubscriberCancellable,Emitter,SingleEmitter,CompletableEmitter,CompletableSubscriber,BackpressureOverflow.StrategyOperators
Observable:create,unsafeCreate,to,zip(Observable[], FuncN),flatMapCompletable,flatMapSingle,groupby(Func1, Func1, Func1<Action1<K>, Map<K, Object>>),onTerminateDetach,rebatchRequests,subscribeOn(Scheduler, boolean),sorted,withLatestFrom,test,toCompletable,concatDelayError,mergeDelayError,switchOnNextDelayError,using(Func0, Func1, Action1, boolean),concatMapDelayError,delaySubscription(Observable),distinctUntilChanged(Func2),concatEager,concatMapEager,onBackpressureBuffer(long, Action0, BackpressureOverflow.Strategy),switchMapDelayError,toSortedList(int),toSortedList(Func2, int)Completable:fromEmitter,testSingle:fromEmitter,merge,mergeDelayError,cache,to,doOnEach,doOnSuccess,test,onErrorResumeNext,toCompletable,doOnError,doOnSubscribe,delay,defer,doOnUnsubscribe,doAfterTerminate,flatMapCompletable,lift,toBlocking,using,delaySubscription(Observable)TestSubscriber:getCompletions,awaitValueCount,assertValuesAndClearSyncOnSubscriber:createSingleState,createStateful,createStatelessOther
Schedulers.resetCompositeException(Throwable...)constructorExceptions.throwOrReport(4 overloads)BlockingObservable.subscribe(6 overloads)RxJavaSchedulersHook:createComputationScheduler,createIoScheduler,createNewThreadSchedulerAssertableSubscriberObservable,FlatMapCompletable,FlatMapSingle,SchedulerWhen,BackpressureDrainManager,BlockingUtils.RxJavaPlugins:reset,getCompletableExecutionHook,registerCompletableExecutionHookRxJavaErrorHandler:handleOnNextValueRendering,renderIn addition, the class
AsyncOnsubscribewith its 7 factory methods andObservable.create(AsyncOnSubscribe<S, T>)have been promoted to beta.Acknowledgements
Thanks to all who contributed to the 1.x line in the past 6 months (in order they appear on the commit page):
@mtiidla, @dhendry, @mostroverkhov, @yshrsmz, @BraisGabin, @cesar1000, @Jawnnypoo, @chanx2, @abersnaze, @davidmoten, @ortex, @marwinxxii, @ekchang, @pyricau, @JakeWharton, @VictorAlbertos
v1.2.10: 1.2.10Maven
Bugfixes
Completable.onErrorResumeNextunsubscribe not propagated.Other
TimeoutExceptionwhen using theSingle.timeout()operator.v1.2.9: 1.2.9Maven
API enhancements
Single.unsubscribeOn.UnicastSubjectwith optional delay error behavior.Bugfixes
replay()not terminating when all items timeout.replay().refCount()avoid leaking items between connections.v1.2.7: 1.2.7Maven
Deprecation of
create(OnSubscribe)The method started out in RxJava 0.x as a simple and direct way for implementing custom operators because 0.x had a much simpler protocol requirements. Over the years, as the
Observableprotocol evolved andcreatebecame a powerful and complicated extension point of RxJava that required users to implement theObservableprotocol, including cancellation and backpressure manually.Unfortunately, guides, blogs, StackOverflow answers and mere typical user behavior still leads to this
createmethod and lots of confusion, unstoppable sequences andMissingBackpressureException. We tried remedying the situation by introducingfromEmitterwith limited discoverability success.Therefore, as of 1.2.7 the
create()method is now deprecated (but won't be removed due to binary compatibility requirements). In additionfromEmitterhas been deprecate-renamed tocreate(Action1, BackpressureMode)and the experimental-markedfromEmitteritself will be removed in 1.3.0.Since the functionality of
create()was useful for writing (custom) operators inside and outside of RxJava, the newunsafeCreate(OnSubscribe)method was introduced as the replacement.The new
create()andunsafeCreate()methods will be fast-tracked to become standard in 1.3.0.API enhancements
create(), add alternativesSingle.merge(Observable<Single<T>>),Observable.flatMapSingle()&Observable.flatMapCompletable.subscribeOn(Scheduler, boolean)avoid same-pool deadlock.API deprecations
Observable.create(OnSubscribe),fromEmitterin favor ofObservable.create(Action1, BackpressureMode).Bugfixes
create(Action1, BackpressureMode)+subscribeOnavoid same-pool deadlock.throttleFirstdetecting clock-drift backwards to open the gateOther
switchIfEmptyv1.2.6: 1.2.6Maven
Documentation
sample(time)diagram to indicate emission of lastBehaviorSubjectBugfixes
groupByconsuming the upstream in an unbounded mannerv1.2.5: 1.2.5Maven
Documentation
Bugfixes
Completable.mergeDelayErrorto check unsafe availabilityv1.2.4: 1.2.4Maven
Other
resolveAndroidApiVersionwhen running under Robolectrictinstead of value to allow for IDE naming.TestSchedulerwith nanosecond periodic schedulingv1.2.3: 1.2.3Maven
Documentation enhancements
Schedulersjavadoc.API enhancements
AssertableSubscriberto provide method chained version ofTestSubscriberand support atest()method on the base reactive classes.Single.fromEmitterSingle.takeUntilCancellationExceptionmessage enhancementsPerformance enhancements
ObjectPool, code style cleanupsBugfixes
Schedule.when()bug fixCompletable.doAfterTerminateto run afteronErroras well.OnNextValuewith itstoString.Completable.concat&mergehanging in async situations.v1.2.2: 1.2.2Maven
Note that the interface
Cancellablehas been moved torx.functionsaffectingCompletableEmitterand the experimentalObservable.fromEmitter(Action1<AsyncEmitter<T>> emitter, AsyncEmitter.BackpressureMode backpressure)has been removed.Another important clarification was added to the javadoc about using
SingleSubscriber: due to the internal enhancements ofSingle, aSingleSubscriberis no longer wrapped into aSubscriber+SafeSubscriberwhich setup used to callunsubscribeon theSingleSubscriberyieldingisUnsubscribed() == truewhen the source terminated. Therefore, when one extends the classSingleSubscriber, theunsubscribe()should be called manually to yield the given expecation mentioned before:Documentation enhancements
timerjavadocSingleSubscriberdoc about unsubscribe invocation inonSuccessandonError.API enhancements
AsyncEmitterdeprecationscache()toSinglePerformance enhancements
zip- check local boolean before volatile in boolean andBugfixes
subscribe(Action1 [, Action1])to reportisUnsubscribedtrue after the callbacks were invokedObservable.switchIfEmptyv1.2.1: 1.2.1Maven
API enhancements
doOnErroranddoOnRequestAsyncEmittertoEmitterPerformance enhancements
NotificationLite- reduce allocationsSingleinternals to reduce overhead and stack depthDeprecations
CompletableEmitter.setCancellationwill change its type in 1.2.2.Single(Observable.OnSubscribe)constructorBugfixes
SafeSubscribernot to callRxJavaHooksbefore delivering the errorv1.2.0: 1.2.0Maven
This is a minor release that is functionally equivalent to 1.1.10 minus the removal of some deprecated experimental APIs.
Promote
@Betato standard (@since 1.2)rx.Observablecreate(SyncOnSubscribe<S, T>)doOnRequest(Action1<Long>)flatMap(Func1<? super T, ? extends Observable<? extends R>>, Func1<? super Throwable, ? extends Observable<? extends R>>, Func0<? extends Observable<? extends R>>, int)flatMap(Func1<? super T, ? extends Observable<? extends R>>, int)flatMap(Func1<? super T, ? extends Observable<? extends U>>, Func2<? super T, ? super U, ? extends R>, int)flatMapIterable(Func1<? super T, ? extends Iterable<? extends R>>, int) rx.Observable.flatMapIterable(Func1<? super T, ? extends Iterable<? extends U>>, Func2<? super T, ? super U, ? extends R>, int)fromCallable(Callable<? extends T>)toSingle()rx.Single(the class itself)fromCallable(Callable<? extends T>)rx.SingleSubscriber<T>rx.observables.ConnectableObservableautoConnect()autoConnect(int, Action1<? super Subscription>)autoConnect(int)rx.observables.SyncOnSubscribe<S, T>rx.subjects.AsyncSubjectgetThrowable()getValue()hasCompleted()hasThrowable()hasValue()rx.subjects.BehaviorSubjectgetThrowable()getValue()getValues()getValues(T[])hasCompleted()hasThrowable()hasValue()rx.subjects.PublishSubjectgetThrowable()hasCompleted()hasThrowable()rx.subjects.ReplaySubjectgetThrowable()getValue()getValues()getValues(T[])hasAnyValue()hasCompleted()hasThrowable()hasValue()size()Promote
@Experimentalto@Betarx.BackpressureOverflowrx.ObservableconcatDelayError(Iterable<? extends Observable<? extends T>>)concatDelayError(Observable<? extends Observable<? extends T>>)concatEager(Iterable<? extends Observable<? extends T>>, int)concatEager(Iterable<? extends Observable<? extends T>>)concatEager(Observable<? extends Observable<? extends T>>, int)concatEager(Observable<? extends Observable<? extends T>>)concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>)concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>)concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>)concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>)concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>)concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>)concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>)concatEager(Observable<? extends T>, Observable<? extends T>)concatMapDelayError(Func1<? super T, ? extends Observable<? extends R>>)concatMapEager(Func1<? super T, ? extends Observable<? extends R>>, int, int)concatMapEager(Func1<? super T, ? extends Observable<? extends R>>, int)concatMapEager(Func1<? super T, ? extends Observable<? extends R>>)delaySubscription(Observable<U>)distinctUntilChanged(Func2<? super T, ? super T, Boolean>)mergeDelayError(Observable<? extends Observable<? extends T>>, int)onBackpressureBuffer(long, Action0, Strategy)switchMapDelayError(Func1<? super T, ? extends Observable<? extends R>>)switchOnNextDelayError(Observable<? extends Observable<? extends T>>)toCompletable()toSortedList(Func2<? super T, ? super T, Integer>, int)toSortedList(int)using(Func0<Resource>, Func1<? super Resource, ? extends Observable<? extends T>>, Action1<? super Resource>, boolean)rx.observables.BlockingObservablesubscribe()subscribe(Action1<? super T>, Action1<? super Throwable>, Action0)subscribe(Action1<? super T>, Action1<? super Throwable>)subscribe(Action1<? super T>)subscribe(Observer<? super T>)subscribe(Subscriber<? super T>)rx.Completablerx.Singledefer(Callable<Single<T>>)delay(long, TimeUnit, Scheduler)delay(long, TimeUnit)delaySubscription(Observable<?>)doAfterTerminate(Action0)doOnError(Action1<Throwable>)doOnSubscribe(Action0)doOnSuccess(Action1<? super T>)doOnUnsubscribe(Action0)lift(Operator<? extends R, ? super T>)onErrorResumeNext(Func1<Throwable, ? extends Single<? extends T>>)onErrorResumeNext(Single<? extends T>)toBlocking()toCompletable()using(Func0<Resource>, Func1<? super Resource, ? extends Single<? extends T>>, Action1<? super Resource>, boolean)using(Func0<Resource>, Func1<? super Resource, ? extends Single<? extends T>>, Action1<? super Resource>)rx.exceptions.CompositeException.CompositeException(Throwable...)rx.exceptions.ExceptionsthrowOrReport(Throwable, Observer<?>, Object)throwOrReport(Throwable, Observer<?>)throwOrReport(Throwable, SingleSubscriber<?>)rx.singles.BlockingSingle<T>Removed
rx.Observableextend(Func1<OnSubscribe<T>, R>): useto(Func1)insteadfromAsync(): renamed tofromEmitter()rx.CompletableCompletableSubscriber: nowrx.CompletableSubscriberCompletableOnSubscribe: renamed toCompletable.OnSubscribeCompletableOperator: renamed toCompletable.OperatorCompletableTransformer: renamed toCompletable.Transformerv1.1.10: 1.1.10Maven
The release contains a few javadoc and internal cleanups, some enhancements and some deprecations.
Notable renames:
fromAsyncis nowfromEmitterrx.Completable.CompletableSubscriberis nowrx.CompletableSubscriberAPI enhancements
to(Func1)toObservable,SingleandCompletable.Completablehelper interfaces by dropping theCompletableprefix, moverx.Completable.CompletableSubscribertorx.CompletableSubscriber.fromAsynctofromEmitter.Completable.fromEmitterthrows InterruptedExceptionfromTestSubscriber.awaitValueCount()Completable.doOnEach(Action1)Single.doOnEachDeprecations
CompletableOnSubscribe,CompletableOperatorandCompletableTransformerand rename them by dropping theCompletableprefixObservable.fromAsyncby renaming it toObservable.fromEmitter.Notification.createOnCompleted(Class)Bugfixes
throttleFirstwithTestSchedulerObservable.fromEmitter(formerlyObservable.fromAsync) post-complete event suppressionObservable.withLatestFromv1.1.9: 1.1.9(Maven)
This release contains mostly internal cleanups, reinforced Observable-protocol adherence and minor javadoc fixes.
Warning: the backpressure-behavior of
PublishSubjecthas been changed. In earlier versions, when you calledPublishSubject.onNexttoo frequently, that usually triggered aMissingBackpressureExceptionin some downstream operator (observeOn,zip, etc.) and often it was not obvious who to blame for it. With 1.1.9,PublishSubjectnow tracks the request amounts of each of its children and refuses to overflow them, signalling aMissingBackpressureExceptionto them instead which now points to the right operator.API enhancements
Single.flatMapCompletable.PublishSubjectnow signalsMissingBackpressureExceptionwhen backpressured.Observable.sorted()+ overloads: sorts and re-emits each element of a finite sequence.concatDelayErrormultiple arguments.Observable.concat(Iterable)overload.TestSubscriber.assertValuesAndClearPerformance enhancements
amb.autoConnect.join.groupJoin.skipwith time.doOnEach.MultipleAssignmentSubscriptionandSerialSubscriptionBugfixes
Schedulers.io()workers now wait until a blocking task finishes before becoming available again.allmultiple terminal events.repeatWhenandretryWhenwhen the resubscription happens.PublishSubjectnow checks for unsubscribed child while dispatching events.anymultiple terminal events.reducemultiple terminal events.onBackpressureDropmultiple terminal events.collectmultiple terminal events.toMapmultiple terminal events and backpressure behavior.toMultimapmultiple terminal events .Schedulers.from()to callRxJavaHooks.onScheduleAction.v1.1.8: 1.1.8Version 1.1.8 - July 23, 2016 (Maven)
Bugfixes
merge/flatMapto keep scalar/inner element relative order.v1.1.7: 1.1.7Version 1.1.7 - July 10, 2016 (Maven)
This release has several documentation fixes (
AsyncSubject,doOnEach,cache,scan,reduce, backpressure descriptions) and internal cleanups based on tool feedback (code-coverage and PMD).Warning: behavior change in the time-bound
replay()operator: the aging of the values continues after the termination of the source and thus late subscribers no longer get old data. For example, a givenjust(1).replay(1, TimeUnit.MINUTE)a subscriber subscribing after 2 minutes won't get1but onlyonCompleted.Warning: behavior change in
timestamp()andtimeInterval()(no arguments) operators: they now take timing information from thecomputationscheduler instead of theimmediatescheduler. This change now allows hooking these operators' time source.Warning: the parameter order of
Completable.subscribe(onError, onComplete)has been changed toCompletable.subscribe(onComplete, onError)to better match the callback order in the other base reactive classes, namely the most significant signal comes first (Observer.onNext,SingleSubscriber.onSuccess, and nowCompletableSubscriber.onCompleted).The new RxJavaHooks API
PR #4007 introduced a new way of hooking into the lifecycle of the base reactive types (
Observable,Single,Completable) and theSchedulers. The originalRxJavaPlugins' design was too much focused on class-initialization time hooking and didn't properly allow hooking up different behavior after that. There is areset()available on it but sometimes that doesn't work as expected.The new class
rx.plugins.RxJavaHooksallows changing the hooks at runtime, allowing tests to temporarily hook onto an internal behavior and then un-hook once the test completed.It is now also possible to override what
Schedulers theSchedulers.computation(),.io()and.newThread()returns without the need to fiddle withSchedulers' own reset behavior:By default, all
RxJavaHooksdelegate to the originalRxJavaPluginscallbacks so if you have hooks the old way, they still work.RxJavaHooks.reset()resets to this delegation andRxJavaHooks.clear()clears all hooks (i.e., everything becomes a pass-through hook).API enhancements
withLatestFromoperators.Subscriptions to composite subscription.distinctUntilChangedwith direct value comparator - alternative.AsyncCompletableSubscriberthat exposesunsubscribe().TestObserver, enhanceTestSubscribera bit.groupByoverload withevictingMapFactoryCompletable.subscribe(onError, onComplete)to(onComplete, onError)Scheduler.when.fromAsyncto bridge the callback world with the reactive.API deprecations
TestObserver, enhanceTestSubscribera bit.RxJavaPluginsmethods).Performance enhancements
map()andfilter()to implementOnSubscribedirectly.Bugfixes
Completable.onErrorComplete(Func1)not relaying function crash.ReplaySubjectanomaly around caughtUp by disabling that optimization.v1.1.6: 1.1.6Version 1.1.6 - June 15, 2016 (Maven)
API enhancements
TestSubscriberextra info on assertion failuresCompletable.andThen(Completable)Completable.subscribeto be safe, addunsafeSubscribeoption +RxJavaPluginshook supportUnicastSubjectto be a standard+experimentalSubjectObservable.rebatchRequestsoperator to change and stabilize request amounts of the downstream.Schedulers.reset()for better testingReplaySubjectnow supports backpressureAPI deprecations
Completable.endWith()in favor ofandThen()Performance enhancements
replayrequest coordination reduce overheadBugfixes
RxRingBuffer-pool depending on thecomputationschedulerusing()resource cleanup when factory throws or being non-eagerSingle.flatMapnot composing subscription throughjust()construction to call theonCreateexecution hookThrowableto set the cause forCompositeExceptionv1.1.5: 1.1.5Version 1.1.5 - May 5, 2016 (Maven)
Bugfixes
Configuration
📅 Schedule: Branch creation - At any time (no schedule defined), Automerge - At any time (no schedule defined).
🚦 Automerge: Disabled by config. Please merge this manually once you are satisfied.
♻ Rebasing: Whenever PR becomes conflicted, or you tick the rebase/retry checkbox.
🔕 Ignore: Close this PR and you won't be reminded about this update again.
This PR has been generated by Mend Renovate. View repository job log here.