Update dependency io.reactivex:rxjava to v1.3.8 - abandoned #49
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.8
Release 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
groupBy
and add a new overload with the corrected signature.v1.3.6
: 1.3.6Maven
Bugfixes
OperatorMaterialize
emit the wrong signals.OperatorMerge.InnerSubscriber#onError
causing incorrect terminal event.v1.3.5
: 1.3.5Maven
Other
RxJavaPlugins
lookup workaround forSystem.getProperties()
access restrictions.v1.3.4
: 1.3.4Maven
Bugfixes
Completable.concat
to usereplace
and don't dispose the oldSubscription
on switching to the next source.unsubscribeOn()
.Documentation
take()
operator will signal theonCompleted
event on the givenScheduler
when 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.
cast
operator toSingle
.Bugfixes
AsyncOnSubscribe
when the lastObservable
is still running.TestSubscriber::assertValuesAndClear
should resetvalueCount
.RxJavHooks.onError
inSafeCompletableSuscriber
.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
Completable
base 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.0
finalizing 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
,SafeCompletableSubscriber
Cancellable
,Emitter
,SingleEmitter
,CompletableEmitter
,CompletableSubscriber
,BackpressureOverflow.Strategy
Operators
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
,test
Single
: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
,assertValuesAndClear
SyncOnSubscriber
:createSingleState
,createStateful
,createStateless
Other
Schedulers.reset
CompositeException(Throwable...)
constructorExceptions.throwOrReport
(4 overloads)BlockingObservable.subscribe
(6 overloads)RxJavaSchedulersHook
:createComputationScheduler
,createIoScheduler
,createNewThreadScheduler
AssertableSubscriberObservable
,FlatMapCompletable
,FlatMapSingle
,SchedulerWhen
,BackpressureDrainManager
,BlockingUtils
.RxJavaPlugins
:reset
,getCompletableExecutionHook
,registerCompletableExecutionHook
RxJavaErrorHandler
:handleOnNextValueRendering
,render
In addition, the class
AsyncOnsubscribe
with 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.onErrorResumeNext
unsubscribe not propagated.Other
TimeoutException
when using theSingle.timeout()
operator.v1.2.9
: 1.2.9Maven
API enhancements
Single.unsubscribeOn
.UnicastSubject
with 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
Observable
protocol evolved andcreate
became a powerful and complicated extension point of RxJava that required users to implement theObservable
protocol, including cancellation and backpressure manually.Unfortunately, guides, blogs, StackOverflow answers and mere typical user behavior still leads to this
create
method and lots of confusion, unstoppable sequences andMissingBackpressureException
. We tried remedying the situation by introducingfromEmitter
with 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 additionfromEmitter
has been deprecate-renamed tocreate(Action1, BackpressureMode)
and the experimental-markedfromEmitter
itself 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)
,fromEmitter
in favor ofObservable.create(Action1, BackpressureMode)
.Bugfixes
create(Action1, BackpressureMode)
+subscribeOn
avoid same-pool deadlock.throttleFirst
detecting clock-drift backwards to open the gateOther
switchIfEmpty
v1.2.6
: 1.2.6Maven
Documentation
sample(time)
diagram to indicate emission of lastBehaviorSubject
Bugfixes
groupBy
consuming the upstream in an unbounded mannerv1.2.5
: 1.2.5Maven
Documentation
Bugfixes
Completable.mergeDelayError
to check unsafe availabilityv1.2.4
: 1.2.4Maven
Other
resolveAndroidApiVersion
when running under Robolectrict
instead of value to allow for IDE naming.TestScheduler
with nanosecond periodic schedulingv1.2.3
: 1.2.3Maven
Documentation enhancements
Schedulers
javadoc.API enhancements
AssertableSubscriber
to provide method chained version ofTestSubscriber
and support atest()
method on the base reactive classes.Single.fromEmitter
Single.takeUntil
CancellationException
message enhancementsPerformance enhancements
ObjectPool
, code style cleanupsBugfixes
Schedule.when()
bug fixCompletable.doAfterTerminate
to run afteronError
as well.OnNextValue
with itstoString
.Completable.concat
&merge
hanging in async situations.v1.2.2
: 1.2.2Maven
Note that the interface
Cancellable
has been moved torx.functions
affectingCompletableEmitter
and 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
, aSingleSubscriber
is no longer wrapped into aSubscriber
+SafeSubscriber
which setup used to callunsubscribe
on theSingleSubscriber
yieldingisUnsubscribed() == true
when the source terminated. Therefore, when one extends the classSingleSubscriber
, theunsubscribe()
should be called manually to yield the given expecation mentioned before:Documentation enhancements
timer
javadocSingleSubscriber
doc about unsubscribe invocation inonSuccess
andonError
.API enhancements
AsyncEmitter
deprecationscache()
toSingle
Performance enhancements
zip
- check local boolean before volatile in boolean andBugfixes
subscribe(Action1 [, Action1])
to reportisUnsubscribed
true after the callbacks were invokedObservable.switchIfEmpty
v1.2.1
: 1.2.1Maven
API enhancements
doOnError
anddoOnRequest
AsyncEmitter
toEmitter
Performance enhancements
NotificationLite
- reduce allocationsSingle
internals to reduce overhead and stack depthDeprecations
CompletableEmitter.setCancellation
will change its type in 1.2.2.Single(Observable.OnSubscribe)
constructorBugfixes
SafeSubscriber
not to callRxJavaHooks
before 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
@Beta
to standard (@since 1.2
)rx.Observable
create(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.ConnectableObservable
autoConnect()
autoConnect(int, Action1<? super Subscription>)
autoConnect(int)
rx.observables.SyncOnSubscribe<S, T>
rx.subjects.AsyncSubject
getThrowable()
getValue()
hasCompleted()
hasThrowable()
hasValue()
rx.subjects.BehaviorSubject
getThrowable()
getValue()
getValues()
getValues(T[])
hasCompleted()
hasThrowable()
hasValue()
rx.subjects.PublishSubject
getThrowable()
hasCompleted()
hasThrowable()
rx.subjects.ReplaySubject
getThrowable()
getValue()
getValues()
getValues(T[])
hasAnyValue()
hasCompleted()
hasThrowable()
hasValue()
size()
Promote
@Experimental
to@Beta
rx.BackpressureOverflow
rx.Observable
concatDelayError(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.BlockingObservable
subscribe()
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.Completable
rx.Single
defer(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.Exceptions
throwOrReport(Throwable, Observer<?>, Object)
throwOrReport(Throwable, Observer<?>)
throwOrReport(Throwable, SingleSubscriber<?>)
rx.singles.BlockingSingle<T>
Removed
rx.Observable
extend(Func1<OnSubscribe<T>, R>)
: useto(Func1)
insteadfromAsync()
: renamed tofromEmitter()
rx.Completable
CompletableSubscriber
: nowrx.CompletableSubscriber
CompletableOnSubscribe
: renamed toCompletable.OnSubscribe
CompletableOperator
: renamed toCompletable.Operator
CompletableTransformer
: renamed toCompletable.Transformer
v1.1.10
: 1.1.10Maven
The release contains a few javadoc and internal cleanups, some enhancements and some deprecations.
Notable renames:
fromAsync
is nowfromEmitter
rx.Completable.CompletableSubscriber
is nowrx.CompletableSubscriber
API enhancements
to(Func1)
toObservable
,Single
andCompletable
.Completable
helper interfaces by dropping theCompletable
prefix, moverx.Completable.CompletableSubscriber
torx.CompletableSubscriber
.fromAsync
tofromEmitter
.Completable.fromEmitter
throws InterruptedException
fromTestSubscriber.awaitValueCount()
Completable.doOnEach(Action1)
Single.doOnEach
Deprecations
CompletableOnSubscribe
,CompletableOperator
andCompletableTransformer
and rename them by dropping theCompletable
prefixObservable.fromAsync
by renaming it toObservable.fromEmitter
.Notification.createOnCompleted(Class)
Bugfixes
throttleFirst
withTestScheduler
Observable.fromEmitter
(formerlyObservable.fromAsync
) post-complete event suppressionObservable.withLatestFrom
v1.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
PublishSubject
has been changed. In earlier versions, when you calledPublishSubject.onNext
too frequently, that usually triggered aMissingBackpressureException
in some downstream operator (observeOn
,zip
, etc.) and often it was not obvious who to blame for it. With 1.1.9,PublishSubject
now tracks the request amounts of each of its children and refuses to overflow them, signalling aMissingBackpressureException
to them instead which now points to the right operator.API enhancements
Single.flatMapCompletable
.PublishSubject
now signalsMissingBackpressureException
when backpressured.Observable.sorted()
+ overloads: sorts and re-emits each element of a finite sequence.concatDelayError
multiple arguments.Observable.concat(Iterable)
overload.TestSubscriber.assertValuesAndClear
Performance enhancements
amb
.autoConnect
.join
.groupJoin
.skip
with time.doOnEach
.MultipleAssignmentSubscription
andSerialSubscription
Bugfixes
Schedulers.io()
workers now wait until a blocking task finishes before becoming available again.all
multiple terminal events.repeatWhen
andretryWhen
when the resubscription happens.PublishSubject
now checks for unsubscribed child while dispatching events.any
multiple terminal events.reduce
multiple terminal events.onBackpressureDrop
multiple terminal events.collect
multiple terminal events.toMap
multiple terminal events and backpressure behavior.toMultimap
multiple terminal events .Schedulers.from()
to callRxJavaHooks.onScheduleAction
.v1.1.8
: 1.1.8Version 1.1.8 - July 23, 2016 (Maven)
Bugfixes
merge
/flatMap
to 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 get1
but onlyonCompleted
.Warning: behavior change in
timestamp()
andtimeInterval()
(no arguments) operators: they now take timing information from thecomputation
scheduler instead of theimmediate
scheduler. 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 theScheduler
s. 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.RxJavaHooks
allows 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
Scheduler
s theSchedulers.computation()
,.io()
and.newThread()
returns without the need to fiddle withSchedulers
' own reset behavior:By default, all
RxJavaHooks
delegate to the originalRxJavaPlugins
callbacks 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
withLatestFrom
operators.Subscription
s to composite subscription.distinctUntilChanged
with direct value comparator - alternative.AsyncCompletableSubscriber
that exposesunsubscribe()
.TestObserver
, enhanceTestSubscriber
a bit.groupBy
overload withevictingMapFactory
Completable.subscribe(onError, onComplete)
to(onComplete, onError)
Scheduler.when
.fromAsync
to bridge the callback world with the reactive.API deprecations
TestObserver
, enhanceTestSubscriber
a bit.RxJavaPlugins
methods).Performance enhancements
map()
andfilter()
to implementOnSubscribe
directly.Bugfixes
Completable.onErrorComplete(Func1)
not relaying function crash.ReplaySubject
anomaly around caughtUp by disabling that optimization.v1.1.6
: 1.1.6Version 1.1.6 - June 15, 2016 (Maven)
API enhancements
TestSubscriber
extra info on assertion failuresCompletable.andThen(Completable)
Completable.subscribe
to be safe, addunsafeSubscribe
option +RxJavaPlugins
hook supportUnicastSubject
to be a standard+experimentalSubject
Observable.rebatchRequests
operator to change and stabilize request amounts of the downstream.Schedulers.reset()
for better testingReplaySubject
now supports backpressureAPI deprecations
Completable.endWith()
in favor ofandThen()
Performance enhancements
replay
request coordination reduce overheadBugfixes
RxRingBuffer
-pool depending on thecomputation
schedulerusing()
resource cleanup when factory throws or being non-eagerSingle.flatMap
not composing subscription throughjust()
construction to call theonCreate
execution hookThrowable
to set the cause forCompositeException
v1.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.