跳过导航链接
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

R

r1 - 类 中的变量reactor.core.publisher.FluxSwitchOnFirstStressTest.LLLLLLLLL_Result
 
r2 - 类 中的变量reactor.core.publisher.FluxSwitchOnFirstStressTest.LLLLLLLLL_Result
 
r3 - 类 中的变量reactor.core.publisher.FluxSwitchOnFirstStressTest.LLLLLLLLL_Result
 
r4 - 类 中的变量reactor.core.publisher.FluxSwitchOnFirstStressTest.LLLLLLLLL_Result
 
r5 - 类 中的变量reactor.core.publisher.FluxSwitchOnFirstStressTest.LLLLLLLLL_Result
 
r6 - 类 中的变量reactor.core.publisher.FluxSwitchOnFirstStressTest.LLLLLLLLL_Result
 
r7 - 类 中的变量reactor.core.publisher.FluxSwitchOnFirstStressTest.LLLLLLLLL_Result
 
r8 - 类 中的变量reactor.core.publisher.FluxSwitchOnFirstStressTest.LLLLLLLLL_Result
 
r9 - 类 中的变量reactor.core.publisher.FluxSwitchOnFirstStressTest.LLLLLLLLL_Result
 
race(Runnable, Runnable, Scheduler) - 类 中的静态方法reactor.core.publisher.MonoSubscriberTest
Synchronizes the execution of two runnables (as much as possible) to test race conditions.
race(T, Function<? super T, ? extends T>, Predicate<? super T>, BiPredicate<? super T, ? super T>) - 类 中的静态方法reactor.test.util.RaceTestUtils
Synchronizes the execution of two concurrent state modifications as much as possible to test race conditions.
race(Runnable...) - 类 中的静态方法reactor.test.util.RaceTestUtils
Synchronizes the execution of several Runnables as much as possible to test race conditions.
race(Runnable, Runnable) - 类 中的静态方法reactor.test.util.RaceTestUtils
Synchronizes the execution of two Runnables as much as possible to test race conditions.
race(Runnable, Runnable, Scheduler) - 类 中的静态方法reactor.test.util.RaceTestUtils
已过时。
Use RaceTestUtils.race(Scheduler, Runnable...). To be removed in 3.6.0, at the earliest.
race(Scheduler, Runnable...) - 类 中的静态方法reactor.test.util.RaceTestUtils
Synchronizes the execution of several Runnables as much as possible to test race conditions.
race(int, Scheduler, Runnable...) - 类 中的静态方法reactor.test.util.RaceTestUtils
Synchronizes the execution of several Runnables as much as possible to test race conditions.
raceSubscribeAndCache() - 类 中的方法reactor.core.publisher.MonoCacheTimeTest
 
raceSubscribeAndCancel() - 类 中的方法reactor.core.publisher.FluxRefCountGraceTest
 
raceSubscribeAndCancel() - 类 中的方法reactor.core.publisher.FluxRefCountTest
 
raceSubscribeAndCancelNoTimeout() - 类 中的方法reactor.core.publisher.FluxRefCountGraceTest
 
RaceTestUtils - reactor.test.util中的类
 
RaceTestUtils() - 类 的构造器reactor.test.util.RaceTestUtils
 
racingAdvanceTimeOnEmptyQueue() - 类 中的方法reactor.test.scheduler.VirtualTimeSchedulerTests
 
racingAdvanceTimeOnFullQueue() - 类 中的方法reactor.test.scheduler.VirtualTimeSchedulerTests
 
racingAdvanceTimeOnVaryingQueue() - 类 中的方法reactor.test.scheduler.VirtualTimeSchedulerTests
 
range(int, int) - 类 中的静态方法reactor.core.publisher.Flux
Build a Flux that will only emit a sequence of count incrementing integers, starting from start.
range() - 类 中的方法reactor.core.publisher.FluxDetachTest
 
rangeOverflow() - 类 中的方法reactor.core.publisher.FluxRangeTest
 
reactor - 程序包 reactor
 
reactor.adapter - 程序包 reactor.adapter
Adapt Publisher to Java 9+ Flow.Publisher.
reactor.core - 程序包 reactor.core
Core components of the framework supporting extensions to the Reactive Stream programming model.
reactor.core.observability - 程序包 reactor.core.observability
 
reactor.core.observability.micrometer - 程序包 reactor.core.observability.micrometer
Support of Micrometer 1.10+ instrumentation on reactor-core classes.
reactor.core.publisher - 程序包 reactor.core.publisher
Provide main Reactive APIs in Flux and Mono, as well as various helper classes, interfaces used in the composition API, variants of Flux and operator-building utilities.
reactor.core.publisher.loop - 程序包 reactor.core.publisher.loop
 
reactor.core.publisher.scenarios - 程序包 reactor.core.publisher.scenarios
 
reactor.core.publisher.tck - 程序包 reactor.core.publisher.tck
 
reactor.core.scheduler - 程序包 reactor.core.scheduler
Scheduler contract and static registry and factory methods in Schedulers.
reactor.core.scrabble - 程序包 reactor.core.scrabble
 
reactor.core.util - 程序包 reactor.core.util
 
reactor.doc - 程序包 reactor.doc
 
reactor.guide - 程序包 reactor.guide
 
reactor.test - 程序包 reactor.test
Main test components supporting the testing and assertion of publishers.
reactor.test.publisher - 程序包 reactor.test.publisher
Components supporting the creation of test-oriented Publishers.
reactor.test.scheduler - 程序包 reactor.test.scheduler
Components supporting the creation of test-oriented Schedulers.
reactor.test.subscriber - 程序包 reactor.test.subscriber
Components supporting the creation of test-oriented Subscribers.
reactor.test.util - 程序包 reactor.test.util
 
reactor.tools - 程序包 reactor.tools
 
reactor.tools.agent - 程序包 reactor.tools.agent
 
reactor.util - 程序包 reactor.util
Miscellaneous utility classes, such as loggers, tuples or queue suppliers and implementations.
reactor.util.annotation - 程序包 reactor.util.annotation
 
reactor.util.concurrent - 程序包 reactor.util.concurrent
Queue suppliers and utilities Used for operational serialization (serializing threads) or buffering (asynchronous boundary).
reactor.util.context - 程序包 reactor.util.context
Miscellaneous utility classes, such as loggers, tuples or queue suppliers and implementations.
reactor.util.function - 程序包 reactor.util.function
Tuples provide a type-safe way to specify multiple parameters.
reactor.util.retry - 程序包 reactor.util.retry
 
