Trait/Object

reactor.core.scala.publisher

FluxProcessor

Related Docs: object FluxProcessor | package publisher

Permalink

trait FluxProcessor[IN, OUT] extends SFlux[OUT] with Processor[IN, OUT] with Disposable with Scannable

A base processor that exposes SFlux API for org.reactivestreams.Processor.

Implementors include reactor.core.publisher.UnicastProcessor, reactor.core.publisher.EmitterProcessor, reactor.core.publisher.ReplayProcessor, reactor.core.publisher.WorkQueueProcessor and reactor.core.publisher.TopicProcessor.

IN

the input value type

OUT

the output value type

Linear Supertypes
Scannable, Disposable, Processor[IN, OUT], Subscriber[IN], SFlux[OUT], MapablePublisher[OUT], Publisher[OUT @scala.annotation.unchecked.uncheckedVariance], SFluxLike[OUT], ScalaConverters, AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. FluxProcessor
  2. Scannable
  3. Disposable
  4. Processor
  5. Subscriber
  6. SFlux
  7. MapablePublisher
  8. Publisher
  9. SFluxLike
  10. ScalaConverters
  11. AnyRef
  12. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. implicit class PimpConnectableFlux[T] extends AnyRef

    Permalink
    Definition Classes
    ScalaConverters
  2. implicit class PimpJFlux[T] extends AnyRef

    Permalink
    Definition Classes
    ScalaConverters
  3. implicit class PimpJMono[T] extends AnyRef

    Permalink
    Definition Classes
    ScalaConverters

Abstract Value Members

  1. abstract def jFluxProcessor: publisher.FluxProcessor[IN, OUT]

    Permalink
    Attributes
    protected

