Docs: sort all operators by method name in left-hand menu (#28900)
This commit is contained in:
parent
fcd960ad78
commit
bb4940b027
42 changed files with 214 additions and 218 deletions
|
|
@ -1,4 +1,4 @@
|
|||
# actorRef
|
||||
# Sink.actorRef
|
||||
|
||||
Send the elements from the stream to an `ActorRef`.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# asPublisher
|
||||
# Sink.asPublisher
|
||||
|
||||
Integration with Reactive Streams, materializes into a `org.reactivestreams.Publisher`.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# cancelled
|
||||
# Sink.cancelled
|
||||
|
||||
Immediately cancel the stream
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# combine
|
||||
# Sink.combine
|
||||
|
||||
Combine several sinks into one using a user specified strategy
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# fold
|
||||
# Sink.fold
|
||||
|
||||
Fold over emitted element with a function, where each invocation will get the new element and the result from the previous fold invocation.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# foreach
|
||||
# Sink.foreach
|
||||
|
||||
Invoke a given procedure for each element received.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# foreachAsync
|
||||
# Sink.foreachAsync
|
||||
|
||||
Invoke a given procedure asynchronously for each element received.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# foreachParallel
|
||||
# Sink.foreachParallel
|
||||
|
||||
Like `foreach` but allows up to `parallellism` procedure calls to happen in parallel.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# fromSubscriber
|
||||
# Sink.fromSubscriber
|
||||
|
||||
Integration with Reactive Streams, wraps a `org.reactivestreams.Subscriber` as a sink.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# head
|
||||
# Sink.head
|
||||
|
||||
Materializes into a @scala[`Future`] @java[`CompletionStage`] which completes with the first value arriving, after this the stream is canceled.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# Flow.ask
|
||||
# ask
|
||||
|
||||
Use the "Ask Pattern" to send a request-reply message to the target `ref` actor (of the classic actors API).
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# Source/Flow.fromMaterializer
|
||||
# fromMaterializer
|
||||
|
||||
Defer the creation of a `Source/Flow` until materialization and access `Materializer` and `Attributes`
|
||||
|
||||
|
|
@ -16,4 +16,4 @@ Defer the creation of a `Source/Flow` until materialization and access `Material
|
|||
## Description
|
||||
|
||||
Typically used when access to materializer is needed to run a different stream during the construction of a source/flow.
|
||||
Can also be used to access the underlying `ActorSystem` from `Materializer`.
|
||||
Can also be used to access the underlying `ActorSystem` from `Materializer`.
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# Source/Flow.setup
|
||||
# setup
|
||||
|
||||
Defer the creation of a `Source/Flow` until materialization and access `Materializer` and `Attributes`
|
||||
|
||||
|
|
@ -22,4 +22,4 @@ The `setup` operator has been deprecated, use @ref:[fromMaterializer](./fromMate
|
|||
## Description
|
||||
|
||||
Typically used when access to materializer is needed to run a different stream during the construction of a source/flow.
|
||||
Can also be used to access the underlying `ActorSystem` from `ActorMaterializer`.
|
||||
Can also be used to access the underlying `ActorSystem` from `ActorMaterializer`.
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# actorRef
|
||||
# Source.actorRef
|
||||
|
||||
Materialize an `ActorRef`; sending messages to it will emit them on the stream.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# actorRefWithBackpressure
|
||||
# Source.actorRefWithBackpressure
|
||||
|
||||
Materialize an `ActorRef`; sending messages to it will emit them on the stream. The source acknowledges reception after emitting a message, to provide back pressure from the source.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# asSubscriber
|
||||
# Source.asSubscriber
|
||||
|
||||
Integration with Reactive Streams, materializes into a @javadoc[Subscriber](java.util.concurrent.Flow.Subscriber).
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# combine
|
||||
# Source.combine
|
||||
|
||||
Combine several sources, using a given strategy such as merge or concat, into one source.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# completionStage
|
||||
# Source.completionStage
|
||||
|
||||
Send the single value of the `CompletionStage` when it completes and there is demand.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# completionStageSource
|
||||
# Source.completionStageSource
|
||||
|
||||
Streams the elements of an asynchronous source once its given *completion* operator completes.
|
||||
|
||||
|
|
@ -35,4 +35,4 @@ Java
|
|||
|
||||
**completes** after the asynchronous source completes
|
||||
|
||||
@@@
|
||||
@@@
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# cycle
|
||||
# Source.cycle
|
||||
|
||||
Stream iterator in cycled manner.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# empty
|
||||
# Source.empty
|
||||
|
||||
Complete right away without ever emitting any elements.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# failed
|
||||
# Source.failed
|
||||
|
||||
Fail directly with a user specified exception.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# @scala[apply]@java[from]
|
||||
# @scala[Source.apply]@java[Source.from]
|
||||
|
||||
Stream the values of an @scala[`immutable.Seq`]@java[`Iterable`].
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# fromCompletionStage
|
||||
# Source.fromCompletionStage
|
||||
|
||||
Deprecated by @ref:[`Source.completionStage`](completionStage.md).
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# fromFuture
|
||||
# Source.fromFuture
|
||||
|
||||
Deprecated by @ref[`Source.future`](future.md).
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# fromFutureSource
|
||||
# Source.fromFutureSource
|
||||
|
||||
Deprecated by @ref:[`Source.futureSource`](futureSource.md).
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# fromIterator
|
||||
# Source.fromIterator
|
||||
|
||||
Stream the values from an `Iterator`, requesting the next value when there is demand.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# fromPublisher
|
||||
# Source.fromPublisher
|
||||
|
||||
Integration with Reactive Streams, subscribes to a @javadoc[Publisher](java.util.concurrent.Flow.Publisher).
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# fromSourceCompletionStage
|
||||
# Source.fromSourceCompletionStage
|
||||
|
||||
Deprecated by @ref:[`Source.completionStageSource`](completionStageSource.md).
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# future
|
||||
# Source.future
|
||||
|
||||
Send the single value of the `Future` when it completes and there is demand.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# futureSource
|
||||
# Source.futureSource
|
||||
|
||||
Streams the elements of the given future source once it successfully completes.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# lazily
|
||||
# Source.lazily
|
||||
|
||||
Deprecated by @ref:[`Source.lazySource`](lazySource.md).
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# lazilyAsync
|
||||
# Source.lazilyAsync
|
||||
|
||||
Deprecated by @ref:[`Source.lazyFutureSource`](lazyFutureSource.md).
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# lazyCompletionStage
|
||||
# Source.lazyCompletionStage
|
||||
|
||||
Defers creation of a future of a single element source until there is demand.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# lazyCompletionStageSource
|
||||
# Source.lazyCompletionStageSource
|
||||
|
||||
Defers creation of a future source until there is demand.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# lazyFuture
|
||||
# Source.lazyFuture
|
||||
|
||||
Defers creation of a future of a single element source until there is demand.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# lazyFutureSource
|
||||
# Source.lazyFutureSource
|
||||
|
||||
Defers creation and materialization of a `Source` until there is demand.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# lazySingle
|
||||
# Source.lazySingle
|
||||
|
||||
Defers creation of a single element source until there is demand.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# lazySource
|
||||
# Source.lazySource
|
||||
|
||||
Defers creation and materialization of a `Source` until there is demand.
|
||||
|
||||
|
|
|
|||
|
|
@ -1,4 +1,4 @@
|
|||
# maybe
|
||||
# Source.maybe
|
||||
|
||||
Create a source that emits once the materialized @scala[`Promise`] @java[`CompletableFuture`] is completed with a value.
|
||||
|
||||
|
|
|
|||
|
|
@ -350,196 +350,196 @@ For more background see the @ref[Error Handling in Streams](../stream-error.md)
|
|||
|
||||
@@@ index
|
||||
|
||||
* [combine](Source/combine.md)
|
||||
* [actorRef](Source/actorRef.md)
|
||||
* [actorRef](Sink/actorRef.md)
|
||||
* [actorRef](ActorSource/actorRef.md)
|
||||
* [actorRef](ActorSink/actorRef.md)
|
||||
* [actorRefWithBackpressure](Source/actorRefWithBackpressure.md)
|
||||
* [actorRefWithBackpressure](Sink/actorRefWithBackpressure.md)
|
||||
* [actorRefWithBackpressure](ActorSource/actorRefWithBackpressure.md)
|
||||
* [actorRefWithBackpressure](ActorSink/actorRefWithBackpressure.md)
|
||||
* [alsoTo](Source-or-Flow/alsoTo.md)
|
||||
* [asFlowWithContext](Flow/asFlowWithContext.md)
|
||||
* [asInputStream](StreamConverters/asInputStream.md)
|
||||
* [asJavaStream](StreamConverters/asJavaStream.md)
|
||||
* [ask](Source-or-Flow/ask.md)
|
||||
* [ask](ActorFlow/ask.md)
|
||||
* [asOutputStream](StreamConverters/asOutputStream.md)
|
||||
* [asPublisher](Sink/asPublisher.md)
|
||||
* [asSourceWithContext](Source/asSourceWithContext.md)
|
||||
* [fromPublisher](Source/fromPublisher.md)
|
||||
* [asSubscriber](Source/asSubscriber.md)
|
||||
* [backpressureTimeout](Source-or-Flow/backpressureTimeout.md)
|
||||
* [Balance](Balance.md)
|
||||
* [batch](Source-or-Flow/batch.md)
|
||||
* [batchWeighted](Source-or-Flow/batchWeighted.md)
|
||||
* [Broadcast](Broadcast.md)
|
||||
* [buffer](Source-or-Flow/buffer.md)
|
||||
* [cancelled](Sink/cancelled.md)
|
||||
* [collect](Source-or-Flow/collect.md)
|
||||
* [collection](Sink/collection.md)
|
||||
* [collectType](Source-or-Flow/collectType.md)
|
||||
* [combine](Source/combine.md)
|
||||
* [combine](Sink/combine.md)
|
||||
* [completionStage](Source/completionStage.md)
|
||||
* [completionStageFlow](Flow/completionStageFlow.md)
|
||||
* [completionStageSink](Sink/completionStageSink.md)
|
||||
* [completionStageSource](Source/completionStageSource.md)
|
||||
* [completionTimeout](Source-or-Flow/completionTimeout.md)
|
||||
* [concat](Source-or-Flow/concat.md)
|
||||
* [conflate](Source-or-Flow/conflate.md)
|
||||
* [conflateWithSeed](Source-or-Flow/conflateWithSeed.md)
|
||||
* [cycle](Source/cycle.md)
|
||||
* [deflate](Compression/deflate.md)
|
||||
* [delay](Source-or-Flow/delay.md)
|
||||
* [delayWith](Source-or-Flow/delayWith.md)
|
||||
* [detach](Source-or-Flow/detach.md)
|
||||
* [divertTo](Source-or-Flow/divertTo.md)
|
||||
* [drop](Source-or-Flow/drop.md)
|
||||
* [dropWhile](Source-or-Flow/dropWhile.md)
|
||||
* [dropWithin](Source-or-Flow/dropWithin.md)
|
||||
* [empty](Source/empty.md)
|
||||
* [expand](Source-or-Flow/expand.md)
|
||||
* [extrapolate](Source-or-Flow/extrapolate.md)
|
||||
* [failed](Source/failed.md)
|
||||
* [filter](Source-or-Flow/filter.md)
|
||||
* [filterNot](Source-or-Flow/filterNot.md)
|
||||
* [flatMapConcat](Source-or-Flow/flatMapConcat.md)
|
||||
* [flatMapMerge](Source-or-Flow/flatMapMerge.md)
|
||||
* [flatMapPrefix](Source-or-Flow/flatMapPrefix.md)
|
||||
* [fold](Source-or-Flow/fold.md)
|
||||
* [fold](Sink/fold.md)
|
||||
* [foldAsync](Source-or-Flow/foldAsync.md)
|
||||
* [foreach](Sink/foreach.md)
|
||||
* [foreachAsync](Sink/foreachAsync.md)
|
||||
* [foreachParallel](Sink/foreachParallel.md)
|
||||
* [from](Source/from.md)
|
||||
* [fromCompletionStage](Source/fromCompletionStage.md)
|
||||
* [fromFile](FileIO/fromFile.md)
|
||||
* [fromFuture](Source/fromFuture.md)
|
||||
* [fromFutureSource](Source/fromFutureSource.md)
|
||||
* [fromInputStream](StreamConverters/fromInputStream.md)
|
||||
* [fromIterator](Source/fromIterator.md)
|
||||
* [fromJavaStream](Source/fromJavaStream.md)
|
||||
* [cycle](Source/cycle.md)
|
||||
* [fromJavaStream](StreamConverters/fromJavaStream.md)
|
||||
* [fromMaterializer](Source-or-Flow/fromMaterializer.md)
|
||||
* [setup](Source-or-Flow/setup.md)
|
||||
* [fromFuture](Source/fromFuture.md)
|
||||
* [fromCompletionStage](Source/fromCompletionStage.md)
|
||||
* [fromFutureSource](Source/fromFutureSource.md)
|
||||
* [fromMaterializer](Sink/fromMaterializer.md)
|
||||
* [fromOutputStream](StreamConverters/fromOutputStream.md)
|
||||
* [fromPath](FileIO/fromPath.md)
|
||||
* [fromPublisher](Source/fromPublisher.md)
|
||||
* [fromSinkAndSource](Flow/fromSinkAndSource.md)
|
||||
* [fromSinkAndSourceCoupled](Flow/fromSinkAndSourceCoupled.md)
|
||||
* [fromSourceCompletionStage](Source/fromSourceCompletionStage.md)
|
||||
* [tick](Source/tick.md)
|
||||
* [single](Source/single.md)
|
||||
* [repeat](Source/repeat.md)
|
||||
* [unfold](Source/unfold.md)
|
||||
* [unfoldAsync](Source/unfoldAsync.md)
|
||||
* [empty](Source/empty.md)
|
||||
* [maybe](Source/maybe.md)
|
||||
* [failed](Source/failed.md)
|
||||
* [fromSubscriber](Sink/fromSubscriber.md)
|
||||
* [future](Source/future.md)
|
||||
* [futureFlow](Flow/futureFlow.md)
|
||||
* [futureSink](Sink/futureSink.md)
|
||||
* [futureSource](Source/futureSource.md)
|
||||
* [groupBy](Source-or-Flow/groupBy.md)
|
||||
* [grouped](Source-or-Flow/grouped.md)
|
||||
* [groupedWeightedWithin](Source-or-Flow/groupedWeightedWithin.md)
|
||||
* [groupedWithin](Source-or-Flow/groupedWithin.md)
|
||||
* [gzip](Compression/gzip.md)
|
||||
* [head](Sink/head.md)
|
||||
* [headOption](Sink/headOption.md)
|
||||
* [idleTimeout](Source-or-Flow/idleTimeout.md)
|
||||
* [ignore](Sink/ignore.md)
|
||||
* [initialDelay](Source-or-Flow/initialDelay.md)
|
||||
* [initialTimeout](Source-or-Flow/initialTimeout.md)
|
||||
* [interleave](Source-or-Flow/interleave.md)
|
||||
* [intersperse](Source-or-Flow/intersperse.md)
|
||||
* [javaCollector](StreamConverters/javaCollector.md)
|
||||
* [javaCollectorParallelUnordered](StreamConverters/javaCollectorParallelUnordered.md)
|
||||
* [keepAlive](Source-or-Flow/keepAlive.md)
|
||||
* [last](Sink/last.md)
|
||||
* [lastOption](Sink/lastOption.md)
|
||||
* [lazily](Source/lazily.md)
|
||||
* [lazilyAsync](Source/lazilyAsync.md)
|
||||
* [future](Source/future.md)
|
||||
* [completionStage](Source/completionStage.md)
|
||||
* [futureSource](Source/futureSource.md)
|
||||
* [lazySingle](Source/lazySingle.md)
|
||||
* [lazyFuture](Source/lazyFuture.md)
|
||||
* [lazySource](Source/lazySource.md)
|
||||
* [lazyFutureSource](Source/lazyFutureSource.md)
|
||||
* [asSubscriber](Source/asSubscriber.md)
|
||||
* [actorRef](Source/actorRef.md)
|
||||
* [actorRefWithBackpressure](Source/actorRefWithBackpressure.md)
|
||||
* [zipN](Source/zipN.md)
|
||||
* [zipWithN](Source/zipWithN.md)
|
||||
* [queue](Source/queue.md)
|
||||
* [unfoldResource](Source/unfoldResource.md)
|
||||
* [unfoldResourceAsync](Source/unfoldResourceAsync.md)
|
||||
* [@scala[apply]@java[from]](Source/from.md)
|
||||
* [range](Source/range.md)
|
||||
* [completionStageSource](Source/completionStageSource.md)
|
||||
* [lazyCompletionStage](Source/lazyCompletionStage.md)
|
||||
* [lazyCompletionStageFlow](Flow/lazyCompletionStageFlow.md)
|
||||
* [lazyCompletionStageSink](Sink/lazyCompletionStageSink.md)
|
||||
* [lazyCompletionStageSource](Source/lazyCompletionStageSource.md)
|
||||
* [concat](Source-or-Flow/concat.md)
|
||||
* [prepend](Source-or-Flow/prepend.md)
|
||||
* [orElse](Source-or-Flow/orElse.md)
|
||||
* [alsoTo](Source-or-Flow/alsoTo.md)
|
||||
* [divertTo](Source-or-Flow/divertTo.md)
|
||||
* [wireTap](Source-or-Flow/wireTap.md)
|
||||
* [interleave](Source-or-Flow/interleave.md)
|
||||
* [lazyFlow](Flow/lazyFlow.md)
|
||||
* [lazyFuture](Source/lazyFuture.md)
|
||||
* [lazyFutureFlow](Flow/lazyFutureFlow.md)
|
||||
* [lazyFutureSink](Sink/lazyFutureSink.md)
|
||||
* [lazyFutureSource](Source/lazyFutureSource.md)
|
||||
* [lazyInitAsync](Flow/lazyInitAsync.md)
|
||||
* [lazyInitAsync](Sink/lazyInitAsync.md)
|
||||
* [lazySingle](Source/lazySingle.md)
|
||||
* [lazySink](Sink/lazySink.md)
|
||||
* [lazySource](Source/lazySource.md)
|
||||
* [limit](Source-or-Flow/limit.md)
|
||||
* [limitWeighted](Source-or-Flow/limitWeighted.md)
|
||||
* [log](Source-or-Flow/log.md)
|
||||
* [logWithMarker](Source-or-Flow/logWithMarker.md)
|
||||
* [map](Source-or-Flow/map.md)
|
||||
* [mapAsync](Source-or-Flow/mapAsync.md)
|
||||
* [mapAsyncUnordered](Source-or-Flow/mapAsyncUnordered.md)
|
||||
* [mapConcat](Source-or-Flow/mapConcat.md)
|
||||
* [mapError](Source-or-Flow/mapError.md)
|
||||
* [maybe](Source/maybe.md)
|
||||
* [merge](Source-or-Flow/merge.md)
|
||||
* [mergeLatest](Source-or-Flow/mergeLatest.md)
|
||||
* [mergePreferred](Source-or-Flow/mergePreferred.md)
|
||||
* [mergePrioritized](Source-or-Flow/mergePrioritized.md)
|
||||
* [mergeSorted](Source-or-Flow/mergeSorted.md)
|
||||
* [zip](Source-or-Flow/zip.md)
|
||||
* [zipAll](Source-or-Flow/zipAll.md)
|
||||
* [zipLatest](Source-or-Flow/zipLatest.md)
|
||||
* [zipWith](Source-or-Flow/zipWith.md)
|
||||
* [zipLatestWith](Source-or-Flow/zipLatestWith.md)
|
||||
* [zipWithIndex](Source-or-Flow/zipWithIndex.md)
|
||||
* [map](Source-or-Flow/map.md)
|
||||
* [monitor](Source-or-Flow/monitor.md)
|
||||
* [onComplete](Sink/onComplete.md)
|
||||
* [onFailuresWithBackoff](RestartSource/onFailuresWithBackoff.md)
|
||||
* [onFailuresWithBackoff](RestartFlow/onFailuresWithBackoff.md)
|
||||
* [orElse](Source-or-Flow/orElse.md)
|
||||
* [Partition](Partition.md)
|
||||
* [prefixAndTail](Source-or-Flow/prefixAndTail.md)
|
||||
* [preMaterialize](Sink/preMaterialize.md)
|
||||
* [prepend](Source-or-Flow/prepend.md)
|
||||
* [queue](Source/queue.md)
|
||||
* [queue](Sink/queue.md)
|
||||
* [range](Source/range.md)
|
||||
* [recover](Source-or-Flow/recover.md)
|
||||
* [mapError](Source-or-Flow/mapError.md)
|
||||
* [recoverWith](Source-or-Flow/recoverWith.md)
|
||||
* [recoverWithRetries](Source-or-Flow/recoverWithRetries.md)
|
||||
* [mapConcat](Source-or-Flow/mapConcat.md)
|
||||
* [statefulMapConcat](Source-or-Flow/statefulMapConcat.md)
|
||||
* [mapAsync](Source-or-Flow/mapAsync.md)
|
||||
* [mapAsyncUnordered](Source-or-Flow/mapAsyncUnordered.md)
|
||||
* [ask](Source-or-Flow/ask.md)
|
||||
* [watch](Source-or-Flow/watch.md)
|
||||
* [filter](Source-or-Flow/filter.md)
|
||||
* [filterNot](Source-or-Flow/filterNot.md)
|
||||
* [collect](Source-or-Flow/collect.md)
|
||||
* [collectType](Source-or-Flow/collectType.md)
|
||||
* [grouped](Source-or-Flow/grouped.md)
|
||||
* [limit](Source-or-Flow/limit.md)
|
||||
* [limitWeighted](Source-or-Flow/limitWeighted.md)
|
||||
* [sliding](Source-or-Flow/sliding.md)
|
||||
* [reduce](Source-or-Flow/reduce.md)
|
||||
* [reduce](Sink/reduce.md)
|
||||
* [repeat](Source/repeat.md)
|
||||
* [scan](Source-or-Flow/scan.md)
|
||||
* [scanAsync](Source-or-Flow/scanAsync.md)
|
||||
* [fold](Source-or-Flow/fold.md)
|
||||
* [foldAsync](Source-or-Flow/foldAsync.md)
|
||||
* [reduce](Source-or-Flow/reduce.md)
|
||||
* [intersperse](Source-or-Flow/intersperse.md)
|
||||
* [groupedWithin](Source-or-Flow/groupedWithin.md)
|
||||
* [groupedWeightedWithin](Source-or-Flow/groupedWeightedWithin.md)
|
||||
* [delay](Source-or-Flow/delay.md)
|
||||
* [delayWith](Source-or-Flow/delayWith.md)
|
||||
* [drop](Source-or-Flow/drop.md)
|
||||
* [dropWithin](Source-or-Flow/dropWithin.md)
|
||||
* [takeWhile](Source-or-Flow/takeWhile.md)
|
||||
* [dropWhile](Source-or-Flow/dropWhile.md)
|
||||
* [take](Source-or-Flow/take.md)
|
||||
* [takeWithin](Source-or-Flow/takeWithin.md)
|
||||
* [conflateWithSeed](Source-or-Flow/conflateWithSeed.md)
|
||||
* [conflate](Source-or-Flow/conflate.md)
|
||||
* [batch](Source-or-Flow/batch.md)
|
||||
* [batchWeighted](Source-or-Flow/batchWeighted.md)
|
||||
* [expand](Source-or-Flow/expand.md)
|
||||
* [extrapolate](Source-or-Flow/extrapolate.md)
|
||||
* [buffer](Source-or-Flow/buffer.md)
|
||||
* [prefixAndTail](Source-or-Flow/prefixAndTail.md)
|
||||
* [flatMapPrefix](Source-or-Flow/flatMapPrefix.md)
|
||||
* [groupBy](Source-or-Flow/groupBy.md)
|
||||
* [splitWhen](Source-or-Flow/splitWhen.md)
|
||||
* [splitAfter](Source-or-Flow/splitAfter.md)
|
||||
* [flatMapConcat](Source-or-Flow/flatMapConcat.md)
|
||||
* [flatMapMerge](Source-or-Flow/flatMapMerge.md)
|
||||
* [initialTimeout](Source-or-Flow/initialTimeout.md)
|
||||
* [completionTimeout](Source-or-Flow/completionTimeout.md)
|
||||
* [idleTimeout](Source-or-Flow/idleTimeout.md)
|
||||
* [backpressureTimeout](Source-or-Flow/backpressureTimeout.md)
|
||||
* [keepAlive](Source-or-Flow/keepAlive.md)
|
||||
* [throttle](Source-or-Flow/throttle.md)
|
||||
* [detach](Source-or-Flow/detach.md)
|
||||
* [watchTermination](Source-or-Flow/watchTermination.md)
|
||||
* [monitor](Source-or-Flow/monitor.md)
|
||||
* [initialDelay](Source-or-Flow/initialDelay.md)
|
||||
* [log](Source-or-Flow/log.md)
|
||||
* [logWithMarker](Source-or-Flow/logWithMarker.md)
|
||||
* [asFlowWithContext](Flow/asFlowWithContext.md)
|
||||
* [fromSinkAndSource](Flow/fromSinkAndSource.md)
|
||||
* [fromSinkAndSourceCoupled](Flow/fromSinkAndSourceCoupled.md)
|
||||
* [lazyInitAsync](Flow/lazyInitAsync.md)
|
||||
* [futureFlow](Flow/futureFlow.md)
|
||||
* [lazyFlow](Flow/lazyFlow.md)
|
||||
* [lazyFutureFlow](Flow/lazyFutureFlow.md)
|
||||
* [completionStageFlow](Flow/completionStageFlow.md)
|
||||
* [lazyCompletionStageFlow](Flow/lazyCompletionStageFlow.md)
|
||||
* [preMaterialize](Sink/preMaterialize.md)
|
||||
* [fromMaterializer](Sink/fromMaterializer.md)
|
||||
* [setup](Sink/setup.md)
|
||||
* [fromSubscriber](Sink/fromSubscriber.md)
|
||||
* [cancelled](Sink/cancelled.md)
|
||||
* [head](Sink/head.md)
|
||||
* [headOption](Sink/headOption.md)
|
||||
* [last](Sink/last.md)
|
||||
* [lastOption](Sink/lastOption.md)
|
||||
* [takeLast](Sink/takeLast.md)
|
||||
* [seq](Sink/seq.md)
|
||||
* [collection](Sink/collection.md)
|
||||
* [asPublisher](Sink/asPublisher.md)
|
||||
* [ignore](Sink/ignore.md)
|
||||
* [foreach](Sink/foreach.md)
|
||||
* [foreachAsync](Sink/foreachAsync.md)
|
||||
* [combine](Sink/combine.md)
|
||||
* [foreachParallel](Sink/foreachParallel.md)
|
||||
* [fold](Sink/fold.md)
|
||||
* [reduce](Sink/reduce.md)
|
||||
* [onComplete](Sink/onComplete.md)
|
||||
* [actorRef](Sink/actorRef.md)
|
||||
* [actorRefWithBackpressure](Sink/actorRefWithBackpressure.md)
|
||||
* [queue](Sink/queue.md)
|
||||
* [lazyInitAsync](Sink/lazyInitAsync.md)
|
||||
* [futureSink](Sink/futureSink.md)
|
||||
* [lazySink](Sink/lazySink.md)
|
||||
* [lazyFutureSink](Sink/lazyFutureSink.md)
|
||||
* [completionStageSink](Sink/completionStageSink.md)
|
||||
* [lazyCompletionStageSink](Sink/lazyCompletionStageSink.md)
|
||||
* [fromInputStream](StreamConverters/fromInputStream.md)
|
||||
* [asOutputStream](StreamConverters/asOutputStream.md)
|
||||
* [fromOutputStream](StreamConverters/fromOutputStream.md)
|
||||
* [asInputStream](StreamConverters/asInputStream.md)
|
||||
* [javaCollector](StreamConverters/javaCollector.md)
|
||||
* [javaCollectorParallelUnordered](StreamConverters/javaCollectorParallelUnordered.md)
|
||||
* [asJavaStream](StreamConverters/asJavaStream.md)
|
||||
* [fromJavaStream](StreamConverters/fromJavaStream.md)
|
||||
* [fromFile](FileIO/fromFile.md)
|
||||
* [fromPath](FileIO/fromPath.md)
|
||||
* [setup](Source-or-Flow/setup.md)
|
||||
* [setup](Sink/setup.md)
|
||||
* [single](Source/single.md)
|
||||
* [sliding](Source-or-Flow/sliding.md)
|
||||
* [splitAfter](Source-or-Flow/splitAfter.md)
|
||||
* [splitWhen](Source-or-Flow/splitWhen.md)
|
||||
* [statefulMapConcat](Source-or-Flow/statefulMapConcat.md)
|
||||
* [take](Source-or-Flow/take.md)
|
||||
* [takeLast](Sink/takeLast.md)
|
||||
* [takeWhile](Source-or-Flow/takeWhile.md)
|
||||
* [takeWithin](Source-or-Flow/takeWithin.md)
|
||||
* [throttle](Source-or-Flow/throttle.md)
|
||||
* [tick](Source/tick.md)
|
||||
* [toFile](FileIO/toFile.md)
|
||||
* [toPath](FileIO/toPath.md)
|
||||
* [unfold](Source/unfold.md)
|
||||
* [unfoldAsync](Source/unfoldAsync.md)
|
||||
* [unfoldResource](Source/unfoldResource.md)
|
||||
* [unfoldResourceAsync](Source/unfoldResourceAsync.md)
|
||||
* [Unzip](Unzip.md)
|
||||
* [UnzipWith](UnzipWith.md)
|
||||
* [watch](Source-or-Flow/watch.md)
|
||||
* [watchTermination](Source-or-Flow/watchTermination.md)
|
||||
* [wireTap](Source-or-Flow/wireTap.md)
|
||||
* [withBackoff](RestartSource/withBackoff.md)
|
||||
* [onFailuresWithBackoff](RestartSource/onFailuresWithBackoff.md)
|
||||
* [withBackoff](RestartFlow/withBackoff.md)
|
||||
* [onFailuresWithBackoff](RestartFlow/onFailuresWithBackoff.md)
|
||||
* [withBackoff](RestartSink/withBackoff.md)
|
||||
* [withBackoff](RetryFlow/withBackoff.md)
|
||||
* [withBackoffAndContext](RetryFlow/withBackoffAndContext.md)
|
||||
* [gzip](Compression/gzip.md)
|
||||
* [deflate](Compression/deflate.md)
|
||||
* [actorRef](ActorSource/actorRef.md)
|
||||
* [actorRefWithBackpressure](ActorSource/actorRefWithBackpressure.md)
|
||||
* [ask](ActorFlow/ask.md)
|
||||
* [actorRef](ActorSink/actorRef.md)
|
||||
* [actorRefWithBackpressure](ActorSink/actorRefWithBackpressure.md)
|
||||
* [Partition](Partition.md)
|
||||
* [Broadcast](Broadcast.md)
|
||||
* [Balance](Balance.md)
|
||||
* [Unzip](Unzip.md)
|
||||
* [UnzipWith](UnzipWith.md)
|
||||
* [zip](Source-or-Flow/zip.md)
|
||||
* [zipAll](Source-or-Flow/zipAll.md)
|
||||
* [zipLatest](Source-or-Flow/zipLatest.md)
|
||||
* [zipLatestWith](Source-or-Flow/zipLatestWith.md)
|
||||
* [zipN](Source/zipN.md)
|
||||
* [zipWith](Source-or-Flow/zipWith.md)
|
||||
* [zipWithIndex](Source-or-Flow/zipWithIndex.md)
|
||||
* [zipWithN](Source/zipWithN.md)
|
||||
|
||||
@@@
|
||||
|
|
|
|||
|
|
@ -70,8 +70,7 @@ object StreamOperatorsIndexGenerator extends AutoPlugin {
|
|||
"alsoToGraph",
|
||||
"orElseGraph",
|
||||
"divertToGraph",
|
||||
"zipWithGraph",
|
||||
)
|
||||
"zipWithGraph")
|
||||
|
||||
// FIXME document these methods as well
|
||||
val pendingTestCases = Map(
|
||||
|
|
@ -98,14 +97,8 @@ object StreamOperatorsIndexGenerator extends AutoPlugin {
|
|||
"fromGraph",
|
||||
"actorSubscriber",
|
||||
"foldAsync",
|
||||
"newOnCompleteStage",
|
||||
),
|
||||
"Compression" -> Seq(
|
||||
"inflate",
|
||||
"gunzip",
|
||||
)
|
||||
|
||||
)
|
||||
"newOnCompleteStage"),
|
||||
"Compression" -> Seq("inflate", "gunzip"))
|
||||
|
||||
val ignore =
|
||||
Set("equals", "hashCode", "notify", "notifyAll", "wait", "toString", "getClass") ++
|
||||
|
|
@ -230,7 +223,10 @@ object StreamOperatorsIndexGenerator extends AutoPlugin {
|
|||
"# Operators\n\n" +
|
||||
tables +
|
||||
"\n\n@@@ index\n\n" +
|
||||
groupedDefs.map { case (_, method, md) => s"* [${methodToShow(method)}]($md)" }.mkString("\n") + "\n\n@@@\n"
|
||||
groupedDefs
|
||||
.sortBy { case (_, method, _) => method.toLowerCase }
|
||||
.map { case (_, method, md) => s"* [$method]($md)" }
|
||||
.mkString("\n") + "\n\n@@@\n"
|
||||
|
||||
if (!file.exists || IO.read(file) != content) IO.write(file, content)
|
||||
Seq(file)
|
||||
|
|
|
|||
Loading…
Add table
Add a link
Reference in a new issue