ReactorBlockHoundIntegration - reactor.core.scheduler中的类
BlockHoundIntegration with Reactor's scheduling mechanism.
ReactorBlockHoundIntegration() - 类 的构造器reactor.core.scheduler.ReactorBlockHoundIntegration
 
ReactorBlockHoundIntegrationSPITest - reactor.core.scheduler中的类
 
ReactorBlockHoundIntegrationSPITest() - 类 的构造器reactor.core.scheduler.ReactorBlockHoundIntegrationSPITest
 
ReactorBlockHoundIntegrationTest - reactor.core.scheduler中的类
 
ReactorBlockHoundIntegrationTest() - 类 的构造器reactor.core.scheduler.ReactorBlockHoundIntegrationTest
 
ReactorContextAccessor - reactor.util.context中的类
A ContextAccessor to enable reading values from a Reactor ContextView and writing values to Context.
ReactorContextAccessor() - 类 的构造器reactor.util.context.ReactorContextAccessor
 
ReactorDebugAgent - reactor.tools.agent中的类
 
ReactorDebugAgent() - 类 的构造器reactor.tools.agent.ReactorDebugAgent
 
ReactorDebugAgentTest - reactor.tools.agent中的类
 
ReactorDebugAgentTest() - 类 的构造器reactor.tools.agent.ReactorDebugAgentTest
 
ReactorDebugByteBuddyPlugin - reactor.tools.agent中的类
 
ReactorDebugByteBuddyPlugin() - 类 的构造器reactor.tools.agent.ReactorDebugByteBuddyPlugin
 
ReactorDebugJavaAgentTest - reactor.tools.agent中的类
This test assumes that the agent is added to the JVM as a Java Agent and does not manually install it.
ReactorDebugJavaAgentTest() - 类 的构造器reactor.tools.agent.ReactorDebugJavaAgentTest
 
ReactorLauncherSessionListener - reactor中的类
 
ReactorLauncherSessionListener() - 类 的构造器reactor.ReactorLauncherSessionListener
 
ReactorTestExecutionListener - reactor中的类
A custom TestExecutionListener that helps with tests in reactor: resets Hooks once a test is finished, making sure no dirty state remains, resets Schedulers related infrastructure, making sure no dirty state remains, installs custom assertJ Representation for some of reactor types, installs a custom Logger factory very early in the suite lifecycle, so that loggers in reactor (which are typically static members initialized early) can be diverted and asserted in tests.
ReactorTestExecutionListener() - 类 的构造器reactor.ReactorTestExecutionListener
 
readableType() - 类 中的方法reactor.util.context.ReactorContextAccessor
 
readOnly() - 接口 中的方法reactor.util.context.Context
Switch to the ContextView interface, which only allows reading from the context.
readQueuesFromPublishers() - 类 中的方法reactor.core.publisher.scenarios.FluxSpecTests
 
readValue(ContextView, Object) - 类 中的方法reactor.util.context.ReactorContextAccessor
 
readValues(ContextView, Predicate<Object>, Map<Object, Object>) - 类 中的方法reactor.util.context.ReactorContextAccessor
 
receive(Consumer<? super O>...) - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
 
receive(int, IntFunction<? extends O>) - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
 
receive(Consumer<? super O>...) - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
 
receive(int, IntFunction<? extends O>) - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
 
receive(Consumer<? super O>...) - 类 中的方法reactor.test.publisher.OperatorScenario
 
receive(int, IntFunction<? extends O>) - 类 中的方法reactor.test.publisher.OperatorScenario
 
receive(Consumer<? super O>...) - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
 
receive(int, IntFunction<? extends O>) - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
 
receive(Consumer<? super O>...) - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
 
receive(int, IntFunction<? extends O>) - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
 
receivedValues - 类 中的变量reactor.core.publisher.StressSubscriber
 
receiverDemand(long) - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
 
receiverDemand(long) - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
 
receiverDemand(long) - 类 中的方法reactor.test.publisher.OperatorScenario
 
receiverDemand(long) - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
 
receiverDemand(long) - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
 
receiverEmpty() - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
 
receiverEmpty() - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
 
receiverEmpty() - 类 中的方法reactor.test.publisher.OperatorScenario
 
receiverEmpty() - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
 
receiverEmpty() - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
 
receiveValues(O...) - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
 
receiveValues(O...) - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
 
receiveValues(O...) - 类 中的方法reactor.test.publisher.OperatorScenario
 
receiveValues(O...) - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
 
receiveValues(O...) - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
 
reconnectsAfterRefCountZero() - 类 中的方法reactor.core.publisher.FluxRefCountTest
 
recordWith(Supplier<? extends Collection<T>>) - 接口 中的方法reactor.test.StepVerifier.Step
Start a recording session storing Subscriber.onNext(Object) values in the supplied Collection.
recursiveCountdown() - 类 中的方法reactor.core.publisher.MonoExpandTest
 
recursiveCountdownBackpressure() - 类 中的方法reactor.core.publisher.FluxExpandTest
 
recursiveCountdownBackpressure() - 类 中的方法reactor.core.publisher.MonoExpandTest
 
recursiveCountdownBackpressureDepth() - 类 中的方法reactor.core.publisher.FluxExpandTest
 
recursiveCountdownBackpressureDepth() - 类 中的方法reactor.core.publisher.MonoExpandTest
 
recursiveCountdownBreadth() - 类 中的方法reactor.core.publisher.FluxExpandTest
 
recursiveCountdownDepth() - 类 中的方法reactor.core.publisher.FluxExpandTest
 
recursiveCountdownDepth() - 类 中的方法reactor.core.publisher.MonoExpandTest
 
recursiveCountdownLoop() - 类 中的方法reactor.core.publisher.FluxExpandTest
 
recursiveCountdownLoop() - 类 中的方法reactor.core.publisher.MonoExpandTest
 
recursiveCountdownLoopDepth() - 类 中的方法reactor.core.publisher.FluxExpandTest
 
recursiveCountdownLoopDepth() - 类 中的方法reactor.core.publisher.MonoExpandTest
 
recursiveCountdownTake() - 类 中的方法reactor.core.publisher.FluxExpandTest
 
recursiveCountdownTake() - 类 中的方法reactor.core.publisher.MonoExpandTest
 
recursiveCountdownTakeDepth() - 类 中的方法reactor.core.publisher.FluxExpandTest
 
recursiveCountdownTakeDepth() - 类 中的方法reactor.core.publisher.MonoExpandTest
 
recursiveParallelCall() - 类 中的方法reactor.core.scheduler.SchedulersTest
 
