跳过导航链接
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 

O

observation(ObservationRegistry) - 类 中的静态方法reactor.core.observability.micrometer.Micrometer
A SignalListener factory that will ultimately produce a Micrometer Observation representing the runtime of the publisher to the provided ObservationRegistry.
of(Publisher<? extends T>) - 接口 中的静态方法reactor.test.publisher.PublisherProbe
Create a PublisherProbe out of a Publisher, ensuring that its PublisherProbe.flux() and PublisherProbe.mono() versions will propagate signals from this publisher while capturing subscription, cancellation and request events around it.
of(Object, Object) - 接口 中的静态方法reactor.util.context.Context
Create a Context pre-initialized with one key-value pair.
of(Object, Object, Object, Object) - 接口 中的静态方法reactor.util.context.Context
Create a Context pre-initialized with two key-value pairs.
of(Object, Object, Object, Object, Object, Object) - 接口 中的静态方法reactor.util.context.Context
Create a Context pre-initialized with three key-value pairs.
of(Object, Object, Object, Object, Object, Object, Object, Object) - 接口 中的静态方法reactor.util.context.Context
Create a Context pre-initialized with four key-value pairs.
of(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - 接口 中的静态方法reactor.util.context.Context
Create a Context pre-initialized with five key-value pairs.
of(Map<?, ?>) - 接口 中的静态方法reactor.util.context.Context
Create a Context out of a Map.
of(ContextView) - 接口 中的静态方法reactor.util.context.Context
Create a Context out of a ContextView, enabling write API on top of the read-only view.
of(T1, T2) - 类 中的静态方法reactor.util.function.Tuples
Create a Tuple2 with the given objects.
of(T1, T2, T3) - 类 中的静态方法reactor.util.function.Tuples
Create a Tuple3 with the given objects.
of(T1, T2, T3, T4) - 类 中的静态方法reactor.util.function.Tuples
Create a Tuple4 with the given objects.
of(T1, T2, T3, T4, T5) - 类 中的静态方法reactor.util.function.Tuples
Create a Tuple5 with the given objects.
of(T1, T2, T3, T4, T5, T6) - 类 中的静态方法reactor.util.function.Tuples
Create a Tuple6 with the given objects.
of(T1, T2, T3, T4, T5, T6, T7) - 类 中的静态方法reactor.util.function.Tuples
Create a Tuple7 with the given objects.
of(T1, T2, T3, T4, T5, T6, T7, T8) - 类 中的静态方法reactor.util.function.Tuples
Create a Tuple8 with the given objects.
ofApi() - 类 中的方法reactor.util.context.Context1Test
 
ofApi() - 类 中的方法reactor.util.context.Context2Test
 
ofApi() - 类 中的方法reactor.util.context.Context3Test
 
ofApi() - 类 中的方法reactor.util.context.Context4Test
 
ofApi() - 类 中的方法reactor.util.context.Context5Test
 
offer(T) - 接口 中的方法reactor.core.Fuseable.QueueSubscription
 
offer() - 类 中的方法reactor.util.concurrent.SpscArrayQueueStressTest.OfferAndPollStressTest
 
OfferAndPollStressTest() - 类 的构造器reactor.util.concurrent.SpscArrayQueueStressTest.OfferAndPollStressTest
 
offerPair() - 类 中的方法reactor.util.concurrent.MpscLinkedQueueStressTest.BiPredicateAndOfferStressTest
 
offerPair() - 类 中的方法reactor.util.concurrent.MpscLinkedQueueStressTest.BiPredicateAndPollStressTest
 
offerPair() - 类 中的方法reactor.util.concurrent.SpscLinkedArrayQueueStressTest.BiPredicateAndPollStressTest
 
offerPairA() - 类 中的方法reactor.util.concurrent.MpscLinkedQueueStressTest.BiPredicateTwoActorsStressTest
 
offerPairA() - 类 中的方法reactor.util.concurrent.MpscLinkedQueueStressTest.BiPredicateTwoProducersOneConsumerStressTest
 
offerPairB() - 类 中的方法reactor.util.concurrent.MpscLinkedQueueStressTest.BiPredicateTwoActorsStressTest
 
offerPairB() - 类 中的方法reactor.util.concurrent.MpscLinkedQueueStressTest.BiPredicateTwoProducersOneConsumerStressTest
 
offerPairs() - 类 中的方法reactor.util.concurrent.SpscLinkedArrayQueueStressTest.BiPredicateAndPollAtGrowthBoundaryStressTest
 
offerSingle() - 类 中的方法reactor.util.concurrent.MpscLinkedQueueStressTest.BiPredicateAndOfferStressTest
 
OffHeapDetector() - 类 的构造器reactor.test.MemoryUtils.OffHeapDetector
 
ofType(Class<U>) - 类 中的方法reactor.core.publisher.Flux
Evaluate each accepted value against the given Class type.
ofType(Class<U>) - 类 中的方法reactor.core.publisher.Mono
判断当前Mono的类型能否转换成指定类型,不能转换则直接忽略 Evaluate the emitted value against the given Class type.
oldTimeoutCompleteHasNoEffect() - 类 中的方法reactor.core.publisher.FluxTimeoutTest
 
oldTimeoutErrorHasNoEffect() - 类 中的方法reactor.core.publisher.FluxTimeoutTest
 
oldTimeoutHasNoEffect() - 类 中的方法reactor.core.publisher.FluxTimeoutTest
 
onAfterTerminateFuseableConditionalNegotiatedNone() - 类 中的方法reactor.core.publisher.MonoPeekAfterTest
 
onAfterTerminateNormalConditional() - 类 中的方法reactor.core.publisher.MonoPeekAfterTest
 
onAssemblyDescription() - 类 中的方法reactor.core.publisher.MonoSourceTest
 
onBackpressureBuffer() - 类 中的方法reactor.core.publisher.Flux
Request an unbounded demand and push to the returned Flux, or park the observed elements if not enough demand is requested downstream.
onBackpressureBuffer(int) - 类 中的方法reactor.core.publisher.Flux
Request an unbounded demand and push to the returned Flux, or park up to maxSize elements when not enough demand is requested downstream.
onBackpressureBuffer(int, Consumer<? super T>) - 类 中的方法reactor.core.publisher.Flux
Request an unbounded demand and push to the returned Flux, or park up to maxSize elements when not enough demand is requested downstream.
onBackpressureBuffer(int, BufferOverflowStrategy) - 类 中的方法reactor.core.publisher.Flux
Request an unbounded demand and push to the returned Flux, or park the observed elements if not enough demand is requested downstream, within a maxSize limit.
onBackpressureBuffer(int, Consumer<? super T>, BufferOverflowStrategy) - 类 中的方法reactor.core.publisher.Flux
Request an unbounded demand and push to the returned Flux, or park the observed elements if not enough demand is requested downstream, within a maxSize limit.
onBackpressureBuffer(Duration, int, Consumer<? super T>) - 类 中的方法reactor.core.publisher.Flux
Request an unbounded demand and push to the returned Flux, or park the observed elements if not enough demand is requested downstream, within a maxSize limit and for a maximum Duration of ttl (as measured on the parallel Scheduler).
onBackpressureBuffer(Duration, int, Consumer<? super T>, Scheduler) - 类 中的方法reactor.core.publisher.Flux
Request an unbounded demand and push to the returned Flux, or park the observed elements if not enough demand is requested downstream, within a maxSize limit and for a maximum Duration of ttl (as measured on the provided Scheduler).
onBackpressureBuffer() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferTest
 
onBackpressureBuffer() - 接口 中的方法reactor.core.publisher.Sinks.MulticastSpec
A Sinks.Many with the following characteristics: Multicast Without Subscriber: warm up.
onBackpressureBuffer(int) - 接口 中的方法reactor.core.publisher.Sinks.MulticastSpec
A Sinks.Many with the following characteristics: Multicast Without Subscriber: warm up.
onBackpressureBuffer(int, boolean) - 接口 中的方法reactor.core.publisher.Sinks.MulticastSpec
A Sinks.Many with the following characteristics: Multicast Without Subscriber: warm up.
onBackpressureBuffer() - 接口 中的方法reactor.core.publisher.Sinks.UnicastSpec
A Sinks.Many with the following characteristics: Unicast: contrary to most other Sinks.Many, the Flux view rejects subscribers past the first one.
onBackpressureBuffer(Queue<T>) - 接口 中的方法reactor.core.publisher.Sinks.UnicastSpec
A Sinks.Many with the following characteristics: Unicast: contrary to most other Sinks.Many, the Flux view rejects subscribers past the first one.
onBackpressureBuffer(Queue<T>, Disposable) - 接口 中的方法reactor.core.publisher.Sinks.UnicastSpec
A Sinks.Many with the following characteristics: Unicast: contrary to most other Sinks.Many, the Flux view rejects subscribers past the first one.
onBackpressureBufferMax() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferTest
 
onBackpressureBufferMaxCallback() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferTest
 
onBackpressureBufferMaxCallbackOverflowDropLatest() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferStrategyTest
 
onBackpressureBufferMaxCallbackOverflowDropOldest() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferStrategyTest
 
onBackpressureBufferMaxCallbackOverflowError() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferStrategyTest
 
onBackpressureBufferMaxCallbackSourceEmitsAfterComplete() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferTest
 
onBackpressureBufferMaxCallbackUnder8() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferTest
 
onBackpressureBufferWithBadSourceEmitsAfterComplete() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferStrategyTest
 
onBackpressureDrop() - 类 中的方法reactor.core.publisher.Flux
Request an unbounded demand and push to the returned Flux, or drop the observed elements if not enough demand is requested downstream.
onBackpressureDrop(Consumer<? super T>) - 类 中的方法reactor.core.publisher.Flux
Request an unbounded demand and push to the returned Flux, or drop and notify dropping Consumer with the observed elements if not enough demand is requested downstream.
onBackpressureDrop() - 类 中的方法reactor.core.publisher.FluxOnBackpressureDropTest
 
onBackpressureError() - 类 中的方法reactor.core.publisher.Flux
Request an unbounded demand and push to the returned Flux, or emit onError fom Exceptions.failWithOverflow() if not enough demand is requested downstream.
onBackpressureError() - 接口 中的方法reactor.core.publisher.Sinks.UnicastSpec
A Sinks.Many with the following characteristics: Unicast: contrary to most other Sinks.Many, the Flux view rejects subscribers past the first one.
onBackpressureLatest() - 类 中的方法reactor.core.publisher.Flux
Request an unbounded demand and push to the returned Flux, or only keep the most recent observed item if not enough demand is requested downstream.
onCancel(Disposable) - 接口 中的方法reactor.core.publisher.FluxSink
Attach a Disposable as a callback for when this FluxSink is cancelled.
onCancel(Disposable) - 接口 中的方法reactor.core.publisher.MonoSink
取消订阅事件,调用Subscription.cancel()方法触发,多次注册以最后一次为准,当元素发布后再调用取消订阅时不生效 Attach a Disposable as a callback for when this MonoSink is cancelled.
onComplete() - 类 中的方法reactor.core.publisher.BaseSubscriber
 
onComplete() - 类 中的方法reactor.core.publisher.DirectProcessor
已过时。
 
onComplete() - 类 中的方法reactor.core.publisher.EmitterProcessor
已过时。
 
onComplete() - 类 中的方法reactor.core.publisher.InnerStressSubscriber
 
onComplete() - 类 中的方法reactor.core.publisher.Operators.MonoSubscriber
 
onComplete() - 类 中的方法reactor.core.publisher.ReplayProcessor
已过时。
 
onComplete() - 类 中的方法reactor.core.publisher.StressSubscriber
 
onComplete() - 类 中的方法reactor.core.publisher.UnicastProcessor
已过时。
 
onComplete() - 类 中的方法reactor.test.subscriber.AssertSubscriber
 
onCompleteAfterComplete() - 类 中的方法reactor.core.publisher.FluxDelaySequenceTest
 
onCompleteCalls - 类 中的变量reactor.core.publisher.StressSubscriber
 
onCompleteErrorPropagatedToOnError() - 类 中的方法reactor.core.publisher.BaseSubscriberTest
 
OnCompleteStressTest() - 类 的构造器reactor.core.publisher.FluxConcatMapNoPrefetchStressTest.OnCompleteStressTest
 
OnCompleteStressTest() - 类 的构造器reactor.core.publisher.FluxSwitchMapStressTest.OnCompleteStressTest
 
onCompletionBeforeLastBoundaryBufferEmitted() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
 
onCompletionBeforeLastBoundaryWindowEmitted() - 类 中的方法reactor.core.publisher.FluxWindowPredicateTest
 
onDiscard(T, Context) - 类 中的静态方法reactor.core.publisher.Operators
Invoke a (local or global) hook that processes elements that get discarded.
onDiscardMultiple(Stream<?>, Context) - 类 中的静态方法reactor.core.publisher.Operators
Invoke a (local or global) hook that processes elements that get discarded en masse.
onDiscardMultiple(Collection<?>, Context) - 类 中的静态方法reactor.core.publisher.Operators
Invoke a (local or global) hook that processes elements that get discarded en masse.
onDiscardMultiple(Iterator<?>, boolean, Context) - 类 中的静态方法reactor.core.publisher.Operators
Invoke a (local or global) hook that processes elements that remains in an Iterator.
onDiscardQueueWithClear(Queue<T>, Context, Function<T, Stream<?>>) - 类 中的静态方法reactor.core.publisher.Operators
Invoke a (local or global) hook that processes elements that get discarded en masse after having been enqueued, due to cancellation or error.
OnDiscardShouldNotLeakTest - reactor.core.publisher中的类
 
OnDiscardShouldNotLeakTest() - 类 的构造器reactor.core.publisher.OnDiscardShouldNotLeakTest
 
onDispose(Disposable) - 接口 中的方法reactor.core.publisher.FluxSink
Attach a Disposable as a callback for when this FluxSink is effectively disposed, that is it cannot be used anymore.
onDispose(Disposable) - 接口 中的方法reactor.core.publisher.MonoSink
在完成时,在发生异常时(onComplete, onError),在Subscription调用Subscription.cancel()方法取消时触发,可重复注册 Attach a Disposable as a callback for when this MonoSink is effectively disposed, that is it cannot be used anymore.
onDropNull() - 类 中的方法reactor.core.publisher.FluxOnBackpressureDropTest
 
onDropThrows() - 类 中的方法reactor.core.publisher.FluxOnBackpressureDropTest
 
one() - 类 中的方法reactor.core.publisher.SinkManyBestEffortStressTest.ImmediatelyCancelledSubscriberAndNewSubscriberStressTest
 
one() - 类 中的方法reactor.core.publisher.SinkManyBestEffortStressTest.ParallelSubscribersStressTest
 
one() - 类 中的静态方法reactor.core.publisher.Sinks
A Sinks.One that works like a conceptual promise: it can be completed with or without a value at any time, but only once.
one() - 接口 中的方法reactor.core.publisher.Sinks.RootSpec
A Sinks.One that works like a conceptual promise: it can be completed with or without a value at any time, but only once.
one() - 类 中的静态方法reactor.util.concurrent.Queues
 
onEachOperator(Function<? super Publisher<Object>, ? extends Publisher<Object>>) - 类 中的静态方法reactor.core.publisher.Hooks
Add a Publisher operator interceptor for each operator created (Flux or Mono).
onEachOperator(String, Function<? super Publisher<Object>, ? extends Publisher<Object>>) - 类 中的静态方法reactor.core.publisher.Hooks
Add or replace a named Publisher operator interceptor for each operator created (Flux or Mono).
onEachOperatorClearByName() - 类 中的方法reactor.core.publisher.HooksTest
 
onEachOperatorNamedReplacesKeepsOrder() - 类 中的方法reactor.core.publisher.HooksTest
 
onEachOperatorOneHookNoComposite() - 类 中的方法reactor.core.publisher.HooksTest
 
onEachOperatorReset() - 类 中的方法reactor.core.publisher.HooksTest
 
onEachOperatorResetSpecific() - 类 中的方法reactor.core.publisher.HooksTest
 
onEachOperatorSameLambdaDifferentNamesAppliedTwice() - 类 中的方法reactor.core.publisher.HooksTest
 
onEachOperatorSameLambdaSameNameAppliedOnce() - 类 中的方法reactor.core.publisher.HooksTest
 
oneAndErrorInner() - 类 中的方法reactor.core.publisher.FluxFilterWhenTest
 
oneAndErrorInner() - 类 中的方法reactor.core.publisher.MonoFilterWhenTest
 
oneGroupLongMerge() - 类 中的方法reactor.core.publisher.FluxGroupByTest
 
oneGroupLongMergeHidden() - 类 中的方法reactor.core.publisher.FluxGroupByTest
 
onEmitFailure(SignalType, Sinks.EmitResult) - 接口 中的方法reactor.core.publisher.Sinks.EmitFailureHandler
Decide whether the emission should be retried, depending on the provided Sinks.EmitResult and the type of operation that was attempted (represented as a SignalType).
oneQueueWithOneElementShouldConvertToArrayAndPutNullMarkerAndReuseInputArrayWhenPassedLargerArray() - 类 中的方法reactor.util.concurrent.QueuesOneQueueTest
 
oneQueueWithOneElementShouldConvertToArrayAndReuseInputArrayWhenPassedOneLengthArray() - 类 中的方法reactor.util.concurrent.QueuesOneQueueTest
 
oneQueueWithOneElementShouldConvertToArrayWhenPassedZeroLengthArray() - 类 中的方法reactor.util.concurrent.QueuesOneQueueTest
 
oneRepeat() - 类 中的方法reactor.core.publisher.FluxRepeatTest
 
oneRepeat() - 类 中的方法reactor.core.publisher.MonoRepeatTest
 
oneRepeatBackpressured() - 类 中的方法reactor.core.publisher.FluxRepeatTest
 
oneRepeatBackpressured() - 类 中的方法reactor.core.publisher.MonoRepeatTest
 
oneRetry() - 类 中的方法reactor.core.publisher.FluxRetryTest
 
oneRetry() - 类 中的方法reactor.core.publisher.MonoRetryTest
 
oneRetryBackpressured() - 类 中的方法reactor.core.publisher.FluxRetryTest
 
onError(Throwable) - 类 中的方法reactor.core.publisher.BaseSubscriber
 
onError(Throwable) - 类 中的方法reactor.core.publisher.DirectProcessor
已过时。
 
onError(Throwable) - 类 中的方法reactor.core.publisher.EmitterProcessor
已过时。
 
onError(Throwable) - 类 中的方法reactor.core.publisher.Operators.MonoSubscriber
 
onError(Throwable) - 类 中的方法reactor.core.publisher.ReplayProcessor
已过时。
 
onError(Throwable) - 类 中的方法reactor.core.publisher.StressSubscriber
 
onError(Throwable) - 类 中的方法reactor.core.publisher.UnicastProcessor
已过时。
 
onError(Throwable) - 类 中的方法reactor.test.subscriber.AssertSubscriber
 
onErrorAfterCompleteDrops() - 类 中的方法reactor.core.publisher.FluxDelaySequenceTest
 
onErrorAsyncCompleteDiscardsValue() - 类 中的方法reactor.core.publisher.MonoUsingWhenTest
 
onErrorCalls - 类 中的变量reactor.core.publisher.StressSubscriber
 
onErrorComplete() - 类 中的方法reactor.core.publisher.Flux
Simply complete the sequence by replacing an onError signal with an onComplete signal.
onErrorComplete(Class<? extends Throwable>) - 类 中的方法reactor.core.publisher.Flux
Simply complete the sequence by replacing an onError signal with an onComplete signal if the error matches the given Class.
onErrorComplete(Predicate<? super Throwable>) - 类 中的方法reactor.core.publisher.Flux
Simply complete the sequence by replacing an onError signal with an onComplete signal if the error matches the given Predicate.
onErrorComplete() - 类 中的方法reactor.core.publisher.Mono
吃掉Error信号,只需将 onError 信号替换为 onComplete 信号即可完成序列。
onErrorComplete(Class<? extends Throwable>) - 类 中的方法reactor.core.publisher.Mono
如果错误与给定的Class匹配,只需将onError signal替换为onComplete signal即可完成序列。
onErrorComplete(Predicate<? super Throwable>) - 类 中的方法reactor.core.publisher.Mono
使用一个 Predicate 返回的布尔值来决定是否吞掉异常让源完成 Simply complete the sequence by replacing an onError signal with an onComplete signal if the error matches the given Predicate.
onErrorContinue(BiConsumer<Throwable, Object>) - 类 中的方法reactor.core.publisher.Flux
Let compatible operators upstream recover from errors by dropping the incriminating element from the sequence and continuing with subsequent elements.
onErrorContinue(Class<E>, BiConsumer<Throwable, Object>) - 类 中的方法reactor.core.publisher.Flux
Let compatible operators upstream recover from errors by dropping the incriminating element from the sequence and continuing with subsequent elements.
onErrorContinue(Predicate<E>, BiConsumer<Throwable, Object>) - 类 中的方法reactor.core.publisher.Flux
Let compatible operators upstream recover from errors by dropping the incriminating element from the sequence and continuing with subsequent elements.
onErrorContinue(BiConsumer<Throwable, Object>) - 类 中的方法reactor.core.publisher.Mono
Let compatible operators upstream recover from errors by dropping the incriminating element from the sequence and continuing with subsequent elements.
onErrorContinue(Class<E>, BiConsumer<Throwable, Object>) - 类 中的方法reactor.core.publisher.Mono
Let compatible operators upstream recover from errors by dropping the incriminating element from the sequence and continuing with subsequent elements.
onErrorContinue(Predicate<E>, BiConsumer<Throwable, Object>) - 类 中的方法reactor.core.publisher.Mono
Let compatible operators upstream recover from errors by dropping the incriminating element from the sequence and continuing with subsequent elements.
onErrorDropped(Consumer<? super Throwable>) - 类 中的静态方法reactor.core.publisher.Hooks
Override global error dropped strategy which by default bubble back the error.
onErrorDropped(Throwable, Context) - 类 中的静态方法reactor.core.publisher.Operators
An unexpected exception is about to be dropped.
onErrorDroppedLocal() - 类 中的方法reactor.core.publisher.OperatorsTest
 
onErrorMap(Function<? super Throwable, ? extends Throwable>) - 类 中的方法reactor.core.publisher.Flux
Transform any error emitted by this Flux by synchronously applying a function to it.
onErrorMap(Class<E>, Function<? super E, ? extends Throwable>) - 类 中的方法reactor.core.publisher.Flux
Transform an error emitted by this Flux by synchronously applying a function to it if the error matches the given type.
onErrorMap(Predicate<? super Throwable>, Function<? super Throwable, ? extends Throwable>) - 类 中的方法reactor.core.publisher.Flux
Transform an error emitted by this Flux by synchronously applying a function to it if the error matches the given predicate.
onErrorMap(Predicate<? super Throwable>, Function<? super Throwable, ? extends Throwable>) - 类 中的方法reactor.core.publisher.Mono
如果错误与给定 Predicate 匹配,则通过同步应用函数来转换此Mono发出的错误。
onErrorMap(Function<? super Throwable, ? extends Throwable>) - 类 中的方法reactor.core.publisher.Mono
通过同步方法,将一个类型的异常转换为另一种类型的异常 Transform any error emitted by this Mono by synchronously applying a function to it.
onErrorMap(Class<E>, Function<? super E, ? extends Throwable>) - 类 中的方法reactor.core.publisher.Mono
如果错误与给定类型匹配,则通过同步应用函数来转换此Mono发出的错误。
onErrorResume(Function<? super Throwable, ? extends Publisher<? extends T>>) - 类 中的方法reactor.core.publisher.Flux
Subscribe to a returned fallback publisher when any error occurs, using a function to choose the fallback depending on the error.
onErrorResume(Class<E>, Function<? super E, ? extends Publisher<? extends T>>) - 类 中的方法reactor.core.publisher.Flux
Subscribe to a fallback publisher when an error matching the given type occurs, using a function to choose the fallback depending on the error.
onErrorResume(Predicate<? super Throwable>, Function<? super Throwable, ? extends Publisher<? extends T>>) - 类 中的方法reactor.core.publisher.Flux
Subscribe to a fallback publisher when an error matching a given predicate occurs.
onErrorResume(Function<? super Throwable, ? extends Mono<? extends T>>) - 类 中的方法reactor.core.publisher.Mono
错误恢复(动态候补值),当上游发生异常进行回调 Subscribe to a fallback publisher when any error occurs, using a function to choose the fallback depending on the error.
onErrorResume(Class<E>, Function<? super E, ? extends Mono<? extends T>>) - 类 中的方法reactor.core.publisher.Mono
当发生与给定类型匹配的错误时进行错误恢复(动态候补值),当上游发生异常进行回调 Subscribe to a fallback publisher when an error matching the given type occurs, using a function to choose the fallback depending on the error.
onErrorResume(Predicate<? super Throwable>, Function<? super Throwable, ? extends Mono<? extends T>>) - 类 中的方法reactor.core.publisher.Mono
当与给定的 Predicate 匹配时,进行错误恢复(动态候补值),当上游发生异常进行回调 Subscribe to a fallback publisher when an error matching a given predicate occurs.
onErrorResumeErrorPredicate() - 类 中的方法reactor.core.publisher.FluxOnErrorResumeTest
 
onErrorResumeErrorPredicateNot() - 类 中的方法reactor.core.publisher.FluxOnErrorResumeTest
 
onErrorReturn(T) - 类 中的方法reactor.core.publisher.Flux
Simply emit a captured fallback value when any error is observed on this Flux.
onErrorReturn(Class<E>, T) - 类 中的方法reactor.core.publisher.Flux
Simply emit a captured fallback value when an error of the specified type is observed on this Flux.
onErrorReturn(Predicate<? super Throwable>, T) - 类 中的方法reactor.core.publisher.Flux
Simply emit a captured fallback value when an error matching the given predicate is observed on this Flux.
onErrorReturn(T) - 类 中的方法reactor.core.publisher.Mono
当前Mono发生异常时,返回一个默认的值 Simply emit a captured fallback value when any error is observed on this Mono.
onErrorReturn(Class<E>, T) - 类 中的方法reactor.core.publisher.Mono
当Mono的异常和给定的异常匹配,返回一个默认的值 Simply emit a captured fallback value when an error of the specified type is observed on this Mono.
onErrorReturn(Predicate<? super Throwable>, T) - 类 中的方法reactor.core.publisher.Mono
如果Mono发生的异常与 Predicate 匹配,则返回一个默认的值 Simply emit a captured fallback value when an error matching the given predicate is observed on this Mono.
onErrorReturnErrorPredicate() - 类 中的方法reactor.core.publisher.FluxOnErrorResumeTest
 
onErrorReturnErrorPredicate2() - 类 中的方法reactor.core.publisher.FluxOnErrorResumeTest
 
onErrorReturnErrorPredicateNot() - 类 中的方法reactor.core.publisher.FluxOnErrorResumeTest
 
onErrorReturnErrorPredicateNot2() - 类 中的方法reactor.core.publisher.FluxOnErrorResumeTest
 
onErrorStop() - 类 中的方法reactor.core.publisher.Flux
If an Flux.onErrorContinue(BiConsumer) variant has been used downstream, reverts to the default 'STOP' mode where errors are terminal events upstream.
onErrorStop() - 类 中的方法reactor.core.publisher.Mono
If an Mono.onErrorContinue(BiConsumer) variant has been used downstream, reverts to the default 'STOP' mode where errors are terminal events upstream.
OnErrorStressTest() - 类 的构造器reactor.core.publisher.FluxConcatMapNoPrefetchStressTest.OnErrorStressTest
 
oneSourceIsNull() - 类 中的方法reactor.core.publisher.FluxConcatArrayTest
 
oneSourceIsNull() - 类 中的方法reactor.core.publisher.FluxConcatIterableTest
 
oneSourcePublisher() - 类 中的方法reactor.core.publisher.MonoWhenTest
 
oneSourcePublisherCombined() - 类 中的方法reactor.core.publisher.MonoZipTest
 
oneSourcePublisherCombinedDelay() - 类 中的方法reactor.core.publisher.MonoZipTest
 
oneSourcePublisherDelay() - 类 中的方法reactor.core.publisher.MonoWhenTest
 
oneWindowOnly() - 类 中的方法reactor.core.publisher.FluxWindowWhenTest
 
onHandleError(BiConsumer<Thread, ? super Throwable>) - 类 中的静态方法reactor.core.scheduler.Schedulers
Define a hook anonymous part that is executed alongside keyed parts when a Scheduler has handled an error.
onHandleError(String, BiConsumer<Thread, ? super Throwable>) - 类 中的静态方法reactor.core.scheduler.Schedulers
Define a keyed hook part that is executed alongside other parts when a Scheduler has handled an error.
onLastAssembly(CorePublisher<T>) - 类 中的静态方法reactor.core.publisher.Operators
onLastAssemblyOnce() - 类 中的方法reactor.core.publisher.FluxRepeatTest
 
onLastAssemblyOnce() - 类 中的方法reactor.core.publisher.FluxRetryTest
 
onLastOperator(Function<? super Publisher<Object>, ? extends Publisher<Object>>) - 类 中的静态方法reactor.core.publisher.Hooks
Add a Publisher operator interceptor for the last operator created in every flow (Flux or Mono).
onLastOperator(String, Function<? super Publisher<Object>, ? extends Publisher<Object>>) - 类 中的静态方法reactor.core.publisher.Hooks
Add or replace a named Publisher operator interceptor for the last operator created in every flow (Flux or Mono).
onLastOperatorClearByName() - 类 中的方法reactor.core.publisher.HooksTest
 
onLastOperatorNamedReplacesKeepsOrder() - 类 中的方法reactor.core.publisher.HooksTest
 
onLastOperatorOneHookNoComposite() - 类 中的方法reactor.core.publisher.HooksTest
 
onLastOperatorReset() - 类 中的方法reactor.core.publisher.HooksTest
 
onLastOperatorResetSpecific() - 类 中的方法reactor.core.publisher.HooksTest
 
onLastOperatorSameLambdaDifferentNamesAppliedTwice() - 类 中的方法reactor.core.publisher.HooksTest
 
onLastOperatorSameLambdaSameNameAppliedOnce() - 类 中的方法reactor.core.publisher.HooksTest
 
onlyConsumerPartOfRange() - 类 中的方法reactor.core.publisher.FluxScanSeedTest
 
onlyInitialRequestWithLateUnboundedSubscriber() - 类 中的方法reactor.core.publisher.FluxReplayTest
 
onMonoDoOnRequest() - 类 中的方法reactor.core.publisher.MonoPeekTest
 
onMonoDoOnSubscribe() - 类 中的方法reactor.core.publisher.MonoPeekTest
 
onMonoEmptyCallableOnBlock() - 类 中的方法reactor.core.publisher.MonoCallableTest
返回空的回调 block() 测试
onMonoErrorCallableOnBlock() - 类 中的方法reactor.core.publisher.MonoCallableTest
回调里抛出异常 block() 也会抛出异常
onMonoErrorSupplierOnBlock() - 类 中的方法reactor.core.publisher.MonoSupplierTest
 
onMonoRejectedDoOnError() - 类 中的方法reactor.core.publisher.MonoPeekTest
 
onMonoRejectedDoOnErrorClazz() - 类 中的方法reactor.core.publisher.MonoPeekTest
 
onMonoRejectedDoOnErrorClazzNot() - 类 中的方法reactor.core.publisher.MonoPeekTest
 
onMonoRejectedDoOnTerminate() - 类 中的方法reactor.core.publisher.MonoPeekTest
 
onMonoRejectedThrowOnBlock() - 类 中的方法reactor.core.publisher.MonoErrorTest
 
onMonoSuccessCallableOnBlock() - 类 中的方法reactor.core.publisher.MonoCallableTest
成功的回到 block() 测试
onMonoSuccessDoOnSuccess() - 类 中的方法reactor.core.publisher.MonoPeekTest
 
onMonoSuccessDoOnTerminate() - 类 中的方法reactor.core.publisher.MonoPeekTest
 
onMonoSuccessNullDoOnSuccess() - 类 中的方法reactor.core.publisher.MonoPeekTest
 
onMonoSuccessReturnOnBlock() - 类 中的方法reactor.core.publisher.MonoJustTest
 
onMonoSuccessSupplierOnBlock() - 类 中的方法reactor.core.publisher.MonoSupplierTest
 
onNext(T) - 类 中的方法reactor.core.publisher.BaseSubscriber
 
onNext(T) - 类 中的方法reactor.core.publisher.DirectProcessor
已过时。
 
onNext(T) - 类 中的方法reactor.core.publisher.EmitterProcessor
已过时。
 
onNext(I) - 类 中的方法reactor.core.publisher.Operators.MonoSubscriber
 
onNext(T) - 类 中的方法reactor.core.publisher.ReplayProcessor
已过时。
 
onNext(T) - 类 中的方法reactor.core.publisher.StressSubscriber
 
onNext(T) - 类 中的方法reactor.core.publisher.UnicastProcessor
已过时。
 
onNext(T) - 类 中的方法reactor.test.subscriber.AssertSubscriber
 
onNextAfterCompleteDrops() - 类 中的方法reactor.core.publisher.FluxDelaySequenceTest
 
onNextAfterErrorDrops() - 类 中的方法reactor.core.publisher.FluxDelaySequenceTest
 
onNextAndCancelRace() - 类 中的方法reactor.core.publisher.MonoReduceSeedTest
 
onNextAndCancelRace() - 类 中的方法reactor.core.publisher.MonoReduceTest
 
onNextAndCancelRaceDontPassNullToAccumulator() - 类 中的方法reactor.core.publisher.FluxScanSeedTest
 
onNextAndCancelRaceDontPassNullToAccumulator() - 类 中的方法reactor.core.publisher.FluxScanTest
 
onNextCalls - 类 中的变量reactor.core.publisher.StressSubscriber
 
onNextConsumerExceptionTriggersCancellation() - 类 中的方法reactor.core.publisher.LambdaMonoSubscriberTest
 
onNextConsumerExceptionTriggersCancellation() - 类 中的方法reactor.core.publisher.LambdaSubscriberTest
 
onNextConsumerFatalDoesntTriggerCancellation() - 类 中的方法reactor.core.publisher.LambdaSubscriberTest
 
onNextDiscarded - 类 中的变量reactor.core.publisher.StressSubscriber
 
onNextDropped(Consumer<Object>) - 类 中的静态方法reactor.core.publisher.Hooks
Override global data dropped strategy which by default logs at DEBUG level.
onNextDropped(T, Context) - 类 中的静态方法reactor.core.publisher.Operators
An unexpected event is about to be dropped.
onNextDroppedFail() - 类 中的静态方法reactor.core.publisher.Hooks
Resets onNextDropped hook(s) and apply a strategy of throwing Exceptions.failWithCancel() instead.
onNextDroppedFailReplaces() - 类 中的方法reactor.core.publisher.HooksTest
 
onNextDroppedLocal() - 类 中的方法reactor.core.publisher.OperatorsTest
 
onNextError(BiFunction<? super Throwable, Object, ? extends Throwable>) - 类 中的静态方法reactor.core.publisher.Hooks
Set the custom global error mode hook for operators that support resuming during an error in their Subscriber.onNext(Object).
onNextError(T, Throwable, Context, Subscription) - 类 中的静态方法reactor.core.publisher.Operators
Find the OnNextFailureStrategy to apply to the calling operator (which could be a local error mode defined in the Context) and apply it.
onNextError(T, Throwable, Context) - 类 中的静态方法reactor.core.publisher.Operators
Find the OnNextFailureStrategy to apply to the calling async operator (which could be a local error mode defined in the Context) and apply it.
onNextErrorFunction(Context) - 类 中的静态方法reactor.core.publisher.Operators
 
onNextErrorModeLocalStrategy() - 类 中的方法reactor.core.publisher.OperatorsTest
 
onNextErrorPropagatedToOnError() - 类 中的方法reactor.core.publisher.BaseSubscriberTest
 
OnNextFailureStrategyTest - reactor.core.publisher中的类
 
OnNextFailureStrategyTest() - 类 的构造器reactor.core.publisher.OnNextFailureStrategyTest
 
onNextFailureWithStrategyMatchingButNotNullDoesCancel() - 类 中的方法reactor.core.publisher.OperatorsTest
 
onNextFailureWithStrategyMatchingDoesntCancel() - 类 中的方法reactor.core.publisher.OperatorsTest
 
onNextFailureWithStrategyNotMatchingDoesCancel() - 类 中的方法reactor.core.publisher.OperatorsTest
 
onNextInnerError(Throwable, Context, Subscription) - 类 中的静态方法reactor.core.publisher.Operators
Find the OnNextFailureStrategy to apply to the calling operator (which could be a local error mode defined in the Context) and apply it.
onNextOnDisposedSchedulerThrows() - 类 中的方法reactor.core.publisher.MonoDelayElementTest
 
onNextPollError(T, Throwable, Context) - 类 中的静态方法reactor.core.publisher.Operators
Find the OnNextFailureStrategy to apply to the calling async operator (which could be a local error mode defined in the Context) and apply it.
onNextRaceWithCancelDoesNotLeak() - 类 中的方法reactor.core.publisher.SerializedSubscriberTest
 
onNextRaceWithRequest() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
 
onNextRaceWithRequestOfTwo() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
 
onNextTimerCounts() - 类 中的方法reactor.core.publisher.FluxMetricsTest
 
onNextTimerCountsFuseable() - 类 中的方法reactor.core.publisher.FluxMetricsFuseableTest
 
OnNextVsCancelStressTest() - 类 的构造器reactor.core.publisher.MonoDelayUntilStressTest.OnNextVsCancelStressTest
 
onOperatorDebug() - 类 中的静态方法reactor.core.publisher.Hooks
Enable operator stack recorder that captures a declaration stack whenever an operator is instantiated.
onOperatorError() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
 
onOperatorError(BiFunction<? super Throwable, Object, ? extends Throwable>) - 类 中的静态方法reactor.core.publisher.Hooks
Add a custom error mapping, overriding the default one.
onOperatorError(String, BiFunction<? super Throwable, Object, ? extends Throwable>) - 类 中的静态方法reactor.core.publisher.Hooks
Add or replace a named custom error mapping, overriding the default one.
onOperatorError(Throwable, Context) - 类 中的静态方法reactor.core.publisher.Operators
Map an "operator" error.
onOperatorError(Subscription, Throwable, Context) - 类 中的静态方法reactor.core.publisher.Operators
Map an "operator" error given an operator parent Subscription.
onOperatorError(Subscription, Throwable, Object, Context) - 类 中的静态方法reactor.core.publisher.Operators
Map an "operator" error given an operator parent Subscription.
onOperatorErrorClearByName() - 类 中的方法reactor.core.publisher.HooksTest
 
onOperatorErrorLocal() - 类 中的方法reactor.core.publisher.OperatorsTest
 
onOperatorErrorNamedReplacesKeepsOrder() - 类 中的方法reactor.core.publisher.HooksTest
 
onOperatorErrorOneHookNoComposite() - 类 中的方法reactor.core.publisher.HooksTest
 
onOperatorErrorReset() - 类 中的方法reactor.core.publisher.HooksTest
 
onOperatorErrorResetSpecific() - 类 中的方法reactor.core.publisher.HooksTest
 
onOperatorErrorSameLambdaDifferentNamesAppliedTwice() - 类 中的方法reactor.core.publisher.HooksTest
 
onOperatorErrorSameLambdaSameNameAppliedOnce() - 类 中的方法reactor.core.publisher.HooksTest
 
onRejectedExecution(Throwable, Context) - 类 中的静态方法reactor.core.publisher.Operators
Return a wrapped RejectedExecutionException which can be thrown by the operator.
onRejectedExecution(Throwable, Subscription, Throwable, Object, Context) - 类 中的静态方法reactor.core.publisher.Operators
Return a wrapped RejectedExecutionException which can be thrown by the operator.
onRejectedExecutionLocalTakesPrecedenceOverOnOperatorError() - 类 中的方法reactor.core.publisher.OperatorsTest
 
onRejectedExecutionWithDataSignalDelegatesToErrorLocal() - 类 中的方法reactor.core.publisher.OperatorsTest
 
onRejectedExecutionWithoutDataSignalDelegatesToErrorLocal() - 类 中的方法reactor.core.publisher.OperatorsTest
 
onRequest(LongConsumer) - 接口 中的方法reactor.core.publisher.FluxSink
Attaches a LongConsumer to this FluxSink that will be notified of any request to this sink.
onRequest() - 类 中的方法reactor.core.publisher.MonoCreateTest
背压数 n 默认是Long.MAX_VALUE
onRequest(LongConsumer) - 接口 中的方法reactor.core.publisher.MonoSink
请求事件,订阅者订阅后发起请求数据时触发,会传入一个Long型的背压数,默认是Long.MAX_VALUE Attaches a LongConsumer to this MonoSink that will be notified of any request to this sink.
onRequestDeferred() - 类 中的方法reactor.core.publisher.MonoCreateTest
背压数最小为1
onRetryExhaustedThrow(BiFunction<RetryBackoffSpec, Retry.RetrySignal, Throwable>) - 类 中的方法reactor.util.retry.RetryBackoffSpec
Set the generator for the Exception to be propagated when the maximum amount of retries is exhausted.
onRetryExhaustedThrow(BiFunction<RetrySpec, Retry.RetrySignal, Throwable>) - 类 中的方法reactor.util.retry.RetrySpec
Set the generator for the Exception to be propagated when the maximum amount of retries is exhausted.
onSchedule(Runnable) - 类 中的静态方法reactor.core.scheduler.Schedulers
Applies the hooks registered with Schedulers.onScheduleHook(String, Function).
onScheduleHook(String, Function<Runnable, Runnable>) - 类 中的静态方法reactor.core.scheduler.Schedulers
Add or replace a named scheduling decorator.
onScheduleIgnoresUnknownRemovals() - 类 中的方法reactor.core.scheduler.SchedulersHooksTest
 
onScheduleIsAdditive() - 类 中的方法reactor.core.scheduler.SchedulersHooksTest
 
onScheduleReplaces() - 类 中的方法reactor.core.scheduler.SchedulersHooksTest
 
onScheduleResetAll() - 类 中的方法reactor.core.scheduler.SchedulersHooksTest
 
onScheduleResetOne() - 类 中的方法reactor.core.scheduler.SchedulersHooksTest
 
onSchedulesAreOrdered() - 类 中的方法reactor.core.scheduler.SchedulersHooksTest
 
onScheduleWorksWhenEmpty() - 类 中的方法reactor.core.scheduler.SchedulersHooksTest
 
onSubscribe(Subscription) - 接口 中的方法reactor.core.CoreSubscriber
Implementors should initialize any state used by Subscriber.onNext(Object) before calling Subscription.request(long).
onSubscribe(Subscription) - 类 中的方法reactor.core.publisher.BaseSubscriber
 
onSubscribe(Subscription) - 类 中的方法reactor.core.publisher.DirectProcessor
已过时。
 
onSubscribe(Subscription) - 类 中的方法reactor.core.publisher.EmitterProcessor
已过时。
 
onSubscribe(Subscription) - 类 中的方法reactor.core.publisher.Operators.MonoSubscriber
 
onSubscribe(Subscription) - 类 中的方法reactor.core.publisher.ReplayProcessor
已过时。
 
onSubscribe(Subscription) - 类 中的方法reactor.core.publisher.StressSubscriber
 
onSubscribe(Subscription) - 类 中的方法reactor.core.publisher.UnicastProcessor
已过时。
 
onSubscribe(Subscription) - 类 中的方法reactor.test.subscriber.AssertSubscriber
 
onSubscribeCalls - 类 中的变量reactor.core.publisher.StressSubscriber
 
onSubscribeErrorPropagatedToOnError() - 类 中的方法reactor.core.publisher.BaseSubscriberTest
 
onSubscribeFatalThrown() - 类 中的方法reactor.core.publisher.BaseSubscriberTest
 
onSubscribeRace() - 类 中的方法reactor.core.publisher.FluxTimeoutTest
 
onSubscribeRaceRequestingShouldBeConsistentForTakeConditionalTest() - 类 中的方法reactor.core.publisher.FluxTakeTest
 
onSubscribeRaceRequestingShouldBeConsistentForTakeFuseableTest() - 类 中的方法reactor.core.publisher.FluxTakeTest
 
onSubscribeRaceRequestingShouldBeConsistentForTakeTest() - 类 中的方法reactor.core.publisher.FluxTakeTest
 
onSuccessCallbackFailureInterruptsOnNext() - 类 中的方法reactor.core.publisher.MonoPeekAfterTest
 
onSuccessForEmpty() - 类 中的方法reactor.core.publisher.MonoPeekAfterTest
 
onSuccessNormal() - 类 中的方法reactor.core.publisher.MonoPeekAfterTest
 
onSuccessNormalConditional() - 类 中的方法reactor.core.publisher.MonoPeekAfterTest
 
onSuccessNotCalledOnError() - 类 中的方法reactor.core.publisher.MonoPeekAfterTest
 
onTerminateDetach() - 类 中的方法reactor.core.publisher.Flux
Detaches both the child Subscriber and the Subscription on termination or cancellation.
onTerminateDetach() - 类 中的方法reactor.core.publisher.Mono
在终止或取消时分离 Subscriber(事件处理者,是真正去响应事件和处理数据的角色) 和 Subscription(订阅者,是实际从Publisher中获取数据的角色) Detaches both the child Subscriber and the Subscription on termination or cancellation.
openCloseBadClose() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
 
openCloseBadOpen() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
 
openCloseBadSource() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
 
openCloseDisposedOnComplete() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
 
openCloseEmptyBackpressure() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
 
openCloseErrorBackpressure() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
 
openCloseLimit() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
 
openCloseMainError() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
 
openCloseOpenCompletes() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
 
openCloseOpenCompletesNoBuffers() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
 
openCloseTake() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
 
OPERATOR_NAME_UNRELATED_WORDS_PATTERN - 接口 中的静态变量reactor.core.Scannable
The pattern for matching words unrelated to operator name.
operatorChainWithCheckpoint() - 类 中的方法reactor.core.ScannableTest
 
operatorChainWithDebugMode() - 类 中的方法reactor.core.ScannableTest
 
operatorChainWithLastOperator() - 类 中的方法reactor.core.ScannableTest
 
operatorChainWithLastSubscriber() - 类 中的方法reactor.core.ScannableTest
 
operatorChainWithLightCheckpoint() - 类 中的方法reactor.core.ScannableTest
 
operatorChainWithoutDebugMode() - 类 中的方法reactor.core.ScannableTest
 
OperatorDisposablesTest - reactor.core.publisher中的类
 
OperatorDisposablesTest() - 类 的构造器reactor.core.publisher.OperatorDisposablesTest
 
Operators - reactor.core.publisher中的类
A helper to support "Operator" writing, handle noop subscriptions, validate request size and to cap concurrent additive operations to Long.MAX_VALUE, which is generic to Subscription.request(long) handling.
Operators.DeferredSubscription - reactor.core.publisher中的类
Base class for Subscribers that will receive their Subscriptions at any time, yet they might also need to be cancelled or requested at any time.
Operators.MonoSubscriber<I,O> - reactor.core.publisher中的类
A Subscriber/Subscription barrier that holds a single value at most and properly gates asynchronous behaviors resulting from concurrent request or cancel and onXXX signals.
OperatorScenario<I,PI extends org.reactivestreams.Publisher<? extends I>,O,PO extends org.reactivestreams.Publisher<? extends O>> - reactor.test.publisher中的类
 
OperatorsTest - reactor.core.publisher中的类
 
OperatorsTest() - 类 的构造器reactor.core.publisher.OperatorsTest
 
optionalEmpty() - 类 中的方法reactor.core.publisher.BlockingOptionalMonoSubscriberTest
 
optionalEmptyDelayed() - 类 中的方法reactor.core.publisher.BlockingOptionalMonoSubscriberTest
 
optionalError() - 类 中的方法reactor.core.publisher.BlockingOptionalMonoSubscriberTest
 
optionalValued() - 类 中的方法reactor.core.publisher.BlockingOptionalMonoSubscriberTest
 
optionalValuedDelayed() - 类 中的方法reactor.core.publisher.BlockingOptionalMonoSubscriberTest
 
or(Publisher<? extends T>) - 类 中的方法reactor.core.publisher.Flux
Pick the first Publisher between this Flux and another publisher to emit any signal (onNext/onError/onComplete) and replay all signals from that Publisher, effectively behaving like the fastest of these competing sources.
or(Mono<? extends T>) - 类 中的方法reactor.core.publisher.Mono
从当前Mono或给定的另一个Mono发布一个可用的元素 Emit the first available signal from this mono or the other mono.
ordered(Comparator<? super T>) - 类 中的方法reactor.core.publisher.ParallelFlux
Merges the values from each 'rail', but choose which one to merge by way of a provided Comparator, picking the smallest of all rails.
ordered(Comparator<? super T>, int) - 类 中的方法reactor.core.publisher.ParallelFlux
Merges the values from each 'rail', but choose which one to merge by way of a provided Comparator, picking the smallest of all rails.
orderIsReversed_Fused() - 类 中的方法reactor.core.publisher.FluxDoFirstTest
 
orderIsReversed_Fused() - 类 中的方法reactor.core.publisher.MonoDoFirstTest
 
orderIsReversed_NoFusion() - 类 中的方法reactor.core.publisher.FluxDoFirstTest
 
orderIsReversed_NoFusion() - 类 中的方法reactor.core.publisher.MonoDoFirstTest
 
orThrow() - 枚举 中的方法reactor.core.publisher.Sinks.EmitResult
Easily convert from an Sinks.EmitResult to throwing an exception on failure cases.
orThrowWithCause(Throwable) - 枚举 中的方法reactor.core.publisher.Sinks.EmitResult
Easily convert from an Sinks.EmitResult to throwing an exception on failure cases.
otherCompletesImmediately() - 类 中的方法reactor.core.publisher.FluxSampleTest
 
otherEmpty() - 类 中的方法reactor.core.publisher.FluxZipIterableTest
 
otherError() - 类 中的方法reactor.core.publisher.FluxBufferBoundaryTest
 
otherError() - 类 中的方法reactor.core.publisher.FluxWindowBoundaryTest
 
otherIsEmpty() - 类 中的方法reactor.core.publisher.FluxWithLatestFromTest
 
otherIsNever() - 类 中的方法reactor.core.publisher.FluxWithLatestFromTest
 
otherNull() - 类 中的方法reactor.core.publisher.FluxDelaySubscriptionTest
 
otherNull() - 类 中的方法reactor.core.publisher.FluxSampleTest
 
otherNull() - 类 中的方法reactor.core.publisher.FluxSwitchIfEmptyTest
 
otherNull() - 类 中的方法reactor.core.publisher.FluxWithLatestFromTest
 
otherNull() - 类 中的方法reactor.core.publisher.MonoDelaySubscriptionTest
 
otherNull() - 类 中的方法reactor.core.publisher.MonoSwitchIfEmptyTest
 
otherSignalsError() - 类 中的方法reactor.core.publisher.FluxSkipUntilOtherTest
 
otherSignalsError() - 类 中的方法reactor.core.publisher.FluxTakeUntilOtherTest
 
otherSignalsErrorBackpressured() - 类 中的方法reactor.core.publisher.FluxSkipUntilOtherTest
 
otherSignalsErrorBackpressured() - 类 中的方法reactor.core.publisher.FluxTakeUntilOtherTest
 
otherwiseErrorFilter() - 类 中的方法reactor.core.publisher.MonoOnErrorResumeTest
 
otherwiseErrorUnfilter() - 类 中的方法reactor.core.publisher.MonoOnErrorResumeTest
 
otherwiseReturnErrorFilter() - 类 中的方法reactor.core.publisher.MonoOnErrorResumeTest
 
otherwiseReturnErrorFilter2() - 类 中的方法reactor.core.publisher.MonoOnErrorResumeTest
 
otherwiseReturnErrorUnfilter() - 类 中的方法reactor.core.publisher.MonoOnErrorResumeTest
 
otherwiseReturnErrorUnfilter2() - 类 中的方法reactor.core.publisher.MonoOnErrorResumeTest
 
OutboundCancelAndInboundCancelStressTest() - 类 的构造器reactor.core.publisher.FluxSwitchOnFirstStressTest.OutboundCancelAndInboundCancelStressTest
 
OutboundCancelAndInboundCompleteStressTest() - 类 的构造器reactor.core.publisher.FluxSwitchOnFirstStressTest.OutboundCancelAndInboundCompleteStressTest
 
OutboundCancelAndInboundErrorStressTest() - 类 的构造器reactor.core.publisher.FluxSwitchOnFirstStressTest.OutboundCancelAndInboundErrorStressTest
 
OutboundCancelAndInboundNextStressTest() - 类 的构造器reactor.core.publisher.FluxSwitchOnFirstConditionalStressTest.OutboundCancelAndInboundNextStressTest
 
OutboundCancelAndInboundNextStressTest() - 类 的构造器reactor.core.publisher.FluxSwitchOnFirstStressTest.OutboundCancelAndInboundNextStressTest
 
OutboundOnSubscribeAndRequestStressTest() - 类 的构造器reactor.core.publisher.FluxSwitchOnFirstConditionalStressTest.OutboundOnSubscribeAndRequestStressTest
 
OutboundOnSubscribeAndRequestStressTest() - 类 的构造器reactor.core.publisher.FluxSwitchOnFirstStressTest.OutboundOnSubscribeAndRequestStressTest
 
outer() - 类 中的方法reactor.core.publisher.FluxConcatMapNoPrefetchStressTest.OnCompleteStressTest
 
outer() - 类 中的方法reactor.core.publisher.FluxConcatMapNoPrefetchStressTest.OnErrorStressTest
 
outerCancel() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.CancelInnerCompleteStressTest
 
outerProducer() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.CancelInnerCompleteStressTest
 
outerProducer() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.CancelInnerErrorStressTest
 
outerProducer() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.MainErrorInnerErrorStressTest
 
outerProducer() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.OnCompleteStressTest
 
outerProducer() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest1
 
outerProducer() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest2
 
outerProducer() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest3
 
outerProducer() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest4
 
outerProducer() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.SimpleRequestAndProduceStressTest
 
outerRequest() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.CancelInnerCompleteStressTest
 
outerRequest() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest1
 
outerRequest() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest2
 
outerRequest() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest3
 
outerRequest() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.RequestAndProduceStressTest4
 
outerRequest() - 类 中的方法reactor.core.publisher.FluxSwitchMapStressTest.SimpleRequestAndProduceStressTest
 
overflowQueueNull() - 类 中的方法reactor.core.publisher.FluxWindowTest
 
overlap() - 类 中的方法reactor.core.publisher.FluxWindowTest
 
overlapBackpressured() - 类 中的方法reactor.core.publisher.FluxWindowTest
 
overlapError() - 类 中的方法reactor.core.publisher.FluxWindowTest
 
overrideInheritedErrorStrategyInFlatMap() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
overrideInheritedErrorStrategyInFlatMapMono() - 类 中的方法reactor.core.publisher.OnNextFailureStrategyTest
 
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 
跳过导航链接