Concrete Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ++[U >: OUT](other: Publisher[U]): SFlux[U]

    Permalink

    Alias for SFlux.concatWith

    other

    the other Publisher sequence to concat after this SFlux

    returns

    a concatenated SFlux

    Definition Classes
    SFluxLike
  4. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  5. def actuals(): Stream[_ <: Scannable]

    Permalink
    Definition Classes
    Scannable
  6. final def all(predicate: (OUT) ⇒ Boolean): SMono[Boolean]

    Permalink

    Emit a single boolean true if all values of this sequence match the given predicate.

    Emit a single boolean true if all values of this sequence match the given predicate.

    The implementation uses short-circuit logic and completes with false if the predicate doesn't match a value.

    predicate

    the predicate to match all emitted items

    returns

    a SMono of all evaluations

    Definition Classes
    SFlux
  7. final def any(predicate: (OUT) ⇒ Boolean): SMono[Boolean]

    Permalink

    Emit a single boolean true if any of the values of this SFlux sequence match the predicate.

    Emit a single boolean true if any of the values of this SFlux sequence match the predicate.

    The implementation uses short-circuit logic and completes with true if the predicate matches a value.

    predicate

    predicate tested upon values

    returns

    a new SFlux with true if any value satisfies a predicate and false otherwise

    Definition Classes
    SFlux
  8. final def as[U >: OUT, P](transformer: (SFlux[U]) ⇒ P): P

    Permalink

    Immediately apply the given transformation to this SFlux in order to generate a target type.

    Immediately apply the given transformation to this SFlux in order to generate a target type.

    flux.as(Mono::from).subscribe()

    P

    the returned type

    transformer

    the Function1 to immediately map this SFlux into a target type instance.

    returns

    a an instance of P

    Definition Classes
    SFlux
    See also

    SFlux.compose for a bounded conversion to Publisher

  9. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  10. final def asJava(): Flux[OUT]

    Permalink
    Definition Classes
    SFlux
  11. final def blockFirst(timeout: Duration = Duration.Inf): Option[OUT]

    Permalink

    Blocks until the upstream signals its first value or completes.

    Blocks until the upstream signals its first value or completes.

    returns

    the Some value or None

    Definition Classes
    SFlux
  12. final def blockLast(timeout: Duration = Duration.Inf): Option[OUT]

    Permalink

    Blocks until the upstream completes and return the last emitted value.

    Blocks until the upstream completes and return the last emitted value.

    timeout

    max duration timeout to wait for.

    returns

    the last value or None

    Definition Classes
    SFlux
  13. final def buffer[U >: OUT, C >: Buffer[U]](maxSize: Int = Int.MaxValue, bufferSupplier: () ⇒ C = () => mutable.ListBuffer.empty[U])(implicit skip: Int = maxSize): SFlux[Seq[U]]

    Permalink

    Collect incoming values into multiple Seq that will be pushed into the returned SFlux when the given max size is reached or onComplete is received.

    Collect incoming values into multiple Seq that will be pushed into the returned SFlux when the given max size is reached or onComplete is received. A new container Seq will be created every given skip count.

    When Skip > Max Size : dropping buffers

    When Skip < Max Size : overlapping buffers

    When Skip == Max Size : exact buffers

    C

    the supplied Seq type

    maxSize

    the max collected size

    bufferSupplier

    the collection to use for each data segment

    skip

    the number of items to skip before creating a new bucket

    returns

    a microbatched SFlux of possibly overlapped or gapped Seq

    Definition Classes
    SFlux
  14. final def bufferPublisher[U >: OUT, C >: Buffer[U]](other: Publisher[_], bufferSupplier: () ⇒ C = () => mutable.ListBuffer.empty[U]): SFlux[Seq[U]]

    Permalink

    Collect incoming values into multiple Seq delimited by the given Publisher signals.

    Collect incoming values into multiple Seq delimited by the given Publisher signals.

    C

    the supplied Seq type

    other

    the other Publisher to subscribe to for emitting and recycling receiving bucket

    bufferSupplier

    the collection to use for each data segment

    returns

    a microbatched SFlux of Seq delimited by a Publisher

    Definition Classes
    SFlux
  15. def bufferSize(): Int

    Permalink

    Return the processor buffer capacity if any or Int.MaxValue

    Return the processor buffer capacity if any or Int.MaxValue

    returns

    processor buffer capacity if any or Int.MaxValue

  16. final def bufferTimeSpan(timespan: Duration, timer: Scheduler = Schedulers.parallel())(timeshift: Duration = timespan): SFlux[Seq[OUT]]

    Permalink
    Definition Classes
    SFlux
  17. final def bufferTimeout[U >: OUT, C >: Buffer[U]](maxSize: Int, timespan: Duration, timer: Scheduler = Schedulers.parallel(), bufferSupplier: () ⇒ C = () => mutable.ListBuffer.empty[U]): SFlux[Seq[U]]

    Permalink

    Collect incoming values into a Seq that will be pushed into the returned SFlux every timespan OR maxSize items.

    Collect incoming values into a Seq that will be pushed into the returned SFlux every timespan OR maxSize items.

    C

    the supplied Seq type

    maxSize

    the max collected size

    timespan

    the timeout to use to release a buffered list

    bufferSupplier

    the collection to use for each data segment

    returns

    a microbatched SFlux of Seq delimited by given size or a given period timeout

    Definition Classes
    SFlux
  18. final def bufferUntil(predicate: (OUT) ⇒ Boolean, cutBefore: Boolean = false): SFlux[Seq[OUT]]

    Permalink

    Collect incoming values into multiple Seq that will be pushed into the returned SFlux each time the given predicate returns true.

    Collect incoming values into multiple Seq that will be pushed into the returned SFlux each time the given predicate returns true. Note that the buffer into which the element that triggers the predicate to return true (and thus closes a buffer) is included depends on the cutBefore parameter: set it to true to include the boundary element in the newly opened buffer, false to include it in the closed buffer (as in SFlux.bufferUntil).

    On completion, if the latest buffer is non-empty and has not been closed it is emitted. However, such a "partial" buffer isn't emitted in case of onError termination.

    predicate

    a predicate that triggers the next buffer when it becomes true.

    cutBefore

    set to true to include the triggering element in the new buffer rather than the old.

    returns

    a microbatched SFlux of Seq

    Definition Classes
    SFlux
  19. final def bufferWhen[U >: OUT, V, W, C >: Buffer[U]](bucketOpening: Publisher[V], closeSelector: (V) ⇒ Publisher[W], bufferSupplier: () ⇒ C = () => mutable.ListBuffer.empty[U]): SFlux[Seq[U]]

    Permalink

    Collect incoming values into multiple Seq delimited by the given Publisher signals.

    Collect incoming values into multiple Seq delimited by the given Publisher signals. Each Seq bucket will last until the mapped Publisher receiving the boundary signal emits, thus releasing the bucket to the returned SFlux.

    When Open signal is strictly not overlapping Close signal : dropping buffers

    When Open signal is strictly more frequent than Close signal : overlapping buffers

    When Open signal is exactly coordinated with Close signal : exact buffers

    U

    the element type of the bucket-opening sequence

    V

    the element type of the bucket-closing sequence

    C

    the supplied Seq type

    bucketOpening

    a Publisher to subscribe to for creating new receiving bucket signals.

    closeSelector

    a Publisher factory provided the opening signal and returning a Publisher to subscribe to for emitting relative bucket.

    bufferSupplier

    the collection to use for each data segment

    returns

    a microbatched SFlux of Seq delimited by an opening Publisher and a relative closing Publisher

    Definition Classes
    SFlux
  20. final def bufferWhile(predicate: (OUT) ⇒ Boolean): SFlux[Seq[OUT]]

    Permalink

    Collect incoming values into multiple Seq that will be pushed into the returned SFlux.

    Collect incoming values into multiple Seq that will be pushed into the returned SFlux. Each buffer continues aggregating values while the given predicate returns true, and a new buffer is created as soon as the predicate returns false... Note that the element that triggers the predicate to return false (and thus closes a buffer) is NOT included in any emitted buffer.

    On completion, if the latest buffer is non-empty and has not been closed it is emitted. However, such a "partial" buffer isn't emitted in case of onError termination.

    predicate

    a predicate that triggers the next buffer when it becomes false.

    returns

    a microbatched SFlux of Seq

    Definition Classes
    SFlux
  21. final def cache(history: Int = Int.MaxValue, ttl: Duration = Duration.Inf): SFlux[OUT]

    Permalink

    Turn this SFlux into a hot source and cache last emitted signals for further Subscriber.

    Turn this SFlux into a hot source and cache last emitted signals for further Subscriber. Will retain up to the given history size with per-item expiry timeout.

    history

    number of events retained in history excluding complete and error

    ttl

    Time-to-live for each cached item.

    returns

    a replaying SFlux

    Definition Classes
    SFlux
  22. final def cancelOn(scheduler: Scheduler): SFlux[OUT]

    Permalink

    Prepare this SFlux so that subscribers will cancel from it on a specified Scheduler.

    Prepare this SFlux so that subscribers will cancel from it on a specified Scheduler.

    scheduler

    the Scheduler to signal cancel on

    returns

    a scheduled cancel SFlux

    Definition Classes
    SFlux
  23. final def cast[E](implicit classTag: ClassTag[E]): SFlux[E]

    Permalink

    Cast the current SFlux produced type into a target produced type.

    Cast the current SFlux produced type into a target produced type.

    E

    the SFlux output type

    returns

    a casted SFlux

    Definition Classes
    SFlux
  24. final def checkpoint(description: Option[String] = None, forceStackTrace: Option[Boolean] = None): SFlux[OUT]

    Permalink

    Activate assembly tracing or the lighter assembly marking depending on the forceStackTrace option.

    Activate assembly tracing or the lighter assembly marking depending on the forceStackTrace option.

    By setting the forceStackTrace parameter to true, activate assembly tracing for this particular SFlux and give it a description that will be reflected in the assembly traceback in case of an error upstream of the checkpoint. Note that unlike SFlux.checkpoint(Option[String]), this will incur the cost of an exception stack trace creation. The description could for example be a meaningful name for the assembled flux or a wider correlation ID, since the stack trace will always provide enough information to locate where this Flux was assembled.

    By setting forceStackTrace to false, behaves like SFlux.checkpoint(Option[String]) and is subject to the same caveat in choosing the description.

    It should be placed towards the end of the reactive chain, as errors triggered downstream of it cannot be observed and augmented with assembly marker.

    description

    a description (must be unique enough if forceStackTrace is set to false).

    forceStackTrace

    false to make a light checkpoint without a stacktrace, true to use a stack trace.

    returns

    the assembly marked SFlux.

    Definition Classes
    SFlux
  25. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  26. final def collect[E](containerSupplier: () ⇒ E, collector: (E, OUT) ⇒ Unit): SMono[E]

    Permalink
    Definition Classes
    SFluxLike
  27. final def collectMap[K, V](keyExtractor: (OUT) ⇒ K, valueExtractor: (OUT) ⇒ V, mapSupplier: () ⇒ Map[K, V] = () => mutable.HashMap.empty[K, V]): SMono[Map[K, V]]

    Permalink
    Definition Classes
    SFlux
  28. final def collectMap[K](keyExtractor: (OUT) ⇒ K): SMono[Map[K, OUT]]

    Permalink
    Definition Classes
    SFlux
  29. final def collectMultimap[K, V](keyExtractor: (OUT) ⇒ K, valueExtractor: (OUT) ⇒ V, mapSupplier: () ⇒ Map[K, Collection[V]] = ...): SMono[Map[K, Traversable[V]]]

    Permalink
    Definition Classes
    SFlux
  30. final def collectMultimap[K](keyExtractor: (OUT) ⇒ K): SMono[Map[K, Traversable[OUT]]]

    Permalink
    Definition Classes
    SFlux
  31. final def collectSeq(): SMono[Seq[OUT]]

    Permalink
    Definition Classes
    SFlux
  32. final def collectSortedSeq[U >: OUT](ordering: Ordering[U] = None.orNull): SMono[Seq[U]]

    Permalink
    Definition Classes
    SFlux
  33. final def concatMap[V](mapper: (OUT) ⇒ Publisher[_ <: V], prefetch: Int = XS_BUFFER_SIZE): SFlux[V]

    Permalink
    Definition Classes
    SFluxLike
  34. final def concatMapDelayError[V](mapper: (OUT) ⇒ Publisher[_ <: V], delayUntilEnd: Boolean = false, prefetch: Int = XS_BUFFER_SIZE): SFlux[V]

    Permalink
    Definition Classes
    SFlux
  35. final def concatMapIterable[R](mapper: (OUT) ⇒ Iterable[_ <: R], prefetch: Int = XS_BUFFER_SIZE): SFlux[R]

    Permalink
    Definition Classes
    SFlux
  36. final def concatWith[U >: OUT](other: Publisher[U]): SFlux[U]

    Permalink

    Concatenate emissions of this SFlux with the provided Publisher (no interleave).

    Concatenate emissions of this SFlux with the provided Publisher (no interleave).

    other

    the Publisher sequence to concat after this SFlux

    returns

    a concatenated SFlux

    Definition Classes
    SFluxLike
  37. final def count(): SMono[Long]

    Permalink
    Definition Classes
    SFlux
  38. final def defaultIfEmpty[U >: OUT](defaultV: U): SFlux[U]

    Permalink

    Provide a default unique value if this sequence is completed without any data

    Provide a default unique value if this sequence is completed without any data

    defaultV

    the alternate value if this sequence is empty

    returns

    a new SFlux

    Definition Classes
    SFlux
  39. final def delayElements(delay: Duration, timer: Scheduler = Schedulers.parallel()): SFlux[OUT]

    Permalink

    Delay each of this SFlux elements Subscriber#onNext signals) by a given duration.

    Delay each of this SFlux elements Subscriber#onNext signals) by a given duration. Signals are delayed and continue on an user-specified Scheduler, but empty sequences or immediate error signals are not delayed.

    delay

    period to delay each Subscriber#onNext signal

    timer

    a time-capable Scheduler instance to delay each signal on

    returns

    a delayed SFlux

    Definition Classes
    SFlux
  40. final def delaySequence(delay: Duration, timer: Scheduler = Schedulers.parallel()): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  41. final def delaySubscription[U](subscriptionDelay: Publisher[U]): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  42. final def delaySubscription(delay: Duration, timer: Scheduler = Schedulers.parallel()): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  43. final def dematerialize[X](): SFlux[X]

    Permalink
    Definition Classes
    SFlux
  44. def dispose(): Unit

    Permalink
    Definition Classes
    FluxProcessor → Disposable
  45. final def distinct[V](keySelector: (OUT) ⇒ V): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  46. final def distinct(): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  47. final def distinctUntilChanged[V](keySelector: (OUT) ⇒ V, keyComparator: (V, V) ⇒ Boolean = (x: V, y: V) => x == y): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  48. final def distinctUntilChanged(): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  49. final def doAfterTerminate(afterTerminate: () ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  50. final def doFinally(onFinally: (SignalType) ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  51. final def doOnCancel(onCancel: () ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  52. final def doOnComplete(onComplete: () ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  53. final def doOnEach(signalConsumer: (Signal[_ <: OUT]) ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  54. final def doOnError(onError: (Throwable) ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  55. final def doOnNext(onNext: (OUT) ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  56. final def doOnRequest(f: (Long) ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  57. final def doOnSubscribe(onSubscribe: (Subscription) ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFluxLike
  58. final def doOnTerminate(onTerminate: () ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  59. def downstreamCount: Long

    Permalink

    Return the number of active Subscriber or -1 if untracked.

    Return the number of active Subscriber or -1 if untracked.

    returns

    the number of active Subscriber or -1 if untracked

  60. final def drop(n: Long): SFlux[OUT]

    Permalink
    Definition Classes
    SFluxLike
  61. final def elapsed(scheduler: Scheduler = Schedulers.parallel()): SFlux[(Long, OUT)]

    Permalink
    Definition Classes
    SFlux
  62. final def elementAt[U >: OUT](index: Int, defaultValue: Option[U] = None): SMono[U]

    Permalink
    Definition Classes
    SFlux
  63. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  64. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  65. def error: Option[Throwable]

    Permalink

    Current error if any, default to None

    Current error if any, default to None

    returns

    Current error if any, default to None

  66. final def expand[U >: OUT](expander: (OUT) ⇒ Publisher[U], capacityHint: Int = SMALL_BUFFER_SIZE): SFlux[U]

    Permalink
    Definition Classes
    SFlux
  67. final def expandDeep[U >: OUT](expander: (OUT) ⇒ Publisher[U], capacity: Int = SMALL_BUFFER_SIZE): SFlux[U]

    Permalink
    Definition Classes
    SFlux
  68. final def filter(p: (OUT) ⇒ Boolean): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  69. final def filterWhen(asyncPredicate: Function1[OUT, _ <: MapablePublisher[Boolean]], bufferSize: Int = SMALL_BUFFER_SIZE): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  70. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  71. final def flatMap[R](mapper: (OUT) ⇒ Publisher[_ <: R], maxConcurrency: Int = SMALL_BUFFER_SIZE, prefetch: Int = XS_BUFFER_SIZE, delayError: Boolean = false): SFlux[R]

    Permalink
    Definition Classes
    SFlux
  72. final def flatMap[R](mapperOnNext: (OUT) ⇒ Publisher[_ <: R], mapperOnError: (Throwable) ⇒ Publisher[_ <: R], mapperOnComplete: () ⇒ Publisher[_ <: R]): SFlux[R]

    Permalink
    Definition Classes
    SFlux
  73. final def flatMapIterable[R](mapper: (OUT) ⇒ Iterable[_ <: R], prefetch: Int = SMALL_BUFFER_SIZE): SFlux[R]

    Permalink
    Definition Classes
    SFlux
  74. final def flatMapSequential[R](mapper: (OUT) ⇒ Publisher[_ <: R], maxConcurrency: Int = SMALL_BUFFER_SIZE, prefetch: Int = XS_BUFFER_SIZE, delayError: Boolean = false): SFlux[R]

    Permalink
    Definition Classes
    SFlux
  75. final def flatten[S](implicit ev: <:<[OUT, SFlux[S]]): SFlux[S]

    Permalink
    Definition Classes
    SFluxLike
  76. final def fold[R](initial: R)(binaryOps: (R, OUT) ⇒ R): SMono[R]

    Permalink
    Definition Classes
    SFluxLike
  77. final def foldWith[R](initial: ⇒ R)(binaryOps: (R, OUT) ⇒ R): SMono[R]

    Permalink
    Definition Classes
    SFluxLike
  78. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  79. final def groupBy[K, V](keyMapper: (OUT) ⇒ K, valueMapper: (OUT) ⇒ V, prefetch: Int = SMALL_BUFFER_SIZE): SFlux[SGroupedFlux[K, V]]

    Permalink

    Divide this sequence into dynamically created SFlux (or groups) for each unique key, as produced by the provided keyMapper.

    Divide this sequence into dynamically created SFlux (or groups) for each unique key, as produced by the provided keyMapper. Source elements are also mapped to a different value using the valueMapper. Note that groupBy works best with a low cardinality of groups, so chose your keyMapper function accordingly.

    The groups need to be drained and consumed downstream for groupBy to work correctly. Notably when the criteria produces a large amount of groups, it can lead to hanging if the groups are not suitably consumed downstream (eg. due to a flatMap with a maxConcurrency parameter that is set too low).

    K

    the key type extracted from each value of this sequence

    V

    the value type extracted from each value of this sequence

    keyMapper

    the key mapping function that evaluates an incoming data and returns a key.

    valueMapper

    the value mapping function that evaluates which data to extract for re-routing.

    prefetch

    the number of values to prefetch from the source

    returns

    a SFlux of SGroupedFlux grouped sequences

    Definition Classes
    SFlux
  80. final def groupBy[K](keyMapper: (OUT) ⇒ K): SFlux[SGroupedFlux[K, _ <: OUT]]

    Permalink
    Definition Classes
    SFlux
  81. final def handle[R](handler: (OUT, SynchronousSink[R]) ⇒ Unit): SFlux[R]

    Permalink

    Handle the items emitted by this SFlux by calling a biconsumer with the output sink for each onNext.

    Handle the items emitted by this SFlux by calling a biconsumer with the output sink for each onNext. At most one SynchronousSink.next(Anyref) call must be performed and/or 0 or 1 SynchronousSink.error(Throwable) or SynchronousSink.complete().

    R

    the transformed type

    handler

    the handling Function2

    returns

    a transformed SFlux

    Definition Classes
    SFlux
  82. def hasCompleted: Boolean

    Permalink

    Return true if terminated with onComplete

    Return true if terminated with onComplete

    returns

    true if terminated with onComplete

  83. def hasDownstreams: Boolean

    Permalink

    Return true if any Subscriber is actively subscribed

    Return true if any Subscriber is actively subscribed

    returns

    true if any Subscriber is actively subscribed

  84. final def hasElement[U >: OUT](value: U): SMono[Boolean]

    Permalink
    Definition Classes
    SFlux
  85. final def hasElements: SMono[Boolean]

    Permalink
    Definition Classes
    SFlux
  86. def hasError: Boolean

    Permalink

    Return true if terminated with onError

    Return true if terminated with onError

    returns

    true if terminated with onError

  87. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  88. final def head: SMono[OUT]

    Permalink
    Definition Classes
    SFluxLike
  89. final def ignoreElements(): SMono[OUT]

    Permalink
    Definition Classes
    SFlux
  90. final def index[I](indexMapper: (Long, OUT) ⇒ I): SFlux[I]

    Permalink
    Definition Classes
    SFlux
  91. final def index(): SFlux[(Long, OUT)]

    Permalink
    Definition Classes
    SFlux
  92. def inners(): Stream[_ <: Scannable]

    Permalink
    Definition Classes
    FluxProcessorScannable
  93. def isDisposed(): Boolean

    Permalink
    Definition Classes
    Disposable
  94. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  95. def isScanAvailable: Boolean

    Permalink
    Definition Classes
    Scannable
  96. def isSerialized: Boolean

    Permalink

    Return true if this FluxProcessor supports multithread producing

    Return true if this FluxProcessor supports multithread producing

    returns

    true if this FluxProcessor supports multithread producing

  97. def isTerminated: Boolean

    Permalink

    Has this upstream finished or "completed" / "failed" ?

    Has this upstream finished or "completed" / "failed" ?

    returns

    has this upstream finished or "completed" / "failed" ?

  98. final def last[U >: OUT](defaultValue: Option[U] = None): SMono[U]

    Permalink
    Definition Classes
    SFlux
  99. final def log(category: String = None.orNull[String]): SFlux[OUT]

    Permalink

    Observe all Reactive Streams signals and use Logger support to handle trace implementation.

    Observe all Reactive Streams signals and use Logger support to handle trace implementation. Default will use Level.INFO and java.util.logging. If SLF4J is available, it will be used instead.

    The default log category will be "reactor.*", a generated operator suffix will complete, e.g. "reactor.Flux.Map".

    returns

    a new unaltered SFlux

    Definition Classes
    SFlux
  100. final def map[V](mapper: (OUT) ⇒ V): SFlux[V]

    Permalink

    Transform the items emitted by this SFlux by applying a synchronous function to each item.

    Transform the items emitted by this SFlux by applying a synchronous function to each item.

    V

    the transformed type

    mapper

    the synchronous transforming Function1

    returns

    a transformed { @link Flux}

    Definition Classes
    SFluxMapablePublisher
  101. final def materialize(): SFlux[Signal[_ <: OUT]]

    Permalink
    Definition Classes
    SFlux
  102. final def max[R >: OUT](implicit ev: Ordering[R]): SMono[Option[R]]

    Permalink
    Definition Classes
    SFluxLike
  103. final def mergeWith[U >: OUT](other: Publisher[U]): SFlux[U]

    Permalink
    Definition Classes
    SFlux
  104. final def metrics: SFlux[OUT]

    Permalink

    Activate metrics for this sequence, provided there is an instrumentation facade on the classpath (otherwise this method is a pure no-op).

    Activate metrics for this sequence, provided there is an instrumentation facade on the classpath (otherwise this method is a pure no-op).

    Metrics are gathered on Subscriber events, and it is recommended to also name (and optionally tag) the sequence.

    returns

    an instrumented SFlux

    Definition Classes
    SFlux
  105. final def min[R >: OUT](implicit ev: Ordering[R]): SMono[Option[R]]

    Permalink
    Definition Classes
    SFluxLike
  106. def name: String

    Permalink

    Check this Scannable and its Scannable.parents() for a name an return the first one that is reachable.

    Check this Scannable and its Scannable.parents() for a name an return the first one that is reachable.

    returns

    the name of the first parent that has one defined (including this scannable)

    Definition Classes
    Scannable
  107. final def name(name: String): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  108. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  109. final def next(): SMono[OUT]

    Permalink
    Definition Classes
    SFlux
  110. final def nonEmpty: SMono[Boolean]

    Permalink
    Definition Classes
    SFlux
  111. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  112. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  113. final def ofType[U](implicit classTag: ClassTag[U]): SFlux[U]

    Permalink
    Definition Classes
    SFlux
  114. final def onBackpressureBuffer(maxSize: Int, onBufferOverflow: (OUT) ⇒ Unit, bufferOverflowStrategy: BufferOverflowStrategy): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  115. final def onBackpressureBuffer(maxSize: Int, bufferOverflowStrategy: BufferOverflowStrategy): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  116. final def onBackpressureBuffer(maxSize: Int, onOverflow: (OUT) ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  117. final def onBackpressureBuffer(maxSize: Int): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  118. final def onBackpressureBuffer(): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  119. final def onBackpressureDrop(onDropped: (OUT) ⇒ Unit): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  120. final def onBackpressureDrop(): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  121. final def onBackpressureError(): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  122. final def onBackpressureLatest(): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  123. def onComplete(): Unit

    Permalink
    Definition Classes
    FluxProcessor → Subscriber
  124. def onError(t: Throwable): Unit

    Permalink
    Definition Classes
    FluxProcessor → Subscriber
  125. final def onErrorMap(mapper: Function1[Throwable, _ <: Throwable]): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  126. final def onErrorRecover[U >: OUT](pf: PartialFunction[Throwable, U]): SFlux[U]

    Permalink
    Definition Classes
    SFluxLike
  127. final def onErrorRecoverWith[U >: OUT](pf: PartialFunction[Throwable, SFlux[U]]): SFlux[U]

    Permalink
    Definition Classes
    SFluxLike
  128. final def onErrorResume[U >: OUT](fallback: (Throwable) ⇒ Publisher[U]): SFlux[U]

    Permalink
    Definition Classes
    SFluxLike
  129. final def onErrorReturn[U >: OUT](fallbackValue: U, predicate: (Throwable) ⇒ Boolean = (_: Throwable ) => true): SFlux[U]

    Permalink
    Definition Classes
    SFlux
  130. def onNext(t: IN): Unit

    Permalink
    Definition Classes
    FluxProcessor → Subscriber
  131. def onSubscribe(s: Subscription): Unit

    Permalink
    Definition Classes
    FluxProcessor → Subscriber
  132. final def or[U >: OUT](other: Publisher[U]): SFlux[U]

    Permalink
    Definition Classes
    SFlux
  133. final def parallel(parallelism: Int = ..., prefetch: Int = Queues.SMALL_BUFFER_SIZE): SParallelFlux[OUT]

    Permalink

    Prepare to consume this SFlux on number of 'rails' matching number of CPU in round-robin fashion.

    Prepare to consume this SFlux on number of 'rails' matching number of CPU in round-robin fashion.

    parallelism

    the number of parallel rails

    prefetch

    the number of values to prefetch from the source

    returns

    a new SParallelFlux instance

    Definition Classes
    SFlux
  134. def parents: Stream[_ <: Scannable]

    Permalink

    Return a Stream navigating the org.reactivestreams.Subscription chain (upward).

    Return a Stream navigating the org.reactivestreams.Subscription chain (upward).

    returns

    a Stream navigating the org.reactivestreams.Subscription chain (upward)

    Definition Classes
    Scannable
  135. final def product[R >: OUT](implicit R: Numeric[R]): SMono[R]

    Permalink

    Multiple all element within this SFlux given the type element is Numeric

    Multiple all element within this SFlux given the type element is Numeric

    R

    Numeric

    returns

    SMono with the result of all element multiplied.

    Definition Classes
    SFluxLike
  136. final def publish(prefetch: Int = Queues.SMALL_BUFFER_SIZE): ConnectableSFlux[OUT]

    Permalink

    Prepare a ConnectableSFlux which shares this SFlux sequence and dispatches values to subscribers in a backpressure-aware manner.

    Prepare a ConnectableSFlux which shares this SFlux sequence and dispatches values to subscribers in a backpressure-aware manner. This will effectively turn any type of sequence into a hot sequence.

    Backpressure will be coordinated on org.reactivestreams.Subscription.request and if any Subscriber is missing demand (requested = 0), multicast will pause pushing/pulling.

    prefetch

    bounded requested demand

    returns

    a new ConnectableSFlux

    Definition Classes
    SFlux
  137. final def publishNext(): SMono[OUT]

    Permalink

    Prepare a SMono which shares this SFlux sequence and dispatches the first observed item to subscribers in a backpressure-aware manner.

    Prepare a SMono which shares this SFlux sequence and dispatches the first observed item to subscribers in a backpressure-aware manner. This will effectively turn any type of sequence into a hot sequence when the first Subscriber subscribes.

    returns

    a new SMono

    Definition Classes
    SFlux
  138. final def reduce[U >: OUT](aggregator: (U, U) ⇒ U): SMono[U]

    Permalink
    Definition Classes
    SFlux
  139. final def reduce[A](initial: A)(accumulator: (A, OUT) ⇒ A): SMono[A]

    Permalink
    Definition Classes
    SFluxLike
  140. final def repeat(numRepeat: Long = Long.MaxValue, predicate: () ⇒ Boolean = () => true): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  141. final def retry(numRetries: Long = Long.MaxValue, retryMatcher: (Throwable) ⇒ Boolean = (_: Throwable) => true): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  142. final def retryWhen(retry: Retry): SFlux[OUT]

    Permalink

    Retries this SFlux in response to signals emitted by a companion Publisher.

    Retries this SFlux in response to signals emitted by a companion Publisher. The companion is generated by the provided Retry instance, see Retry#max(long), Retry#maxInARow(long) and Duration) for readily available strategy builders.

    The operator generates a base for the companion, a SFlux of reactor.util.retry.Retry.RetrySignal which each give metadata about each retryable failure whenever this SFlux signals an error. The final companion should be derived from that base companion and emit data in response to incoming onNext (although it can emit less elements, or delay the emissions).

    Terminal signals in the companion terminate the sequence with the same signal, so emitting an Subscriber#onError(Throwable) will fail the resulting SFlux with that same error.

    Note that the Retry.RetrySignal state can be transient and change between each source onError or onNext. If processed with a delay, this could lead to the represented state being out of sync with the state at which the retry was evaluated. Map it to Retry.RetrySignal#copy() right away to mediate this.

    Note that if the companion Publisher created by the whenFactory emits reactor.util.context.Context as trigger objects, these reactor.util.context.Context will be merged with the previous Context:

    
    Retry customStrategy = Retry.fromFunction(companion -> companion.handle((retrySignal, sink) -> {
    	    Context ctx = sink.currentContext();
    	    int rl = ctx.getOrDefault("retriesLeft", 0);
    	    if (rl > 0) {
    	    sink.next(Context.of(
    	        "retriesLeft", rl - 1,
    	        "lastError", retrySignal.failure()
    	    ));
    	     else {
    	        sink.error(Exceptions.retryExhausted("retries exhausted", retrySignal.failure()));
    }
    }));
    Flux retried = originalFlux.retryWhen(customStrategy);
    }
    

    returns

    a { @link Flux} that retries on onError when a companion { @link Publisher} produces an onNext signal

    Definition Classes
    SFlux
    See also

    Retry.backoff(long, Duration)

    Retry.maxInARow(long)

    Retry.max(long)

  143. final def sample(timespan: Duration): SFlux[OUT]

    Permalink

    Sample this SFlux by periodically emitting an item corresponding to that SFlux latest emitted value within the periodical time window.

    Sample this SFlux by periodically emitting an item corresponding to that SFlux latest emitted value within the periodical time window. Note that if some elements are emitted quicker than the timespan just before source completion, the last of these elements will be emitted along with the onComplete signal.

    timespan

    the duration of the window after which to emit the latest observed item

    returns

    a SFlux sampled to the last item seen over each periodic window

    Definition Classes
    SFlux
  144. final def sampleFirst(timespan: Duration): SFlux[OUT]

    Permalink

    Repeatedly take a value from this SFlux then skip the values that follow within a given duration.

    Repeatedly take a value from this SFlux then skip the values that follow within a given duration.

    timespan

    the duration during which to skip values after each sample

    returns

    a SFlux sampled to the first item of each duration-based window

    Definition Classes
    SFlux
  145. def scan[T](key: Attr[T]): Option[T]

    Permalink

    Introspect a component's specific state attribute, returning an associated value specific to that component, or the default value associated with the key, or null if the attribute doesn't make sense for that particular component and has no sensible default.

    Introspect a component's specific state attribute, returning an associated value specific to that component, or the default value associated with the key, or null if the attribute doesn't make sense for that particular component and has no sensible default.

    key

    a Attr to resolve for the component.

    returns

    a value associated to the key or None if unmatched or unresolved

    Definition Classes
    Scannable
  146. final def scan[A](initial: A)(accumulator: (A, OUT) ⇒ A): SFlux[A]

    Permalink

    Reduce this SFlux values with an accumulator Function2 and also emit the intermediate results of this function.

    Reduce this SFlux values with an accumulator Function2 and also emit the intermediate results of this function.

    The accumulation works as follows:

    
    result[0] = initialValue;
    result[1] = accumulator(result[0], source[0])
    result[2] = accumulator(result[1], source[1])
    result[3] = accumulator(result[2], source[2])
    ...
    
    

    A

    the accumulated type

    initial

    the initial value

    returns

    an accumulating SFlux starting with initial state

    Definition Classes
    SFlux
  147. final def scan[U >: OUT](accumulator: (U, U) ⇒ U): SFlux[U]

    Permalink

    Reduce this SFlux values with an accumulator Function2 and also emit the intermediate results of this function.

    Reduce this SFlux values with an accumulator Function2 and also emit the intermediate results of this function.

    Unlike Function2), this operator doesn't take an initial value but treats the first SFlux value as initial value.
    The accumulation works as follows:

    
    result[0] = source[0]
    result[1] = accumulator(result[0], source[1])
    result[2] = accumulator(result[1], source[2])
    result[3] = accumulator(result[2], source[3])
    ...
    
    

    accumulator

    the accumulating Function2

    returns

    an accumulating SFlux

    Definition Classes
    SFlux
  148. def scanOrDefault[T](key: Attr[T], defaultValue: T): T

    Permalink

    Introspect a component's specific state attribute.

    Introspect a component's specific state attribute. If there's no specific value in the component for that key, fall back to returning the provided non null default.

    key

    a Attr to resolve for the component.

    defaultValue

    a fallback value if key resolve to { @literal null}

    returns

    a value associated to the key or the provided default if unmatched or unresolved

    Definition Classes
    Scannable
  149. def scanUnsafe(key: Attr[_]): Option[AnyRef]

    Permalink

    This method is used internally by components to define their key-value mappings in a single place.

    This method is used internally by components to define their key-value mappings in a single place. Although it is ignoring the generic type of the Attr key, implementors should take care to return values of the correct type, and return None if no specific value is available.

    For public consumption of attributes, prefer using Scannable.scan(Attr), which will return a typed value and fall back to the key's default if the component didn't define any mapping.

    key

    a { @link Attr} to resolve for the component.

    returns

    the value associated to the key for that specific component, or null if none.

    Definition Classes
    FluxProcessorScannable
  150. final def scanWith[A](initial: ⇒ A)(accumulator: (A, OUT) ⇒ A): SFlux[A]

    Permalink

    Reduce this SFlux values with an accumulator Function2 and also emit the intermediate results of this function.

    Reduce this SFlux values with an accumulator Function2 and also emit the intermediate results of this function.

    The accumulation works as follows:

    
    result[0] = initialValue;
    result[1] = accumulator(result[0], source[0])
    result[2] = accumulator(result[1], source[1])
    result[3] = accumulator(result[2], source[2])
    ...
    
    

    A

    the accumulated type

    initial

    the initial value computation

    accumulator

    the accumulating Function2

    returns

    an accumulating SFlux starting with initial state

    Definition Classes
    SFlux
  151. final def serialize(): FluxProcessor[IN, OUT]

    Permalink

    Create a FluxProcessor that safely gates multi-threaded producer

    Create a FluxProcessor that safely gates multi-threaded producer

    returns

    a serializing FluxProcessor

  152. def serializeAlways: Boolean

    Permalink

    Returns serialization strategy.

    Returns serialization strategy. If true, FluxProcessor.sink() will always be serialized. Otherwise sink is serialized only if => Unit) is invoked.

    returns

    true to serialize any sink, false to delay serialization till onRequest

    Attributes
    protected
  153. final def single[U >: OUT](defaultValue: Option[U] = None): SMono[U]

    Permalink
    Definition Classes
    SFlux
  154. final def singleOrEmpty(): SMono[OUT]

    Permalink
    Definition Classes
    SFlux
  155. final def sink(strategy: OverflowStrategy): FluxSink[IN]

    Permalink

    Create a FluxSink that safely gates multi-threaded producer Subscriber.onNext.

    Create a FluxSink that safely gates multi-threaded producer Subscriber.onNext.

    The returned FluxSink will not apply any FluxSink.OverflowStrategy and overflowing FluxSink.next will behave in two possible ways depending on the Processor:

    • an unbounded processor will handle the overflow itself by dropping or buffering
    • a bounded processor will block/spin on IGNORE strategy, or apply the strategy behavior
    strategy

    the overflow strategy, see FluxSink.OverflowStrategy for the available strategies

    returns

    a serializing FluxSink

  156. final def sink(): FluxSink[IN]

    Permalink

    Create a FluxSink that safely gates multi-threaded producer Subscriber.onNext.

    Create a FluxSink that safely gates multi-threaded producer Subscriber.onNext.

    The returned FluxSink will not apply any FluxSink.OverflowStrategy and overflowing FluxSink.next will behave in two possible ways depending on the Processor:

    • an unbounded processor will handle the overflow itself by dropping or buffering
    • a bounded processor will block/spin
    returns

    a serializing FluxSink

  157. final def skip(timespan: Duration, timer: Scheduler = Schedulers.parallel): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  158. final def skip(skipped: Long): SFlux[OUT]

    Permalink
    Definition Classes
    SFluxLike
  159. final def skipLast(n: Int): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  160. final def skipUntil(untilPredicate: (OUT) ⇒ Boolean): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  161. final def skipWhile(skipPredicate: (OUT) ⇒ Boolean): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  162. final def sort[U >: OUT](sortFunction: Ordering[U]): SFlux[U]

    Permalink
    Definition Classes
    SFlux
  163. final def sort(): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  164. final def startWith[U >: OUT](publisher: Publisher[U]): SFlux[U]

    Permalink

    Prepend the given Publisher sequence to this SFlux sequence.

    Prepend the given Publisher sequence to this SFlux sequence.

    publisher

    the Publisher whose values to prepend

    returns

    a new SFlux prefixed with the given Publisher sequence

    Definition Classes
    SFlux
  165. final def startWith[U >: OUT](value: U, values: U*): SFlux[U]

    Permalink
    Definition Classes
    SFlux
  166. final def startWith[U >: OUT](iterable: Iterable[U]): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  167. def stepName: String

    Permalink

    Return a meaningful String representation of this Scannable in its chain of Scannable.parents and Scannable.actuals.

    Return a meaningful String representation of this Scannable in its chain of Scannable.parents and Scannable.actuals.

    Definition Classes
    Scannable
  168. def subscribe(s: Subscriber[_ >: OUT]): Unit

    Permalink
    Definition Classes
    FluxProcessorSFlux → Publisher
  169. final def subscribe(): Disposable

    Permalink

    Subscribe to this SFlux and request unbounded demand.

    Subscribe to this SFlux and request unbounded demand.

    This version doesn't specify any consumption behavior for the events from the chain, especially no error handling, so other variants should usually be preferred.

    returns

    a new Disposable that can be used to cancel the underlying org.reactivestreams.Subscription

    Definition Classes
    SFlux
  170. final def subscribe(consumer: (OUT) ⇒ Unit, errorConsumer: Option[(Throwable) ⇒ Unit] = None, completeConsumer: Option[Runnable] = None): Disposable

    Permalink

    Subscribe a consumer to this SFlux that will consume all the sequence.

    Subscribe a consumer to this SFlux that will consume all the sequence. It will request an unbounded demand.

    For a passive version that observe and forward incoming data see SFlux.doOnNext.

    For a version that gives you more control over backpressure and the request, see SFlux.subscribe with a reactor.core.publisher.BaseSubscriber.

    consumer

    the consumer to invoke on each value

    errorConsumer

    the consumer to invoke on error signal

    completeConsumer

    the consumer to invoke on complete signal

    returns

    a new Disposable to dispose the org.reactivestreams.Subscription

    Definition Classes
    SFlux
  171. final def sum[R >: OUT](implicit R: Numeric[R]): SMono[R]

    Permalink
    Definition Classes
    SFluxLike
  172. final def switchIfEmpty[U >: OUT](alternate: Publisher[U]): SFlux[U]

    Permalink

    Provide an alternative if this sequence is completed without any data

    Provide an alternative if this sequence is completed without any data

    alternate

    the alternate publisher if this sequence is empty

    returns

    an alternating SFlux on source onComplete without elements

    Definition Classes
    SFlux
  173. final def switchMap[V](fn: (OUT) ⇒ Publisher[_ <: V], prefetch: Int = XS_BUFFER_SIZE): SFlux[V]

    Permalink
    Definition Classes
    SFlux
  174. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  175. final def tag(key: String, value: String): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  176. def tags: Stream[(String, String)]

    Permalink

    Visit this Scannable and its Scannable.parents() and stream all the observed tags

    Visit this Scannable and its Scannable.parents() and stream all the observed tags

    returns

    the stream of tags for this Scannable and its parents

    Definition Classes
    Scannable
  177. final def tail: SFlux[OUT]

    Permalink

    Alias for skip(1)

    Alias for skip(1)

    Definition Classes
    SFluxLike
  178. final def take(timespan: Duration, timer: Scheduler = Schedulers.parallel): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  179. final def take(n: Long): SFlux[OUT]

    Permalink
    Definition Classes
    SFluxLike
  180. final def takeLast(n: Int): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  181. final def takeUntil(predicate: (OUT) ⇒ Boolean): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  182. final def takeWhile(continuePredicate: (OUT) ⇒ Boolean): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  183. final def then(): SMono[Unit]

    Permalink
    Definition Classes
    SFlux
  184. final def thenEmpty(other: MapablePublisher[Unit]): SMono[Unit]

    Permalink
    Definition Classes
    SFlux
  185. final def thenMany[V](other: Publisher[V]): SFlux[V]

    Permalink
    Definition Classes
    SFlux
  186. final def timeout[U >: OUT, V, W](firstTimeout: Publisher[V], nextTimeoutFactory: (U) ⇒ Publisher[W], fallback: Publisher[U]): SFlux[U]

    Permalink
    Definition Classes
    SFlux
  187. final def timeout[U, V](firstTimeout: Publisher[U], nextTimeoutFactory: (OUT) ⇒ Publisher[V]): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  188. final def timeout[U](firstTimeout: Publisher[U]): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  189. final def timeout[U >: OUT](timeout: Duration, fallback: Option[Publisher[U]]): SFlux[U]

    Permalink
    Definition Classes
    SFlux
  190. final def timeout(timeout: Duration): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
  191. final def toIterable[U >: OUT](batchSize: Int = SMALL_BUFFER_SIZE, queueProvider: Option[Supplier[Queue[U]]] = None): Iterable[U]

    Permalink
    Definition Classes
    SFlux
  192. final def toStream(batchSize: Int = SMALL_BUFFER_SIZE): Stream[OUT]

    Permalink
    Definition Classes
    SFlux
  193. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  194. final def transform[U >: OUT, V](transformer: (SFlux[U]) ⇒ Publisher[V]): SFlux[V]

    Permalink
    Definition Classes
    SFlux
  195. final def transformDeferred[V](transformer: (SFlux[OUT]) ⇒ Publisher[V]): SFlux[V]

    Permalink
    Definition Classes
    SFlux
  196. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  197. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  198. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  199. final def withLatestFrom[U, R](other: Publisher[_ <: U], resultSelector: Function2[OUT, U, _ <: R]): SFlux[R]

    Permalink
    Definition Classes
    SFlux
  200. final def zipWith[T2](source2: Publisher[_ <: T2], prefetch: Int = XS_BUFFER_SIZE): SFlux[(OUT, T2)]

    Permalink
    Definition Classes
    SFlux
  201. final def zipWithCombinator[T2, V](source2: Publisher[_ <: T2], prefetch: Int = XS_BUFFER_SIZE)(combinator: (OUT, T2) ⇒ V): SFlux[V]

    Permalink
    Definition Classes
    SFlux
  202. final def zipWithIterable[T2, V](iterable: Iterable[_ <: T2], zipper: Function2[OUT, T2, _ <: V]): SFlux[V]

    Permalink
    Definition Classes
    SFlux
  203. final def zipWithIterable[T2](iterable: Iterable[_ <: T2]): SFlux[(OUT, T2)]

    Permalink
    Definition Classes
    SFlux
  204. final def zipWithTimeSinceSubscribe(): SFlux[(OUT, Long)]

    Permalink
    Definition Classes
    SFluxLike

Deprecated Value Members

  1. final def compose[V](transformer: (SFlux[OUT]) ⇒ Publisher[V]): SFlux[V]

    Permalink
    Definition Classes
    SFlux
    Annotations
    @deprecated
    Deprecated

    (Since version reactor-scala-extensions 0.5.0) will be removed, use transformDeferred() instead

  2. final def reduceWith[A](initial: () ⇒ A, accumulator: (A, OUT) ⇒ A): SMono[A]

    Permalink
    Definition Classes
    SFlux
    Annotations
    @deprecated
    Deprecated

    Use foldWith instead

  3. final def retryWhen(whenFactory: (SFlux[Throwable]) ⇒ Publisher[_]): SFlux[OUT]

    Permalink
    Definition Classes
    SFlux
    Annotations
    @deprecated
    Deprecated

    Use retryWhen(Retry)

Inherited from Scannable

Inherited from Disposable

Inherited from Processor[IN, OUT]

Inherited from Subscriber[IN]

Inherited from SFlux[OUT]

Inherited from MapablePublisher[OUT]

Inherited from Publisher[OUT @scala.annotation.unchecked.uncheckedVariance]

Inherited from SFluxLike[OUT]

Inherited from ScalaConverters

Inherited from AnyRef

Inherited from Any

Ungrouped