reduce(BiFunction<T, T, T>) - 类 中的方法reactor.core.publisher.Flux
将一个 Flux 规约为一个 Mono Reduce the values from this Flux sequence into a single object of the same type than the emitted items.
reduce(A, BiFunction<A, ? super T, A>) - 类 中的方法reactor.core.publisher.Flux
Reduce the values from this Flux sequence into a single object matching the type of a seed value.
reduce(BiFunction<T, T, T>) - 类 中的方法reactor.core.publisher.ParallelFlux
Reduces all values within a 'rail' and across 'rails' with a reducer function into a single sequential value.
reduce(Supplier<R>, BiFunction<R, ? super T, R>) - 类 中的方法reactor.core.publisher.ParallelFlux
Reduces all values within a 'rail' to a single value (with a possibly different type) via a reducer function that is initialized on each rail from an initialSupplier value.
reduceFull() - 类 中的方法reactor.core.publisher.ParallelMergeReduceTest
 
ReduceOperatorTest<I,O> - reactor.test.publisher中的类
 
ReduceOperatorTest() - 类 的构造器reactor.test.publisher.ReduceOperatorTest
 
ReduceOperatorTest.Scenario<I,O> - reactor.test.publisher中的类
 
reduceWillAccumulateListOfAcceptedValues() - 类 中的方法reactor.core.publisher.scenarios.FluxSpecTests
 
reduceWith(Supplier<A>, BiFunction<A, ? super T, A>) - 类 中的方法reactor.core.publisher.Flux
Reduce the values from this Flux sequence into a single object matching the type of a lazily supplied seed value.
refCount() - 类 中的方法reactor.core.publisher.ConnectableFlux
Connects to the upstream source when the first Subscriber subscribes and disconnects when all Subscribers cancelled or the upstream source completed.
refCount(int) - 类 中的方法reactor.core.publisher.ConnectableFlux
Connects to the upstream source when the given number of Subscriber subscribes and disconnects when all Subscribers cancelled or the upstream source completed.
refCount(int, Duration) - 类 中的方法reactor.core.publisher.ConnectableFlux
Connects to the upstream source when the given number of Subscriber subscribes.
refCount(int, Duration, Scheduler) - 类 中的方法reactor.core.publisher.ConnectableFlux
Connects to the upstream source when the given number of Subscriber subscribes.
regrowFromEviction() - 类 中的方法reactor.core.scheduler.BoundedElasticSchedulerTest
 
regularMapper() - 类 中的方法reactor.core.publisher.FluxMapNotNullTest
 
regularMapper() - 类 中的方法reactor.core.publisher.MonoMapNotNullTest
 
rejectedDuringLifecycle() - 类 中的方法reactor.core.publisher.FluxWindowTimeoutTest
 
rejectedExecutionExceptionOnDataSignalExecutor() - 类 中的方法reactor.core.publisher.FluxPublishOnTest
 
rejectedExecutionExceptionOnDataSignalExecutor() - 类 中的方法reactor.core.publisher.MonoPublishOnTest
 
rejectedExecutionExceptionOnDataSignalExecutorService() - 类 中的方法reactor.core.publisher.FluxPublishOnTest
 
rejectedExecutionExceptionOnDataSignalExecutorService() - 类 中的方法reactor.core.publisher.MonoPublishOnTest
 
rejectedExecutionExceptionOnErrorSignalExecutor() - 类 中的方法reactor.core.publisher.FluxPublishOnTest
 
rejectedExecutionExceptionOnErrorSignalExecutor() - 类 中的方法reactor.core.publisher.MonoPublishOnTest
 
rejectedExecutionExceptionOnErrorSignalExecutorService() - 类 中的方法reactor.core.publisher.FluxPublishOnTest
 
rejectedExecutionExceptionOnErrorSignalExecutorService() - 类 中的方法reactor.core.publisher.MonoPublishOnTest
 
rejectedExecutionSubscribeExecutorScheduler() - 类 中的方法reactor.core.publisher.MonoPublishOnTest
 
rejectedExecutionSubscribeExecutorServiceScheduler() - 类 中的方法reactor.core.publisher.MonoPublishOnTest
 
RejectedExecutionTest - reactor.core.scheduler中的类
 
RejectedExecutionTest(TestInfo) - 类 的构造器reactor.core.scheduler.RejectedExecutionTest
 
rejectedOnNextLeadsToOnError() - 类 中的方法reactor.core.publisher.FluxBufferTimeoutTest
 
rejectedOnSubscription() - 类 中的方法reactor.core.publisher.FluxWindowTimeoutTest
 
rejectsNullRunnable() - 类 中的方法reactor.core.publisher.FluxDoFirstTest
 
rejectsNullRunnable() - 类 中的方法reactor.core.publisher.MonoDoFirstTest
 
release() - 类 中的方法reactor.test.MemoryUtils.Tracked
Release this MemoryUtils.Tracked object.
RELEASED - 类 中的静态变量reactor.test.MemoryUtils.Tracked
A pre-released MemoryUtils.Tracked instance for convenience in some tests.
remove(Disposable) - 接口 中的方法reactor.core.Disposable.Composite
Delete the Disposable from this container, without disposing it.
remove() - 接口 中的方法reactor.core.Fuseable.QueueSubscription
 
remove(Object) - 接口 中的方法reactor.core.Fuseable.QueueSubscription
 
remove(SinkManyBestEffort.DirectInner<T>) - 类 中的方法reactor.core.publisher.DirectProcessor
已过时。
 
remove() - 类 中的方法reactor.core.publisher.SinkManyBestEffortStressTest.AddVsRemoveStressTest
 
removeAfterDispose() - 类 中的方法reactor.core.ListCompositeDisposableTest
 
removeAll(Collection<?>) - 接口 中的方法reactor.core.Fuseable.QueueSubscription
 
removeConcurrent() - 类 中的方法reactor.core.ListCompositeDisposableTest
 
removeDoesntDispose() - 类 中的方法reactor.core.ListCompositeDisposableTest
 
removeExecutorServiceDecorator(String) - 类 中的静态方法reactor.core.scheduler.Schedulers
Remove an existing ScheduledExecutorService decorator if it has been set up via Schedulers.addExecutorServiceDecorator(String, BiFunction).
removeHooks(TestInfo) - 类 中的方法reactor.guide.GuideTests
 
removeKeys() - 类 中的方法reactor.util.context.Context0Test
 
removeKeys() - 类 中的方法reactor.util.context.Context1Test
 
removeKeys() - 类 中的方法reactor.util.context.Context2Test
 
removeKeys() - 类 中的方法reactor.util.context.Context3Test
 
removeKeys() - 类 中的方法reactor.util.context.Context4Test
 
