Home
last modified time | relevance | path

Searched refs:Flow (Results 1 – 25 of 321) sorted by relevance

12345678910>>...13

/external/kotlinx.coroutines/kotlinx-coroutines-core/common/src/flow/
DMigration.kt48 public fun <T> Flow<T>.observeOn(context: CoroutineContext): Flow<T> = noImpl() in <lambda>()
72 public fun <T> Flow<T>.publishOn(context: CoroutineContext): Flow<T> = noImpl() in <lambda>()
101 public fun <T> Flow<T>.subscribeOn(context: CoroutineContext): Flow<T> = noImpl() in <lambda>()
113 public fun <T> Flow<T>.onErrorResume(fallback: Flow<T>): Flow<T> = noImpl() in <lambda>()
125 public fun <T> Flow<T>.onErrorResumeNext(fallback: Flow<T>): Flow<T> = noImpl() in <lambda>()
155 public fun <T> Flow<T>.subscribe(): Unit = noImpl() in <lambda>()
164 )public fun <T> Flow<T>.subscribe(onEach: suspend (T) -> Unit): Unit = noImpl() in <lambda>()
173 )public fun <T> Flow<T>.subscribe(onEach: suspend (T) -> Unit, onError: suspend (Throwable) -> Unit… in <lambda>()
185 public fun <T, R> Flow<T>.flatMap(mapper: suspend (T) -> Flow<R>): Flow<R> = noImpl() in <lambda>()
196 public fun <T, R> Flow<T>.concatMap(mapper: (T) -> Flow<R>): Flow<R> = noImpl() in <lambda>()
[all …]
DBuilders.kt56 public fun <T> flow(@BuilderInference block: suspend FlowCollector<T>.() -> Unit): Flow<T> = SafeFl… in <lambda>()
68 public fun <T> (() -> T).asFlow(): Flow<T> = flow { in <lambda>()
82 public fun <T> (suspend () -> T).asFlow(): Flow<T> = flow { in <lambda>()
89 public fun <T> Iterable<T>.asFlow(): Flow<T> = flow { in <lambda>()
98 public fun <T> Iterator<T>.asFlow(): Flow<T> = flow { in <lambda>()
107 public fun <T> Sequence<T>.asFlow(): Flow<T> = flow { in <lambda>()
122 public fun <T> flowOf(vararg elements: T): Flow<T> = flow { in <lambda>()
131 public fun <T> flowOf(value: T): Flow<T> = flow { in <lambda>()
142 public fun <T> emptyFlow(): Flow<T> = EmptyFlow in emptyFlow()
144 private object EmptyFlow : Flow<Nothing> { in emptyFlow()
[all …]
/external/perfetto/test/trace_processor/diff_tests/chrome/
Dscroll_jank_cause_queuing_delay.out3 "Browser","CrProcessMain",2918,0,55000,"InputLatency.LatencyInfo.Flow.QueuingDelay.NoJank.BlockingT…
4Flow.QueuingDelay.NoJank.BlockingTasksUs.RenderWidgetHostImpl::ForwardTouchEvent-PassthroughTouchE…
5 …putLatency.LatencyInfo.Flow.QueuingDelay.NoJank.BlockingTasksUs.WidgetInputHandlerImpl::DispatchNo…
6 …00,"InputLatency.LatencyInfo.Flow.QueuingDelay.NoJank.BlockingTasksUs.WidgetInputHandlerImpl::Disp…
7 …putLatency.LatencyInfo.Flow.QueuingDelay.NoJank.BlockingTasksUs.WidgetInputHandlerImpl::DispatchNo…
8 "Renderer","Compositor",2918,0,7000,"InputLatency.LatencyInfo.Flow.QueuingDelay.NoJank.BlockingTask…
9 "Renderer","Compositor",2918,0,25000,"InputLatency.LatencyInfo.Flow.QueuingDelay.NoJank.BlockingTas…
10 …mpositor",2918,0,6000,"InputLatency.LatencyInfo.Flow.QueuingDelay.NoJank.BlockingTasksUs.LatencyIn…
11 …rThread",2918,0,10000,"InputLatency.LatencyInfo.Flow.QueuingDelay.NoJank.BlockingTasksUs.LatencyIn…
12 "Browser","CrProcessMain",2926,1,52000,"InputLatency.LatencyInfo.Flow.QueuingDelay.Jank.BlockingTas…
[all …]
Dscroll_jank_cause_queuing_delay_restricted.out10 "Renderer","Compositor",2918,0,6000,"QueuingDelay.NoJank.BlockingTasksUs.LatencyInfo.Flow"
11 "Gpu","VizCompositorThread",2918,0,10000,"QueuingDelay.NoJank.BlockingTasksUs.LatencyInfo.Flow"
20 "Gpu","VizCompositorThread",2926,1,2000,"QueuingDelay.Jank.BlockingTasksUs.LatencyInfo.Flow"
21 "Gpu","VizCompositorThread",2926,1,5000,"QueuingDelay.Jank.BlockingTasksUs.LatencyInfo.Flow"
22 "Gpu","VizCompositorThread",2926,1,8000,"QueuingDelay.Jank.BlockingTasksUs.LatencyInfo.Flow"
23 "Gpu","VizCompositorThread",2926,1,2000,"QueuingDelay.Jank.BlockingTasksUs.LatencyInfo.Flow"
24 "Gpu","VizCompositorThread",2926,1,8000,"QueuingDelay.Jank.BlockingTasksUs.LatencyInfo.Flow"
25 "Gpu","VizCompositorThread",2926,1,2000,"QueuingDelay.Jank.BlockingTasksUs.LatencyInfo.Flow"
/external/kotlinx.coroutines/kotlinx-coroutines-core/common/src/flow/operators/
DZip.kt32 public fun <T1, T2, R> Flow<T1>.combine(flow: Flow<T2>, transform: suspend (a: T1, b: T2) -> R): Fl… in <lambda>()
51 public fun <T1, T2, R> combine(flow: Flow<T1>, flow2: Flow<T2>, transform: suspend (a: T1, b: T2) -… in combine()
72 public fun <T1, T2, R> Flow<T1>.combineTransform( in combine()
73 flow: Flow<T2>, in combine()
75 ): Flow<R> = combineTransformUnsafe(this, flow) { args: Array<*> -> in combine()
100 flow: Flow<T1>, in combineTransform()
101 flow2: Flow<T2>, in combineTransform()
103 ): Flow<R> = combineTransformUnsafe(flow, flow2) { args: Array<*> -> in combineTransform()
115 flow: Flow<T1>, in combine()
116 flow2: Flow<T2>, in combine()
[all …]
DMerge.kt46 public fun <T, R> Flow<T>.flatMapConcat(transform: suspend (value: T) -> Flow<R>): Flow<R> = in <lambda>()
70 public fun <T, R> Flow<T>.flatMapMerge( in <lambda>()
72 transform: suspend (value: T) -> Flow<R> in <lambda>()
73 ): Flow<R> = in <lambda>()
82 public fun <T> Flow<Flow<T>>.flattenConcat(): Flow<T> = flow { in <lambda>()
95 public fun <T> Iterable<Flow<T>>.merge(): Flow<T> { in merge()
118 public fun <T> merge(vararg flows: Flow<T>): Flow<T> = flows.asIterable().merge() in merge()
139 public fun <T> Flow<Flow<T>>.flattenMerge(concurrency: Int = DEFAULT_CONCURRENCY): Flow<T> { in merge()
166 public fun <T, R> Flow<T>.transformLatest(@BuilderInference transform: suspend FlowCollector<R>.(va… in transformLatest()
192 public inline fun <T, R> Flow<T>.flatMapLatest(@BuilderInference crossinline transform: suspend (va… in transformLatest()
[all …]
DTransform.kt21 public inline fun <T> Flow<T>.filter(crossinline predicate: suspend (T) -> Boolean): Flow<T> = tran… in <lambda>()
28 public inline fun <T> Flow<T>.filterNot(crossinline predicate: suspend (T) -> Boolean): Flow<T> = t… in filterNot()
36 public inline fun <reified R> Flow<*>.filterIsInstance(): Flow<R> = filter { it is R } as Flow<R> in <lambda>()
41 public fun <R : Any> Flow<*>.filterIsInstance(klass: KClass<R>): Flow<R> = filter { klass.isInstanc… in <lambda>()
46 public fun <T: Any> Flow<T?>.filterNotNull(): Flow<T> = transform<T?, T> { value -> in filterNotNull()
53 public inline fun <T, R> Flow<T>.map(crossinline transform: suspend (value: T) -> R): Flow<R> = tra… in map()
60 public inline fun <T, R: Any> Flow<T>.mapNotNull(crossinline transform: suspend (value: T) -> R?): in mapNotNull()
68 public fun <T> Flow<T>.withIndex(): Flow<IndexedValue<T>> = flow { in <lambda>()
78 public fun <T> Flow<T>.onEach(action: suspend (T) -> Unit): Flow<T> = transform { value -> in onEach()
94 public fun <T, R> Flow<T>.scan(initial: R, @BuilderInference operation: suspend (accumulator: R, va… in scan()
[all …]
DDelay.kt65 public fun <T> Flow<T>.debounce(timeoutMillis: Long): Flow<T> { in <lambda>()
116 public fun <T> Flow<T>.debounce(timeoutMillis: (T) -> Long): Flow<T> = in debounce()
152 public fun <T> Flow<T>.debounce(timeout: Duration): Flow<T> = in debounce()
201 public fun <T> Flow<T>.debounce(timeout: (T) -> Duration): Flow<T> = in debounce()
206 private fun <T> Flow<T>.debounceInternal(timeoutMillisSelector: (T) -> Long) : Flow<T> = in debounceInternal()
275 public fun <T> Flow<T>.sample(periodMillis: Long): Flow<T> { in sample()
346 public fun <T> Flow<T>.sample(period: Duration): Flow<T> = sample(period.toDelayMillis()) in sample()
382 public fun <T> Flow<T>.timeout( in sample()
384 ): Flow<T> = timeoutInternal(timeout) in sample()
386 private fun <T> Flow<T>.timeoutInternal( in sample()
[all …]
DLint.kt23 public fun <T> SharedFlow<T>.cancellable(): Flow<T> = noImpl() in cancellable()
35 public fun <T> SharedFlow<T>.flowOn(context: CoroutineContext): Flow<T> = noImpl() in cancellable()
47 public fun <T> StateFlow<T>.conflate(): Flow<T> = noImpl() in cancellable()
59 public fun <T> StateFlow<T>.distinctUntilChanged(): Flow<T> = noImpl() in cancellable()
108 …haredFlow<T>.catch(noinline action: suspend FlowCollector<T>.(cause: Throwable) -> Unit): Flow<T> = in cancellable()
109 (this as Flow<T>).catch(action) in cancellable()
123 ): Flow<T> =
124 (this as Flow<T>).retry(retries, predicate)
135 …inline predicate: suspend FlowCollector<T>.(cause: Throwable, attempt: Long) -> Boolean): Flow<T> = in retryWhen()
136 (this as Flow<T>).retryWhen(predicate) in retryWhen()
[all …]
DContext.kt125 public fun <T> Flow<T>.buffer(capacity: Int = BUFFERED, onBufferOverflow: BufferOverflow = BufferOv… in buffer()
147 public fun <T> Flow<T>.buffer(capacity: Int = BUFFERED): Flow<T> = buffer(capacity) in buffer()
187 public fun <T> Flow<T>.conflate(): Flow<T> = buffer(CONFLATED) in buffer()
240 public fun <T> Flow<T>.flowOn(context: CoroutineContext): Flow<T> { in buffer()
257 public fun <T> Flow<T>.cancellable(): Flow<T> = in cancellable()
266 internal interface CancellableFlow<out T> : Flow<T>
271 private class CancellableFlowImpl<T>(private val flow: Flow<T>) : CancellableFlow<T> {
DLimit.kt20 public fun <T> Flow<T>.drop(count: Int): Flow<T> { in <lambda>()
33 public fun <T> Flow<T>.dropWhile(predicate: suspend (T) -> Boolean): Flow<T> = flow { in <lambda>()
50 public fun <T> Flow<T>.take(count: Int): Flow<T> { in take()
83 public fun <T> Flow<T>.takeWhile(predicate: suspend (T) -> Boolean): Flow<T> = flow { in <lambda>()
114 public fun <T, R> Flow<T>.transformWhile( in transformWhile()
116 ): Flow<R> = in transformWhile()
125 internal suspend inline fun <T> Flow<T>.collectWhile(crossinline predicate: suspend (value: T) -> B… in collectWhile()
DDistinct.kt21 public fun <T> Flow<T>.distinctUntilChanged(): Flow<T> = in <lambda>()
34 public fun <T> Flow<T>.distinctUntilChanged(areEquivalent: (old: T, new: T) -> Boolean): Flow<T> = in distinctUntilChanged()
43 public fun <T, K> Flow<T>.distinctUntilChangedBy(keySelector: (T) -> K): Flow<T> = in distinctUntilChanged()
57 private fun <T> Flow<T>.distinctUntilChangedBy( in distinctUntilChangedBy()
60 ): Flow<T> = when { in distinctUntilChangedBy()
66 private val upstream: Flow<T>,
69 ): Flow<T> {
DEmitters.kt37 public inline fun <T, R> Flow<T>.transform( in <lambda>()
39 ): Flow<R> = flow { // Note: safe flow is used here, because collector is exposed to transform on e… in <lambda>()
48 internal inline fun <T, R> Flow<T>.unsafeTransform( in unsafeTransform()
50 ): Flow<R> = unsafeFlow { // Note: unsafe flow is used here, because unsafeTransform is only for in… in unsafeTransform()
74 public fun <T> Flow<T>.onStart( in onStart()
76 ): Flow<T> = unsafeFlow { // Note: unsafe flow is used here, but safe collector is used to invoke s… in onStart()
144 public fun <T> Flow<T>.onCompletion( in onCompletion()
146 ): Flow<T> = unsafeFlow { // Note: unsafe flow is used here, but safe collector is used to invoke c… in onCompletion()
179 public fun <T> Flow<T>.onEmpty( in onEmpty()
181 ): Flow<T> = unsafeFlow { in onEmpty()
DErrors.kt57 public fun <T> Flow<T>.catch(action: suspend FlowCollector<T>.(cause: Throwable) -> Unit): Flow<T> = in <lambda>()
90 public fun <T> Flow<T>.retry( in retry()
93 ): Flow<T> {
131 public fun <T> Flow<T>.retryWhen(predicate: suspend FlowCollector<T>.(cause: Throwable, attempt: Lo… in retryWhen()
151 internal suspend fun <T> Flow<T>.catchImpl( in catchImpl()
/external/kotlinx.coroutines/reactive/kotlinx-coroutines-jdk9/api/
Dkotlinx-coroutines-jdk9.api2 …public static final fun awaitFirst (Ljava/util/concurrent/Flow$Publisher;Lkotlin/coroutines/Contin…
3 …public static final fun awaitFirstOrDefault (Ljava/util/concurrent/Flow$Publisher;Ljava/lang/Objec…
4 …public static final fun awaitFirstOrElse (Ljava/util/concurrent/Flow$Publisher;Lkotlin/jvm/functio…
5 …public static final fun awaitFirstOrNull (Ljava/util/concurrent/Flow$Publisher;Lkotlin/coroutines/…
6 …public static final fun awaitLast (Ljava/util/concurrent/Flow$Publisher;Lkotlin/coroutines/Continu…
7 …public static final fun awaitSingle (Ljava/util/concurrent/Flow$Publisher;Lkotlin/coroutines/Conti…
11 …/coroutines/CoroutineContext;Lkotlin/jvm/functions/Function2;)Ljava/util/concurrent/Flow$Publisher;
12 …neContext;Lkotlin/jvm/functions/Function2;ILjava/lang/Object;)Ljava/util/concurrent/Flow$Publisher;
16 …public static final fun asFlow (Ljava/util/concurrent/Flow$Publisher;)Lkotlinx/coroutines/flow/Flo…
17 …public static final fun asPublisher (Lkotlinx/coroutines/flow/Flow;)Ljava/util/concurrent/Flow$Pub…
[all …]
/external/kotlinx.coroutines/kotlinx-coroutines-core/common/test/flow/
DFlowInvariantsTest.kt17 testBody: suspend (flowFactory: (suspend FlowCollector<T>.() -> Unit) -> Flow<T>) -> Unit in <lambda>()
27 …private fun <T> abstractFlow(block: suspend FlowCollector<T>.() -> Unit): Flow<T> = object : Abstr… in <lambda>()
109 fun Flow<Int>.merge(other: Flow<Int>): Flow<Int> = flow { in <lambda>() method
118 fun Flow<Int>.trickyMerge(other: Flow<Int>): Flow<Int> = flow { in <lambda>() method
136 fun Flow<Int>.merge(other: Flow<Int>): Flow<Int> = channelFlow { in <lambda>() method
143 fun Flow<Int>.trickyMerge(other: Flow<Int>): Flow<Int> = channelFlow { in <lambda>() method
161 fun Flow<Int>.buffer(): Flow<Int> = flow { in <lambda>() method
176 …private fun Flow<Int>.buffer(coroutineContext: CoroutineContext, flow: (suspend FlowCollector<Int>… in <lambda>() method
262 private suspend fun emptyContextTest(block: Flow<Int>.() -> Flow<Int>) { in <lambda>()
/external/kotlinx.coroutines/kotlinx-coroutines-core/common/test/flow/operators/
DCombineTest.kt18 …abstract fun <T1, T2, R> Flow<T1>.combineLatest(other: Flow<T2>, transform: suspend (T1, T2) -> R)… in <lambda>()
261 …override fun <T1, T2, R> Flow<T1>.combineLatest(other: Flow<T2>, transform: suspend (T1, T2) -> R)… in combineLatest()
265 …override fun <T1, T2, R> Flow<T1>.combineLatest(other: Flow<T2>, transform: suspend (T1, T2) -> R)… in combineLatest()
272 …override fun <T1, T2, R> Flow<T1>.combineLatest(other: Flow<T2>, transform: suspend (T1, T2) -> R)… in combineLatest()
282 …override fun <T1, T2, R> Flow<T1>.combineLatest(other: Flow<T2>, transform: suspend (T1, T2) -> R)… in combineLatest()
292 …override fun <T1, T2, R> Flow<T1>.combineLatest(other: Flow<T2>, transform: suspend (T1, T2) -> R)… in combineLatest()
297 …override fun <T1, T2, R> Flow<T1>.combineLatest(other: Flow<T2>, transform: suspend (T1, T2) -> R)… in combineLatest()
306 …override fun <T1, T2, R> Flow<T1>.combineLatest(other: Flow<T2>, transform: suspend (T1, T2) -> R)… in combineLatest()
DMergeTest.kt13 abstract fun <T> Iterable<Flow<T>>.merge(): Flow<T> in <lambda>()
96 private fun <T> Iterable<Flow<T>>.nonFuseableMerge(): Flow<T> { in <lambda>()
121 override fun <T> Iterable<Flow<T>>.merge(): Flow<T> = originalMerge() in merge()
125 override fun <T> Iterable<Flow<T>>.merge(): Flow<T> = originalMerge(*toList().toTypedArray()) in merge()
/external/kotlinx.coroutines/kotlinx-coroutines-core/api/
Dkotlinx-coroutines-core.api973 …outines/flow/AbstractFlow : kotlinx/coroutines/flow/CancellableFlow, kotlinx/coroutines/flow/Flow {
979 public abstract interface class kotlinx/coroutines/flow/Flow {
989 public static final fun asFlow (Ljava/lang/Iterable;)Lkotlinx/coroutines/flow/Flow;
990 public static final fun asFlow (Ljava/util/Iterator;)Lkotlinx/coroutines/flow/Flow;
991 public static final fun asFlow (Lkotlin/jvm/functions/Function0;)Lkotlinx/coroutines/flow/Flow;
992 public static final fun asFlow (Lkotlin/jvm/functions/Function1;)Lkotlinx/coroutines/flow/Flow;
993 public static final fun asFlow (Lkotlin/ranges/IntRange;)Lkotlinx/coroutines/flow/Flow;
994 public static final fun asFlow (Lkotlin/ranges/LongRange;)Lkotlinx/coroutines/flow/Flow;
995 public static final fun asFlow (Lkotlin/sequences/Sequence;)Lkotlinx/coroutines/flow/Flow;
996 …tic final fun asFlow (Lkotlinx/coroutines/channels/BroadcastChannel;)Lkotlinx/coroutines/flow/Flow;
[all …]
/external/kotlinx.coroutines/kotlinx-coroutines-core/common/src/flow/terminal/
DReduce.kt19 public suspend fun <S, T : S> Flow<T>.reduce(operation: suspend (accumulator: S, value: T) -> S): S… in <lambda>()
39 public suspend inline fun <T, R> Flow<T>.fold( in fold()
55 public suspend fun <T> Flow<T>.single(): T { in single()
70 public suspend fun <T> Flow<T>.singleOrNull(): T? { in singleOrNull()
90 public suspend fun <T> Flow<T>.first(): T { in first()
104 public suspend fun <T> Flow<T>.first(predicate: suspend (T) -> Boolean): T { in first()
122 public suspend fun <T> Flow<T>.firstOrNull(): T? { in firstOrNull()
135 public suspend fun <T> Flow<T>.firstOrNull(predicate: suspend (T) -> Boolean): T? { in firstOrNull()
153 public suspend fun <T> Flow<T>.last(): T { in last()
165 public suspend fun <T> Flow<T>.lastOrNull(): T? { in lastOrNull()
DCollect.kt30 public suspend fun Flow<*>.collect(): Unit = collect(NopCollector) in collect()
49 public fun <T> Flow<T>.launchIn(scope: CoroutineScope): Job = scope.launch { in collect()
59 public suspend inline fun <T> Flow<T>.collectIndexed(crossinline action: suspend (index: Int, value… in collectIndexed()
86 public suspend fun <T> Flow<T>.collectLatest(action: suspend (value: T) -> Unit) { in collectLatest()
107 public suspend fun <T> FlowCollector<T>.emitAll(flow: Flow<T>) { in emitAll()
114 public suspend inline fun <T> Flow<T>.collect(crossinline action: suspend (value: T) -> Unit): Unit… in collect()
/external/kotlinx.coroutines/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/
DFlowPlaysScrabbleOpt.kt9 import kotlinx.coroutines.flow.Flow in <lambda>()
92 … val buildHistoOnScore: (((String) -> Flow<Int>) -> Flow<TreeMap<Int, List<String>>>) = { score -> in <lambda>()
127 public suspend inline fun Flow<Int>.sum(): Int { in asFlow()
139 public suspend inline fun Flow<Int>.max(): Int { in max()
152 public suspend inline fun Flow<Long>.sum(): Long { in sum()
164 …w(private val source: String, private val startIndex: Int, private val endIndex: Int): Flow<Char> {
170 public fun <T> concat(first: Flow<T>, second: Flow<T>): Flow<T> = flow { in <lambda>()
180 public fun <T, R> Flow<T>.flatMapConcatIterable(transformer: (T) -> Iterable<R>): Flow<R> = flow { in <lambda>()
188 …e fun <T> flow(@BuilderInference crossinline block: suspend FlowCollector<T>.() -> Unit): Flow<T> { in flow()
189 return object : Flow<T> { in flow()
/external/kotlinx.coroutines/reactive/kotlinx-coroutines-jdk9/src/
DAwait.kt22 public suspend fun <T> Flow.Publisher<T>.awaitFirst(): T =
34 public suspend fun <T> Flow.Publisher<T>.awaitFirstOrDefault(default: T): T =
45 public suspend fun <T> Flow.Publisher<T>.awaitFirstOrNull(): T? =
57 public suspend fun <T> Flow.Publisher<T>.awaitFirstOrElse(defaultValue: () -> T): T =
70 public suspend fun <T> Flow.Publisher<T>.awaitLast(): T =
84 public suspend fun <T> Flow.Publisher<T>.awaitSingle(): T =
/external/kotlinx.coroutines/kotlinx-coroutines-core/common/test/flow/channels/
DChannelFlowTest.kt98 private fun Flow<Int>.mergeTwoCoroutines(other: Flow<Int>): Flow<Int> = channelFlow { in <lambda>() method
107 private fun Flow<Int>.mergeOneCoroutine(other: Flow<Int>): Flow<Int> = channelFlow { in <lambda>() method
118 fun Flow<Int>.bufferWithTimeout(): Flow<Int> = channelFlow { in <lambda>() method
/external/kotlinx.coroutines/benchmarks/src/jmh/kotlin/benchmarks/flow/
DTakeBenchmark.kt26 private suspend inline fun Flow<Long>.consume() = in <lambda>()
54 public fun <T> Flow<T>.originalTake(count: Int): Flow<T> { in <lambda>()
75 public fun <T> Flow<T>.fastPathTake(count: Int): Flow<T> { in <lambda>()
93 public fun <T> Flow<T>.mergedStateMachineTake(count: Int): Flow<T> { in <lambda>()

12345678910>>...13