Skip navigation links
reactor-test
A B C D E F G H I L M N O P R S T U V W 

A

advanceTime() - Method in class reactor.test.scheduler.VirtualTimeScheduler
Triggers any tasks that have not yet been executed and that are scheduled to be executed at or before this VirtualTimeScheduler's present time.
advanceTimeBy(Duration) - Method in class reactor.test.scheduler.VirtualTimeScheduler
Moves the VirtualTimeScheduler's clock forward by a specified amount of time.
advanceTimeTo(Instant) - Method in class reactor.test.scheduler.VirtualTimeScheduler
Moves the VirtualTimeScheduler's clock to a particular moment in time.
apply(Object, Function<Object, String>) - Method in interface reactor.test.ValueFormatters.Extractor
Given an arbitrary object and a ValueFormatters.ToStringConverter, if the object passes the ValueFormatters.Extractor.test(Object), extract elements from it and convert them using the ValueFormatters.ToStringConverter, joining the result together to obtain a customized String representation of both the container and its contents.
arrayExtractor(Class<T[]>) - Static method in class reactor.test.ValueFormatters
Default array extractor that use the [CONVERTED1, CONVERTED2] representation.
as(String) - Method in interface reactor.test.StepVerifier.Step
Set a description for the previous verification step.
assertCancelled() - Method in class reactor.test.publisher.TestPublisher
Asserts that this publisher has had at least one subscriber that has been cancelled.
assertCancelled(int) - Method in class reactor.test.publisher.TestPublisher
Asserts that this publisher has had at least n subscribers that have been cancelled.
assertMaxRequested(long) - Method in class reactor.test.publisher.TestPublisher
Assert that the current maximum request of all this publisher's subscribers is <= n.
assertMinRequested(long) - Method in class reactor.test.publisher.TestPublisher
Assert that the current minimum request of all this publisher's subscribers is >= n.
assertNext(Consumer<? super T>) - Method in interface reactor.test.StepVerifier.Step
Expect an element and consume it with the given consumer, usually performing assertions on it (eg.
assertNoRequestOverflow() - Method in class reactor.test.publisher.TestPublisher
Asserts that this publisher has had no subscriber with request overflow.
assertNoSubscribers() - Method in class reactor.test.publisher.TestPublisher
Asserts that this publisher has no subscribers.
assertNotCancelled() - Method in class reactor.test.publisher.TestPublisher
Asserts that this publisher has had no cancelled subscribers.
assertRequestOverflow() - Method in class reactor.test.publisher.TestPublisher
Asserts that this publisher has had subscriber that saw request overflow, that is received an onNext event despite having a requested amount of 0 at the time.
assertSubscribers() - Method in class reactor.test.publisher.TestPublisher
Asserts that this publisher has subscribers.
assertSubscribers(int) - Method in class reactor.test.publisher.TestPublisher
Asserts that this publisher has exactly n subscribers.
assertThat(Consumer<Context>) - Method in interface reactor.test.StepVerifier.ContextExpectations
Apply custom assertions to the propagated Context.
assertWasCancelled() - Method in interface reactor.test.publisher.PublisherProbe
Check that the probe was cancelled at least once, or throw an AssertionError.
assertWasNotCancelled() - Method in interface reactor.test.publisher.PublisherProbe
Check that the probe was never cancelled, or throw an AssertionError.
assertWasNotRequested() - Method in interface reactor.test.publisher.PublisherProbe
Check that the probe was never requested, or throw an AssertionError.
assertWasNotSubscribed() - Method in interface reactor.test.publisher.PublisherProbe
Check that the probe was never subscribed to, or throw an AssertionError.
assertWasRequested() - Method in interface reactor.test.publisher.PublisherProbe
Check that the probe was requested at least once, or throw an AssertionError.
assertWasSubscribed() - Method in interface reactor.test.publisher.PublisherProbe
Check that the probe was subscribed to at least once, or throw an AssertionError.

B

block() - Method in interface reactor.test.subscriber.TestSubscriber
Block until an assertable end state has been reached.
block(Duration) - Method in interface reactor.test.subscriber.TestSubscriber
Block until an assertable end state has been reached, or a timeout Duration has elapsed.
build() - Method in class reactor.test.subscriber.TestSubscriberBuilder
Create a TestSubscriber according to this builder.
buildConditional(Predicate<? super T>) - Method in class reactor.test.subscriber.TestSubscriberBuilder
Create a Fuseable.ConditionalSubscriber variant of TestSubscriber according to this builder.
builder() - Static method in interface reactor.test.subscriber.TestSubscriber
Create a TestSubscriber with tuning.

C

cancel() - Method in interface reactor.test.subscriber.TestSubscriber
Cancel the underlying subscription to the Publisher and unblock any pending TestSubscriber.block() calls.
checkUnderRequesting(boolean) - Method in class reactor.test.StepVerifierOptions
Activate or deactivate the StepVerifier check of request amount being too low.
complete() - Method in class reactor.test.publisher.TestPublisher
Triggers completion of this publisher.
ConditionalTestSubscriber<T> - Interface in reactor.test.subscriber
Simple interface for a Fuseable.ConditionalSubscriber variant of the TestSubscriber.
consumeErrorWith(Consumer<Throwable>) - Method in interface reactor.test.StepVerifier.LastStep
Expect an error and consume with the given consumer.
consumeNextWith(Consumer<? super T>) - Method in interface reactor.test.StepVerifier.Step
Expect an element and consume with the given consumer.Any AssertionErrors thrown by the consumer will be rethrown during verification.
consumeRecordedWith(Consumer<? super Collection<T>>) - Method in interface reactor.test.StepVerifier.Step
Expect a recording session started via StepVerifier.Step.recordWith(java.util.function.Supplier<? extends java.util.Collection<T>>), end it and verify it by applying the given consumer.
consumeSubscriptionWith(Consumer<? super Subscription>) - Method in interface reactor.test.StepVerifier.Step
Expect a Subscription and consume with the given consumer.
contains(Object, Object) - Method in interface reactor.test.StepVerifier.ContextExpectations
Check that the propagated Context contains the given value associated to the given key.
containsAllOf(Context) - Method in interface reactor.test.StepVerifier.ContextExpectations
Check that the propagated Context contains all of the key-value pairs of the given Context.
containsAllOf(Map<?, ?>) - Method in interface reactor.test.StepVerifier.ContextExpectations
Check that the propagated Context contains all of the key-value pairs of the given Map.
containsOnly(Context) - Method in interface reactor.test.StepVerifier.ContextExpectations
Check that the propagated Context contains all of the key-value pairs of the given Context, and nothing else.
containsOnly(Map<?, ?>) - Method in interface reactor.test.StepVerifier.ContextExpectations
Check that the propagated Context contains all of the key-value pairs of the given Map, and nothing else.
contextPut(Object, Object) - Method in class reactor.test.subscriber.TestSubscriberBuilder
Enrich the Context with a single entry.
contextPutAll(ContextView) - Method in class reactor.test.subscriber.TestSubscriberBuilder
Enrich the Context by putting all entries of the given ContextView in it.
copy() - Method in class reactor.test.StepVerifierOptions
Make a copy of this StepVerifierOptions instance.
create() - Static method in class reactor.test.publisher.TestPublisher
Create a standard hot TestPublisher.
create() - Static method in class reactor.test.scheduler.VirtualTimeScheduler
Create a new VirtualTimeScheduler without enabling it.
create(boolean) - Static method in class reactor.test.scheduler.VirtualTimeScheduler
Create a new VirtualTimeScheduler without enabling it.
create(Publisher<? extends T>) - Static method in interface reactor.test.StepVerifier
Prepare a new StepVerifier in an uncontrolled environment: StepVerifier.Step.thenAwait() will block in real time.
create(Publisher<? extends T>, long) - Static method in interface reactor.test.StepVerifier
Prepare a new StepVerifier in an uncontrolled environment: StepVerifier.Step.thenAwait() will block in real time.
create(Publisher<? extends T>, StepVerifierOptions) - Static method in interface reactor.test.StepVerifier
Prepare a new StepVerifier in an uncontrolled environment: StepVerifier.Step.thenAwait() will block in real time.
create() - Static method in class reactor.test.StepVerifierOptions
Create a new default set of options for a StepVerifier that can be tuned using the various available non-getter methods (which can be chained).
create() - Static method in interface reactor.test.subscriber.TestSubscriber
Create a simple plain TestSubscriber which will make an unbounded demand on subscription, has an empty Context and makes no attempt at fusion negotiation.
createCold() - Static method in class reactor.test.publisher.TestPublisher
Create a cold TestPublisher, which can be subscribed to by multiple subscribers.
createColdNonBuffering() - Static method in class reactor.test.publisher.TestPublisher
Create a cold TestPublisher, which can be subscribed to by multiple subscribers.
createColdNonCompliant(boolean, TestPublisher.Violation, TestPublisher.Violation...) - Static method in class reactor.test.publisher.TestPublisher
Create a cold TestPublisher, which can be subscribed to by multiple subscribers.
createNoncompliant(TestPublisher.Violation, TestPublisher.Violation...) - Static method in class reactor.test.publisher.TestPublisher
Create a noncompliant hot TestPublisher with a given set of reactive streams spec violations that will be overlooked.
createWorker() - Method in class reactor.test.scheduler.VirtualTimeScheduler
 

D

debug(String) - Method in class reactor.test.util.TestLogger
 
debug(String, Object...) - Method in class reactor.test.util.TestLogger
 
debug(String, Throwable) - Method in class reactor.test.util.TestLogger
 
DEFAULT_VERIFY_TIMEOUT - Static variable in interface reactor.test.StepVerifier
Default verification timeout (see StepVerifier.verify()) is "no timeout".
disableCapture() - Static method in class reactor.test.util.LoggerUtils
Disable capturing, forgetting about the logger set via LoggerUtils.enableCaptureWith(Logger).
dispose() - Method in class reactor.test.scheduler.VirtualTimeScheduler
 
DURATION_CONVERTER - Static variable in class reactor.test.ValueFormatters
Default Duration ValueFormatters.ToStringConverter that removes the PT prefix and switches to lower case.

E

emit(T...) - Method in class reactor.test.publisher.TestPublisher
Combine emitting items and completing this publisher.
empty() - Static method in interface reactor.test.publisher.PublisherProbe
Create a PublisherProbe of which PublisherProbe.flux() and PublisherProbe.mono() versions will simply complete, capturing subscription, cancellation and request events around them.
enableCaptureWith(Logger) - Static method in class reactor.test.util.LoggerUtils
Set the logger used for capturing.
enableCaptureWith(Logger, boolean) - Static method in class reactor.test.util.LoggerUtils
Set the logger used for capturing, an optionally suppress log messages from original logger.
enableConditionalSupport(Predicate<? super T>) - Method in interface reactor.test.StepVerifier.FirstStep
Provide a Predicate that will turn this StepVerifier's subscribers into Fuseable.ConditionalSubscriber and drive the Fuseable.ConditionalSubscriber.tryOnNext(Object) behavior of these subscribers.
error(Throwable) - Method in class reactor.test.publisher.TestPublisher
Triggers an error signal to the subscribers.
error(String) - Method in class reactor.test.util.TestLogger
 
error(String, Object...) - Method in class reactor.test.util.TestLogger
 
error(String, Throwable) - Method in class reactor.test.util.TestLogger
 
expectAccessibleContext() - Method in interface reactor.test.StepVerifier.Step
Expect that after the Subscription step, a Context has been propagated.
expectComplete() - Method in interface reactor.test.StepVerifier.LastStep
Expect the completion signal.
expectError() - Method in interface reactor.test.StepVerifier.LastStep
Expect an unspecified error.
expectError(Class<? extends Throwable>) - Method in interface reactor.test.StepVerifier.LastStep
Expect an error of the specified type.
expectErrorMatches(Predicate<Throwable>) - Method in interface reactor.test.StepVerifier.LastStep
Expect an error and evaluate with the given predicate.
expectErrorMessage(String) - Method in interface reactor.test.StepVerifier.LastStep
Expect an error with the specified message.
expectErrorSatisfies(Consumer<Throwable>) - Method in interface reactor.test.StepVerifier.LastStep
Expect an error and assert it via assertion(s) provided as a Consumer.
expectFusion() - Method in interface reactor.test.StepVerifier.FirstStep
Expect the source Publisher to run with Reactor Fusion flow optimization.
expectFusion(int) - Method in interface reactor.test.StepVerifier.FirstStep
Expect the source Publisher to run the requested Reactor Fusion mode from any of these modes : Fuseable.NONE, Fuseable.SYNC, Fuseable.ASYNC, Fuseable.ANY, Fuseable.THREAD_BARRIER.
expectFusion(int, int) - Method in interface reactor.test.StepVerifier.FirstStep
Expect the source Publisher to run with Reactor Fusion flow optimization.
expectNext(T) - Method in interface reactor.test.StepVerifier.Step
Expect the next element received to be equal to the given value.
expectNext(T, T) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNext(T, T, T) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNext(T, T, T, T) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNext(T, T, T, T, T) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNext(T, T, T, T, T, T) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNext(T...) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements received to be equal to the given values.
expectNextCount(long) - Method in interface reactor.test.StepVerifier.Step
Expect to received count elements, starting from the previous expectation or onSubscribe.
expectNextMatches(Predicate<? super T>) - Method in interface reactor.test.StepVerifier.Step
Expect an element and evaluate with the given predicate.
expectNextSequence(Iterable<? extends T>) - Method in interface reactor.test.StepVerifier.Step
Expect the next elements to match the given Iterable until its iterator depletes.
expectNoAccessibleContext() - Method in interface reactor.test.StepVerifier.Step
Expect that NO Context was propagated after the Subscription phase, which usually indicates that the sequence under test doesn't contain Reactor operators (i.e.
expectNoEvent(Duration) - Method in interface reactor.test.StepVerifier.Step
Expect that no event has been observed by the verifier for the length of the provided Duration.
expectNoFusionSupport() - Method in interface reactor.test.StepVerifier.FirstStep
Expect the source Publisher to NOT run with Reactor Fusion flow optimization.
expectRecordedMatches(Predicate<? super Collection<T>>) - Method in interface reactor.test.StepVerifier.Step
Expect a recording session started via StepVerifier.Step.recordWith(java.util.function.Supplier<? extends java.util.Collection<T>>), end it and verify it by ensuring the provided predicate matches.
expectSubscription() - Method in interface reactor.test.StepVerifier.FirstStep
Expect a Subscription.
expectSubscriptionMatches(Predicate<? super Subscription>) - Method in interface reactor.test.StepVerifier.FirstStep
Expect a Subscription and evaluate with the given predicate.
expectTerminalError() - Method in interface reactor.test.subscriber.TestSubscriber
Expect the TestSubscriber to be terminated with an Subscriber.onError(Throwable) and return the terminating Throwable if so.
expectTerminalSignal() - Method in interface reactor.test.subscriber.TestSubscriber
Expect the TestSubscriber to be terminated, and return the terminal Signal if so.
expectTimeout(Duration) - Method in interface reactor.test.StepVerifier.LastStep
Verify that the Publisher under test doesn't terminate but rather times out after the provided Duration (a timeout implying a cancellation of the source).
explode(CONTAINER) - Method in interface reactor.test.ValueFormatters.Extractor
Explode the container into a Stream of Object, each of which is a candidate for individual String conversion by a ValueFormatters.ToStringConverter when applied as a BiFunction.
extractor(ValueFormatters.Extractor<T>) - Method in class reactor.test.StepVerifierOptions
Add an ValueFormatters.Extractor, replacing any existing ValueFormatters.Extractor that targets the same Class (as in ValueFormatters.Extractor.getTargetClass()).

F

filtering(Predicate<Object>, Function<Object, String>) - Static method in class reactor.test.ValueFormatters
Create a value formatter that applies the given String conversion Function only to objects matching a given Predicate
flux() - Method in class reactor.test.publisher.PublisherProbe.DefaultPublisherProbe
 
flux() - Method in interface reactor.test.publisher.PublisherProbe
Return a Flux version of the probe.
flux() - Method in class reactor.test.publisher.TestPublisher
Convenience method to wrap this TestPublisher to a Flux.
forClass(Class<T>, Function<T, String>) - Static method in class reactor.test.ValueFormatters
Create a value formatter that is specific to a particular Class, applying the given String conversion Function provided the object is an instance of that Class.
forClassMatching(Class<T>, Predicate<T>, Function<T, String>) - Static method in class reactor.test.ValueFormatters
Create a value formatter that is specific to a particular Class and filters based on a provided Predicate.

G

get() - Static method in class reactor.test.scheduler.VirtualTimeScheduler
The current VirtualTimeScheduler assigned in Schedulers
getErrContent() - Method in class reactor.test.util.TestLogger
 
getExtractors() - Method in class reactor.test.StepVerifierOptions
Get the list of value extractors added to the options, including default ones at the end (unless they've been individually replaced).
getFusionMode() - Method in interface reactor.test.subscriber.TestSubscriber
Return an int code that represents the negotiated fusion mode for this TestSubscriber.
getInitialContext() - Method in class reactor.test.StepVerifierOptions
 
getInitialRequest() - Method in class reactor.test.StepVerifierOptions
 
getName() - Method in class reactor.test.util.TestLogger
 
getOrSet() - Static method in class reactor.test.scheduler.VirtualTimeScheduler
Assign a newly created VirtualTimeScheduler to all Schedulers.Factory factories ONLY if no VirtualTimeScheduler is currently set.
getOrSet(boolean) - Static method in class reactor.test.scheduler.VirtualTimeScheduler
Assign a newly created VirtualTimeScheduler to all Schedulers.Factory factories ONLY if no VirtualTimeScheduler is currently set.
getOrSet(VirtualTimeScheduler) - Static method in class reactor.test.scheduler.VirtualTimeScheduler
Assign an externally created VirtualTimeScheduler to the relevant Schedulers.Factory factories, depending on how it was created (see VirtualTimeScheduler.create() and VirtualTimeScheduler.create()).
getOutContent() - Method in class reactor.test.util.TestLogger
 
getProtocolErrors() - Method in interface reactor.test.subscriber.TestSubscriber
Return a List of Signal which represent detected protocol error from the source Publisher, that is to say signals that were emitted to this TestSubscriber in violation of the Reactive Streams specification.
getReceivedOnNext() - Method in interface reactor.test.subscriber.TestSubscriber
Return the List of all elements that have correctly been emitted to the TestSubscriber (onNext signals) so far.
getReceivedOnNextAfterCancellation() - Method in interface reactor.test.subscriber.TestSubscriber
Return the List of elements that have been emitted to the TestSubscriber (onNext signals) so far, after a TestSubscriber.cancel() was triggered.
getScenarioName() - Method in class reactor.test.StepVerifierOptions
 
getScheduledTaskCount() - Method in class reactor.test.scheduler.VirtualTimeScheduler
Get the number of scheduled tasks.
getTargetClass() - Method in interface reactor.test.ValueFormatters.Extractor
Return the targeted container Class.
getTerminalSignal() - Method in interface reactor.test.subscriber.TestSubscriber
Return the terminal Signal if this TestSubscriber TestSubscriber.isTerminated(), or null otherwise.
getValueFormatter() - Method in class reactor.test.StepVerifierOptions
Get the custom object formatter to use when producing messages.
getVirtualTimeSchedulerSupplier() - Method in class reactor.test.StepVerifierOptions
 

H

hasDiscarded(Object...) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has discarded at least all of the provided elements to the discard hook, in any order.
hasDiscardedElements() - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has discarded at least one element to the discard hook.
hasDiscardedElementsMatching(Predicate<Collection<Object>>) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has discarded one or more elements to the discard hook, and check that the collection of discarded elements matches a predicate.
hasDiscardedElementsSatisfying(Consumer<Collection<Object>>) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has discarded one or more elements to the discard hook, and assert them as a collection.
hasDiscardedExactly(Object...) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has discarded all of the provided elements to the discard hook, in any order, and that no other elements were dropped.
hasDropped(Object...) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has dropped at least all of the provided elements to the Hooks.onNextDropped(Consumer) hook, in any order.
hasDroppedElements() - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has dropped at least one element to the Hooks.onNextDropped(Consumer) hook.
hasDroppedErrorMatching(Predicate<Throwable>) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has dropped exactly one error matching the given predicate to the Hooks.onErrorDropped(Consumer) hook.
hasDroppedErrorOfType(Class<? extends Throwable>) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has dropped exactly one error of the given type to the Hooks.onErrorDropped(Consumer) hook.
hasDroppedErrors() - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has dropped at least one error to the Hooks.onErrorDropped(Consumer) hook.
hasDroppedErrors(int) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has dropped exactly n errors to the Hooks.onErrorDropped(Consumer) hook.
hasDroppedErrorsMatching(Predicate<Collection<Throwable>>) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has dropped one or more errors to the Hooks.onErrorDropped(Consumer) hook, and check that the collection of errors matches a predicate.
hasDroppedErrorsSatisfying(Consumer<Collection<Throwable>>) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has dropped one or more errors to the Hooks.onErrorDropped(Consumer) hook, and assert them as a collection.
hasDroppedErrorWithMessage(String) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has dropped exactly one error with the exact provided message to the Hooks.onErrorDropped(Consumer) hook.
hasDroppedErrorWithMessageContaining(String) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has dropped exactly one error with a message containing the provided string to the Hooks.onErrorDropped(Consumer) hook.
hasDroppedExactly(Object...) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has dropped all of the provided elements to the Hooks.onNextDropped(Consumer) hook, in any order, and that no other elements were dropped.
hasKey(Object) - Method in interface reactor.test.StepVerifier.ContextExpectations
Check that the propagated Context contains a value for the given key.
hasNotDiscardedElements() - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has not discarded any element to the discard hook.
hasNotDroppedElements() - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has not dropped any element to the Hooks.onNextDropped(Consumer) hook.
hasNotDroppedErrors() - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has not dropped any error to the Hooks.onErrorDropped(Consumer) hook.
hasOperatorErrorMatching(Predicate<Throwable>) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has triggered the onOperatorError hook exactly once and the error matches the given predicate.
hasOperatorErrorOfType(Class<? extends Throwable>) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has triggered the onOperatorError hook exactly once and the error is of the given type.
hasOperatorErrors() - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has triggered the onOperatorError hook at least once.
hasOperatorErrors(int) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has triggered the onOperatorError hook exactly n times.
hasOperatorErrorsMatching(Predicate<Collection<Tuple2<Optional<Throwable>, Optional<?>>>>) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has triggered the onOperatorError hook once or more, and check that the collection of errors and their optionally associated data matches a predicate.
hasOperatorErrorsSatisfying(Consumer<Collection<Tuple2<Optional<Throwable>, Optional<?>>>>) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has triggered the onOperatorError hook once or more, and assert the errors and optionally associated data as a collection.
hasOperatorErrorWithMessage(String) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has triggered the onOperatorError hook exactly once and the error has the exact provided message.
hasOperatorErrorWithMessageContaining(String) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the tested publisher has triggered the onOperatorError hook exactly once, with the error message containing the provided string.
hasSize(int) - Method in interface reactor.test.StepVerifier.ContextExpectations
Check that the propagated Context is of the given size.

I

info(String) - Method in class reactor.test.util.TestLogger
 
info(String, Object...) - Method in class reactor.test.util.TestLogger
 
info(String, Throwable) - Method in class reactor.test.util.TestLogger
 
initialRequest(long) - Method in class reactor.test.StepVerifierOptions
Set the amount the StepVerifier should request initially.
initialRequest(long) - Method in class reactor.test.subscriber.TestSubscriberBuilder
Set the request to be made upon receiving the Subscription in Subscriber.onSubscribe(Subscription).
initialRequestUnbounded() - Method in class reactor.test.subscriber.TestSubscriberBuilder
Set the request to be made upon receiving the Subscription in Subscriber.onSubscribe(Subscription) to be an unbounded request, ie.
isCancelled() - Method in interface reactor.test.subscriber.TestSubscriber
Check if this TestSubscriber has been cancelled, which implies TestSubscriber.isTerminatedOrCancelled() is also true.
isCheckUnderRequesting() - Method in class reactor.test.StepVerifierOptions
 
isDebugEnabled() - Method in class reactor.test.util.TestLogger
 
isDisposed() - Method in class reactor.test.scheduler.VirtualTimeScheduler
 
isErrorEnabled() - Method in class reactor.test.util.TestLogger
 
isFactoryEnabled() - Static method in class reactor.test.scheduler.VirtualTimeScheduler
Return true if there is a VirtualTimeScheduler currently used by the Schedulers factory (ie it has been enabled), false otherwise (ie it has been reset).
isInfoEnabled() - Method in class reactor.test.util.TestLogger
 
isLogCurrentThreadName() - Method in class reactor.test.util.TestLogger
 
isTerminated() - Method in interface reactor.test.subscriber.TestSubscriber
Check if this TestSubscriber has received a terminal signal, ie.
isTerminatedComplete() - Method in interface reactor.test.subscriber.TestSubscriber
Check if this TestSubscriber has received a terminal signal that is specifically onComplete.
isTerminatedError() - Method in interface reactor.test.subscriber.TestSubscriber
Check if this TestSubscriber has received a terminal signal that is specifically onError.
isTerminatedOrCancelled() - Method in interface reactor.test.subscriber.TestSubscriber
Check if this TestSubscriber has either: been cancelled: TestSubscriber.isCancelled() would return true been terminated, having been signalled with onComplete or onError: TestSubscriber.isTerminated() would return true and TestSubscriber.getTerminalSignal() would return a non-null Signal The third possible failure condition, subscription failure, results in an AssertionError being thrown by this method (like all other accessors, see also TestSubscriber javadoc).
isTraceEnabled() - Method in class reactor.test.util.TestLogger
 
isWarnEnabled() - Method in class reactor.test.util.TestLogger
 
iterableExtractor() - Static method in class reactor.test.ValueFormatters
Default Iterable extractor that use the [CONVERTED1, CONVERTED2] representation.

L

log() - Method in interface reactor.test.StepVerifier
Activate debug logging of a description of the test scenario, as well as some details about certain verification steps.
LoggerUtils - Class in reactor.test.util
This class eases testing interested in what reactor classes emit using loggers.

M

matches(Predicate<Context>) - Method in interface reactor.test.StepVerifier.ContextExpectations
Check that the propagated Context matches a given Predicate.
matches(Predicate<Context>, String) - Method in interface reactor.test.StepVerifier.ContextExpectations
Check that the propagated Context matches a given Predicate that is given a description.
matches(CONTAINER) - Method in interface reactor.test.ValueFormatters.Extractor
An additional test to perform on a matching container to further decide to convert it or not.
mono() - Method in class reactor.test.publisher.PublisherProbe.DefaultPublisherProbe
 
mono() - Method in interface reactor.test.publisher.PublisherProbe
Return a Mono version of the probe.
mono() - Method in class reactor.test.publisher.TestPublisher
Convenience method to wrap this TestPublisher to a Mono.

N

next(T) - Method in class reactor.test.publisher.TestPublisher
Send 1 onNext signal to the subscribers.
next(T, T...) - Method in class reactor.test.publisher.TestPublisher
Send 1-n onNext signals to the subscribers.
now(TimeUnit) - Method in class reactor.test.scheduler.VirtualTimeScheduler
 

O

of(Publisher<? extends T>) - Static method in interface 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.

P

prefix(CONTAINER) - Method in interface reactor.test.ValueFormatters.Extractor
Return the prefix to use in the container's String representation, given the original container.
PublisherProbe<T> - Interface in 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> - Class in reactor.test.publisher
 

R

race(T, Function<? super T, ? extends T>, Predicate<? super T>, BiPredicate<? super T, ? super T>) - Static method in class reactor.test.util.RaceTestUtils
Synchronizes the execution of two concurrent state modifications as much as possible to test race conditions.
race(Runnable...) - Static method in class reactor.test.util.RaceTestUtils
Synchronizes the execution of several Runnables as much as possible to test race conditions.
race(Runnable, Runnable) - Static method in class reactor.test.util.RaceTestUtils
Synchronizes the execution of two Runnables as much as possible to test race conditions.
race(Runnable, Runnable, Scheduler) - Static method in class reactor.test.util.RaceTestUtils
Deprecated.
Use RaceTestUtils.race(Scheduler, Runnable...). To be removed in 3.6.0, at the earliest.
race(Scheduler, Runnable...) - Static method in class reactor.test.util.RaceTestUtils
Synchronizes the execution of several Runnables as much as possible to test race conditions.
race(int, Scheduler, Runnable...) - Static method in class reactor.test.util.RaceTestUtils
Synchronizes the execution of several Runnables as much as possible to test race conditions.
RaceTestUtils - Class in reactor.test.util
 
RaceTestUtils() - Constructor for class reactor.test.util.RaceTestUtils
 
reactor.test - package reactor.test
Main test components supporting the testing and assertion of publishers.
reactor.test.publisher - package reactor.test.publisher
Components supporting the creation of test-oriented Publishers.
reactor.test.scheduler - package reactor.test.scheduler
Components supporting the creation of test-oriented Schedulers.
reactor.test.subscriber - package reactor.test.subscriber
Components supporting the creation of test-oriented Subscribers.
reactor.test.util - package reactor.test.util
 
recordWith(Supplier<? extends Collection<T>>) - Method in interface reactor.test.StepVerifier.Step
Start a recording session storing Subscriber.onNext(Object) values in the supplied Collection.
request(long) - Method in interface reactor.test.subscriber.TestSubscriber
Request n elements from the Publisher's Subscription.
requireFusion(int) - Method in class reactor.test.subscriber.TestSubscriberBuilder
Expect fusion to be possible with the TestSubscriber, with Fuseable.NONE) being a special case.
requireFusion(int, int) - Method in class reactor.test.subscriber.TestSubscriberBuilder
Expect fusion to be possible with the TestSubscriber, with both parameters set to Fuseable.NONE being a special case.
requireNotFuseable() - Method in class reactor.test.subscriber.TestSubscriberBuilder
Enforce that the Subscription passed to the TestSubscriber isn't a Fuseable.QueueSubscription.
reset() - Static method in class reactor.test.scheduler.VirtualTimeScheduler
Re-activate the global Schedulers and potentially customized Schedulers.Factory that were active prior to last activation of VirtualTimeScheduler factories.
reset() - Method in class reactor.test.util.TestLogger
 
resetDefaultTimeout() - Static method in interface reactor.test.StepVerifier
Reset the StepVerifier.verify() timeout to the "unlimited" default.

S

scenarioName(String) - Method in class reactor.test.StepVerifierOptions
Give a name to the whole scenario tested by the configured StepVerifier.
schedule(Runnable) - Method in class reactor.test.scheduler.VirtualTimeScheduler
 
schedule(Runnable, long, TimeUnit) - Method in class reactor.test.scheduler.VirtualTimeScheduler
 
schedulePeriodically(Runnable, long, long, TimeUnit) - Method in class reactor.test.scheduler.VirtualTimeScheduler
 
set(VirtualTimeScheduler) - Static method in class reactor.test.scheduler.VirtualTimeScheduler
Assign an externally created VirtualTimeScheduler to the relevant Schedulers.Factory factories, depending on how it was created (see VirtualTimeScheduler.create() and VirtualTimeScheduler.create()).
setDefaultTimeout(Duration) - Static method in interface reactor.test.StepVerifier
Set the StepVerifier.verify() timeout for all StepVerifier created through the factory methods (StepVerifier.create(Publisher), StepVerifier.withVirtualTime(Supplier), etc.).
signalExtractor() - Static method in class reactor.test.ValueFormatters
Default Signal extractor that unwraps only onNext.
StepVerifier - Interface in reactor.test
A StepVerifier provides a declarative way of creating a verifiable script for an async Publisher sequence, by expressing expectations about the events that will happen upon subscription.
StepVerifier.Assertions - Interface in reactor.test
Exposes post-verification state assertions.
StepVerifier.ContextExpectations<T> - Interface in reactor.test
Allow to set expectations about the Context propagated during the Subscription phase.
StepVerifier.FirstStep<T> - Interface in reactor.test
Define a builder for explicitly expecting an initializing Subscription as first signal.
StepVerifier.LastStep - Interface in reactor.test
Define a builder for terminal states.
StepVerifier.Step<T> - Interface in reactor.test
Define a builder for expecting main sequence individual signals.
StepVerifierOptions - Class in reactor.test
Options for a StepVerifier, including the initial request amount, VirtualTimeScheduler supplier and toggles for some checks.
subscribeCount() - Method in class reactor.test.publisher.PublisherProbe.DefaultPublisherProbe
 
subscribeCount() - Method in interface reactor.test.publisher.PublisherProbe
 
suffix(CONTAINER) - Method in interface reactor.test.ValueFormatters.Extractor
Return the suffix to use in the container's String representation, given the original container.

T

test(Object) - Method in interface reactor.test.ValueFormatters.Extractor
Test if an object is a container that can be extracted and converted by this ValueFormatters.Extractor.
TestLogger - Class in reactor.test.util
A Logger that writes to ByteArrayOutputStream and allows retrieval of the logs via TestLogger.getErrContent() and TestLogger.getOutContent().
TestLogger() - Constructor for class reactor.test.util.TestLogger
 
TestLogger(boolean) - Constructor for class reactor.test.util.TestLogger
 
TestPublisher<T> - Class in reactor.test.publisher
A Publisher that you can directly manipulate, triggering onNext, onComplete and onError events, for testing purposes.
TestPublisher() - Constructor for class reactor.test.publisher.TestPublisher
 
TestPublisher.Violation - Enum in reactor.test.publisher
Possible misbehavior for a TestPublisher.
TestSubscriber<T> - Interface in reactor.test.subscriber
A CoreSubscriber that can be attached to any Publisher to later assert which events occurred at runtime.
TestSubscriber.FusionRequirement - Enum in reactor.test.subscriber
An enum representing the 3 broad expectations around fusion.
TestSubscriberBuilder - Class in reactor.test.subscriber
A configuration builder used to create a fine-tuned TestSubscriber, also allowing for a Fuseable.ConditionalSubscriber variant.
then() - Method in interface reactor.test.StepVerifier.ContextExpectations
Add the context checks set up by this StepVerifier.ContextExpectations as a StepVerifier expectation, and return the current StepVerifier.Step in order to build further sequence expectations and ultimately verify the sequence.
then(Runnable) - Method in interface reactor.test.StepVerifier.Step
Run an arbitrary task scheduled after previous expectations or tasks.
thenAwait() - Method in interface reactor.test.StepVerifier.Step
Mark a Pause in the expectation evaluation.
thenAwait(Duration) - Method in interface reactor.test.StepVerifier.Step
Pause the expectation evaluation for a given Duration.
thenCancel() - Method in interface reactor.test.StepVerifier.LastStep
Cancel the underlying subscription.
thenConsumeWhile(Predicate<T>) - Method in interface reactor.test.StepVerifier.Step
Consume further onNext signals as long as they match a predicate.
thenConsumeWhile(Predicate<T>, Consumer<T>) - Method in interface reactor.test.StepVerifier.Step
Consume further onNext signals using a provided Consumer as long as they match a Predicate.
thenRequest(long) - Method in interface reactor.test.StepVerifier.Step
Request the given amount of elements from the upstream Publisher.
tookLessThan(Duration) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the whole verification took strictly less than the provided duration to execute.
tookMoreThan(Duration) - Method in interface reactor.test.StepVerifier.Assertions
Assert that the whole verification took strictly more than the provided duration to execute.
trace(String) - Method in class reactor.test.util.TestLogger
 
trace(String, Object...) - Method in class reactor.test.util.TestLogger
 
trace(String, Throwable) - Method in class reactor.test.util.TestLogger
 

U

useCurrentLoggersWithCapture() - Static method in class reactor.test.util.LoggerUtils
Sets a logger factory that will return loggers that not only use the original logging framework used by reactor, but also use the logger set via LoggerUtils.enableCaptureWith(Logger), irrespective of its name or how it was obtained.

V

valueFormatter(ValueFormatters.ToStringConverter) - Method in class reactor.test.StepVerifierOptions
Set up a custom value formatter to be used in error messages when presenting expected and actual values.
ValueFormatters - Class in reactor.test
An utility class to create ValueFormatters.ToStringConverter Function that convert objects to String.
ValueFormatters.Extractor<CONTAINER> - Interface in reactor.test
An extractor of data wrapped in a BiFunction aiming at producing a customized String representation of a container type and its contained elements, each element being potentially itself converted to String using a ValueFormatters.ToStringConverter: it only considers specific container types, see ValueFormatters.Extractor.getTargetClass() it can further filter these container instances using ValueFormatters.Extractor.matches(Object) it can be applied to arbitrary objects, as it will default to String.valueOf(Object) on non-matching containers it can apply a ValueFormatters.ToStringConverter to the content, passed as the second parameter of the BiFunction it reconstructs the String representation of the container by exploding it and then joining it with {#code ", "} delimiter, as well as custom ValueFormatters.Extractor.prefix(Object) and ValueFormatters.Extractor.suffix(Object)
ValueFormatters.ToStringConverter - Interface in reactor.test
A generic Object to String conversion Function which is also a Predicate, and which only applies a custom conversion to targets that match said Predicate.
valueOf(String) - Static method in enum reactor.test.publisher.TestPublisher.Violation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.test.subscriber.TestSubscriber.FusionRequirement
Returns the enum constant of this type with the specified name.
values() - Static method in enum reactor.test.publisher.TestPublisher.Violation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.test.subscriber.TestSubscriber.FusionRequirement
Returns an array containing the constants of this enum type, in the order they are declared.
verify() - Method in interface reactor.test.StepVerifier
Verify the signals received by this subscriber.
verify(Duration) - Method in interface reactor.test.StepVerifier
Verify the signals received by this subscriber.
verifyComplete() - Method in interface reactor.test.StepVerifier.LastStep
Trigger the verification, expecting a completion signal as terminal event.
verifyError() - Method in interface reactor.test.StepVerifier.LastStep
Trigger the verification, expecting an unspecified error as terminal event.
verifyError(Class<? extends Throwable>) - Method in interface reactor.test.StepVerifier.LastStep
Trigger the verification, expecting an error of the specified type as terminal event.
verifyErrorMatches(Predicate<Throwable>) - Method in interface reactor.test.StepVerifier.LastStep
Trigger the verification, expecting an error that matches the given predicate as terminal event.
verifyErrorMessage(String) - Method in interface reactor.test.StepVerifier.LastStep
Trigger the verification, expecting an error with the specified message as terminal event.
verifyErrorSatisfies(Consumer<Throwable>) - Method in interface reactor.test.StepVerifier.LastStep
Trigger the verification, expecting an error as terminal event which gets asserted via assertion(s) provided as a Consumer.
verifyLater() - Method in interface reactor.test.StepVerifier
Trigger the subscription and prepare for verifications but doesn't block.
verifyThenAssertThat() - Method in interface reactor.test.StepVerifier
Verifies the signals received by this subscriber, then exposes various assertion methods on the final state.
verifyThenAssertThat(Duration) - Method in interface reactor.test.StepVerifier
Verifies the signals received by this subscriber, then exposes various assertion methods on the final state.
verifyTimeout(Duration) - Method in interface reactor.test.StepVerifier.LastStep
Trigger the verification, expecting that the Publisher under test doesn't terminate but rather times out after the provided Duration.
VirtualTimeScheduler - Class in reactor.test.scheduler
A Scheduler that uses a virtual clock, allowing to manipulate time (eg.
VirtualTimeScheduler(boolean) - Constructor for class reactor.test.scheduler.VirtualTimeScheduler
 
virtualTimeSchedulerSupplier(Supplier<? extends VirtualTimeScheduler>) - Method in class reactor.test.StepVerifierOptions
Set a supplier for a VirtualTimeScheduler, which is mandatory for a StepVerifier to work with virtual time.

W

warn(String) - Method in class reactor.test.util.TestLogger
 
warn(String, Object...) - Method in class reactor.test.util.TestLogger
 
warn(String, Throwable) - Method in class reactor.test.util.TestLogger
 
wasCancelled() - Method in class reactor.test.publisher.PublisherProbe.DefaultPublisherProbe
 
wasCancelled() - Method in interface reactor.test.publisher.PublisherProbe
 
wasRequested() - Method in class reactor.test.publisher.PublisherProbe.DefaultPublisherProbe
 
wasRequested() - Method in interface reactor.test.publisher.PublisherProbe
 
wasSubscribed() - Method in class reactor.test.publisher.PublisherProbe.DefaultPublisherProbe
 
wasSubscribed() - Method in interface reactor.test.publisher.PublisherProbe
 
withInitialContext(Context) - Method in class reactor.test.StepVerifierOptions
Set an initial Context to be propagated by the StepVerifier when it subscribes to the sequence under test.
withVirtualTime(Supplier<? extends Publisher<? extends T>>) - Static method in interface reactor.test.StepVerifier
Prepare a new StepVerifier in a controlled environment using VirtualTimeScheduler to manipulate a virtual clock via StepVerifier.Step.thenAwait().
withVirtualTime(Supplier<? extends Publisher<? extends T>>, long) - Static method in interface reactor.test.StepVerifier
Prepare a new StepVerifier in a controlled environment using VirtualTimeScheduler to manipulate a virtual clock via StepVerifier.Step.thenAwait().
withVirtualTime(Supplier<? extends Publisher<? extends T>>, Supplier<? extends VirtualTimeScheduler>, long) - Static method in interface reactor.test.StepVerifier
Prepare a new StepVerifier in a controlled environment using a user-provided VirtualTimeScheduler to manipulate a virtual clock via StepVerifier.Step.thenAwait().
withVirtualTime(Supplier<? extends Publisher<? extends T>>, StepVerifierOptions) - Static method in interface reactor.test.StepVerifier
Prepare a new StepVerifier in a controlled environment using a user-provided VirtualTimeScheduler to manipulate a virtual clock via StepVerifier.Step.thenAwait().
A B C D E F G H I L M N O P R S T U V W 
Skip navigation links
reactor-test