removeKeys() - 类 中的方法reactor.util.context.Context5Test
 
removeKeys() - 类 中的方法reactor.util.context.ContextNTest
 
removeKeysOver6ReturnsSame() - 类 中的方法reactor.util.context.ContextNTest
 
removeNonexistant() - 类 中的方法reactor.core.ListCompositeDisposableTest
 
removeQueueWrapper(String) - 类 中的静态方法reactor.core.publisher.Hooks
Removes existing Queue wrapper by key.
removeQueueWrappers() - 类 中的静态方法reactor.core.publisher.Hooks
Remove all queue wrappers.
removeRegistry() - 类 中的方法reactor.core.publisher.FluxMetricsFuseableTest
 
removeRegistry() - 类 中的方法reactor.core.publisher.FluxMetricsTest
 
removeRegistry() - 类 中的方法reactor.core.publisher.MonoMetricsFuseableTest
 
removeRegistry() - 类 中的方法reactor.core.publisher.MonoMetricsTest
 
removeUnknownInnerIgnored() - 类 中的方法reactor.core.publisher.FluxPublishTest
 
repeat() - 类 中的方法reactor.core.publisher.Flux
Repeatedly and indefinitely subscribe to the source upon completion of the previous subscription.
repeat(BooleanSupplier) - 类 中的方法reactor.core.publisher.Flux
Repeatedly subscribe to the source if the predicate returns true after completion of the previous subscription.
repeat(long) - 类 中的方法reactor.core.publisher.Flux
Repeatedly subscribe to the source numRepeat times.
repeat(long, BooleanSupplier) - 类 中的方法reactor.core.publisher.Flux
Repeatedly subscribe to the source if the predicate returns true after completion of the previous subscription.
repeat() - 类 中的方法reactor.core.publisher.Mono
在上一次订阅完成后重复无限期订阅源 Repeatedly and indefinitely subscribe to the source upon completion of the previous subscription.
repeat(BooleanSupplier) - 类 中的方法reactor.core.publisher.Mono
如果 BooleanSupplier 在上一次订阅完成后返回 true,则重复订阅源 Repeatedly subscribe to the source if the predicate returns true after completion of the previous subscription.
repeat(long) - 类 中的方法reactor.core.publisher.Mono
重复订阅源 numRepeat 次。
repeat(long, BooleanSupplier) - 类 中的方法reactor.core.publisher.Mono
重复订阅,如果 predicate 在上一次订阅完成后返回 true,则重复订阅源,可指定重复次数 Repeatedly subscribe to the source if the predicate returns true after completion of the previous subscription.
repeat() - 类 中的方法reactor.core.publisher.TailCallSubscribeTest
 
repeatAlways() - 类 中的方法reactor.core.publisher.FluxRepeatWhenTest
 
repeatAlwaysScalar() - 类 中的方法reactor.core.publisher.FluxRepeatWhenTest
 
repeaterErrorsInResponse() - 类 中的方法reactor.core.publisher.FluxRepeatWhenTest
 
repeatFinite() - 类 中的方法reactor.core.publisher.MonoRepeatWhenEmptyTest
 
repeatFiniteExceeded() - 类 中的方法reactor.core.publisher.MonoRepeatWhenEmptyTest
 
repeatInfinite() - 类 中的方法reactor.core.publisher.FluxRepeatTest
 
repeatInfinite() - 类 中的方法reactor.core.publisher.MonoRepeatTest
 
repeatInfinite() - 类 中的方法reactor.core.publisher.MonoRepeatWhenEmptyTest
 
repeatWhen(Function<Flux<Long>, ? extends Publisher<?>>) - 类 中的方法reactor.core.publisher.Flux
Repeatedly subscribe to this Flux when a companion sequence emits elements in response to the flux completion signal.
repeatWhen(Function<Flux<Long>, ? extends Publisher<?>>) - 类 中的方法reactor.core.publisher.Mono
Repeatedly subscribe to this Mono when a companion sequence emits elements in response to the flux completion signal.
repeatWhenEmpty(Function<Flux<Long>, ? extends Publisher<?>>) - 类 中的方法reactor.core.publisher.Mono
当前 Mono 完成订阅后返回空并且对伴随的发布者产生 onNext 信号,就重复订阅该 Mono Repeatedly subscribe to this Mono as long as the current subscription to this Mono completes empty and the companion Publisher produces an onNext signal.
repeatWhenEmpty(int, Function<Flux<Long>, ? extends Publisher<?>>) - 类 中的方法reactor.core.publisher.Mono
Repeatedly subscribe to this Mono as long as the current subscription to this Mono completes empty and the companion Publisher produces an onNext signal.
repeatWithVolumeCondition() - 类 中的方法reactor.core.publisher.FluxRepeatWhenTest
 
replace(Disposable) - 接口 中的方法reactor.core.Disposable.Swap
Atomically set the next Disposable on this container but don't dispose the previous one (if any).
replace(AtomicReferenceFieldUpdater<F, Subscription>, F, Subscription) - 类 中的静态方法reactor.core.publisher.Operators
A generic utility to atomically replace a subscription or cancel the replacement if the current subscription is marked as already cancelled (as in Operators.cancelledSubscription()).
replaceKey1NewContext() - 类 中的方法reactor.util.context.Context1Test
 
replaceKey1NewContext() - 类 中的方法reactor.util.context.Context2Test
 
replaceKey1NewContext() - 类 中的方法reactor.util.context.Context3Test
 
replaceKey1NewContext() - 类 中的方法reactor.util.context.Context4Test
 
replaceKey1NewContext() - 类 中的方法reactor.util.context.Context5Test
 
replaceKey1NewContext() - 类 中的方法reactor.util.context.ContextNTest
 
replaceKey2NewContext() - 类 中的方法reactor.util.context.Context2Test
 
replaceKey2NewContext() - 类 中的方法reactor.util.context.Context3Test
 
replaceKey2NewContext() - 类 中的方法reactor.util.context.Context4Test
 
replaceKey2NewContext() - 类 中的方法reactor.util.context.Context5Test
 
replaceKey2NewContext() - 类 中的方法reactor.util.context.ContextNTest
 
replaceKey3NewContext() - 类 中的方法reactor.util.context.Context3Test
 
replaceKey3NewContext() - 类 中的方法reactor.util.context.Context4Test
 
replaceKey3NewContext() - 类 中的方法reactor.util.context.Context5Test
 
replaceKey3NewContext() - 类 中的方法reactor.util.context.ContextNTest
 
replaceKey4NewContext() - 类 中的方法reactor.util.context.Context4Test
 
replaceKey4NewContext() - 类 中的方法reactor.util.context.Context5Test
 
