This repository has been archived by the owner on Aug 8, 2021. It is now read-only.
Update dependency io.reactivex.rxjava2:rxjava to v2.2.21 #45
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:
2.1.3
->2.2.21
Release Notes
ReactiveX/RxJava
v2.2.21
Maven
JavaDocs
Enhancements
Scheduler
. (#7162)Scheduler
s to useSystem.nanoTime()
fornow()
. (#7170)v2.2.20
Maven
JavaDocs
Bugfixes
Observable.flatMap
withmaxConcurrency
hangs (#6960)Observable.toFlowable(ERROR)
not cancelling uponMissingBackpressureException
(#7084)Flowable.concatMap
backpressure with scalars. (#7091)v2.2.19
Maven
JavaDocs
Bugfixes
switchMap
not canceling properly duringonNext
-cancel
races.v2.2.18
Maven
Bugfixes
groupBy
not requesting more if a group is cancelled with buffered items.v2.2.17
Maven
Bugfixes
Flowable.flatMap
not canceling the inner sources on outer error.v2.2.16
Maven
Bugfixes
amb
,combineLatest
andzip
Iterable
overloads throwingArrayStoreException
forObservableSource
s.Documentation changes
v2.2.15
Maven
Bugfixes
MulticastProcessor
not requesting more after limit is reached.clear
inobserveOn
while output-fused.parallel()
on grouped flowable not replenishing properly.Documentation changes
observeOn
to mention its eagerness.Other changes
j.u.c.Flow
warnings due to RS 1.0.3.v2.2.14
Maven
Bugfixes
clear()
calls when fused chains are canceled.window(time)
possible interrupts while terminating.Documentation changes
Single
from 3.x.v2.2.13
Maven
Dependencies
Bugfixes
System.getProperties()
.takeLast(time)
last events time window calculation.window
not creating windows properly.v2.2.12
Maven
Bugfixes
switchMap
incorrect sync-fusion & error management.blockingIterable
hang when force-disposed.refCount
not resetting when cross-canceled.v2.2.11
Maven
Bugfixes
mergeWith
not canceling other when the main fails.ObservableBlockingSubscribe
compares with wrong object.replay()
andReplaySubject
/Processor
.Documentation changes
Single.doOnTerminate
refer toonComplete
notification.v2.2.10
Maven
Bugfixes
BufferExactBoundedObserver
.publish().refCount()
hang due to race.concatMapDelayError
not continuing on fused inner source crash.Documentation changes
Additional-Reading.md
.Alphabetical-List-of-Observable-Operators.md
.Flowable
.v2.2.9
Maven
Bugfixes
zip
not stopping the subscription upon eager error.Documentation changes
Maybe
andSingle
JavaDocs.retry
operator.Other
Schedulers
fromObservableRefCount
.ObservableFromArray
.sample(Observable)
.Flowable.java
.else
from theObservable
.v2.2.8
Maven
Bugfixes
Completable.fromRunnable
&fromAction
operators.Documentation changes
CompositeDisposable
.Creating-Observables
wiki doc.Other
v2.2.7
Maven
API enhancements
doOnTerminate
toSingle
/Maybe
for consistency.Bugfixes
window()
with start/end selector not disposing/cancelling properly.Documentation changes
Observable#debounce
andFlowable#debounce
javadoc.flattenAsFlowable
andflattenAsObservable
methods.v2.2.6
Maven
API enhancements
Schedulers.from(Executor, boolean)
overload.Bugfixes
Observable.repeatWhen
due to flooding repeat signal.Completable.andThen(Completable)
not running onobserveOn
'sScheduler
.Flowable.publish
not requesting upon client change.replay()
memory leak due to bad node retention.{Single|Maybe|Completable}.amb()
.CompositeException.getRootCause()
detecting loops in the cause graph.Documentation changes
timeout(fallback)
.Other changes
ignoreElement
to convertSingle
toCompletable
in theREADME.md
.v2.2.5
Maven
Documentation changes
elementAtOrDefault
.@code
.Wiki changes
Other changes
@NonNull
annotation factory methods.v2.2.4
Maven
API changes
Maybe
/Single
/Completable
materialize
operator,Single.dematerialize(selector)
operator.Flowable
/Observable
dematerialize(selector)
operator.Bugfixes
doOn{Dispose|Cancel}
handler at most once.Observable.flatMap
to sustain concurrency level.Documentation changes
io.reactivex.schedulers
.onSubscribe
null-checks to NPE docs onFlowable
/Observable
subscribe
.Flowable.zip
docs.Emitter
interface methods.Flowable.groupBy
.distinctUntilChanged
requires non-mutating data to work as expected.Wiki changes
generate
examples toCreating-Observables.md
.Creating-Observables.md
docs stlye mistake.How-to-Contribute.md
.Other changes
SubscriptionHelper.isCancelled()
.Observable
/Flowable
cache()
operators.Scheduler
as System property.Flowable.toObservable
backpressure annotation.v2.2.3
Maven
API changes
Completable.delaySubscription()
operator.Documentation changes
ConnectableObservable
.io.reactivex.functions.Functions
nonexistent utility class.Other changes
Observable.flatMap
drain logic.TimeoutException
message in thetimeout
operators.UndeliverableException
andOnErrorNotImplementedException
message to use the full inner exception.@Nullable
annotations for blocking methods inCompletable
.v2.2.2
Maven
Bugfixes
refCount
termination-reconnect race.Documentation changes
Undeliverable
&OnErrorNotImplemented
exceptions.null
observer/subscriber return errors fromRxJavaPlugins
in detail.Additional-Reading.md
.Flowable.reduce(BiFunction)
JavaDoc; the operator does not signalNoSuchElementException
.fromCallable
& co.toFuture
marbles and descriptions.v2.2.1
Maven
API changes
concatArrayEagerDelayError
operator (expose feature).Bugfixes
concatMap
andpublish
operator.Flowable.fromCallable
consistent with the otherfromCallable
s.Completable.fromCallable
viaRxJavaPlugins
.observeOn
not letworker.dispose()
get called prematurely.Performance improvements
Completable.onErrorResumeNext
internals.Flowable.onErrorResumeNext
improvements.Documentation changes
JavaDocs
Single.timer
,Single.defer
andSingle.toXXX
operators.Single.concat
operator.Single
operators.TestObserver.assertValueSet
in docs and via tests.Maybe.flatMap
events toMaybeSource
.Wiki changes
fromEmitter()
in wiki._Sidebar.md
with new order of topics.Creating-Observables.md
wiki.v2.2.0
Maven
Summary
Version 2.2.0 is the next minor release of the 2.x era and contains the standardization of many experimental API additions from the past year since version 2.1.0. Therefore, the following components are now considered stable and will be supported throughout the rest of the life of RxJava 2.x.
Classes, Enums, Annotations
MulticastProcessor
ParallelFlowable
,UndeliverableException
,OnErrorNotImplementedException
ParallelFailureHandling
{Completable|Single|Maybe|Observable|Flowable|Parallel}Emitter
,{Completable|Single|Maybe|Observable|Flowable|Parallel}Converter
,LambdaConsumerIntrospection
,ScheduledRunnableIntrospection
Operators
Flowable
:as
,concatMap{Single|Maybe|Completable}
,limit
,parallel
,switchMap{Single|Maybe|Completable}
,throttleLatest
Observable
:as
,concatMap{Single|Maybe|Completable}
,switchMap{Single|Maybe|Completable}
,throttleLatest
Single
:as
,mergeDelayError
,onTerminateDetach
,unsubscribeOn
Maybe
:as
,mergeDelayError
,switchIfEmpty
Completable
:as
,fromMaybe
,onTerminateDetach
,takeUntil
ParallelFlowable
:as
,map|filter|doOnNext(errorHandling)
˙,sequentialDelayError
Connectable{Flowable, Observable}
:refCount(count + timeout)
Subject
/FlowableProcessor
:offer
,cleanupBuffer
,create(..., delayError)
Test{Observer, Subscriber}
:assertValueAt
,assertValuesOnly
,assertValueSetOnly
(For the complete list and details on the promotions, see PR 6105.)
Release 2.2.0 is functionally identical to 2.1.17. Also to clarify, just like with previous minor version increments with RxJava, there won't be any further development or updates on the version 2.1.x (patch) level.
Other promotions
All Experimental/Beta APIs introduced up to version 2.1.17 are now standard with 2.2.
Project statistics
Acknowledgements
The project would like to thank the following contributors for their work on various code and documentation improvements (in the order they appear on the commit page):
@lcybo, @jnlopar, @UMFsimke, @apodkutin, @sircelsius,
@romanzes, @Kiskae, @RomanWuattier, @satoshun, @hans123456,
@fjoshuajr, @davidmoten, @vanniktech, @antego, @strekha,
@artfullyContrived, @VeskoI, @Desislav-Petrov, @Apsaliya, @sidjain270592,
@Milack27, @mekarthedev, @kjkrum, @zhyuri, @artem-zinnatullin,
@vpriscan, @aaronhe42, @adamsp, @bangarharshit, @zhukic,
@afeozzz, @btilbrook-nextfaze, @eventualbuddha, @shaishavgandhi05, @lukaszguz,
@runningcode, @kimkevin, @JakeWharton, @hzsweers, @ggikko,
@philleonard, @sadegh, @dsrees, @benwicks, @dweebo,
@dimsuz, @levaja, @takuaraki, @PhilGlass, @bmaslakov,
@tylerbwong, @AllanWang, @NickFirmani, @plackemacher, @matgabriel,
@jemaystermind, @ansman, @Ganapathi004, @leonardortlima, @pwittchen,
@youngam, @Sroka, @serj-lotutovici, @nathankooij, @mithunsasidharan,
@devisnik, @mg6maciej, @Rémon S, @hvesalai, @kojilin,
@ragunathjawahar, @brucezz, @paulblessing, @cypressf, @langara
(75 contributors)
The project would also thank its tireless reviewer @vanniktech for all his efforts on verifying and providing feedback on the many PRs from the project lead himself. 👍
v2.1.17
Maven
API changes
Completable.takeUntil(Completable)
operator.Completable.fromMaybe
operator.Performance improvements
Completable.delay
operator internals.Documentation changes
Single
class.dl
/dd
entry stylesheet.Single
,Maybe
andCompletable
.dt
/dd
within the method details.Completable
mergeX
JavaDoc missingdt
beforedd
.Observable#lift
.Single.never
method.Single.filter
method.Maybe.hide
marble diagram.Single.delay
method.Single.hide
operator.Completable
marble diagrams (07/17a).Single.repeat
operators.Completable
marbles.Single.repeatUntil
operator.Completable
marbles (+17, 07/18a).Single.amb
operators.Completable
marbles (+19, 07/19a).Completable
marbles (7/19b).Completable
marbles (+26).v2.1.16
Maven
This is a hotfix release for a late-identified issue with
concatMapMaybe
andconcatMapSingle
.Bugfixes
concatMap{Single|Maybe}
null emission on success-dispose race.v2.1.15
Maven
API changes
blockingSubscribe
overload with prefetch amount allowing bounded backpressure.{PublishSubject|PublishProcessor}.subscribeActual
toprotected
. They were accidentally made public and there is no reason to call them outside of RxJava internals.Documentation changes
CompositeDisposable
JavaDoc.MulticastProcessor
JavaDoc comment.throttleWithTimout
is an alias ofdebounce
.Maybe
marble diagrams 06/21/ablockingForEach()
JavaDocs.{X}Processor
JavaDocs by syncing with{X}Subject
docs.Performance enhancements
Single.flatMapPublisher
so it doesn't batch requests.{Single|Maybe}.flatMap{Publisher|Observable}
&andThen(Observable|Publisher)
implementations.Observable.takeUntil
.Bugfixes
Single.takeUntil
,Maybe.takeUntil
dispose behavior.groupBy
eviction so that source is cancelled and reduce volatile reads.LambdaObserver.onError
to route to global error handler.BlockingSubscriber
that would always be false due to wrong variable.Other changes
MulticastProcessor
&{0..1}.flatMapPublisher
TakeUntilPerf
.DESIGN.md
v2.1.14
Maven
API changes
Single.concatEager()
.ConnectableObservable.refCount()
andConnectableFlowable.refCount()
with minimum consumer count & disconnect grace period.Observable.throttleLatest
andFlowable.throttleLatest()
.MulticastProcessor
.assertValueSetOnly
andassertValueSequenceOnly
toTestObserver
/TestSubscriber
.Deprecations
getValues()
inSubject
s/FlowableProcessor
s to be removed in 3.x.Documentation changes
Maybe
/Single
JavaDocs; annotation cleanup.subscribeActual
methods.blockingSubscribe
JavaDoc clarifications.Single.doOnX
methods.Observable
javadoc cleanup.Bugfixes
refCount()
connect/subscribe/cancel deadlock.Flowable.take
to route post-cancel errors to plugin error handler.switchMap
to indicate boundary fusion.Other changes
Scheduler
class.toString
method for someEmitter
s.null
checks on primitives.v2.1.13
Maven
API changes
Single.ignoreElement
, deprecateSingle.toCompletable
(will be removed in 3.0).Documentation changes
Completable.toMaybe()
@return
javadoc.Observable
javadoc mentioningdoOnCancel
instead ofdoOnDispose
.blockingX
JavaDoc to mention wrapping of checked Exceptions.Bugfixes
AppendOnlyLinkedArrayList.forEachWhile
.Observable.concatMapSingle
dropping upstream items.Other changes
@NonNull
annotations to create methods ofSubject
s andProcessor
s.@SchedulerSupport
annotation on constructors.TERMINATED
check inPublishSubject.onNext
andPublishProcessor.onNext
.v2.1.12
Maven
Bugfixes
concatMapSingle
&concatMapMaybe
dispose-cleanup crash.v2.1.11
Maven
API changes
Flowable.concatMapCompletable{DelayError}
operator.Flowable.switchMapCompletable{DelayError}
operator.Flowable.concatMap{Maybe,Single}{DelayError}
operators.Flowable.switchMap{Maybe,Single}{DelayError}
operators.Observable
switchMapX
andconcatMapX
operators.TestScheduler
that takes the initial virtual time.Performance enhancements
Observable.concatMapCompletable
.Observable.(concat|switch)Map{Completable|Single|Maybe}
.Observable.switchMap
inner source.Documentation changes
Flowable.lift()
operator.lift()
operators.NoSuchElementException
toSingle.zip()
.dematerialize()
and terminal items/signals.buffer()
documentation to correctly describeonError
behavior.Bugfixes
window(Observable|Callable)
upstream handling.Flowable.window(Publisher|Callable)
upstream handling.ReplaySubject
.Observable.flatMap
scalarmaxConcurrency
overflow.publish(-|Function)
subscriber swap possible data loss.replay
components.Flowable.singleOrError().toFlowable()
not signallingNoSuchElementException
.FlowableWindowBoundary
not cancelling the upstream on a missing backpressure case, causingNullPointerException
.Other changes
@Nullable
annotations to subjects.v2.1.10
Maven
API changes
concatWith(Single|Maybe|Completable)
overloads toFlowable
andObservable
.mergeWith(Single|Maybe|Completable)
overloads toFlowable
andObservable
.Flowable.groupBy
overload with evicting map factory.Documentation changes
share()
JavaDocs.Observable.blockingIterable(int)
and addObservable.blockingLatest
marbles.replay
emission's item retention property.just()
operator and reference other typical alternatives.SingleSubject
JavaDoc.distinct()
anddistinctUntilChanged()
in JavaDoc.Observer
,SingleObserver
,MaybeObserver
andCompletableObserver
.Scheduler
API.{Flowable|Observable|Single|Maybe|Completable}Emitter
interfaces in detail.Maybe.fromCallable
JavaDoc.Bugfixes
Observable.switchMap
mainonError
not disposing the current inner source.Other changes
Observable.timeInterval(TimeUnit)
.v2.1.9
Maven
API changes
{Maybe|Single}.mergeDelayError
variants.Performance improvements
Flowable
retry
/repeat
.Documentation changes
onTerminateDetach
.BehaviorSubject
JavaDoc + related clarifications.merge()
error handling.Maybe doOn{Success,Error,Complete}
JavaDoc.merge()
operator JavaDocs.XSubject
JavaDocs.Observable
:Observable
marble fixes 01/08-b.Observable.replay(Function, ...)
marble fixes.Observable
marbles, 01/10-a.Observable
marble additions/fixes.Subject
andProcessor
marbles.Bugfixes
flatMap
inner fused poll crash not cancelling the upstream.buffer(open, close)
not disposing indicators properly.v2.1.8
Maven
Warning! Behavior change regarding handling illegal calls with
null
inProcessor
s andSubject
s.The Reactive Streams specification mandates that calling
onNext
andonError
withnull
shouldresult in an immediate
NullPointerException
thrown from these methods. Unfortunately, this requirement was overlooked (it resulted in calls toonError
withNullPointerException
which meant the Processor/Subject variants entered their terminal state).If, for some reason, the original behavior is required, one has to call
onError
with aNullPointerException
explicitly:API changes
Worker
s from someScheduler
s.RxJavaPlugins.unwrapRunnable
to help with RxJava-internal wrappers inScheduler
s.retry(times, predicate)
toSingle
&Completable
and verify behavior across them andMaybe
.Documentation changes
package-info
s + remove unused imports.Observable
marbles 11/28.Observable
(12/06).autoConnect()
JavaDoc + add its marble.@see
toCompletable
.retryWhen()
operators.BehaviorProcessor
JavaDoc.Bugfixes
TrampolineScheduler
not callingRxJavaPlugins.onSchedule()
, add tests for all schedulers.runnable == null
in*Scheduler.schedule*()
.buffer()
calling cancel unnecessarily.Subject
/FlowableProcessor
NPE fixes, addUnicastProcessor
TCK.Other
XOnSubscribe
parameter name toemitter
for better IDE auto-completion.v2.1.7
Maven
API changes
as()
operator on the 6 base classes - similar toto()
but dedicated functional interface for each base class instead of justFunction
.Documentation changes
Schedulers.single()
JavaDoc.flatMapSingle
andflatMapMaybe
.BaseTestConsumer
values()
anderrors()
thread-safety clarifications.Schedulers
.take()
operator about the threadonComplete
may get signaled.ConnectableFlowable
,GroupedFlowable
,FlowableAutoConnect
.Observable
all
,fromPublisher
,zipArray
.Bugfixes
Completable.concat
to use replace (don't dispose old).ScheduledRunnable
.isDisposed
before emitting inSingleFromCallable
.Other
toMap
.v2.1.6
Maven
API changes
Observable.concatMapCompletable()
.Flowable.limit()
to limit both item count and request amount.Documentation changes
io.reactivex
andio.reactivex.observers
.subscribeWith
documentation examples.Observable.just(2..10)
andswitchOnNextDelayError
marbles.Observable.singleElement()
.Observable
marble fixes.Bugfixes
PublishProcessor
cancel/emission overflow bug.parallel()
a fusion-async-boundary.Other
Observable.concatMap(Completable)
.Configuration
📅 Schedule: 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 WhiteSource Renovate. View repository job log here.