- pairWise() - 类 中的方法reactor.core.publisher.FluxConcatArrayTest
-
- pairWise() - 类 中的方法reactor.core.publisher.FluxFirstWithSignalOrTest
-
- pairWise() - 类 中的方法reactor.core.publisher.FluxPublishMulticastTest
-
- pairWise() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- pairWise() - 类 中的方法reactor.core.publisher.MonoFirstWithSignalTest
-
- pairWise() - 类 中的方法reactor.core.publisher.MonoWhenTest
-
- pairWise() - 类 中的方法reactor.core.publisher.MonoZipTest
-
- pairWise2() - 类 中的方法reactor.core.publisher.FluxConcatArrayTest
-
- pairWise2() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- pairWise2() - 类 中的方法reactor.core.publisher.MonoZipTest
-
- pairWise3() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- pairWise3() - 类 中的方法reactor.core.publisher.MonoZipTest
-
- pairWiseIterable() - 类 中的方法reactor.core.publisher.FluxFirstWithSignalOrTest
-
- pairWiseIterable() - 类 中的方法reactor.core.publisher.MonoFirstWithSignalTest
-
- parallel() - 类 中的方法reactor.core.publisher.Flux
-
Prepare this
Flux
by dividing data on a number of 'rails' matching the
number of CPU cores, in a round-robin fashion.
- parallel(int) - 类 中的方法reactor.core.publisher.Flux
-
Prepare this
Flux
by dividing data on a number of 'rails' matching the
provided
parallelism
parameter, in a round-robin fashion.
- parallel(int, int) - 类 中的方法reactor.core.publisher.Flux
-
Prepare this
Flux
by dividing data on a number of 'rails' matching the
provided
parallelism
parameter, in a round-robin fashion and using a
custom prefetch amount and queue for dealing with the source
Flux
's values.
- parallel() - 类 中的静态方法reactor.core.scheduler.Schedulers
-
The common
parallel instance, a
Scheduler
that hosts a fixed pool of single-threaded
ExecutorService-based workers and is suited for parallel work.
- ParallelArraySourceTest - reactor.core.publisher中的类
-
- ParallelArraySourceTest() - 类 的构造器reactor.core.publisher.ParallelArraySourceTest
-
- ParallelCollectTest - reactor.core.publisher中的类
-
- ParallelCollectTest() - 类 的构造器reactor.core.publisher.ParallelCollectTest
-
- ParallelConcatMapTest - reactor.core.publisher中的类
-
- ParallelConcatMapTest() - 类 的构造器reactor.core.publisher.ParallelConcatMapTest
-
- ParallelDoOnEachTest - reactor.core.publisher中的类
-
- ParallelDoOnEachTest() - 类 的构造器reactor.core.publisher.ParallelDoOnEachTest
-
- ParallelFilterTest - reactor.core.publisher中的类
-
- ParallelFilterTest() - 类 的构造器reactor.core.publisher.ParallelFilterTest
-
- ParallelFlatMapTest - reactor.core.publisher中的类
-
- ParallelFlatMapTest() - 类 的构造器reactor.core.publisher.ParallelFlatMapTest
-
- ParallelFlux<T> - reactor.core.publisher中的类
-
A ParallelFlux publishes to an array of Subscribers, in parallel 'rails' (or
'groups'
).
- ParallelFlux() - 类 的构造器reactor.core.publisher.ParallelFlux
-
- ParallelFluxHideTest - reactor.core.publisher中的类
-
- ParallelFluxHideTest() - 类 的构造器reactor.core.publisher.ParallelFluxHideTest
-
- ParallelFluxNameTest - reactor.core.publisher中的类
-
- ParallelFluxNameTest() - 类 的构造器reactor.core.publisher.ParallelFluxNameTest
-
- ParallelFluxOnAssemblyTest - reactor.core.publisher中的类
-
- ParallelFluxOnAssemblyTest() - 类 的构造器reactor.core.publisher.ParallelFluxOnAssemblyTest
-
- ParallelFluxTest - reactor.core.publisher中的类
-
- ParallelFluxTest() - 类 的构造器reactor.core.publisher.ParallelFluxTest
-
- ParallelGroupTest - reactor.core.publisher中的类
-
- ParallelGroupTest() - 类 的构造器reactor.core.publisher.ParallelGroupTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelArraySourceTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelCollectTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelConcatMapTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelFilterTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelFlatMapTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelFlux
-
Returns the number of expected parallel Subscribers.
- parallelism() - 类 中的方法reactor.core.publisher.ParallelFluxHideTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelFluxNameTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelFluxOnAssemblyTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelLiftTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelLogTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelMapTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelPeekTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelReduceSeedTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelRunOnTest
-
- parallelism() - 类 中的方法reactor.core.publisher.ParallelSourceTest
-
- ParallelLiftTest - reactor.core.publisher中的类
-
- ParallelLiftTest() - 类 的构造器reactor.core.publisher.ParallelLiftTest
-
- ParallelLogTest - reactor.core.publisher中的类
-
- ParallelLogTest() - 类 的构造器reactor.core.publisher.ParallelLogTest
-
- ParallelMapTest - reactor.core.publisher中的类
-
- ParallelMapTest() - 类 的构造器reactor.core.publisher.ParallelMapTest
-
- ParallelMergeReduceTest - reactor.core.publisher中的类
-
- ParallelMergeReduceTest() - 类 的构造器reactor.core.publisher.ParallelMergeReduceTest
-
- ParallelMergeSequentialTest - reactor.core.publisher中的类
-
- ParallelMergeSequentialTest() - 类 的构造器reactor.core.publisher.ParallelMergeSequentialTest
-
- ParallelMergeSortTest - reactor.core.publisher中的类
-
- ParallelMergeSortTest() - 类 的构造器reactor.core.publisher.ParallelMergeSortTest
-
- parallelMode() - 类 中的方法reactor.core.publisher.ParallelFluxTest
-
- parallelModeFused() - 类 中的方法reactor.core.publisher.HooksTest
-
- parallelModeFused() - 类 中的方法reactor.core.publisher.ParallelFluxTest
-
- ParallelOperatorTest<I,O> - reactor.test.publisher中的类
-
- ParallelOperatorTest() - 类 的构造器reactor.test.publisher.ParallelOperatorTest
-
- ParallelOperatorTest.Scenario<I,O> - reactor.test.publisher中的类
-
- ParallelPeekTest - reactor.core.publisher中的类
-
- ParallelPeekTest() - 类 的构造器reactor.core.publisher.ParallelPeekTest
-
- parallelReduceFull() - 类 中的方法reactor.core.publisher.ParallelMergeReduceTest
-
- ParallelReduceSeedTest - reactor.core.publisher中的类
-
- ParallelReduceSeedTest() - 类 的构造器reactor.core.publisher.ParallelReduceSeedTest
-
- parallelRunOn() - 类 中的方法reactor.core.scheduler.RejectedExecutionTest
-
Test: onNext cannot be delivered due to RejectedExecutionException
Current behaviour:
No onNext, onError, onNextDropped, onErrorDropped generated
Exception:
[parallel-1] ERROR reactor.core.scheduler.Schedulers - Scheduler worker in group main failed with an uncaught exception
java.util.concurrent.RejectedExecutionException: null
at reactor.core.scheduler.RejectedExecutionTest$BoundedScheduler$BoundedWorker.schedule(RejectedExecutionTest.java:283) ~[bin/:na]
at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.trySchedule(FluxPublishOn.java:294) ~[bin/:na]
at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.onNext(FluxPublishOn.java:234) ~[bin/:na]
at reactor.core.publisher.ParallelSource$ParallelSourceMain.drainAsync(ParallelSource.java:333) ~[bin/:na]
at reactor.core.publisher.ParallelSource$ParallelSourceMain.drain(ParallelSource.java:473) ~[bin/:na]
at reactor.core.publisher.ParallelSource$ParallelSourceMain.onNext(ParallelSource.java:233) ~[bin/:na]
at reactor.core.publisher.FluxTake$TakeSubscriber.onNext(FluxTake.java:118) ~[bin/:na]
at reactor.core.publisher.FluxInterval$IntervalRunnable.run(FluxInterval.java:105) ~[bin/:na]
at reactor.core.scheduler.ParallelScheduler$ParallelWorker$ParallelWorkerTask.run(ParallelScheduler.java:367) ~[bin/:na]
at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511) [na:1.8.0_77]
at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:308) [na:1.8.0_77]
at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$301(ScheduledThreadPoolExecutor.java:180) [na:1.8.0_77]
at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:294) [na:1.8.0_77]
at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142) [na:1.8.0_77]
at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617) [na:1.8.0_77]
at java.lang.Thread.run(Thread.java:745) [na:1.8.0_77]
- ParallelRunOnTest - reactor.core.publisher中的类
-
- ParallelRunOnTest() - 类 的构造器reactor.core.publisher.ParallelRunOnTest
-
- parallelSchedulerDefaultNonBlocking() - 类 中的方法reactor.core.scheduler.SchedulersTest
-
- ParallelSchedulerDisposeGracefullyAndDisposeStressTest() - 类 的构造器reactor.core.scheduler.BasicSchedulersStressTest.ParallelSchedulerDisposeGracefullyAndDisposeStressTest
-
- ParallelSchedulerDisposeGracefullyStressTest() - 类 的构造器reactor.core.scheduler.BasicSchedulersStressTest.ParallelSchedulerDisposeGracefullyStressTest
-
- ParallelSchedulerStartDisposeStressTest() - 类 的构造器reactor.core.scheduler.BasicSchedulersStressTest.ParallelSchedulerStartDisposeStressTest
-
- ParallelSchedulerTest - reactor.core.scheduler中的类
-
- ParallelSchedulerTest() - 类 的构造器reactor.core.scheduler.ParallelSchedulerTest
-
- parallelSchedulerThreadCheck() - 类 中的方法reactor.core.scheduler.SchedulersTest
-
- ParallelSourceTest - reactor.core.publisher中的类
-
- ParallelSourceTest() - 类 的构造器reactor.core.publisher.ParallelSourceTest
-
- parallelSubscribeAndDispose() - 类 中的方法reactor.core.publisher.ParallelFluxTest
-
- ParallelSubscribersStressTest() - 类 的构造器reactor.core.publisher.SinkManyBestEffortStressTest.ParallelSubscribersStressTest
-
- parallelTests() - 类 中的方法reactor.core.publisher.scenarios.FluxTests
-
- parallelThenFull() - 类 中的方法reactor.core.publisher.ParallelThenTest
-
- ParallelThenTest - reactor.core.publisher中的类
-
- ParallelThenTest() - 类 的构造器reactor.core.publisher.ParallelThenTest
-
- parallelVerifyWithVtsMutuallyExclusive() - 类 中的方法reactor.test.StepVerifierTests
-
- ParameterizedTestWithName - reactor.test中的注释类型
-
Meta-annotation that provides a better default for ParameterizedTest
name.
- PARENT - 类 中的静态变量reactor.core.Scannable.Attr
-
Parent key exposes the direct upstream relationship of the scanned component.
- parents() - 接口 中的方法reactor.core.Scannable
-
Return a Stream
navigating the Subscription
chain (upward).
- partialCancelDoesntCancelSource() - 类 中的方法reactor.core.publisher.MonoCacheTimeTest
-
- partialRequestAndCancel() - 类 中的方法reactor.core.publisher.BaseSubscriberTest
-
- partitionByHashCodeShouldNeverCreateMoreStreamsThanSpecified() - 类 中的方法reactor.core.publisher.scenarios.FluxTests
-
See https://github.com/reactor/reactor/issues/451
- peek() - 接口 中的方法reactor.core.Fuseable.QueueSubscription
-
- peek() - 类 中的方法reactor.core.publisher.MonoProcessor
-
- performsDirectSubscriberToSource_Fused() - 类 中的方法reactor.core.publisher.FluxDoFirstTest
-
- performsDirectSubscriberToSource_Fused() - 类 中的方法reactor.core.publisher.MonoDoFirstTest
-
- performsDirectSubscriberToSource_NoFusion() - 类 中的方法reactor.core.publisher.FluxDoFirstTest
-
- performsDirectSubscriberToSource_NoFusion() - 类 中的方法reactor.core.publisher.MonoDoFirstTest
-
- perSubscriberState() - 类 中的方法reactor.core.publisher.FluxDeferComposeTest
-
- perTrackable() - 类 中的方法reactor.core.publisher.MonoDeferComposeTest
-
- pickSetIdleRaceBusy() - 类 中的方法reactor.core.scheduler.BoundedElasticSchedulerTest
-
- pickSetIdleRaceIdle() - 类 中的方法reactor.core.scheduler.BoundedElasticSchedulerTest
-
- pingPongParallelCall() - 类 中的方法reactor.core.scheduler.SchedulersTest
-
- pluginCrash() - 类 中的方法reactor.core.scheduler.WorkerTaskTest
-
- poll() - 类 中的方法reactor.core.publisher.Operators.MonoSubscriber
-
- poll() - 类 中的方法reactor.core.publisher.UnicastProcessor
-
已过时。
- poll(LLLLLL_Result) - 类 中的方法reactor.util.concurrent.SpscArrayQueueStressTest.OfferAndPollStressTest
-
- pollErrorModeLocalStrategy() - 类 中的方法reactor.core.publisher.OperatorsTest
-
- pollPair(LLL_Result) - 类 中的方法reactor.util.concurrent.MpscLinkedQueueStressTest.BiPredicateAndPollStressTest
-
- pollPair(LLLLL_Result) - 类 中的方法reactor.util.concurrent.MpscLinkedQueueStressTest.BiPredicateTwoProducersOneConsumerStressTest
-
- pollPair(LLL_Result) - 类 中的方法reactor.util.concurrent.SpscLinkedArrayQueueStressTest.BiPredicateAndPollStressTest
-
- pollPairs(LLLLLL_Result) - 类 中的方法reactor.util.concurrent.SpscLinkedArrayQueueStressTest.BiPredicateAndPollAtGrowthBoundaryStressTest
-
- PopularTagTests - reactor.core.publisher.scenarios中的类
-
- PopularTagTests() - 类 的构造器reactor.core.publisher.scenarios.PopularTagTests
-
- populateDebug(TestInfo) - 类 中的方法reactor.guide.GuideTests
-
- predicateBasedMatching() - 类 中的方法reactor.test.ValueFormattersTest
-
- predicateBasedNotMatching() - 类 中的方法reactor.test.ValueFormattersTest
-
- predicateBasedNull() - 类 中的方法reactor.test.ValueFormattersTest
-
- predicateBasedTestPredicate() - 类 中的方法reactor.test.ValueFormattersTest
-
- predicateCanConvertNull() - 类 中的方法reactor.test.ValueFormattersTest
-
- predicateError() - 类 中的方法reactor.core.publisher.FluxFilterWhenTest
-
- predicateError() - 类 中的方法reactor.core.publisher.MonoFilterWhenTest
-
- predicateErrorFused() - 类 中的方法reactor.core.publisher.FluxFilterWhenTest
-
- predicateErrorFused() - 类 中的方法reactor.core.publisher.MonoFilterWhenTest
-
- predicateErrorUntil() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
-
- predicateErrorUntil() - 类 中的方法reactor.core.publisher.FluxWindowPredicateTest
-
- predicateErrorUntilCutBefore() - 类 中的方法reactor.core.publisher.FluxWindowPredicateTest
-
- predicateErrorUntilOther() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
-
- predicateErrorWhile() - 类 中的方法reactor.core.publisher.FluxBufferPredicateTest
-
- predicateErrorWhile() - 类 中的方法reactor.core.publisher.FluxWindowPredicateTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.FluxDistinctUntilChangedTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.FluxFilterTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.FluxFilterWhenTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.FluxRepeatPredicateTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.FluxSkipWhileTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.FluxTakeUntilPredicateTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.FluxTakeWhileTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.MonoAllTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.MonoAnyTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.MonoFilterTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.MonoFilterWhenTest
-
- predicateNull() - 类 中的方法reactor.core.publisher.MonoRepeatPredicateTest
-
- predicateThrows() - 类 中的方法reactor.core.publisher.FluxFilterTest
-
- predicateThrows() - 类 中的方法reactor.core.publisher.FluxFilterWhenTest
-
- predicateThrows() - 类 中的方法reactor.core.publisher.FluxRepeatPredicateTest
-
- predicateThrows() - 类 中的方法reactor.core.publisher.FluxRetryWhenTest
-
- predicateThrows() - 类 中的方法reactor.core.publisher.FluxSkipWhileTest
-
- predicateThrows() - 类 中的方法reactor.core.publisher.FluxTakeUntilPredicateTest
-
- predicateThrows() - 类 中的方法reactor.core.publisher.FluxTakeWhileTest
-
- predicateThrows() - 类 中的方法reactor.core.publisher.MonoAllTest
-
- predicateThrows() - 类 中的方法reactor.core.publisher.MonoAnyTest
-
- predicateThrows() - 类 中的方法reactor.core.publisher.MonoFilterTest
-
- predicateThrows() - 类 中的方法reactor.core.publisher.MonoFilterWhenTest
-
- PREFETCH - 类 中的静态变量reactor.core.Scannable.Attr
-
Prefetch is an Integer
attribute defining the rate of processing in a
component which has capacity to request and hold a backlog of data.
- prefetch(int) - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
-
- prefetch(int) - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
-
- prefetch(int) - 类 中的方法reactor.test.publisher.OperatorScenario
-
- prefetch(int) - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
-
- prefetch(int) - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
-
- prefetchAmountOnly() - 类 中的方法reactor.core.publisher.FluxPublishOnTest
-
- prefetchAmountOnlyLoop() - 类 中的方法reactor.core.publisher.loop.FluxPublishOnLoop
-
- prefetchIntegerMaxIsRequestUnboundedUntil() - 类 中的方法reactor.core.publisher.FluxWindowPredicateTest
-
- prefetchIntegerMaxIsRequestUnboundedWhile() - 类 中的方法reactor.core.publisher.FluxWindowPredicateTest
-
- prefetchIsUsed() - 类 中的方法reactor.core.publisher.FluxGroupByTest
-
- prefetchMaxRequestsUnbounded() - 类 中的方法reactor.core.publisher.FluxGroupByTest
-
- prefetchMaxTranslatesToUnboundedRequest() - 类 中的方法reactor.core.publisher.FluxConcatMapTest
-
- prefetchMaxTranslatesToUnboundedRequest2() - 类 中的方法reactor.core.publisher.FluxConcatMapTest
-
- prefix(CONTAINER) - 接口 中的方法reactor.test.ValueFormatters.Extractor
-
Return the prefix to use in the container's String
representation, given
the original container.
- premain(String, Instrumentation) - 类 中的静态方法reactor.tools.agent.ReactorDebugAgent
-
- prematureCancel() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- prematureCancel2() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- prematureCancelInnerArrayMoreThanDefaultArraySize4() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- prematureCompleteCallableNull() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteCallableNullHide() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteCallableNullHideAll() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteEmpty() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteEmptySource() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteEmptySourceHide() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteFusedSync() - 类 中的方法reactor.core.publisher.FluxHandleTest
-
- prematureCompleteIterableCallableNull() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteIterableEmpty() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteIterableEmptyScalarSource() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteMaxPrefetch() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- prematureCompleteSourceEmpty() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteSourceEmptyDouble() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteSourceError() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureCompleteSourceErrorHide() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- prematureFlatMapCompletion() - 类 中的方法reactor.core.publisher.scenarios.FluxTests
-
- prematureInnerCancel() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- prematureOnComplete() - 类 中的方法reactor.core.publisher.FluxPublishTest
-
- prematureScalarMapCallableEmptyComplete() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- prematureScalarMapCallableJust() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- prematureScalarMapCallableNullComplete() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- processExistingClasses() - 类 中的静态方法reactor.tools.agent.ReactorDebugAgent
-
- processExistingClassesIsNoOp() - 类 中的方法reactor.tools.agent.ReactorDebugJavaAgentTest
-
- processOrFallback(Mono<String>, Publisher<String>) - 类 中的方法reactor.guide.GuideTests
-
- processOrFallback(Mono<String>, Mono<Void>) - 类 中的方法reactor.guide.GuideTests
-
- processorQueue1Null() - 类 中的方法reactor.core.publisher.FluxWindowTest
-
- processorQueue2Null() - 类 中的方法reactor.core.publisher.FluxWindowTest
-
- produced(AtomicLongFieldUpdater<T>, T, long) - 类 中的静态方法reactor.core.publisher.Operators
-
Concurrent subtraction bound to 0, mostly used to decrement a request tracker by
the amount produced by the operator.
- producer(int, IntFunction<? extends I>) - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
-
- producer(int, IntFunction<? extends I>) - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
-
- producer(int, IntFunction<? extends I>) - 类 中的方法reactor.test.publisher.OperatorScenario
-
- producer(int, IntFunction<? extends I>) - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
-
- producer(int, IntFunction<? extends I>) - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
-
- producerEmpty() - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
-
- producerEmpty() - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
-
- producerEmpty() - 类 中的方法reactor.test.publisher.OperatorScenario
-
- producerEmpty() - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
-
- producerEmpty() - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
-
- producerError(RuntimeException) - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
-
- producerError(RuntimeException) - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
-
- producerError(RuntimeException) - 类 中的方法reactor.test.publisher.OperatorScenario
-
- producerError(RuntimeException) - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
-
- producerError(RuntimeException) - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
-
- producerNever() - 类 中的方法reactor.test.publisher.FluxOperatorTest.Scenario
-
- producerNever() - 类 中的方法reactor.test.publisher.MonoOperatorTest.Scenario
-
- producerNever() - 类 中的方法reactor.test.publisher.OperatorScenario
-
- producerNever() - 类 中的方法reactor.test.publisher.ParallelOperatorTest.Scenario
-
- producerNever() - 类 中的方法reactor.test.publisher.ReduceOperatorTest.Scenario
-
- producingCreate() - 类 中的方法reactor.guide.GuideTests
-
- producingGenerate() - 类 中的方法reactor.guide.GuideTests
-
- producingGenerateMutableState() - 类 中的方法reactor.guide.GuideTests
-
- producingHandle() - 类 中的方法reactor.guide.GuideTests
-
- progressiveRequest() - 类 中的方法reactor.core.publisher.FluxFlatMapTest
-
- promiseAcceptCountAndErrorCountCannotExceedOneInTotal() - 类 中的方法reactor.core.publisher.scenarios.FluxTests
-
- promiseAcceptCountCannotExceedOne() - 类 中的方法reactor.core.publisher.scenarios.FluxTests
-
- promiseDelays() - 类 中的方法reactor.core.publisher.scenarios.MonoTests
-
- promiseErrorCountCannotExceedOne() - 类 中的方法reactor.core.publisher.scenarios.FluxTests
-
- promiseOnAfter() - 类 中的方法reactor.core.publisher.scenarios.MonoTests
-
- promiseOnErrorHandlesExceptions() - 类 中的方法reactor.core.publisher.scenarios.MonoTests
-
- propagate(Throwable) - 类 中的静态方法reactor.core.Exceptions
-
Prepare an unchecked RuntimeException
that should be propagated
downstream through Subscriber.onError(Throwable)
.
- propagateCancellationToCompletionFuture() - 类 中的方法reactor.core.publisher.MonoCompletionStageTest
-
- propagateDoesntWrapRuntimeException() - 类 中的方法reactor.core.ExceptionsTest
-
- publish() - 类 中的方法reactor.core.publisher.Flux
-
Prepare a
ConnectableFlux
which shares this
Flux
sequence and
dispatches values to subscribers in a backpressure-aware manner.
- publish(int) - 类 中的方法reactor.core.publisher.Flux
-
Prepare a
ConnectableFlux
which shares this
Flux
sequence and
dispatches values to subscribers in a backpressure-aware manner.
- publish(Function<? super Flux<T>, ? extends Publisher<? extends R>>) - 类 中的方法reactor.core.publisher.Flux
-
Shares a sequence for the duration of a function that may transform it and
consume it as many times as necessary without causing multiple subscriptions
to the upstream.
- publish(Function<? super Flux<T>, ? extends Publisher<? extends R>>, int) - 类 中的方法reactor.core.publisher.Flux
-
Shares a sequence for the duration of a function that may transform it and
consume it as many times as necessary without causing multiple subscriptions
to the upstream.
- publish(Function<? super Mono<T>, ? extends Mono<? extends R>>) - 类 中的方法reactor.core.publisher.Mono
-
再次发布
Share a
Mono
for the duration of a function that may transform it and
consume it as many times as necessary without causing multiple subscriptions
to the upstream.
- publisherOfPublisher() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- publisherOfPublisherDelay() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- publisherOfPublisherDelayEnd() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- publisherOfPublisherDelayEnd2() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- publisherOfPublisherDelayEnd3() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- publisherOfPublisherDelayEndError() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- publisherOfPublisherDelayEndError2() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- publisherOfPublisherDelayEndNot3() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- publisherOfPublisherDelayError() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- publisherOfPublisherDelayError2() - 类 中的方法reactor.core.publisher.AbstractFluxConcatMapTest
-
- publisherOfPublishersUsesCorrectTuple() - 类 中的方法reactor.core.publisher.FluxZipTest
-
- PublisherProbe<T> - reactor.test.publisher中的接口
-
A test utility that allow to easily obtain an instrumented
Publisher
(
Mono
or
Flux
) for tests involving control flow.
- PublisherProbe.DefaultPublisherProbe<T> - reactor.test.publisher中的类
-
- PublisherProbeTest - reactor.test.publisher中的类
-
- PublisherProbeTest() - 类 的构造器reactor.test.publisher.PublisherProbeTest
-
- publisherToFlowPublisher(Publisher<T>) - 类 中的静态方法reactor.adapter.JdkFlowAdapter
-
Return a java
Flow.Publisher
from a
Flux
- publishNext() - 类 中的方法reactor.core.publisher.Flux
-
- publishOn(Scheduler) - 类 中的方法reactor.core.publisher.Flux
-
- publishOn(Scheduler, int) - 类 中的方法reactor.core.publisher.Flux
-
- publishOn(Scheduler, boolean, int) - 类 中的方法reactor.core.publisher.Flux
-
- publishOn(Scheduler) - 类 中的方法reactor.core.publisher.Mono
-
设置发布者的线程池,设置后发布者的下游操作生效
Run onNext, onComplete and onError on a supplied
Scheduler
Worker
.
- publishOn() - 类 中的方法reactor.core.scheduler.RejectedExecutionTest
-
Test: onNext cannot be delivered due to RejectedExecutionException
Current behaviour:
No onNext, onError, onNextDropped, onErrorDropped generated
Exception:
[parallel-1] ERROR reactor.core.scheduler.Schedulers - Scheduler worker in group main failed with an uncaught exception
java.util.concurrent.RejectedExecutionException: null
at reactor.core.scheduler.RejectedExecutionTest$BoundedScheduler$BoundedWorker.schedule(RejectedExecutionTest.java:228) ~[bin/:na]
at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.trySchedule(FluxPublishOn.java:294) ~[bin/:na]
at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.onNext(FluxPublishOn.java:234) ~[bin/:na]
at reactor.core.publisher.FluxTake$TakeSubscriber.onNext(FluxTake.java:118) ~[bin/:na]
at reactor.core.publisher.FluxInterval$IntervalRunnable.run(FluxInterval.java:105) ~[bin/:na]
at reactor.core.scheduler.ParallelScheduler$ParallelWorker$ParallelWorkerTask.run(ParallelScheduler.java:367) ~[bin/:na]
at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511) [na:1.8.0_77]
at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:308) [na:1.8.0_77]
at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$301(ScheduledThreadPoolExecutor.java:180) [na:1.8.0_77]
at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:294) [na:1.8.0_77]
at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142) [na:1.8.0_77]
at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617) [na:1.8.0_77]
at java.lang.Thread.run(Thread.java:745) [na:1.8.0_77]
- publishOnAsyncDetection() - 类 中的方法reactor.core.publisher.FluxPublishOnTest
-
- publishOnAsyncDetectionConditional() - 类 中的方法reactor.core.publisher.FluxPublishOnTest
-
- publishOnDisposesWorkerWhenCancelled() - 类 中的方法reactor.core.scheduler.BoundedElasticSchedulerTest
-
- publishOnFilter() - 类 中的方法reactor.core.scheduler.RejectedExecutionTest
-
- push(Consumer<? super FluxSink<T>>) - 类 中的静态方法reactor.core.publisher.Flux
-
Programmatically create a
Flux
with the capability of emitting multiple
elements from a single-threaded producer through the
FluxSink
API.
- push(Consumer<? super FluxSink<T>>, FluxSink.OverflowStrategy) - 类 中的静态方法reactor.core.publisher.Flux
-
Programmatically create a
Flux
with the capability of emitting multiple
elements from a single-threaded producer through the
FluxSink
API.
- put(Object, Object) - 接口 中的方法reactor.util.context.Context
-
Create a new
Context
that contains all current key/value pairs plus the
given key/value pair.
- putAll(ContextView) - 接口 中的方法reactor.util.context.Context
-
- putAll(Context) - 接口 中的方法reactor.util.context.Context
-
- putAllForeign() - 类 中的方法reactor.util.context.ContextNTest
-
- putAllForeignMiddleSize() - 类 中的方法reactor.util.context.CoreContextTest
-
- putAllForeignSmallSize() - 类 中的方法reactor.util.context.CoreContextTest
-
- putAllMap(Map<?, ?>) - 接口 中的方法reactor.util.context.Context
-
Create a new
Context
by merging the content of this context and a given
Map
.
- putAllOf() - 类 中的方法reactor.util.context.Context0Test
-
- putAllOf() - 类 中的方法reactor.util.context.Context1Test
-
- putAllOf() - 类 中的方法reactor.util.context.Context2Test
-
- putAllOf() - 类 中的方法reactor.util.context.Context3Test
-
- putAllOf() - 类 中的方法reactor.util.context.Context4Test
-
- putAllOf() - 类 中的方法reactor.util.context.Context5Test
-
- putAllOfContext3() - 类 中的方法reactor.util.context.ContextNTest
-
- putAllOfContextN() - 类 中的方法reactor.util.context.ContextNTest
-
- putAllOfEmpty() - 类 中的方法reactor.util.context.Context0Test
-
- putAllOfEmpty() - 类 中的方法reactor.util.context.Context1Test
-
- putAllOfEmpty() - 类 中的方法reactor.util.context.Context2Test
-
- putAllOfEmpty() - 类 中的方法reactor.util.context.Context3Test
-
- putAllOfEmpty() - 类 中的方法reactor.util.context.Context4Test
-
- putAllOfEmpty() - 类 中的方法reactor.util.context.Context5Test
-
- putAllOfEmpty() - 类 中的方法reactor.util.context.ContextNTest
-
- putAllReplaces() - 类 中的方法reactor.util.context.Context1Test
-
- putAllReplaces() - 类 中的方法reactor.util.context.Context2Test
-
- putAllReplaces() - 类 中的方法reactor.util.context.Context3Test
-
- putAllReplaces() - 类 中的方法reactor.util.context.Context4Test
-
- putAllReplaces() - 类 中的方法reactor.util.context.Context5Test
-
- putAllReplaces() - 类 中的方法reactor.util.context.ContextNTest
-
- putAllSelfIntoContextN() - 类 中的方法reactor.util.context.Context1Test
-
- putAllSelfIntoContextN() - 类 中的方法reactor.util.context.Context2Test
-
- putAllSelfIntoContextN() - 类 中的方法reactor.util.context.Context3Test
-
- putAllSelfIntoContextN() - 类 中的方法reactor.util.context.Context4Test
-
- putAllSelfIntoContextN() - 类 中的方法reactor.util.context.Context5Test
-
- putAllSelfIntoContextN() - 类 中的方法reactor.util.context.ContextNTest
-
- putAllSelfIntoContextNReturnsSame() - 类 中的方法reactor.util.context.Context0Test
-
- putAllSelfIntoEmpty() - 类 中的方法reactor.util.context.Context1Test
-
- putAllSelfIntoEmpty() - 类 中的方法reactor.util.context.Context2Test
-
- putAllSelfIntoEmpty() - 类 中的方法reactor.util.context.Context3Test
-
- putAllSelfIntoEmpty() - 类 中的方法reactor.util.context.Context4Test
-
- putAllSelfIntoEmpty() - 类 中的方法reactor.util.context.Context5Test
-
- putAllSelfIntoEmpty() - 类 中的方法reactor.util.context.ContextNTest
-
- putAllSelfIntoEmptyReturnsSame() - 类 中的方法reactor.util.context.Context0Test
-
- putAnyKeyContext1() - 类 中的方法reactor.util.context.Context0Test
-
- putDifferentKeyContext2() - 类 中的方法reactor.util.context.Context1Test
-
- putDifferentKeyContext3() - 类 中的方法reactor.util.context.Context2Test
-
- putDifferentKeyContext4() - 类 中的方法reactor.util.context.Context3Test
-
- putDifferentKeyContext5() - 类 中的方法reactor.util.context.Context4Test
-
- putDifferentKeyContextN() - 类 中的方法reactor.util.context.Context5Test
-
- putDifferentKeyContextN() - 类 中的方法reactor.util.context.ContextNTest
-
- putNonNull(Object, Object) - 接口 中的方法reactor.util.context.Context
-
Create a new
Context
that contains all current key/value pairs plus the
given key/value pair
only if the value is not null.
- putNonNullWithNull() - 类 中的方法reactor.util.context.Context0Test
-
- putNonNullWithNull() - 类 中的方法reactor.util.context.Context1Test
-
- putNonNullWithNull() - 类 中的方法reactor.util.context.Context2Test
-
- putNonNullWithNull() - 类 中的方法reactor.util.context.Context3Test
-
- putNonNullWithNull() - 类 中的方法reactor.util.context.Context4Test
-
- putNonNullWithNull() - 类 中的方法reactor.util.context.Context5Test
-
- putNonNullWithNull() - 类 中的方法reactor.util.context.ContextNTest
-
- putNonNullWithValue() - 类 中的方法reactor.util.context.Context0Test
-
- putNonNullWithValue() - 类 中的方法reactor.util.context.Context1Test
-
- putNonNullWithValue() - 类 中的方法reactor.util.context.Context2Test
-
- putNonNullWithValue() - 类 中的方法reactor.util.context.Context3Test
-
- putNonNullWithValue() - 类 中的方法reactor.util.context.Context4Test
-
- putNonNullWithValue() - 类 中的方法reactor.util.context.Context5Test
-
- putNonNullWithValue() - 类 中的方法reactor.util.context.ContextNTest
-