replaceKey4NewContext() - 类 中的方法reactor.util.context.ContextNTest
 
replaceKey5NewContext() - 类 中的方法reactor.util.context.Context5Test
 
replaceKey5NewContext() - 类 中的方法reactor.util.context.ContextNTest
 
replaceKey6NewContext() - 类 中的方法reactor.util.context.ContextNTest
 
replacingFirstUnderlyingCausesUnsubscription() - 类 中的方法reactor.core.SwapDisposableTest
 
replay() - 类 中的方法reactor.core.publisher.Flux
Turn this Flux into a hot source and cache last emitted signals for further Subscriber.
replay(int) - 类 中的方法reactor.core.publisher.Flux
Turn this Flux into a connectable hot source and cache last emitted signals for further Subscriber.
replay(Duration) - 类 中的方法reactor.core.publisher.Flux
Turn this Flux into a connectable hot source and cache last emitted signals for further Subscriber.
replay(int, Duration) - 类 中的方法reactor.core.publisher.Flux
Turn this Flux into a connectable hot source and cache last emitted signals for further Subscriber.
replay(Duration, Scheduler) - 类 中的方法reactor.core.publisher.Flux
Turn this Flux into a connectable hot source and cache last emitted signals for further Subscriber.
replay(int, Duration, Scheduler) - 类 中的方法reactor.core.publisher.Flux
Turn this Flux into a connectable hot source and cache last emitted signals for further Subscriber.
replay() - 接口 中的方法reactor.core.publisher.Sinks.ManySpec
Help building Sinks.Many that will broadcast signals to multiple Subscriber with the ability to retain and replay all or an arbitrary number of elements.
ReplayProcessor<T> - reactor.core.publisher中的类
已过时。
To be removed in 3.5, prefer clear cut usage of Sinks through variations under Sinks.many().replay().
reportBadRequest(long) - 类 中的静态方法reactor.core.publisher.Operators
Log an IllegalArgumentException if the request is null or negative.
reportMoreProduced() - 类 中的静态方法reactor.core.publisher.Operators
Log an IllegalStateException that indicates more than the requested amount was produced.
reportSubscriptionSet() - 类 中的静态方法reactor.core.publisher.Operators
reportThrowInSubscribe(CoreSubscriber<?>, Throwable) - 类 中的静态方法reactor.core.publisher.Operators
Report a Throwable that was thrown from a call to Publisher.subscribe(Subscriber), attempting to notify the Subscriber by: providing a special Subscription via Subscriber.onSubscribe(Subscription) immediately delivering an onError signal after that As at that point the subscriber MAY have already been provided with a Subscription, we assume most well formed subscribers will ignore this second Subscription per Reactive Streams rule 1.9.
reportThrowInSubscribeWithFuseableErrorResumed() - 类 中的方法reactor.core.publisher.OperatorsTest
 
reproduceClassCastExceptionWithHooks() - 类 中的方法reactor.core.publisher.HooksTest
 
request(long) - 类 中的方法reactor.core.publisher.BaseSubscriber
 
request() - 类 中的方法reactor.core.publisher.FluxSwitchOnFirstConditionalStressTest.OutboundOnSubscribeAndRequestStressTest
 
request() - 类 中的方法reactor.core.publisher.FluxSwitchOnFirstStressTest.OutboundOnSubscribeAndRequestStressTest
 
request() - 类 中的方法reactor.core.publisher.FluxWindowTimeoutStressTest.FluxWindowTimoutStressTest1_0
 
request() - 类 中的方法reactor.core.publisher.FluxWindowTimeoutStressTest.FluxWindowTimoutStressTest1_1
 
request() - 类 中的方法reactor.core.publisher.FluxWindowTimeoutStressTest.FluxWindowTimoutStressTest2_2
 
request() - 类 中的方法reactor.core.publisher.MonoDelayStressTest.RequestAndCancelStressTest
 
request() - 类 中的方法reactor.core.publisher.MonoDelayStressTest.RequestAndRunStressTest
 
request() - 类 中的方法reactor.core.publisher.MonoInnerProducerBaseStressTest.RequestAndCompleteWithValueRace
 
request(long) - 类 中的方法reactor.core.publisher.MonoProcessor
已过时。
the MonoProcessor will cease to implement Subscription in 3.5
request(long) - 类 中的方法reactor.core.publisher.Operators.DeferredSubscription
 
request(long) - 类 中的方法reactor.core.publisher.Operators.MonoSubscriber
 
request() - 类 中的方法reactor.core.publisher.SinkManyBestEffortStressTest.InnerTryEmitNextCancelVersusRequestStressTest
 
request(long) - 类 中的方法reactor.core.publisher.StressSubscriber
 
request(long) - 类 中的方法reactor.core.publisher.StressSubscription
 
request(long) - 类 中的方法reactor.core.publisher.UnicastProcessor
已过时。
 
request() - 类 中的方法reactor.test.StepVerifierTests
 
request(long) - 类 中的方法reactor.test.subscriber.AssertSubscriber
 
request(long) - 接口 中的方法reactor.test.subscriber.TestSubscriber
Request n elements from the Publisher's Subscription.
request1() - 类 中的方法reactor.core.publisher.FluxGenerateStressTest.GenerateSlowPathStressTest
 
request1() - 类 中的方法reactor.core.publisher.FluxOnErrorReturnStressTest.ErrorFallbackVsRequestStressTest
 
request2() - 类 中的方法reactor.core.publisher.FluxGenerateStressTest.GenerateSlowPathStressTest
 
request2() - 类 中的方法reactor.core.publisher.FluxOnErrorReturnStressTest.ErrorFallbackVsRequestStressTest
 
request3() - 类 中的方法reactor.core.publisher.FluxGenerateStressTest.GenerateSlowPathStressTest
 
request3() - 类 中的方法reactor.core.publisher.FluxOnErrorReturnStressTest.ErrorFallbackVsRequestStressTest
 
request4() - 类 中的方法reactor.core.publisher.FluxGenerateStressTest.GenerateSlowPathStressTest
 
request5() - 类 中的方法reactor.core.publisher.FluxGenerateStressTest.GenerateSlowPathStressTest
 
RequestAndCancelStressTest() - 类 的构造器reactor.core.publisher.MonoDelayStressTest.RequestAndCancelStressTest
 
RequestAndCompleteWithValueRace() - 类 的构造器reactor.core.publisher.MonoInnerProducerBaseStressTest.RequestAndCompleteWithValueRace
 
RequestAndProduceStressTest1() - 类 的构造器reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest1
 
