- data() - 类 中的静态方法reactor.core.publisher.OnDiscardShouldNotLeakTest
-
- dataDroppedIfAutoconnectZero(boolean) - 类 中的方法reactor.core.publisher.FluxPublishTest
-
- dataDroppedIfConnectImmediately(boolean) - 类 中的方法reactor.core.publisher.FluxPublishTest
-
- debug(String) - 类 中的方法reactor.core.util.FastLogger
-
- debug(String, Object...) - 类 中的方法reactor.core.util.FastLogger
-
- debug(String, Throwable) - 类 中的方法reactor.core.util.FastLogger
-
- debug(String) - 类 中的方法reactor.test.util.TestLogger
-
- debug(String, Object...) - 类 中的方法reactor.test.util.TestLogger
-
- debug(String, Throwable) - 类 中的方法reactor.test.util.TestLogger
-
- debug() - 类 中的方法reactor.util.ConsoleLoggerTest
-
- debug(String) - 接口 中的方法reactor.util.Logger
-
Log a message at the DEBUG level.
- debug(String, Object...) - 接口 中的方法reactor.util.Logger
-
Log a message at the DEBUG level according to the specified format
and arguments.
- debug(String, Throwable) - 接口 中的方法reactor.util.Logger
-
Log an exception (throwable) at the DEBUG level with an
accompanying message.
- debug1() - 类 中的方法reactor.util.ConsoleLoggerTest
-
- debug2() - 类 中的方法reactor.util.ConsoleLoggerTest
-
- debugDismissedInNonVerboseMode() - 类 中的方法reactor.util.ConsoleLoggerTest
-
- debuggingActivated() - 类 中的方法reactor.guide.GuideTests
-
- debuggingActivatedWithDeepTraceback() - 类 中的方法reactor.guide.GuideDebuggingExtraTests
-
- debuggingCommonStacktrace() - 类 中的方法reactor.guide.GuideTests
-
- debuggingLogging() - 类 中的方法reactor.guide.GuideTests
-
- debugNulls() - 类 中的方法reactor.util.ConsoleLoggerTest
-
- decorateExecutorService(Scheduler, ScheduledExecutorService) - 类 中的静态方法reactor.core.scheduler.Schedulers
-
This method is aimed at
Scheduler
implementors, enabling custom implementations
that are backed by a
ScheduledExecutorService
to also have said executors
decorated (ie. for instrumentation purposes).
- decorateTwiceWithSameSchedulerInstance() - 类 中的方法reactor.core.scheduler.SchedulersMetricsTest
-
- DEFAULT_BOUNDED_ELASTIC_QUEUESIZE - 类 中的静态变量reactor.core.scheduler.Schedulers
-
Default maximum number of enqueued tasks PER THREAD for the global
Schedulers.boundedElastic()
Scheduler
,
initialized by system property
reactor.schedulers.defaultBoundedElasticQueueSize
and falls back to
a bound of 100 000 tasks per backing thread.
- DEFAULT_BOUNDED_ELASTIC_SIZE - 类 中的静态变量reactor.core.scheduler.Schedulers
-
Default maximum size for the global
Schedulers.boundedElastic()
Scheduler
, initialized
by system property
reactor.schedulers.defaultBoundedElasticSize
and falls back to 10 x number
of processors available to the runtime on init.
- DEFAULT_METER_PREFIX - 类 中的静态变量reactor.core.observability.micrometer.Micrometer
-
The default "name" to use as a prefix for meter if the instrumented sequence doesn't define a
name
.
- DEFAULT_POOL_SIZE - 类 中的静态变量reactor.core.scheduler.Schedulers
-
Default pool size, initialized by system property reactor.schedulers.defaultPoolSize
and falls back to the number of processors available to the runtime on init.
- DEFAULT_VALUES_TIMEOUT - 类 中的静态变量reactor.test.subscriber.AssertSubscriber
-
Default timeout for waiting next values to be received
- DEFAULT_VERIFY_TIMEOUT - 接口 中的静态变量reactor.test.StepVerifier
-
- defaultBackpressured() - 类 中的方法reactor.core.publisher.FluxIndexTest
-
- defaultBoundedElasticConfigurationIsConsistentWithJavadoc() - 类 中的方法reactor.core.scheduler.BoundedElasticSchedulerTest
-
- defaultConditional() - 类 中的方法reactor.core.publisher.FluxIndexTest
-
- DefaultContextExpectationsTest - reactor.test中的类
-
- DefaultContextExpectationsTest() - 类 的构造器reactor.test.DefaultContextExpectationsTest
-
- defaultDisposable() - 类 中的方法reactor.core.CoreTest
-
- defaultFuseableQueueSubscription() - 类 中的方法reactor.core.CoreTest
-
- defaultFused() - 类 中的方法reactor.core.publisher.FluxIndexedFuseableTest
-
- defaultFusedBackpressured() - 类 中的方法reactor.core.publisher.FluxIndexedFuseableTest
-
- defaultFusedConditional() - 类 中的方法reactor.core.publisher.FluxIndexedFuseableTest
-
- defaultIfEmpty(T) - 类 中的方法reactor.core.publisher.Flux
-
Provide a default unique value if this sequence is completed without any data
- defaultIfEmpty(T) - 类 中的方法reactor.core.publisher.Mono
-
如果Mono是
Mono.empty()
则提供一个默认值
Provide a default single value if this mono is completed without any data
- defaultNormal() - 类 中的方法reactor.core.publisher.FluxIndexTest
-
- defaultPrefetch() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- defaultRetryExhaustedMessageWithNoTransientErrors() - 类 中的方法reactor.util.retry.RetryBackoffSpecTest
-
- defaultRetryExhaustedMessageWithNoTransientErrors() - 类 中的方法reactor.util.retry.RetrySpecTest
-
- defaultRetryExhaustedMessageWithTransientErrors() - 类 中的方法reactor.util.retry.RetryBackoffSpecTest
-
- defaultRetryExhaustedMessageWithTransientErrors() - 类 中的方法reactor.util.retry.RetrySpecTest
-
- DefaultSignalListener<T> - reactor.core.observability中的类
-
A default implementation of a
SignalListener
with all the handlers no-op.
- DefaultSignalListener() - 类 的构造器reactor.core.observability.DefaultSignalListener
-
- DefaultStepVerifierBuilderTests - reactor.test中的类
-
- DefaultStepVerifierBuilderTests() - 类 的构造器reactor.test.DefaultStepVerifierBuilderTests
-
- defaultSupplierNull() - 类 中的方法reactor.core.publisher.MonoElementAtTest
-
- DefaultTestPublisherTests - reactor.test.publisher中的类
-
- DefaultTestPublisherTests() - 类 的构造器reactor.test.publisher.DefaultTestPublisherTests
-
- defaultUsingZip() - 类 中的方法reactor.core.publisher.MonoTakeLastOneTest
-
- defaultValue() - 类 中的方法reactor.core.Scannable.Attr
-
Meaningful and always applicable default value for the attribute, returned
instead of null when a specific value hasn't been defined for a
component.
- defer(Supplier<? extends Publisher<T>>) - 类 中的静态方法reactor.core.publisher.Flux
-
Lazily supply a
Publisher
every time a
Subscription
is made on the
resulting
Flux
, so the actual source instantiation is deferred until each
subscribe and the
Supplier
can create a subscriber-specific instance.
- defer(Supplier<? extends Mono<? extends T>>) - 类 中的静态方法reactor.core.publisher.Mono
-
为每个订阅者延迟发布一个元素,在被订阅时在发布者端延迟发布(懒汉式创建,而
Mono.just(Object)
则是饿汉式创建)
Create a
Mono
provider that will
supply
a target
Mono
to subscribe to for
each
Subscriber
downstream.
- deferContextual(Function<ContextView, ? extends Publisher<T>>) - 类 中的静态方法reactor.core.publisher.Flux
-
Lazily supply a
Publisher
every time a
Subscription
is made on the
resulting
Flux
, so the actual source instantiation is deferred until each
subscribe and the
Function
can create a subscriber-specific instance.
- deferContextual(Function<ContextView, ? extends Mono<? extends T>>) - 类 中的静态方法reactor.core.publisher.Mono
-
- deferFluxWithContext() - 类 中的方法reactor.core.publisher.FluxDeferTest
-
- deferMono() - 类 中的方法reactor.core.publisher.MonoDeferTest
-
- deferMonoWithContext() - 类 中的方法reactor.core.publisher.MonoDeferTest
-
- deferredFluxInitialValueLaterAvailableUpToLongMax() - 类 中的方法reactor.core.publisher.scenarios.FluxSpecTests
-
- DeferredSubscription() - 类 的构造器reactor.core.publisher.Operators.DeferredSubscription
-
- deferredUpstreamProducer() - 类 中的方法reactor.core.publisher.FluxDetachTest
-
- deferredUpstreamProducer() - 类 中的方法reactor.core.publisher.MonoDetachTest
-
- deferStream() - 类 中的方法reactor.core.publisher.FluxDeferTest
-
- delay(Duration) - 类 中的静态方法reactor.core.publisher.Mono
-
在默认Scheduler上创建一个Mono,它将onNext信号延迟给定的时间。
- delay(Duration, Scheduler) - 类 中的静态方法reactor.core.publisher.Mono
-
在指定Scheduler上创建一个Mono,它将onNext信号延迟给定的时间。
- DELAY_ERROR - 类 中的静态变量reactor.core.Scannable.Attr
-
Delay_Error exposes a Boolean
whether the scanned component
actively supports error delaying if it manages a backlog instead of fast
error-passing which might drop pending backlog.
- delayEach() - 类 中的方法reactor.core.publisher.scenarios.FluxTests
-
- delayedBackpressuredScalar() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- delayedCancelledHide() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- delayedSource() - 类 中的方法reactor.core.publisher.MonoDelayTest
-
- delayedSourceError() - 类 中的方法reactor.core.publisher.MonoDelayTest
-
- delayedTasksWith100kLimit() - 类 中的方法reactor.core.scheduler.BoundedElasticSchedulerTest
-
- delayedTrigger() - 类 中的方法reactor.core.publisher.FluxDelaySubscriptionTest
-
- delayedTrigger() - 类 中的方法reactor.core.publisher.MonoDelaySubscriptionTest
-
- delayedTrigger2() - 类 中的方法reactor.core.publisher.FluxDelaySubscriptionTest
-
- delayedTrigger2() - 类 中的方法reactor.core.publisher.MonoDelaySubscriptionTest
-
- delayedUnboundedScalarThenCancel() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- delayElement(Duration) - 类 中的方法reactor.core.publisher.Mono
-
将此Mono元素(Subscriber.onNext信号)延迟给定的持续时间(并行调度)。
- delayElement(Duration, Scheduler) - 类 中的方法reactor.core.publisher.Mono
-
Delay this
Mono
element (
Subscriber.onNext(T)
signal) by a given
Duration
, on a particular
Scheduler
.
- delayElements(Duration) - 类 中的方法reactor.core.publisher.Flux
-
Delay each of this
Flux
elements (
Subscriber.onNext(T)
signals)
by a given
Duration
.
- delayElements(Duration, Scheduler) - 类 中的方法reactor.core.publisher.Flux
-
Delay each of this
Flux
elements (
Subscriber.onNext(T)
signals)
by a given
Duration
.
- delayElements() - 类 中的方法reactor.core.publisher.FluxDelaySequenceTest
-
- delayElementShouldNotCancelTwice() - 类 中的方法reactor.core.publisher.FluxRefCountTest
-
- delayErrorConcatMapVsFlatMap() - 类 中的方法reactor.core.publisher.scenarios.FluxTests
-
- delayErrorConcatMapVsFlatMapTwoErrors() - 类 中的方法reactor.core.publisher.scenarios.FluxTests
-
- delayErrorEmptySourceErrorSource() - 类 中的方法reactor.core.publisher.MonoZipTest
-
- delayErrorEmptySourceErrorTwoSource() - 类 中的方法reactor.core.publisher.MonoZipTest
-
- delayErrorEmptySources() - 类 中的方法reactor.core.publisher.MonoZipTest
-
- delayErrorWithFluxError() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- delayErrorWithFluxError() - 类 中的方法reactor.core.publisher.FluxMergeTest
-
- delayErrorWithMonoError() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- delayErrorWithMonoError() - 类 中的方法reactor.core.publisher.FluxMergeTest
-
- delayFirstAsymmetricDelays() - 类 中的方法reactor.core.publisher.FluxDelaySequenceTest
-
- delayFirstInterval() - 类 中的方法reactor.core.publisher.FluxDelaySequenceTest
-
- delayItems() - 类 中的方法reactor.core.publisher.scenarios.FluxSpecTests
-
- delayRetryWithIsCumulative() - 类 中的方法reactor.util.retry.RetryBackoffSpecTest
-
- delayRetryWithIsCumulative() - 类 中的方法reactor.util.retry.RetrySpecTest
-
- delaySequence(Duration) - 类 中的方法reactor.core.publisher.Flux
-
Shift this
Flux
forward in time by a given
Duration
.
- delaySequence(Duration, Scheduler) - 类 中的方法reactor.core.publisher.Flux
-
Shift this
Flux
forward in time by a given
Duration
.
- delaySubscription(Duration) - 类 中的方法reactor.core.publisher.Flux
-
- delaySubscription(Duration, Scheduler) - 类 中的方法reactor.core.publisher.Flux
-
- delaySubscription(Publisher<U>) - 类 中的方法reactor.core.publisher.Flux
-
Delay the
subscription
to this
Flux
source until another
Publisher
signals a value or completes.
- delaySubscription(Duration) - 类 中的方法reactor.core.publisher.Mono
-
延迟订阅,直到延期订阅时间到期
Delay the
subscription
to this
Mono
source until the given
period elapses.
- delaySubscription(Duration, Scheduler) - 类 中的方法reactor.core.publisher.Mono
-
- delaySubscription(Publisher<U>) - 类 中的方法reactor.core.publisher.Mono
-
Delay the subscription to this
Mono
until another
Publisher
signals a value or completes.
- delaySubscription() - 类 中的方法reactor.core.publisher.TailCallSubscribeTest
-
- delayTrigger() - 类 中的方法reactor.core.publisher.MonoDelayStressTest.RequestAndCancelStressTest
-
- delayTrigger() - 类 中的方法reactor.core.publisher.MonoDelayStressTest.RequestAndRunStressTest
-
- delayUntil(Function<? super T, ? extends Publisher<?>>) - 类 中的方法reactor.core.publisher.Flux
-
Subscribe to this
Flux
and generate a
Publisher
from each of this
Flux elements, each acting as a trigger for relaying said element.
- delayUntil(Function<? super T, ? extends Publisher<?>>) - 类 中的方法reactor.core.publisher.Mono
-
中继触发器,将当前发布者的发布延迟到下一个发布者的发布
Subscribe to this
Mono
and another
Publisher
that is generated from
this Mono's element and which will be used as a trigger for relaying said element.
- delayUntilTriggerProviderThrows() - 类 中的方法reactor.core.publisher.MonoCreateTest
-
延迟发布,如果 delayUntil 里抛出异常,即时发布已一个消息,异常还是向下传递
- delegateCall() - 类 中的方法reactor.core.publisher.MonoCallableTest
-
- delegateCallError() - 类 中的方法reactor.core.publisher.MonoCallableTest
-
- delegateCallNull() - 类 中的方法reactor.core.publisher.MonoCallableTest
-
- DelegateServiceSchedulerTest - reactor.core.scheduler中的类
-
- DelegateServiceSchedulerTest() - 类 的构造器reactor.core.scheduler.DelegateServiceSchedulerTest
-
- delete(Object) - 接口 中的方法reactor.util.context.Context
-
Return a new
Context
that will resolve all existing keys except the
removed one,
key
.
- dematerialize() - 类 中的方法reactor.core.publisher.Flux
-
An operator working only if this
Flux
emits onNext, onError or onComplete
Signal
instances, transforming these
materialized
signals into
real signals on the
Subscriber
.
- dematerialize() - 类 中的方法reactor.core.publisher.Mono
-
当这个Mono使用
Signal
信号量的 onNext、onError、onComplete时,可以使用这个方法让流消失,让订阅者订阅信号量
An operator working only if this
Mono
emits onNext, onError or onComplete
Signal
instances, transforming these
materialized
signals into
real signals on the
Subscriber
.
- dematerializeUnbounded() - 类 中的方法reactor.core.publisher.FluxDematerializeTest
-
- depthCancelRace() - 类 中的方法reactor.core.publisher.FluxExpandTest
-
- depthCancelRace() - 类 中的方法reactor.core.publisher.MonoExpandTest
-
- depthCancelRace2() - 类 中的方法reactor.core.publisher.FluxExpandTest
-
- depthCancelRace2() - 类 中的方法reactor.core.publisher.MonoExpandTest
-
- depthCompleteCancelRace() - 类 中的方法reactor.core.publisher.FluxExpandTest
-
- depthCompleteCancelRace() - 类 中的方法reactor.core.publisher.MonoExpandTest
-
- depthEmitCancelRace() - 类 中的方法reactor.core.publisher.FluxExpandTest
-
- depthEmitCancelRace() - 类 中的方法reactor.core.publisher.MonoExpandTest
-
- depthFirst() - 类 中的方法reactor.core.publisher.FluxExpandTest
-
- depthFirst() - 类 中的方法reactor.core.publisher.MonoExpandTest
-
- depthFirstAsync() - 类 中的方法reactor.core.publisher.FluxExpandTest
-
- depthFirstAsync() - 类 中的方法reactor.core.publisher.MonoExpandTest
-
- depthFirstCancel() - 类 中的方法reactor.core.publisher.FluxExpandTest
-
- depthFirstCancel() - 类 中的方法reactor.core.publisher.MonoExpandTest
-
- description(String) - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
-
- description(String) - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
-
- description(String) - 类 中的方法reactor.test.publisher.OperatorScenario
-
- description(String) - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
-
- description(String) - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
-
- DetectCiPlugin - io.reactor.gradle中的类
-
- DetectCiPlugin() - 类 的构造器io.reactor.gradle.DetectCiPlugin
-
- DETECTED_EXTENSION - 类 中的静态变量io.reactor.gradle.DetectCiPlugin
-
- diamond() - 类 中的方法reactor.core.publisher.FluxPublishOnTest
-
- diamondLoop() - 类 中的方法reactor.core.publisher.loop.FluxPublishOnLoop
-
- differenceCancelsBothSources() - 类 中的方法reactor.core.publisher.MonoSequenceEqualTest
-
- differentLength() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- differentLengthOpt() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- directAllOrNothing() - 接口 中的方法reactor.core.publisher.Sinks.MulticastSpec
-
- directAndWorkerTimeSchedulingRejected() - 类 中的方法reactor.core.scheduler.ExecutorSchedulerTest
-
- directAndWorkerTimeSchedulingRejected() - 类 中的方法reactor.core.scheduler.ImmediateSchedulerTest
-
- directBestEffort() - 接口 中的方法reactor.core.publisher.Sinks.MulticastSpec
-
- directOtherEmptyPreventsSubscribe() - 类 中的方法reactor.core.publisher.FluxRepeatWhenTest
-
- directOtherEmptyPreventsSubscribeAndCompletes() - 类 中的方法reactor.core.publisher.FluxRetryWhenTest
-
- directOtherErrorPreventsSubscribe() - 类 中的方法reactor.core.publisher.FluxRepeatWhenTest
-
- directOtherErrorPreventsSubscribe() - 类 中的方法reactor.core.publisher.FluxRetryWhenTest
-
- DirectProcessor<T> - reactor.core.publisher中的类
-
- directScheduleAndDispose() - 类 中的方法reactor.core.scheduler.AbstractSchedulerTest
-
- directScheduleAndDisposeDelay() - 类 中的方法reactor.core.scheduler.AbstractSchedulerTest
-
- directScheduleAndDisposePeriod() - 类 中的方法reactor.core.scheduler.AbstractSchedulerTest
-
- disableCapture() - 类 中的静态方法reactor.test.util.LoggerUtils
-
- disableContextLossTracking() - 类 中的静态方法reactor.core.publisher.Hooks
-
- disableMetrics() - 类 中的静态方法reactor.core.scheduler.Schedulers
-
- disablingMetricsRemovesSchedulerMeters() - 类 中的方法reactor.core.scheduler.SchedulersMetricsTest
-
- discardAccumulatedOnCancel() - 类 中的方法reactor.core.publisher.MonoReduceSeedTest
-
- discardAccumulatedOnCancel() - 类 中的方法reactor.core.publisher.MonoReduceTest
-
- discardAdapterIsAdditive() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardAdapterRejectsNull() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardCancelCompleteRace() - 类 中的方法reactor.core.publisher.MonoCollectTest
-
- discardCancelNextRace() - 类 中的方法reactor.core.publisher.MonoCollectTest
-
- discardCollectionContinuesWhenIteratorElementFailsToBeDiscarded() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardCollectionStopsOnIsEmptyError() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardCollectionStopsOnIterationError() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardConditionalOnNextPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardConditionalOnNextPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterTest
-
- discardConditionalOnNextPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardConditionalOnNextPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterTest
-
- discardConditionalPollAsyncPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardConditionalPollAsyncPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardConditionalPollSyncPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardConditionalPollSyncPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardConditionalTryOnNextPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardConditionalTryOnNextPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterTest
-
- discardConditionalTryOnNextPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardConditionalTryOnNextPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterTest
-
- discardDelayedInnerOnDrainMapperError() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- discardDelayedOnCallableInnerErrorWithPrefetch() - 类 中的方法reactor.core.publisher.FluxConcatMapTest
-
- discardDelayedOnDrainMapperError() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- discardDelayedOnDrainMapperError() - 类 中的方法reactor.core.publisher.FluxConcatMapTest
-
TODO this test overrides the base one because
FluxConcatMap only discards the first element and not all (bug?)
- discardDelayedOnInnerErrorWithPrefetch() - 类 中的方法reactor.core.publisher.FluxConcatMapTest
-
- discardDelayedOnNextQueueReject() - 类 中的方法reactor.core.publisher.FluxConcatMapTest
-
- discardedValues - 类 中的变量reactor.core.publisher.StressSubscriber
-
- discardElementAndBufferOnAccumulatorLateFailure() - 类 中的方法reactor.core.publisher.MonoCollectTest
-
- discardElementOnAccumulatorFailure() - 类 中的方法reactor.core.publisher.MonoCollectTest
-
- discardIntermediateListElementsOnCancel() - 类 中的方法reactor.core.publisher.MonoStreamCollectorTest
-
- discardIntermediateListElementsOnError() - 类 中的方法reactor.core.publisher.MonoStreamCollectorTest
-
- discardIntermediateListElementsOnFinisherFailure() - 类 中的方法reactor.core.publisher.MonoStreamCollectorTest
-
- discardIntermediateMapOnCancel() - 类 中的方法reactor.core.publisher.MonoStreamCollectorTest
-
- discardIntermediateMapOnError() - 类 中的方法reactor.core.publisher.MonoStreamCollectorTest
-
- discardIntermediateMapOnFinisherFailure() - 类 中的方法reactor.core.publisher.MonoStreamCollectorTest
-
- discardIteratorContinuesWhenIteratorElementFailsToBeDiscarded() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardIteratorStopsOnIterationError() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardListElementsOnCancel() - 类 中的方法reactor.core.publisher.MonoCollectTest
-
- discardListElementsOnError() - 类 中的方法reactor.core.publisher.MonoCollectTest
-
- discardLocalMultipleFilters() - 类 中的方法reactor.core.publisher.scenarios.FluxTests
-
- discardLocalOrder() - 类 中的方法reactor.core.publisher.scenarios.FluxTests
-
- discardLocalOrder() - 类 中的方法reactor.core.publisher.scenarios.MonoTests
-
- discardOnBoundaryError() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
-
- discardOnCancel() - 类 中的方法reactor.core.publisher.FluxBufferBoundaryTest
-
- discardOnCancel() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
-
- discardOnCancel() - 类 中的方法reactor.core.publisher.FluxBufferTest
-
- discardOnCancel() - 类 中的方法reactor.core.publisher.FluxBufferTimeoutTest
-
- discardOnCancel() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
-
- discardOnCancel() - 类 中的方法reactor.core.publisher.FluxConcatMapTest
-
- discardOnCancelOverlap() - 类 中的方法reactor.core.publisher.FluxBufferTest
-
- discardOnCancelPostQueueing() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
-
- discardOnCancelSkip() - 类 中的方法reactor.core.publisher.FluxBufferTest
-
- discardOnCancelWindowUntil() - 类 中的方法reactor.core.publisher.FluxWindowPredicateTest
-
- discardOnCancelWindowUntilCutBefore() - 类 中的方法reactor.core.publisher.FluxWindowPredicateTest
-
- discardOnCancelWindowWhile() - 类 中的方法reactor.core.publisher.FluxWindowPredicateTest
-
- discardOnDrainCancelled() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
-
- discardOnDrainDoneWithErrors() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
-
- discardOnDrainEmittedAllCancelled() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
-
- discardOnDrainEmittedAllWithErrors() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
-
- discardOnDrainMapperError() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- discardOnEmitOverflow() - 类 中的方法reactor.core.publisher.FluxBufferBoundaryTest
-
- discardOnError() - 类 中的方法reactor.core.publisher.FluxBufferBoundaryTest
-
- discardOnError() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
-
- discardOnError() - 类 中的方法reactor.core.publisher.FluxBufferTest
-
- discardOnError() - 类 中的方法reactor.core.publisher.FluxBufferTimeoutTest
-
- discardOnError() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
-
- discardOnError() - 类 中的方法reactor.core.publisher.FluxConcatMapTest
-
- discardOnError() - 类 中的方法reactor.core.publisher.MonoReduceSeedTest
-
- discardOnError() - 类 中的方法reactor.core.publisher.MonoReduceTest
-
- discardOnErrorOverlap() - 类 中的方法reactor.core.publisher.FluxBufferTest
-
- discardOnErrorSkip() - 类 中的方法reactor.core.publisher.FluxBufferTest
-
- discardOnFlushWithoutRequest() - 类 中的方法reactor.core.publisher.FluxBufferTimeoutTest
-
- discardOnInnerErrorCallableWithPrefetch() - 类 中的方法reactor.core.publisher.FluxConcatMapTest
-
- discardOnInnerErrorWithPrefetch() - 类 中的方法reactor.core.publisher.FluxConcatMapTest
-
- discardOnNextAfterCancel() - 类 中的方法reactor.core.publisher.MonoReduceSeedTest
-
- discardOnNextPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardOnNextPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterTest
-
- discardOnNextPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardOnNextPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterTest
-
- discardOnNextQueueReject() - 类 中的方法reactor.core.publisher.FluxConcatMapTest
-
- discardOnNextSupplierError() - 类 中的方法reactor.core.publisher.FluxBufferTest
-
- discardOnNextSupplierErrorOverlap() - 类 中的方法reactor.core.publisher.FluxBufferTest
-
- discardOnNextSupplierErrorSkip() - 类 中的方法reactor.core.publisher.FluxBufferTest
-
- discardOnNextWhenNoBuffers() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
-
- discardOnOpenError() - 类 中的方法reactor.core.publisher.FluxBufferWhenTest
-
- discardOnPredicateError() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
-
- discardOnSkippedElements() - 类 中的方法reactor.core.publisher.FluxBufferTest
-
- discardOnTimerRejected() - 类 中的方法reactor.core.publisher.FluxBufferTimeoutTest
-
- discardPollAsyncPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardPollAsyncPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardPollSyncPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardPollSyncPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardQueueWithClearContinuesOnExtractedElementNotDiscarded() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardQueueWithClearContinuesOnExtractionError() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardQueueWithClearContinuesOnRawQueueElementNotDiscarded() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardQueueWithClearStopsOnQueuePollingError() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardRaceWithOnNext_bufferAdds() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
-
- discardRaceWithOnNext_bufferUntilCutBeforeWithMatch() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
-
- discardRaceWithOnNext_bufferUntilWithMatch() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
-
- discardRaceWithOnNext_bufferWhileWithNoMatch() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
-
- discardStreamContinuesWhenElementFailsToBeDiscarded() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardStreamStopsOnIterationError() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- discardTryOnNextPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardTryOnNextPredicateFail() - 类 中的方法reactor.core.publisher.FluxFilterTest
-
- discardTryOnNextPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterFuseableTest
-
- discardTryOnNextPredicateMiss() - 类 中的方法reactor.core.publisher.FluxFilterTest
-
- discardValueAndIntermediateListElementsOnAccumulatorFailure() - 类 中的方法reactor.core.publisher.MonoStreamCollectorTest
-
- discardValueAndIntermediateMapOnAccumulatorFailure() - 类 中的方法reactor.core.publisher.MonoStreamCollectorTest
-
- discardWholeArrayOnCancel() - 类 中的方法reactor.core.publisher.MonoCollectTest
-
- discardWholeArrayOnError() - 类 中的方法reactor.core.publisher.MonoCollectTest
-
- disconnect(boolean) - 类 中的方法reactor.core.publisher.FluxPublishTest
-
- disconnectBackpressured(boolean) - 类 中的方法reactor.core.publisher.FluxPublishTest
-
- Disposable - reactor.core中的接口
-
Indicates that a task or resource can be cancelled/disposed.
- Disposable.Composite - reactor.core中的接口
-
- Disposable.Swap - reactor.core中的接口
-
A
Disposable
container that allows updating/replacing its inner Disposable
atomically and with respect of disposing the container itself.
- Disposables - reactor.core中的类
-
- DisposablesTest - reactor.core中的类
-
- DisposablesTest() - 类 的构造器reactor.core.DisposablesTest
-
- DisposableTest - reactor.core中的类
-
- DisposableTest() - 类 的构造器reactor.core.DisposableTest
-
- dispose() - 接口 中的方法reactor.core.Disposable.Composite
-
Atomically mark the container as
disposed
, clear it and then
dispose all the previously contained Disposables.
- dispose() - 接口 中的方法reactor.core.Disposable
-
Cancel or dispose the underlying task or resource.
- dispose() - 类 中的方法reactor.core.DisposablesTest
-
- dispose() - 类 中的方法reactor.core.publisher.BaseSubscriber
-
Dispose
the
Subscription
by
cancelling
it.
- dispose() - 类 中的方法reactor.core.publisher.FluxProcessor
-
已过时。
- dispose() - 类 中的方法reactor.core.publisher.MonoProcessor
-
已过时。
- dispose() - 类 中的方法reactor.core.publisher.OperatorDisposablesTest
-
- dispose(IIZ_Result) - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.ParallelSchedulerDisposeGracefullyAndDisposeStressTest
-
- dispose(IIZ_Result) - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.SingleSchedulerDisposeGracefullyAndDisposeStressTest
-
- dispose() - 类 中的方法reactor.core.scheduler.InstantPeriodicWorkerTaskTest
-
- dispose() - 接口 中的方法reactor.core.scheduler.Scheduler
-
Instructs this Scheduler to release all resources and reject
any new tasks to be executed.
- dispose() - 类 中的方法reactor.core.scheduler.Schedulers.Snapshot
-
- dispose() - 类 中的方法reactor.core.scheduler.WorkerTaskTest
-
- dispose() - 类 中的方法reactor.test.FakeDisposable
-
- dispose() - 类 中的方法reactor.test.scheduler.VirtualTimeScheduler
-
- dispose2() - 类 中的方法reactor.core.scheduler.InstantPeriodicWorkerTaskTest
-
- dispose2CurrentThread() - 类 中的方法reactor.core.scheduler.InstantPeriodicWorkerTaskTest
-
- dispose3() - 类 中的方法reactor.core.scheduler.InstantPeriodicWorkerTaskTest
-
- disposeAfterDispose() - 类 中的方法reactor.core.ListCompositeDisposableTest
-
- disposeAfterRun() - 类 中的方法reactor.core.scheduler.WorkerTaskTest
-
- disposeCancels() - 类 中的方法reactor.core.publisher.BaseSubscriberTest
-
- disposeCancelsBoth() - 类 中的方法reactor.core.publisher.MonoTakeUntilOtherTest
-
- disposeConcurrent() - 类 中的方法reactor.core.ListCompositeDisposableTest
-
- disposed() - 类 中的静态方法reactor.core.Disposables
-
- disposed - 类 中的变量reactor.test.FakeDisposable
-
- disposedCreatesInstances() - 类 中的方法reactor.core.DisposableTest
-
- disposedInitiallyDisposed() - 类 中的方法reactor.core.DisposableTest
-
- disposeDisposesAndDisallowReuse() - 类 中的方法reactor.core.ListCompositeDisposableTest
-
- disposedSchedulerIsStillCleanedUp() - 类 中的方法reactor.test.scheduler.VirtualTimeSchedulerTests
-
- disposeGracefully(IIZ_Result) - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.ParallelSchedulerDisposeGracefullyAndDisposeStressTest
-
- disposeGracefully(IIZ_Result) - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.SingleSchedulerDisposeGracefullyAndDisposeStressTest
-
- disposeGracefully() - 接口 中的方法reactor.core.scheduler.Scheduler
-
Lazy variant of
Scheduler.dispose()
that also allows for graceful cleanup
of underlying resources.
- disposeGracefully1(IIZ_Result) - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.ParallelSchedulerDisposeGracefullyStressTest
-
- disposeGracefully1(IIZ_Result) - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.SingleSchedulerDisposeGracefullyStressTest
-
- disposeGracefully2(IIZ_Result) - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.ParallelSchedulerDisposeGracefullyStressTest
-
- disposeGracefully2(IIZ_Result) - 类 中的方法reactor.core.scheduler.BasicSchedulersStressTest.SingleSchedulerDisposeGracefullyStressTest
-
- disposeOnCurrentThread() - 类 中的方法reactor.core.scheduler.InstantPeriodicWorkerTaskTest
-
- disposeRace() - 类 中的方法reactor.core.DisposablesTest
-
- disposeRace() - 类 中的方法reactor.core.scheduler.WorkerTaskTest
-
- disposeRun() - 类 中的方法reactor.core.scheduler.WorkerTaskTest
-
- disposeWorkerIfCancelledBeforeOnSubscribe() - 类 中的方法reactor.core.publisher.MonoSubscribeOnTest
-
- distinct() - 类 中的方法reactor.core.publisher.Flux
-
For each
Subscriber
, track elements from this
Flux
that have been
seen and filter out duplicates.
- distinct(Function<? super T, ? extends V>) - 类 中的方法reactor.core.publisher.Flux
-
For each
Subscriber
, track elements from this
Flux
that have been
seen and filter out duplicates, as compared by a key extracted through the user
provided
Function
.
- distinct(Function<? super T, ? extends V>, Supplier<C>) - 类 中的方法reactor.core.publisher.Flux
-
For each
Subscriber
, track elements from this
Flux
that have been
seen and filter out duplicates, as compared by a key extracted through the user
provided
Function
and by the
add method
of the
Collection
supplied (typically a
Set
).
- distinct(Function<? super T, ? extends V>, Supplier<C>, BiPredicate<C, V>, Consumer<C>) - 类 中的方法reactor.core.publisher.Flux
-
For each
Subscriber
, track elements from this
Flux
that have been
seen and filter out duplicates, as compared by applying a
BiPredicate
on
an arbitrary user-supplied
<C>
store and a key extracted through the user
provided
Function
.
- distinctCustomCollectionCustomPredicate() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- distinctDefaultCancelDoesntRetainObjects() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- distinctDefaultDoesntRetainObjects() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- distinctDefaultErrorDoesntRetainObjects() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- distinctDefaultWithHashcodeCollisions() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- distinctPredicateNull() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- distinctPredicateThrows() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- distinctPredicateThrowsConditional() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- distinctPredicateThrowsConditionalOnNext() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- distinctUntilChanged() - 类 中的方法reactor.core.publisher.Flux
-
Filter out subsequent repetitions of an element (that is, if they arrive right after
one another).
- distinctUntilChanged(Function<? super T, ? extends V>) - 类 中的方法reactor.core.publisher.Flux
-
Filter out subsequent repetitions of an element (that is, if they arrive right after
one another), as compared by a key extracted through the user provided Function
using equality.
- distinctUntilChanged(Function<? super T, ? extends V>, BiPredicate<? super V, ? super V>) - 类 中的方法reactor.core.publisher.Flux
-
Filter out subsequent repetitions of an element (that is, if they arrive right
after one another), as compared by a key extracted through the user provided Function
and then comparing keys with the supplied BiPredicate
.
- distinctUntilChangedDefaultCancelDoesntRetainObjects() - 类 中的方法reactor.core.publisher.FluxDistinctUntilChangedTest
-
- distinctUntilChangedDefaultDoesntRetainObjects() - 类 中的方法reactor.core.publisher.FluxDistinctUntilChangedTest
-
- distinctUntilChangedDefaultErrorDoesntRetainObjects() - 类 中的方法reactor.core.publisher.FluxDistinctUntilChangedTest
-
- distinctUntilChangedDefaultWithHashcodeCollisions() - 类 中的方法reactor.core.publisher.FluxDistinctUntilChangedTest
-
- doAfterComplete() - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doAfterComplete() - 接口 中的方法reactor.core.observability.SignalListener
-
Handle graceful onComplete sequence termination, after onComplete has been propagated downstream.
- doAfterError(Throwable) - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doAfterError(Throwable) - 接口 中的方法reactor.core.observability.SignalListener
-
Handle onError sequence termination after onError has been propagated downstream.
- doAfterRetry(Consumer<Retry.RetrySignal>) - 类 中的方法reactor.util.retry.RetryBackoffSpec
-
Add synchronous behavior to be executed after the retry trigger is emitted in
the companion publisher.
- doAfterRetry(Consumer<Retry.RetrySignal>) - 类 中的方法reactor.util.retry.RetrySpec
-
Add synchronous behavior to be executed after the retry trigger is emitted in
the companion publisher.
- doAfterRetryAsync(Function<Retry.RetrySignal, Mono<Void>>) - 类 中的方法reactor.util.retry.RetryBackoffSpec
-
Add asynchronous behavior to be executed
after the current retry trigger in the companion publisher,
thus
delaying the resulting retry trigger with the additional
Mono
.
- doAfterRetryAsync(Function<Retry.RetrySignal, Mono<Void>>) - 类 中的方法reactor.util.retry.RetrySpec
-
Add asynchronous behavior to be executed
after the current retry trigger in the companion publisher,
thus
delaying the resulting retry trigger with the additional
Mono
.
- doAfterRetryIsCumulative() - 类 中的方法reactor.util.retry.RetryBackoffSpecTest
-
- doAfterRetryIsCumulative() - 类 中的方法reactor.util.retry.RetrySpecTest
-
- doAfterTerminate(Runnable) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered after the
Flux
terminates, either by completing downstream successfully or with an error.
- doAfterTerminate(Runnable) - 类 中的方法reactor.core.publisher.Mono
-
在Mono终止后触发的行为
Add behavior (side-effect) triggered after the
Mono
terminates, either by
completing downstream successfully or with an error.
- doAfterTerminate(Runnable) - 类 中的方法reactor.core.publisher.ParallelFlux
-
Run the specified runnable when a 'rail' completes or signals an error.
- doBeforeRetry(Consumer<Retry.RetrySignal>) - 类 中的方法reactor.util.retry.RetryBackoffSpec
-
Add synchronous behavior to be executed before the retry trigger is emitted in
the companion publisher.
- doBeforeRetry(Consumer<Retry.RetrySignal>) - 类 中的方法reactor.util.retry.RetrySpec
-
Add synchronous behavior to be executed before the retry trigger is emitted in
the companion publisher.
- doBeforeRetryAsync(Function<Retry.RetrySignal, Mono<Void>>) - 类 中的方法reactor.util.retry.RetryBackoffSpec
-
Add asynchronous behavior to be executed
before the current retry trigger in the companion publisher,
thus
delaying the resulting retry trigger with the additional
Mono
.
- doBeforeRetryAsync(Function<Retry.RetrySignal, Mono<Void>>) - 类 中的方法reactor.util.retry.RetrySpec
-
Add asynchronous behavior to be executed
before the current retry trigger in the companion publisher,
thus
delaying the resulting retry trigger with the additional
Mono
.
- doBeforeRetryIsCumulative() - 类 中的方法reactor.util.retry.RetryBackoffSpecTest
-
- doBeforeRetryIsCumulative() - 类 中的方法reactor.util.retry.RetrySpecTest
-
- Doc - reactor.doc中的注释类型
-
- DocUtil - reactor.doc中的类
-
- doesDisconnectAfterRefCountZeroAndSlowResubscribe() - 类 中的方法reactor.core.publisher.FluxRefCountGraceTest
-
- doesntCompleteWithoutRequest() - 类 中的方法reactor.core.publisher.FluxDematerializeTest
-
- doesntDisconnectAfterRefCountZeroAndQuickResubscribe() - 类 中的方法reactor.core.publisher.FluxRefCountGraceTest
-
- doesntErrorWithoutRequest() - 类 中的方法reactor.core.publisher.FluxDematerializeTest
-
- doesntResubscribeConditional() - 类 中的方法reactor.core.publisher.MonoCacheTimeTest
-
- doesntResubscribeNormal() - 类 中的方法reactor.core.publisher.MonoCacheTimeTest
-
- doesntRetainObjectsWithForcedCancelOnSubscriber() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- doesntRetainObjectsWithForcedCancelOnSubscriber() - 类 中的方法reactor.core.publisher.FluxDistinctUntilChangedTest
-
- doesntRetainObjectsWithForcedCancelOnSubscriber_conditional() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- doesntRetainObjectsWithForcedCancelOnSubscriber_conditional() - 类 中的方法reactor.core.publisher.FluxDistinctUntilChangedTest
-
- doesntRetainObjectsWithForcedCompleteOnSubscriber() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- doesntRetainObjectsWithForcedCompleteOnSubscriber() - 类 中的方法reactor.core.publisher.FluxDistinctUntilChangedTest
-
- doesntRetainObjectsWithForcedCompleteOnSubscriber_conditional() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- doesntRetainObjectsWithForcedCompleteOnSubscriber_conditional() - 类 中的方法reactor.core.publisher.FluxDistinctUntilChangedTest
-
- doesntRetainObjectsWithForcedErrorOnSubscriber() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- doesntRetainObjectsWithForcedErrorOnSubscriber() - 类 中的方法reactor.core.publisher.FluxDistinctUntilChangedTest
-
- doesntRetainObjectsWithForcedErrorOnSubscriber_conditional() - 类 中的方法reactor.core.publisher.FluxDistinctTest
-
- doesntRetainObjectsWithForcedErrorOnSubscriber_conditional() - 类 中的方法reactor.core.publisher.FluxDistinctUntilChangedTest
-
- doFinally(SignalType) - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doFinally(SignalType) - 接口 中的方法reactor.core.observability.SignalListener
-
Handle terminal signals after the signals have been propagated, as the final step.
- doFinally(Consumer<SignalType>) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered
after the
Flux
terminates for any reason,
including cancellation.
- doFinally(Consumer<SignalType>) - 类 中的方法reactor.core.publisher.Mono
-
Mono因任何原因终止后添加行为触发(包括取消、终止、完成),会传递一个信号量类型通知你
SignalType
Add behavior triggering
after the
Mono
terminates for any reason,
including cancellation.
- doFirst() - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doFirst() - 接口 中的方法reactor.core.observability.SignalListener
-
Handle the very beginning of the Subscriber
-Publisher
interaction.
- doFirst(Runnable) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered
before the
Flux
is
subscribed to, which should be the first event after assembly time.
- doFirst(Runnable) - 类 中的方法reactor.core.publisher.Mono
-
添加在订阅Mono之前触发的行为(未开始请求数据),这应该是装配时间之后的第一个事件。
- doFirst() - 类 中的方法reactor.core.publisher.TailCallSubscribeTest
-
- doNotCallToString() - 类 中的方法reactor.core.publisher.FluxIndexedFuseableTest
-
- doNotCallToString() - 类 中的方法reactor.core.publisher.FluxIndexTest
-
- dontBreakAmb() - 类 中的方法reactor.core.publisher.FluxFirstWithSignalOrTest
-
- dontBreakFluxArrayConcatMap() - 类 中的方法reactor.core.publisher.FluxConcatWithTest
-
- dontBreakFluxArrayConcatMap() - 类 中的方法reactor.core.publisher.FluxStartWithTest
-
- dontBreakFluxArrayFlatmap() - 类 中的方法reactor.core.publisher.FluxMergeWithTest
-
- dontRepeat() - 类 中的方法reactor.core.publisher.FluxRepeatPredicateTest
-
- dontRepeat() - 类 中的方法reactor.core.publisher.FluxRetryWhenTest
-
- doOnCancel() - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doOnCancel() - 接口 中的方法reactor.core.observability.SignalListener
-
Handle the downstream cancelling its currently observed Subscription
.
- doOnCancel(Runnable) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered when the
Flux
is cancelled.
- doOnCancel(Runnable) - 类 中的方法reactor.core.publisher.Mono
-
添加取消时的触发行为,首先执行
Runnable
,然后将取消信号向上游传播到源
Add behavior triggered when the
Mono
is cancelled.
- doOnCancel(Runnable) - 类 中的方法reactor.core.publisher.ParallelFlux
-
Run the specified runnable when a 'rail' receives a cancellation.
- doOnComplete() - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doOnComplete() - 接口 中的方法reactor.core.observability.SignalListener
-
Handle graceful onComplete sequence termination.
- doOnComplete(Runnable) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered when the
Flux
completes successfully.
- doOnComplete(Runnable) - 类 中的方法reactor.core.publisher.ParallelFlux
-
Run the specified runnable when a 'rail' completes.
- doOnDiscard(Class<R>, Consumer<? super R>) - 类 中的方法reactor.core.publisher.Flux
-
Potentially modify the behavior of the whole chain of operators upstream of this one to
conditionally clean up elements that get discarded by these operators.
- doOnDiscard(Class<R>, Consumer<? super R>) - 类 中的方法reactor.core.publisher.Mono
-
在非常特殊的情况下,你的应用程序可能会处理那些一旦不再使用就需要某种形式清理的类型。
- doOnEach(Consumer<? super Signal<T>>) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effects) triggered when the
Flux
emits an item, fails with an error
or completes successfully.
- doOnEach(Consumer<? super Signal<T>>) - 类 中的方法reactor.core.publisher.Mono
-
添加当Mono发布、错误失败或成功完成时触发的行为。
- doOnEach(Consumer<? super Signal<T>>) - 类 中的方法reactor.core.publisher.ParallelFlux
-
Triggers side-effects when the
ParallelFlux
emits an item, fails with an error
or completes successfully.
- doOnEachContext() - 类 中的方法reactor.core.publisher.ParallelFluxTest
-
- doOnError(Throwable) - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doOnError(Throwable) - 接口 中的方法reactor.core.observability.SignalListener
-
Handle onError sequence termination.
- doOnError(Consumer<? super Throwable>) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered when the
Flux
completes with an error.
- doOnError(Class<E>, Consumer<? super E>) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered when the
Flux
completes with an error matching the given exception type.
- doOnError(Predicate<? super Throwable>, Consumer<? super Throwable>) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered when the
Flux
completes with an error matching the given exception.
- doOnError(Consumer<? super Throwable>) - 类 中的方法reactor.core.publisher.Mono
-
添加Mono因异常而终止时触发的行为,Consumer首先被执行,然后 onError 信号被传播到下游
Add behavior triggered when the
Mono
completes with an error.
- doOnError(Class<E>, Consumer<? super E>) - 类 中的方法reactor.core.publisher.Mono
-
添加当Mono因异常终止并且匹配指定异常类型触发的行为。
- doOnError(Predicate<? super Throwable>, Consumer<? super Throwable>) - 类 中的方法reactor.core.publisher.Mono
-
添加当Mono完成并出现与给定Predicate
(泛型 Throwable) 匹配的错误时触发的行为。
- doOnError(Consumer<? super Throwable>) - 类 中的方法reactor.core.publisher.ParallelFlux
-
Call the specified consumer with the exception passing through any 'rail'.
- doOnErrorPredicate() - 类 中的方法reactor.core.publisher.FluxPeekTest
-
- doOnErrorPredicateNot() - 类 中的方法reactor.core.publisher.FluxPeekTest
-
- doOnFusion(int) - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doOnFusion(int) - 接口 中的方法reactor.core.observability.SignalListener
-
Handle the negotiation of fusion between two
Fuseable
operators.
- doOnMalformedOnComplete() - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doOnMalformedOnComplete() - 接口 中的方法reactor.core.observability.SignalListener
-
Handle malformed Subscriber.onComplete()
, which means the sequence has already terminated
via Subscriber.onComplete()
or Subscriber.onError(Throwable)
.
- doOnMalformedOnError(Throwable) - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doOnMalformedOnError(Throwable) - 接口 中的方法reactor.core.observability.SignalListener
-
Handle malformed Subscriber.onError(Throwable)
, which means the sequence has already terminated
via Subscriber.onComplete()
or Subscriber.onError(Throwable)
.
- doOnMalformedOnNext(T) - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doOnMalformedOnNext(T) - 接口 中的方法reactor.core.observability.SignalListener
-
Handle malformed Subscriber.onNext(Object)
, which are onNext happening after the sequence has already terminated
via Subscriber.onComplete()
or Subscriber.onError(Throwable)
.
- doOnNext(T) - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doOnNext(T) - 接口 中的方法reactor.core.observability.SignalListener
-
Handle a new value emission from the source.
- doOnNext(Consumer<? super T>) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered when the
Flux
emits an item.
- doOnNext(Consumer<? super T>) - 类 中的方法reactor.core.publisher.Mono
-
添加当Mono成功发出数据时触发的行为,
Consumer
首先执行,然后将 onNext 信号传播到下游
Add behavior triggered when the
Mono
emits a data successfully.
- doOnNext(Consumer<? super T>) - 类 中的方法reactor.core.publisher.ParallelFlux
-
Call the specified consumer with the current element passing through any 'rail'.
- doOnNextFails() - 类 中的方法reactor.core.publisher.FluxRetryTest
-
- doOnNextFails() - 类 中的方法reactor.core.publisher.MonoRetryTest
-
- doOnRequest(long) - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doOnRequest(long) - 接口 中的方法reactor.core.observability.SignalListener
-
Handle a new request made by the downstream, exposing the demand.
- doOnRequest(LongConsumer) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggering a
LongConsumer
when this
Flux
receives any request.
- doOnRequest(LongConsumer) - 类 中的方法reactor.core.publisher.Mono
-
当Mono收到任何请求时添加触发LongConsumer行为 (Long为背压数)。
- doOnRequest(LongConsumer) - 类 中的方法reactor.core.publisher.ParallelFlux
-
Call the specified consumer with the request amount if any rail receives a
request.
- doOnSubscribe(Consumer<? super Subscription>) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered when the
Flux
is being subscribed,
that is to say when a
Subscription
has been produced by the
Publisher
and is being passed to the
Subscriber.onSubscribe(Subscription)
.
- doOnSubscribe(Consumer<? super Subscription>) - 类 中的方法reactor.core.publisher.Mono
-
当发布者被订阅时触发,先传递
Subscription
订阅者给
Consumer
处理后,再将信号传播到下游
Add behavior (side-effect) triggered when the
Mono
is being subscribed,
that is to say when a
Subscription
has been produced by the
Publisher
and is being passed to the
Subscriber.onSubscribe(Subscription)
.
- doOnSubscribe(Consumer<? super Subscription>) - 类 中的方法reactor.core.publisher.ParallelFlux
-
Call the specified callback when a 'rail' receives a Subscription from its
upstream.
- doOnSubscription() - 类 中的方法reactor.core.observability.DefaultSignalListener
-
- doOnSubscription() - 接口 中的方法reactor.core.observability.SignalListener
-
Handle the fact that the upstream Publisher
acknowledged Subscription
.
- doOnSuccess(Consumer<? super T>) - 类 中的方法reactor.core.publisher.Mono
-
一旦可以认为Mono已成功完成,就会触发添加行为。
- doOnTerminate(Runnable) - 类 中的方法reactor.core.publisher.Flux
-
Add behavior (side-effect) triggered when the
Flux
terminates, either by
completing successfully or failing with an error.
- doOnTerminate(Runnable) - 类 中的方法reactor.core.publisher.Mono
-
添加当Mono终止时触发的行为,可以是在正常完成,异常,返回空Mono时触发
Add behavior triggered when the
Mono
terminates, either by completing with a value,
completing empty or failing with an error.
- doOnTerminate(Runnable) - 类 中的方法reactor.core.publisher.ParallelFlux
-
Triggered when the
ParallelFlux
terminates, either by completing successfully or with an error.
- doswitch(int) - 类 中的方法reactor.core.publisher.FluxSwitchMapTest
-
- doubleCancelCancelsOnce() - 类 中的方法reactor.core.publisher.MonoSequenceEqualTest
-
- doubleCreationOfVtsCorrectlyResetsOriginalCustomFactory() - 类 中的方法reactor.test.scheduler.VirtualTimeSchedulerTests
-
- doubleSubscribeOn() - 类 中的方法reactor.core.scheduler.BoundedElasticSchedulerTest
-
- downstreamCount() - 类 中的方法reactor.core.publisher.DirectProcessor
-
已过时。
- downstreamCount() - 类 中的方法reactor.core.publisher.EmitterProcessor
-
已过时。
- downstreamCount() - 类 中的方法reactor.core.publisher.FluxProcessor
-
已过时。
Return the number of active Subscriber
or -1 if untracked.
- downstreamCount() - 类 中的方法reactor.core.publisher.MonoProcessor
-
已过时。
Return the number of active Subscriber
or -1 if untracked.
- downstreamCount() - 类 中的方法reactor.core.publisher.ReplayProcessor
-
已过时。
- downstreamCount() - 类 中的方法reactor.core.publisher.UnicastProcessor
-
已过时。
- downstreamDemandShouldBeAbleToDecreaseOnFullBuffer() - 类 中的方法reactor.core.publisher.FluxBufferTimeoutTest
-
- downstreamDemandShouldBeAbleToDecreaseOnTimeSpan() - 类 中的方法reactor.core.publisher.FluxBufferTimeoutTest
-
- drainSubscriber() - 类 中的静态方法reactor.core.publisher.Operators
-
Return a singleton Subscriber
that does not check for double onSubscribe
and purely request Long.MAX.
- drainSubscriber() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- drop() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferStrategyTest
-
- drop(Throwable, T) - 类 中的静态方法reactor.core.publisher.OnNextFailureStrategyTest
-
Helper for other tests to emulate resumeDrop with the public consumer-based API.
- dropBySizeAndTimeout() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferTimeoutTest
-
- dropCallbackError() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferStrategyTest
-
- dropHandleFusedSync() - 类 中的方法reactor.core.publisher.FluxHandleTest
-
- dropOldest() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferStrategyTest
-
- dropOldestCallbackError() - 类 中的方法reactor.core.publisher.FluxOnBackpressureBufferStrategyTest
-
- droppedError(RuntimeException) - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
-
- droppedError(RuntimeException) - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
-
- droppedError(RuntimeException) - 类 中的方法reactor.test.publisher.OperatorScenario
-
- droppedError(RuntimeException) - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
-
- droppedError(RuntimeException) - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
-
- droppedErrors - 类 中的变量reactor.core.publisher.StressSubscriber
-
- droppedItem(I) - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
-
- droppedItem(I) - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
-
- droppedItem(I) - 类 中的方法reactor.test.publisher.OperatorScenario
-
- droppedItem(I) - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
-
- droppedItem(I) - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
-
- dropsErrorOnCompletedSource() - 类 中的方法reactor.core.publisher.FluxTimeoutTest
-
- dropsErrorOnCompletedSource() - 类 中的方法reactor.core.publisher.MonoTimeoutTest
-
- dumpThreads() - 类 中的静态方法reactor.core.scheduler.BoundedElasticSchedulerTest
-
- duplicateOnSubscribeCreatesNewInstances() - 类 中的方法reactor.core.ExceptionsTest
-
- duplicateOnSubscribeException() - 类 中的静态方法reactor.core.Exceptions
-
- duplicateOnSubscribeReferencesSpec() - 类 中的方法reactor.core.ExceptionsTest
-
- DURATION_CONVERTER - 类 中的静态变量reactor.test.ValueFormatters
-