Skip to content
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

Open
wants to merge 1 commit into
base: master
Choose a base branch
from

Conversation

renovate[bot]
Copy link

@renovate renovate bot commented Jul 10, 2020

WhiteSource Renovate

This PR contains the following updates:

Package Change Age Adoption Passing Confidence
io.reactivex.rxjava2:rxjava 2.1.3 -> 2.2.21 age adoption passing confidence

Release Notes

ReactiveX/RxJava

v2.2.21

Maven
JavaDocs

⚠️ This is the last planned update for the 2.x version line. After February 28, 2021, 2.x becomes End-of-Life (EoL); no further patches, bugfixes, enhancements, documentation or support will be provided by the project.

Enhancements
  • Add a system parameter to allow scheduled worker release in the Io Scheduler. (#​7162)
  • Add a system parameter to allow Schedulers to use System.nanoTime() for now(). (#​7170)

v2.2.20

Maven
JavaDocs

⚠️ The 2.x version line is now in maintenance mode and will be supported only through bugfixes until February 28, 2021. No new features, behavior changes or documentation adjustments will be accepted or applied to 2.x. It is recommended to migrate to 3.x within this time period.

Bugfixes
  • Fix Observable.flatMap with maxConcurrency hangs (#​6960)
  • Fix Observable.toFlowable(ERROR) not cancelling upon MissingBackpressureException (#​7084)
  • Fix Flowable.concatMap backpressure with scalars. (#​7091)

v2.2.19

Maven
JavaDocs

⚠️ The 2.x version line is now in maintenance mode and will be supported only through bugfixes until February 28, 2021. No new features, behavior changes or documentation adjustments will be accepted or applied to 2.x. It is recommended to migrate to 3.x within this time period.

Bugfixes
  • Commit 7980c85b: Fix switchMap not canceling properly during onNext-cancel races.

v2.2.18

Maven

⚠️ The 2.x version line is now in maintenance mode and will be supported only through bugfixes until February 28, 2021. No new features, behavior changes or documentation adjustments will be accepted or applied to 2.x. It is recommended to migrate to 3.x within this time period.

Bugfixes
  • Pull 6894: Fix groupBy not requesting more if a group is cancelled with buffered items.

v2.2.17

Maven

Bugfixes
  • Pull 6827: Fix Flowable.flatMap not canceling the inner sources on outer error.

v2.2.16

Maven

Bugfixes
  • Pull 6754: Fix amb, combineLatest and zip Iterable overloads throwing ArrayStoreException for ObservableSources.
Documentation changes
  • Pull 6746: Fix self-see references, some comments.

v2.2.15

Maven

Bugfixes
  • Pull 6715: Fix MulticastProcessor not requesting more after limit is reached.
  • Pull 6710: Fix concurrent clear in observeOn while output-fused.
  • Pull 6720: Fix parallel() on grouped flowable not replenishing properly.
Documentation changes
  • Pull 6722: Update javadoc for observeOn to mention its eagerness.
Other changes
  • Pull 6704: Add ProGuard rule to avoid j.u.c.Flow warnings due to RS 1.0.3.

v2.2.14

Maven

Bugfixes
  • Pull 6677: Fix concurrent clear() calls when fused chains are canceled.
  • Pull 6684: Fix window(time) possible interrupts while terminating.
Documentation changes
  • Pull 6681: Backport marble diagrams for Single from 3.x.

v2.2.13

Maven

Dependencies
Bugfixes
  • Commit cc690ff2: Avoid using System.getProperties().
  • Pull 6653: Fix takeLast(time) last events time window calculation.
  • Pull 6657: Fix size+time bound window not creating windows properly.

v2.2.12

Maven

Bugfixes
  • Pull 6618: Fix switchMap incorrect sync-fusion & error management.
  • Pull 6627: Fix blockingIterable hang when force-disposed.
  • Pull 6629: Fix refCount not resetting when cross-canceled.

v2.2.11

Maven

Bugfixes
  • Pull 6560: Fix NPE when debouncing an empty source.
  • Pull 6599: Fix mergeWith not canceling other when the main fails.
  • Pull 6601: ObservableBlockingSubscribe compares with wrong object.
  • Pull 6602: Fix truncation bugs in replay() and ReplaySubject/Processor.
Documentation changes
  • Pull 6565: Fix JavaDocs of Single.doOnTerminate refer to onComplete notification.

v2.2.10

Maven

Bugfixes
  • Pull 6499: Add missing null check to BufferExactBoundedObserver.
  • Pull 6505: Fix publish().refCount() hang due to race.
  • Pull 6522: Fix concatMapDelayError not continuing on fused inner source crash.
Documentation changes
  • Pull 6496: Fix outdated links in Additional-Reading.md.
  • Pull 6497: Fix links in Alphabetical-List-of-Observable-Operators.md.
  • Pull 6504: Fix various Javadocs & imports.
  • Pull 6506: Expand the Javadoc of Flowable.
  • Pull 6510: Correct "Reactive-Streams" to "Reactive Streams" in documentation.

v2.2.9

Maven

Bugfixes
  • Pull 6488: Fix zip not stopping the subscription upon eager error.
Documentation changes
  • Pull 6453: Fixed wrong type referenced in Maybe and Single JavaDocs.
  • Pull 6458: Update the Javadoc of the retry operator.
Other
  • Pull 6452: Remove dependency of Schedulers from ObservableRefCount.
  • Pull 6461: Change error message in ObservableFromArray.
  • Pull 6469: Remove redundant methods from sample(Observable).
  • Pull 6470: Remove unused import from Flowable.java.
  • Pull 6485: Remove unused else from the Observable.

v2.2.8

Maven

Bugfixes
  • Pull 6442: Add missing undeliverable error handling logic for Completable.fromRunnable & fromAction operators.
Documentation changes
  • Pull 6432: Improve the docs of CompositeDisposable.
  • Pull 6434: Improve subjects and processors package doc.
  • Pull 6436: Improve Creating-Observables wiki doc.
Other
  • Pull 6433: Make error messages of parameter checks consistent.

v2.2.7

Maven

API enhancements
  • Pull 6386: Add doOnTerminate to Single/Maybe for consistency.
Bugfixes
  • Pull 6405: Fix concatEager to dispose sources & clean up properly.
  • Pull 6398: Fix window() with start/end selector not disposing/cancelling properly.
Documentation changes
  • Pull 6377: Expand Observable#debounce and Flowable#debounce javadoc.
  • Pull 6408: Improving Javadoc of flattenAsFlowable and flattenAsObservable methods.

v2.2.6

Maven

API enhancements
  • Pull 6370: Add interruptible mode via the new Schedulers.from(Executor, boolean) overload.
Bugfixes
  • Pull 6359: Fix the error/race in Observable.repeatWhen due to flooding repeat signal.
  • Pull 6362 : Fix Completable.andThen(Completable) not running on observeOn's Scheduler.
  • Pull 6364: Fix Flowable.publish not requesting upon client change.
  • Pull 6371: Fix bounded replay() memory leak due to bad node retention.
  • Pull 6375: Don't dispose the winner of {Single|Maybe|Completable}.amb().
  • Pull 6380: Fix CompositeException.getRootCause() detecting loops in the cause graph.
Documentation changes
  • Pull 6365: Indicate source disposal in timeout(fallback).
Other changes
  • Pull 6353: Use ignoreElement to convert Single to Completable in the README.md.

v2.2.5

Maven

Documentation changes
  • Pull 6344: Use correct return type in JavaDocs documentation in elementAtOrDefault.
  • Pull 6346: Fix JavaDoc examples using markdown instead of @code.
Wiki changes
Other changes
  • Pull 6313: Adding @NonNull annotation factory methods.
  • Pull 6335: Replace indexed loop with for-each java5 syntax.

v2.2.4

Maven

API changes
  • Pull 6278: Add Maybe/Single/Completable materialize operator,
  • Pull 6278: Add Single.dematerialize(selector) operator.
  • Pull 6281: Add Flowable/Observable dematerialize(selector) operator.
Bugfixes
  • Pull 6258: Fix cancel/dispose upon upstream switch for some operators.
  • Pull 6269: Call the doOn{Dispose|Cancel} handler at most once.
  • Pull 6283: Fix Observable.flatMap to sustain concurrency level.
  • Pull 6297: Fix refCount eager disconnect not resetting the connection.
Documentation changes
  • Pull 6280: Improve the package docs of io.reactivex.schedulers.
  • Pull 6301: Add missing onSubscribe null-checks to NPE docs on Flowable/Observable subscribe.
  • Pull 6303: Fix incorrect image placement in Flowable.zip docs.
  • Pull 6305: Explain the non-concurrency requirement of the Emitter interface methods.
  • Pull 6308: Explain the need to consume both the group sequence and each group specifically with Flowable.groupBy.
  • Pull 6311: Explain that distinctUntilChanged requires non-mutating data to work as expected.
Wiki changes
  • Pull 6260: Add generate examples to Creating-Observables.md.
  • Pull 6267: Fix Creating-Observables.md docs stlye mistake.
  • Pull 6273: Fix broken markdown of How-to-Contribute.md.
  • Pull 6266: Update Error Handling Operators docs.
  • Pull 6291: Update Transforming Observables docs.
Other changes
  • Pull 6262: Use JUnit's assert format for assert messages for better IDE interoperation.
  • Pull 6263: Inline SubscriptionHelper.isCancelled().
  • Pull 6275: Improve the Observable/Flowable cache() operators.
  • Pull 6287: Expose the Keep-Alive value of the IO Scheduler as System property.
  • Pull 6321: Fix Flowable.toObservable backpressure annotation.

v2.2.3

Maven

API changes
  • Pull 6242: Add timed Completable.delaySubscription() operator.
Documentation changes
  • Pull 6220: Remove unnecessary 's' from ConnectableObservable.
  • Pull 6241: Remove mention of io.reactivex.functions.Functions nonexistent utility class.
Other changes
  • Pull 6232: Cleanup Observable.flatMap drain logic.
  • Pull 6234: Add timeout and unit to TimeoutException message in the timeout operators.
  • Pull 6236: Adjust UndeliverableException and OnErrorNotImplementedException message to use the full inner exception.
  • Pull 6244: Add @Nullable annotations for blocking methods in Completable.

v2.2.2

Maven

Bugfixes
  • Pull 6187: Fix refCount termination-reconnect race.
Documentation changes
  • Pull 6171: Add explanation text to Undeliverable & OnErrorNotImplemented exceptions.
  • Pull 6174: Auto-clean up RxJavaPlugins JavaDocs HTML.
  • Pull 6175: Explain null observer/subscriber return errors from RxJavaPlugins in detail.
  • Pull 6180: Update Additional-Reading.md.
  • Pull 6180: Fix Flowable.reduce(BiFunction) JavaDoc; the operator does not signal NoSuchElementException.
  • Pull 6193: Add "error handling" java docs section to fromCallable & co.
  • Pull 6199: Fix terminology of cancel/dispose in the JavaDocs.
  • Pull 6200: Fix toFuture marbles and descriptions.

v2.2.1

Maven

API changes
  • Pull 6143: Add concatArrayEagerDelayError operator (expose feature).
Bugfixes
  • Pull 6145: Fix boundary fusion of concatMap and publish operator.
  • Pull 6158: Make Flowable.fromCallable consistent with the other fromCallables.
  • Pull 6165: Handle undeliverable error in Completable.fromCallable via RxJavaPlugins.
  • Pull 6167: Make observeOn not let worker.dispose() get called prematurely.
Performance improvements
  • Pull 6123: Improve Completable.onErrorResumeNext internals.
  • Pull 6121: Flowable.onErrorResumeNext improvements.
Documentation changes
JavaDocs
  • Pull 6095: Add marbles for Single.timer, Single.defer and Single.toXXX operators.
  • Pull 6137: Add marbles for Single.concat operator.
  • Pull 6141: Add marble diagrams for various Single operators.
  • Pull 6152: Clarify TestObserver.assertValueSet in docs and via tests.
  • Pull 6155: Fix marble of Maybe.flatMap events to MaybeSource.
Wiki changes
  • Pull 6128: Remove fromEmitter() in wiki.
  • Pull 6133: Update _Sidebar.md with new order of topics.
  • Pull 6135: Initial clean up for Combining Observables docs.
  • Pull 6131: Expand Creating-Observables.md wiki.
  • Pull 6134: Update RxJava Android Module documentation.
  • Pull 6140: Update Mathematical and Aggregate Operators docs.

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

  • Annotation: N/A
  • Subject: MulticastProcessor
  • Classes: ParallelFlowable, UndeliverableException, OnErrorNotImplementedException
  • Enum: ParallelFailureHandling
  • Interfaces: {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
  • Unique contributors: 75
  • Issues closed: 283
  • Bugs reported: 20
    • by community: 19 (95%)
  • Commits: 320
  • PRs: 296
    • PRs accepted: 268 (90.54%)
    • Community PRs: 96 (35.82% of all accepted)
  • Bugs fixed: 39
    • by community: 8 (20.51%)
  • Documentation enhancements: 117
    • by community: 40 (34.19%)
  • Cleanup: 50
    • by community: 21 (42%)
  • Performance enhancements: 12
    • by community: 1 (8.33%)
  • Lines
    • added: 70,465
    • removed: 12,373
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
  • Pull 6079: Add Completable.takeUntil(Completable) operator.
  • Pull 6085: Add Completable.fromMaybe operator.
Performance improvements
  • Pull 6096: Improve Completable.delay operator internals.
Documentation changes

v2.1.16

Maven

This is a hotfix release for a late-identified issue with concatMapMaybe and concatMapSingle.

Bugfixes
  • Pull 6060: Fix concatMap{Single|Maybe} null emission on success-dispose race.

v2.1.15

Maven

API changes
  • Pull 6026: Add blockingSubscribe overload with prefetch amount allowing bounded backpressure.
  • Pull 6052: Change {PublishSubject|PublishProcessor}.subscribeActual to protected. They were accidentally made public and there is no reason to call them outside of RxJava internals.
Documentation changes
  • Pull 6031: Inline CompositeDisposable JavaDoc.
  • Pull 6042: Fix MulticastProcessor JavaDoc comment.
  • Pull 6049: Make it explicit that throttleWithTimout is an alias of debounce.
  • Pull 6053: Add Maybe marble diagrams 06/21/a
  • Pull 6057: Use different wording on blockingForEach() JavaDocs.
  • Pull 6054: Expand {X}Processor JavaDocs by syncing with {X}Subject docs.
Performance enhancements
  • Pull 6021: Add full implementation for Single.flatMapPublisher so it doesn't batch requests.
  • Pull 6024: Dedicated {Single|Maybe}.flatMap{Publisher|Observable} & andThen(Observable|Publisher) implementations.
  • Pull 6028: Improve Observable.takeUntil.
Bugfixes
  • Pull 6019: Fix Single.takeUntil, Maybe.takeUntil dispose behavior.
  • Pull 5947: Fix groupBy eviction so that source is cancelled and reduce volatile reads.
  • Pull 6036: Fix disposed LambdaObserver.onError to route to global error handler.
  • Pull 6045: Fix check in BlockingSubscriber that would always be false due to wrong variable.
Other changes
  • Pull 6022: Add TCK for MulticastProcessor & {0..1}.flatMapPublisher
  • Pull 6029: Upgrade to Gradle 4.3.1, add TakeUntilPerf.
  • Pull 6033: Update & fix grammar of DESIGN.md

v2.1.14

Maven

API changes
  • Pull 5976: Add Single.concatEager().
  • Pull 5986: Add ConnectableObservable.refCount() and ConnectableFlowable.refCount() with minimum consumer count & disconnect grace period.
  • Pull 5979: Add Observable.throttleLatest and Flowable.throttleLatest().
  • Pull 6002: Add MulticastProcessor.
  • Pull 6010: Add assertValueSetOnly and assertValueSequenceOnly to TestObserver/TestSubscriber.
Deprecations
  • Pull 5982: Deprecate getValues() in Subjects/FlowableProcessors to be removed in 3.x.
Documentation changes
  • Pull 5977: Maybe/Single JavaDocs; annotation cleanup.
  • Pull 5981: Improve JavaDocs of the subscribeActual methods.
  • Pull 5984: Add blockingSubscribe JavaDoc clarifications.
  • Pull 5987: Add marble diagrams to some Single.doOnX methods.
  • Pull 5992: Observable javadoc cleanup.
Bugfixes
  • Pull 5975: Fix refCount() connect/subscribe/cancel deadlock.
  • Pull 5978: Flowable.take to route post-cancel errors to plugin error handler.
  • Pull 5991: Fix switchMap to indicate boundary fusion.
Other changes
  • Pull 5985: Cleanup in the Scheduler class.
  • Pull 5996: Automatically publish the generated JavaDocs from CI.
  • Pull 5995: Implement toString method for some Emitters.
  • Pull 6005: JavaDocs HTML formatting and whitespace cleanup.
  • Pull 6014: Fix & prevent null checks on primitives.

v2.1.13

Maven

API changes
  • Pull 5957: Add Single.ignoreElement, deprecate Single.toCompletable (will be removed in 3.0).
Documentation changes
  • Pull 5936: Fix Completable.toMaybe() @return javadoc.
  • Pull 5948: Fix Observable javadoc mentioning doOnCancel instead of doOnDispose.
  • Pull 5951: Update blockingX JavaDoc to mention wrapping of checked Exceptions.
Bugfixes
  • Pull 5952: Fixed conditional iteration breaking in AppendOnlyLinkedArrayList.forEachWhile.
  • Pull 5972: Fix Observable.concatMapSingle dropping upstream items.
Other changes
  • Pull 5930: Add @NonNull annotations to create methods of Subjects and Processors.
  • Pull 5940: Allow @SchedulerSupport annotation on constructors.
  • Pull 5942: Removed TERMINATED check in PublishSubject.onNext and PublishProcessor.onNext.
  • Pull 5959: Fix some typos and grammar mistakes.

v2.1.12

Maven

Bugfixes
  • Pull 5928: Fix concatMapSingle & concatMapMaybe dispose-cleanup crash.

v2.1.11

Maven

API changes
  • Pull 5871: Add Flowable.concatMapCompletable{DelayError} operator.
  • Pull 5870: Add Flowable.switchMapCompletable{DelayError} operator.
  • Pull 5872: Add Flowable.concatMap{Maybe,Single}{DelayError} operators.
  • Pull 5873: Add Flowable.switchMap{Maybe,Single}{DelayError} operators.
  • Pull 5875: Add Observable switchMapX and concatMapX operators.
  • Pull 5906: Add public constructor for TestScheduler that takes the initial virtual time.
Performance enhancements
  • Pull 5915: Optimize Observable.concatMapCompletable.
  • Pull 5918: Improve the scalar source performance of Observable.(concat|switch)Map{Completable|Single|Maybe}.
  • Pull 5919: Add fusion to Observable.switchMap inner source.
Documentation changes
  • Pull 5863: Expand the documentation of the Flowable.lift() operator.
  • Pull 5865: Improve the JavaDoc of the other lift() operators.
  • Pull 5876: Add note about NoSuchElementException to Single.zip().
  • Pull 5897: Clarify dematerialize() and terminal items/signals.
  • Pull 5895: Fix buffer() documentation to correctly describe onError behavior.
Bugfixes
  • Pull 5887: Fix window(Observable|Callable) upstream handling.
  • Pull 5888: Fix Flowable.window(Publisher|Callable) upstream handling.
  • Pull 5892: Fix the extra retention problem in ReplaySubject.
  • Pull 5900: Fix Observable.flatMap scalar maxConcurrency overflow.
  • Pull 5893: Fix publish(-|Function) subscriber swap possible data loss.
  • Pull 5898: Fix excess item retention in the other replay components.
  • Pull 5904: Fix Flowable.singleOrError().toFlowable() not signalling NoSuchElementException.
  • Pull 5883: Fix FlowableWindowBoundary not cancelling the upstream on a missing backpressure case, causing NullPointerException.
Other changes
  • Pull 5890: Added @Nullable annotations to subjects.
  • Pull 5886: Upgrade the algorithm of Observable.timeout(time|selector) operators.
  • Coverage improvements
    • Pull 5883: Improve coverage and fix small mistakes/untaken paths in operators.
    • Pull 5889: Cleanup, coverage and related component fixes
    • Pull 5891: Improve coverage & related cleanup 03/05.
    • Pull 5905: Coverage improvements, logical fixes and cleanups 03/08.
    • Pull 5910: Improve coverage, fix operator logic 03/12.

v2.1.10

Maven

API changes
  • Pull 5845: Add efficient concatWith(Single|Maybe|Completable) overloads to Flowable and Observable.
  • Pull 5847: Add efficient mergeWith(Single|Maybe|Completable) overloads to Flowable and Observable.
  • Pull 5860: Add Flowable.groupBy overload with evicting map factory.
Documentation changes
  • Pull 5824: Improve the wording of the share() JavaDocs.
  • Pull 5826: Fix Observable.blockingIterable(int) and add Observable.blockingLatest marbles.
  • Pull 5828: Document size-bounded replay emission's item retention property.
  • Pull 5830: Reword the just() operator and reference other typical alternatives.
  • Pull 5834: Fix copy-paste errors in SingleSubject JavaDoc.
  • Pull 5837: Detail distinct() and distinctUntilChanged() in JavaDoc.
  • Pull 5841: Improve JavaDoc of Observer, SingleObserver, MaybeObserver and CompletableObserver.
  • Pull 5843: Expand the JavaDocs of the Scheduler API.
  • Pull 5844: Explain the properties of the {Flowable|Observable|Single|Maybe|Completable}Emitter interfaces in detail.
  • Pull 5848: Improve the wording of the Maybe.fromCallable JavaDoc.
  • Pull 5856: Add finite requirement to various collector operators' JavaDoc.
Bugfixes
  • Pull 5833: Fix Observable.switchMap main onError not disposing the current inner source.
Other changes
  • Pull 5838: Added nullability annotation for completable assembly.
  • Pull 5858: Remove unnecessary comment from Observable.timeInterval(TimeUnit).

v2.1.9

Maven

API changes
  • Pull 5799: Add missing {Maybe|Single}.mergeDelayError variants.
Performance improvements
  • Pull 5790: Improve request accounting overhead in Flowable retry/repeat.
Documentation changes
  • Pull 5783: Fix JavaDoc wording of onTerminateDetach.
  • Pull 5780: Improve BehaviorSubject JavaDoc + related clarifications.
  • Pull 5781: Describe merge() error handling.
  • Pull 5785: Update Maybe doOn{Success,Error,Complete} JavaDoc.
  • Pull 5786: Add error handling section to merge() operator JavaDocs.
  • Pull 5802: Improved XSubject JavaDocs.
  • Marble diagram fixes to Observable:
    • Pull 5795: More marbles 01/08-a.
    • Pull 5797: Observable marble fixes 01/08-b.
    • Pull 5798: Observable.replay(Function, ...) marble fixes.
    • Pull 5804: More Observable marbles, 01/10-a.
    • Pull 5805: Final planned Observable marble additions/fixes.
  • Pull 5816: Add Subject and Processor marbles.
Bugfixes
  • Pull 5792: Fix flatMap inner fused poll crash not cancelling the upstream.
  • Pull 5811: Fix buffer(open, close) not disposing indicators properly.

v2.1.8

Maven

Warning! Behavior change regarding handling illegal calls with null in Processors and Subjects.

The Reactive Streams specification mandates that calling onNext and onError with null should
result in an immediate NullPointerException thrown from these methods. Unfortunately, this requirement was overlooked (it resulted in calls to onError with NullPointerException 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 a NullPointerException explicitly:

PublishSubject<Integer> ps = PublishSubject.create();

TestObserver<Integer> to = ps.test();

// ps.onNext(null); // doesn't work anymore

ps.onError(new NullPointerException());

to.assertFailure(NullPointerException.class);
API changes
  • Pull 5741: API to get distinct Workers from some Schedulers.
  • Pull 5734: Add RxJavaPlugins.unwrapRunnable to help with RxJava-internal wrappers in Schedulers.
  • Pull 5753: Add retry(times, predicate) to Single & Completable and verify behavior across them and Maybe.
Documentation changes
  • Pull 5746: Improve wording and links in package-infos + remove unused imports.
  • Pull 5745: Add/update Observable marbles 11/28.
  • Commit 53d5a235: Fix JavaDoc link in observables/package-info.
  • Pull 5755: Add marbles for Observable (12/06).
  • Pull 5756: Improve autoConnect() JavaDoc + add its marble.
  • Pull 5758: Add a couple of @see to Completable.
  • Pull 5759: Marble additions and updates (12/11)
  • Pull 5773: Improve JavaDoc of retryWhen() operators.
  • Pull 5778: Improve BehaviorProcessor JavaDoc.
Bugfixes
  • Pull 5747: Fix TrampolineScheduler not calling RxJavaPlugins.onSchedule(), add tests for all schedulers.
  • Pull 5748: Check runnable == null in *Scheduler.schedule*().
  • Pull 5761: Fix timed exact buffer() calling cancel unnecessarily.
  • Pull 5760: Subject/FlowableProcessor NPE fixes, add UnicastProcessor TCK.
Other
  • Pull 5771: Upgrade dependency to Reactive Streams 1.0.2
  • Pull 5766: Rename XOnSubscribe parameter name to emitter for better IDE auto-completion.

v2.1.7

Maven

API changes
  • Pull 5729: Implement as() operator on the 6 base classes - similar to to() but dedicated functional interface for each base class instead of just Function.
Documentation changes
  • Pull 5706: Remove mentions of Main thread from Schedulers.single() JavaDoc.
  • Pull 5709: Improve JavaDocs of flatMapSingle and flatMapMaybe.
  • Pull 5713: Add BaseTestConsumer values() and errors() thread-safety clarifications.
  • Pull 5717: Add period to custom scheduler use sentences in Schedulers.
  • Pull 5718: Add a sentence to documentation of take() operator about the thread onComplete may get signaled.
  • Pull 5738: Correct JavaDoc for ConnectableFlowable, GroupedFlowable, FlowableAutoConnect.
  • Pull 5740: Marbles for Observable all, fromPublisher, zipArray.
Bugfixes
  • Pull 5695: Fix Completable.concat to use replace (don't dispose old).
  • Pull 5715: Distinguish between sync and async dispose in ScheduledRunnable.
  • Pull 5743: Check isDisposed before emitting in SingleFromCallable.
Other
  • Pull 5723: Remove duplicate nullity check line in toMap.

v2.1.6

Maven

API changes
  • Pull 5649: Add Observable.concatMapCompletable().
  • Pull 5655: Add Flowable.limit() to limit both item count and request amount.
Documentation changes
  • Pull 5648: Improve package JavaDoc of io.reactivex and io.reactivex.observers.
  • Pull 5647: Fix subscribeWith documentation examples.
  • Pull 5651: Update Observable.just(2..10) and switchOnNextDelayError marbles.
  • Pull 5668: Fix a misleading documentation of Observable.singleElement().
  • Pull 5680: More Observable marble fixes.
Bugfixes
  • Pull 5669: Fix PublishProcessor cancel/emission overflow bug.
  • Pull 5677: Make parallel() a fusion-async-boundary.
Other
  • Pull 5652: Inline disposability in Observable.concatMap(Completable).
  • Pull 5653: Upgrade testng to get method names to show up in gradle console when skipping, and in testng html output.
  • [Pull 5661](https://to

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.


  • If you want to rebase/retry this PR, check this box.

This PR has been generated by WhiteSource Renovate. View repository job log here.

@renovate renovate bot force-pushed the renovate/io.reactivex.rxjava2-rxjava-2.x branch from 72f2ee5 to 3572682 Compare October 27, 2020 22:57
@renovate renovate bot changed the title Update dependency io.reactivex.rxjava2:rxjava to v2.2.19 Update dependency io.reactivex.rxjava2:rxjava to v2.2.20 Oct 27, 2020
@renovate renovate bot force-pushed the renovate/io.reactivex.rxjava2-rxjava-2.x branch from 3572682 to 8779395 Compare April 26, 2021 17:18
@renovate renovate bot changed the title Update dependency io.reactivex.rxjava2:rxjava to v2.2.20 Update dependency io.reactivex.rxjava2:rxjava to v2.2.21 Apr 26, 2021
Sign up for free to subscribe to this conversation on GitHub. Already have an account? Sign in.
Labels
None yet
Projects
None yet
Development

Successfully merging this pull request may close these issues.

1 participant