RequestAndProduceStressTest2() - 类 的构造器reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest2
 
RequestAndProduceStressTest3() - 类 的构造器reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest3
 
RequestAndProduceStressTest4() - 类 的构造器reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest4
 
RequestAndRunStressTest() - 类 的构造器reactor.core.publisher.MonoDelayStressTest.RequestAndRunStressTest
 
requestBounded() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
 
requestBoundedConditionalFusesDemands() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
 
requestBoundedSeveralInitial() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
 
requestBufferDoesntOverflow() - 类 中的方法reactor.test.StepVerifierTests
 
requestCancelCompleteWithoutValueRace() - 类 中的方法reactor.core.publisher.MonoInnerProducerBaseTest
 
requestCancelCompleteWithValueRace() - 类 中的方法reactor.core.publisher.MonoInnerProducerBaseTest
 
requestCancelRace() - 类 中的方法reactor.core.publisher.MonoSubscriberTest
 
requestCancelRaceAfterCompleteWithValue() - 类 中的方法reactor.core.publisher.MonoInnerProducerBaseTest
 
requestCancelRaceAfterSetValueAndComplete() - 类 中的方法reactor.core.publisher.MonoInnerProducerBaseTest
 
requestClearRace() - 类 中的方法reactor.core.publisher.MonoSubscriberTest
 
requestDelayed() - 类 中的方法reactor.core.publisher.StrictSubscriberTest
 
REQUESTED_FROM_DOWNSTREAM - 类 中的静态变量reactor.core.Scannable.Attr
A Long attribute exposing the current pending demand of a downstream component.
requestedFromDownstream() - 接口 中的方法reactor.core.publisher.FluxSink
The current outstanding request amount.
requestedFromUpstreamShouldNotExceedDownstreamDemand() - 类 中的方法reactor.core.publisher.FluxBufferTimeoutTest
 
requestedFusionMode(int) - 类 中的方法reactor.test.subscriber.AssertSubscriber
Setup what fusion mode should be requested from the incoming Subscription if it happens to be QueueSubscription
requestFusion(int) - 接口 中的方法reactor.core.Fuseable.QueueSubscription
Request a specific fusion mode from this QueueSubscription.
requestFusion(int) - 接口 中的方法reactor.core.Fuseable.SynchronousSubscription
 
requestFusion(int) - 类 中的方法reactor.core.publisher.Operators.MonoSubscriber
 
requestFusion(int) - 类 中的方法reactor.core.publisher.UnicastProcessor
已过时。
 
requestFusionDelegates() - 类 中的方法reactor.core.publisher.FluxMetricsFuseableTest
 
requestFusionDelegates() - 类 中的方法reactor.core.publisher.MonoMetricsFuseableTest
 
requestInbound() - 类 中的方法reactor.core.publisher.FluxSwitchOnFirstStressTest.OutboundCancelAndInboundCancelStressTest
 
requestMain() - 类 中的方法reactor.core.publisher.FluxWindowTimeoutStressTest.FluxWindowTimoutStressTest1_2
 
requestMain() - 类 中的方法reactor.core.publisher.FluxWindowTimeoutStressTest.FluxWindowTimoutStressTest1_3
 
requestNotDelayed() - 类 中的方法reactor.core.publisher.StrictSubscriberTest
 
requestRaceWithOnNext() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
 
requestRaceWithOnNextLoops() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
 
requestRemainingBuffersAfterBufferEmission() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
 
requestRest() - 类 中的方法reactor.core.publisher.FluxGenerateStressTest.GenerateSlowPathStressTest
 
requestsCount - 类 中的变量reactor.core.publisher.StressSubscription
 
requestSwitchingToMaxRequestsSourceOnlyOnceMore() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
 
requestTracking() - 类 中的方法reactor.core.publisher.FluxMetricsTest
 
requestTrackingDisabledIfNotNamed() - 类 中的方法reactor.core.publisher.FluxMetricsTest
 
requestTrackingDisabledIfNotNamedFuseable() - 类 中的方法reactor.core.publisher.FluxMetricsFuseableTest
 
requestTrackingFuseable() - 类 中的方法reactor.core.publisher.FluxMetricsFuseableTest
 
requestTrackingHasMeterForNamedSequence() - 类 中的方法reactor.core.publisher.FluxMetricsTest
 
requestTrackingHasMeterForNamedSequenceFuseable() - 类 中的方法reactor.core.publisher.FluxMetricsFuseableTest
 
requestUnbounded() - 类 中的方法reactor.core.publisher.BaseSubscriber
Request an unbounded amount.
requestUnboundedFromStartRequestsSourceOnce() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
 
requireFusion(int) - 类 中的方法reactor.test.subscriber.TestSubscriberBuilder
Expect fusion to be possible with the TestSubscriber, with Fuseable.NONE) being a special case.
requireFusion(int, int) - 类 中的方法reactor.test.subscriber.TestSubscriberBuilder
Expect fusion to be possible with the TestSubscriber, with both parameters set to Fuseable.NONE being a special case.
requireNotFuseable() - 类 中的方法reactor.test.subscriber.TestSubscriberBuilder
Enforce that the Subscription passed to the TestSubscriber isn't a Fuseable.QueueSubscription.
reset() - 类 中的方法reactor.test.MemoryUtils.OffHeapDetector
Reset this tracker, clearing the queue of tracked objects (which can be useful eg. when looping multiple times in order to test race conditions).
reset() - 类 中的静态方法reactor.test.scheduler.VirtualTimeScheduler
Re-activate the global Schedulers and potentially customized Schedulers.Factory that were active prior to last activation of VirtualTimeScheduler factories.
reset() - 类 中的方法reactor.test.util.TestLogger
 
resetAllHooks() - 类 中的方法reactor.core.scheduler.SchedulersHooksTest
 
resetDefaultTimeout() - 接口 中的静态方法reactor.test.StepVerifier
Reset the StepVerifier.verify() timeout to the "unlimited" default.
resetFactory() - 类 中的静态方法reactor.core.scheduler.Schedulers
Re-apply default factory to Schedulers
resetFrom(Schedulers.Snapshot) - 类 中的静态方法reactor.core.scheduler.Schedulers
Replace the current Factory and shared Schedulers with the ones saved in a previously captured snapshot.
resetLoggerFactory() - 类 中的静态方法reactor.util.Loggers
Attempt to activate the best reactor Logger factory, by first attempting to use the SLF4J one, then falling back to either Console logging or java.util.logging.Logger).
resetLoggersFactory() - 类 中的静态方法reactor.ReactorLauncherSessionListener
Reset the Loggers factory to defaults suitable for reactor-core tests.
resetOnEachOperator(String) - 类 中的静态方法reactor.core.publisher.Hooks
Remove the sub-hook with key key from the onEachOperator hook.
resetOnEachOperator() - 类 中的静态方法reactor.core.publisher.Hooks
Reset global "assembly" hook tracking
resetOnErrorDropped() - 类 中的静态方法reactor.core.publisher.Hooks
Reset global error dropped strategy to bubbling back the error.
resetOnHandleError() - 类 中的静态方法reactor.core.scheduler.Schedulers
Reset the Schedulers.onHandleError(BiConsumer) hook to the default no-op behavior, erasing all sub-hooks that might have individually added via Schedulers.onHandleError(String, BiConsumer) or the whole hook set via Schedulers.onHandleError(BiConsumer).
resetOnHandleError(String) - 类 中的静态方法reactor.core.scheduler.Schedulers
Reset a specific onHandleError hook part keyed to the provided String, removing that sub-hook if it has previously been defined via Schedulers.onHandleError(String, BiConsumer).
resetOnLastOperator(String) - 类 中的静态方法reactor.core.publisher.Hooks
Remove the sub-hook with key key from the onLastOperator hook.
resetOnLastOperator() - 类 中的静态方法reactor.core.publisher.Hooks
Reset global "subscriber" hook tracking
resetOnNextDropped() - 类 中的静态方法reactor.core.publisher.Hooks
Reset global data dropped strategy to throwing via Exceptions.failWithCancel()
resetOnNextError() - 类 中的静态方法reactor.core.publisher.Hooks
Reset global onNext error handling strategy to terminating the sequence with an onError and cancelling upstream (OnNextFailureStrategy.STOP).
resetOnOperatorDebug() - 类 中的静态方法reactor.core.publisher.Hooks
Reset global operator debug.
resetOnOperatorError(String) - 类 中的静态方法reactor.core.publisher.Hooks
Remove the sub-hook with key key from the onOperatorError hook.
resetOnOperatorError() - 类 中的静态方法reactor.core.publisher.Hooks
Reset global operator error mapping to the default behavior.
resetOnScheduleHook(String) - 类 中的静态方法reactor.core.scheduler.Schedulers
Reset a specific onScheduleHook sub-hook if it has been set up via Schedulers.onScheduleHook(String, Function).
resetOnScheduleHooks() - 类 中的静态方法reactor.core.scheduler.Schedulers
Remove all onScheduleHook sub-hooks.
resetRestoresSnapshotOfSchedulers() - 类 中的方法reactor.test.scheduler.VirtualTimeSchedulerTests
 
resetSchedulers() - 类 中的方法reactor.core.scheduler.SchedulersTest
 
resolveParameter(ParameterContext, ExtensionContext) - 类 中的方法reactor.core.TestLoggerExtension
 
resourceCleanupNull() - 类 中的方法reactor.core.publisher.FluxUsingTest
 
resourceCleanupNull() - 类 中的方法reactor.core.publisher.MonoUsingTest
 
resourceSupplierCanAccessContext() - 类 中的方法reactor.core.publisher.MonoUsingWhenTest
 
resourceSupplierNull() - 类 中的方法reactor.core.publisher.FluxUsingTest
 
resourceSupplierNull() - 类 中的方法reactor.core.publisher.MonoUsingTest
 
resourceThrowsEager() - 类 中的方法reactor.core.publisher.FluxUsingTest
 
resourceThrowsEager() - 类 中的方法reactor.core.publisher.MonoUsingTest
 
restart1() - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.ParallelSchedulerStartDisposeStressTest
 
restart1() - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.SingleSchedulerStartDisposeStressTest
 
restart2() - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.ParallelSchedulerStartDisposeStressTest
 
restart2() - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.SingleSchedulerStartDisposeStressTest
 
restartBoundedElastic() - 类 中的方法reactor.core.scheduler.SchedulersTest
 
restartParallel() - 类 中的方法reactor.core.scheduler.SchedulersTest
 
restartSingle() - 类 中的方法reactor.core.scheduler.SchedulersTest
 
restartSupport() - 类 中的方法reactor.core.scheduler.AbstractSchedulerTest
 
restartSupport() - 类 中的方法reactor.core.scheduler.ImmediateSchedulerTest
 
restCancelRace() - 类 中的方法reactor.core.scheduler.InstantPeriodicWorkerTaskTest
 
resultSelectorThrows() - 类 中的方法reactor.core.publisher.FluxGroupJoinTest
 
resultSelectorThrows() - 类 中的方法reactor.core.publisher.FluxJoinTest
 
resume() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeConditional() - 类 中的方法reactor.core.publisher.FluxPeekFuseableTest
 
resumeDrop() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeDropDoesntSelfSuppressIfHookRethrows() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeDropErrorHookFails() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeDropIfMatch() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeDropIfNoMatch() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeDropIfPredicateFails() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeDropIfWithFatalMatch() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeDropIfWithFatalNoMatch() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeDropValueHookFails() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeDropWithFatal() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeErrorConsumerFails() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeFuseable() - 类 中的方法reactor.core.publisher.FluxPeekFuseableTest
 
resumeFuseableConditional() - 类 中的方法reactor.core.publisher.FluxPeekFuseableTest
 
resumeIfDoesntSelfSuppress() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeIfErrorConsumerFails() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeIfMatch() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeIfNoMatch() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeIfPredicateFails() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeIfWithFatalMatch() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeIfWithFatalNoMatch() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
resumeWithFatal() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
retainAll(Collection<?>) - 接口 中的方法reactor.core.Fuseable.QueueSubscription
 
RetainedDetector() - 类 的构造器reactor.test.MemoryUtils.RetainedDetector
 
retry() - 类 中的方法reactor.core.publisher.Flux
Re-subscribes to this Flux sequence if it signals any error, indefinitely.
retry(long) - 类 中的方法reactor.core.publisher.Flux
Re-subscribes to this Flux sequence if it signals any error, for a fixed number of times.
retry(boolean) - 类 中的方法reactor.core.publisher.FluxPublishTest
 
retry() - 类 中的方法reactor.core.publisher.Mono
异常无限重试 Re-subscribes to this Mono sequence if it signals any error, indefinitely.
retry(long) - 类 中的方法reactor.core.publisher.Mono
异常重试指定次数 Re-subscribes to this Mono sequence if it signals any error, for a fixed number of times.
retry() - 类 中的方法reactor.core.publisher.TailCallSubscribeTest
 
Retry - reactor.util.retry中的类
Base abstract class for a strategy to decide when to retry given a companion Flux of Retry.RetrySignal, for use with Flux.retryWhen(Retry) and Mono.retryWhen(Retry).
Retry() - 类 的构造器reactor.util.retry.Retry
 
Retry.RetrySignal - reactor.util.retry中的接口
State used in Flux.retryWhen(Retry) and Mono.retryWhen(Retry), providing the Throwable that caused the source to fail as well as counters keeping track of retries.
retryAlways() - 类 中的方法reactor.core.publisher.FluxRetryWhenTest
 
RetryBackoffSpec - reactor.util.retry中的类
A Retry strategy based on exponential backoffs, with configurable features.
RetryBackoffSpecTest - reactor.util.retry中的类
 
RetryBackoffSpecTest() - 类 的构造器reactor.util.retry.RetryBackoffSpecTest
 
retryContext - 类 中的变量reactor.util.retry.Retry
 
retryContext() - 类 中的方法reactor.util.retry.Retry
Return the user provided context that was set at construction time.
retryContextExposedOnRetrySignal() - 类 中的方法reactor.core.publisher.FluxRetryWhenTest
 
retryContextIsCorrectlyPropagatedAndSet() - 类 中的方法reactor.util.retry.RetryBackoffSpecTest
 
retryContextIsCorrectlyPropagatedAndSet() - 类 中的方法reactor.util.retry.RetrySpecTest
 
retryContextView() - 接口 中的方法reactor.util.retry.Retry.RetrySignal
Return a read-only view of the user provided context, which may be used to store objects to be reset/rolled-back or otherwise mutated before or after a retry.
retryErrorsInResponse() - 类 中的方法reactor.core.publisher.FluxRetryWhenTest
 
retryExceptionCanBeCustomized() - 类 中的方法reactor.util.retry.RetryBackoffSpecTest
 
retryExceptionCanBeCustomized() - 类 中的方法reactor.util.retry.RetrySpecTest
 
retryExceptionDefaultsToRetryExhausted() - 类 中的方法reactor.util.retry.RetryBackoffSpecTest
 
retryExceptionDefaultsToRetryExhausted() - 类 中的方法reactor.util.retry.RetrySpecTest
 
retryExhausted(String, Throwable) - 类 中的静态方法reactor.core.Exceptions
Return a new RuntimeException that represents too many failures on retry.
retryExhaustedMessageWithCause() - 类 中的方法reactor.core.ExceptionsTest
 
retryExhaustedMessageWithNoCause() - 类 中的方法reactor.core.ExceptionsTest
 
retryInfinite() - 类 中的方法reactor.core.publisher.FluxRetryTest
 
retryInfinite() - 类 中的方法reactor.core.publisher.MonoRetryTest
 
RetrySpec - reactor.util.retry中的类
A simple count-based Retry strategy with configurable features.
RetrySpecTest - reactor.util.retry中的类
 
RetrySpecTest() - 类 的构造器reactor.util.retry.RetrySpecTest
 
retryThenIsCumulative() - 类 中的方法reactor.util.retry.RetryBackoffSpecTest
 
retryThenIsCumulative() - 类 中的方法reactor.util.retry.RetrySpecTest
 
retryWhen(Retry) - 类 中的方法reactor.core.publisher.Flux
Retries this Flux in response to signals emitted by a companion Publisher.
retryWhen(Retry) - 类 中的方法reactor.core.publisher.Mono
使用 RetrySpec 自定义重试策略 Retries this Mono in response to signals emitted by a companion Publisher.
retryWhenContextTrigger_MergesOriginalContext() - 类 中的方法reactor.core.publisher.FluxRetryWhenTest
 
retryWhenThrowableCompanionIsComparableToRetryWhenRetryFromFunction() - 类 中的方法reactor.core.publisher.FluxRetryWhenTest
 
retryWhenWithThrowableFunction() - 类 中的方法reactor.core.publisher.FluxRetryWhenTest
 
retryWithPublishOn(boolean) - 类 中的方法reactor.core.publisher.FluxPublishTest
 
returnFromIterableError() - 类 中的方法reactor.core.publisher.FluxOnErrorResumeTest
 
rightDurationSelectorThrows() - 类 中的方法reactor.core.publisher.FluxGroupJoinTest
 
rightDurationSelectorThrows() - 类 中的方法reactor.core.publisher.FluxJoinTest
 
rightDurationThrows() - 类 中的方法reactor.core.publisher.FluxGroupJoinTest
 
rightDurationThrows() - 类 中的方法reactor.core.publisher.FluxJoinTest
 
rightThrows() - 类 中的方法reactor.core.publisher.FluxGroupJoinTest
 
rightThrows() - 类 中的方法reactor.core.publisher.FluxJoinTest
 
RUN_ON - 类 中的静态变量reactor.core.Scannable.Attr
A key that links a Scannable to another Scannable it runs on.
RUN_STYLE - 类 中的静态变量reactor.core.Scannable.Attr
An Scannable.Attr.RunStyle enum attribute indicating whether or not an operator continues to operate on the same thread.
runDispose() - 类 中的方法reactor.core.scheduler.WorkerTaskTest
 
runFuture() - 类 中的方法reactor.core.scheduler.WorkerTaskTest
 
runnableCancelledBeforeRun() - 类 中的方法reactor.core.publisher.MonoRunnableTest
 
runnableFailure_Fuseable() - 类 中的方法reactor.core.publisher.FluxDoFirstTest
 
runnableFailure_Fuseable() - 类 中的方法reactor.core.publisher.MonoDoFirstTest
 
runnableFailure_NotFuseable() - 类 中的方法reactor.core.publisher.FluxDoFirstTest
 
runnableFailure_NotFuseable() - 类 中的方法reactor.core.publisher.MonoDoFirstTest
 
runnableSubscribeToCompleteMeasurement() - 类 中的方法reactor.core.publisher.MonoRunnableTest
 
runnableThrows() - 类 中的方法reactor.core.publisher.MonoRunnableTest
 
runOn(Scheduler) - 类 中的方法reactor.core.publisher.ParallelFlux
Specifies where each 'rail' will observe its incoming values with possible work-stealing and default prefetch amount.
runOn(Scheduler, int) - 类 中的方法reactor.core.publisher.ParallelFlux
Specifies where each 'rail' will observe its incoming values with possible work-stealing and a given prefetch amount.
runOnNegativePrefetchRejected() - 类 中的方法reactor.core.publisher.ParallelFluxTest
 
runOnZeroPrefetchRejected() - 类 中的方法reactor.core.publisher.ParallelFluxTest
 
runtimeExceptionFused() - 类 中的方法reactor.core.publisher.FluxHandleTest
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
跳过导航链接